You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@couchdb.apache.org by be...@apache.org on 2014/02/13 19:11:59 UTC

[01/57] [abbrv] remove couch_collate

Updated Branches:
  refs/heads/1994-merge-rcouch-multi-repo [created] b19d05576


http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/vtzone.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/vtzone.h b/apps/couch_collate/platform/osx/icu/unicode/vtzone.h
deleted file mode 100644
index 9463f35..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/vtzone.h
+++ /dev/null
@@ -1,443 +0,0 @@
-/*
-*******************************************************************************
-* Copyright (C) 2007-2008, International Business Machines Corporation and         *
-* others. All Rights Reserved.                                                *
-*******************************************************************************
-*/
-#ifndef VTZONE_H
-#define VTZONE_H
-
-#include "unicode/utypes.h"
-
-/**
- * \file 
- * \brief C++ API: RFC2445 VTIMEZONE support
- */
-
-#if !UCONFIG_NO_FORMATTING
-
-#include "unicode/basictz.h"
-
-U_NAMESPACE_BEGIN
-
-class VTZWriter;
-class VTZReader;
-class UVector;
-
-/**
- * <code>VTimeZone</code> is a class implementing RFC2445 VTIMEZONE.  You can create a
- * <code>VTimeZone</code> instance from a time zone ID supported by <code>TimeZone</code>.
- * With the <code>VTimeZone</code> instance created from the ID, you can write out the rule
- * in RFC2445 VTIMEZONE format.  Also, you can create a <code>VTimeZone</code> instance
- * from RFC2445 VTIMEZONE data stream, which allows you to calculate time
- * zone offset by the rules defined by the data.<br><br>
- * Note: The consumer of this class reading or writing VTIMEZONE data is responsible to
- * decode or encode Non-ASCII text.  Methods reading/writing VTIMEZONE data in this class
- * do nothing with MIME encoding.
- * @stable ICU 4.0
- */
-class U_I18N_API VTimeZone : public BasicTimeZone {
-public:
-    /**
-     * Copy constructor.
-     * @param source    The <code>VTimeZone</code> object to be copied.
-     * @stable ICU 4.0
-     */
-    VTimeZone(const VTimeZone& source);
-
-    /**
-     * Destructor.
-     * @stable ICU 4.0
-     */
-    virtual ~VTimeZone();
-
-    /**
-     * Assignment operator.
-     * @param right The object to be copied.
-     * @stable ICU 4.0
-     */
-    VTimeZone& operator=(const VTimeZone& right);
-
-    /**
-     * Return true if the given <code>TimeZone</code> objects are
-     * semantically equal. Objects of different subclasses are considered unequal.
-     * @param that  The object to be compared with.
-     * @return  true if the given <code>TimeZone</code> objects are
-      *semantically equal.
-     * @stable ICU 4.0
-     */
-    virtual UBool operator==(const TimeZone& that) const;
-
-    /**
-     * Return true if the given <code>TimeZone</code> objects are
-     * semantically unequal. Objects of different subclasses are considered unequal.
-     * @param that  The object to be compared with.
-     * @return  true if the given <code>TimeZone</code> objects are
-     * semantically unequal.
-     * @stable ICU 4.0
-     */
-    virtual UBool operator!=(const TimeZone& that) const;
-
-    /**
-     * Create a <code>VTimeZone</code> instance by the time zone ID.
-     * @param ID The time zone ID, such as America/New_York
-     * @return A <code>VTimeZone</code> object initialized by the time zone ID,
-     * or NULL when the ID is unknown.
-     * @stable ICU 4.0
-     */
-    static VTimeZone* createVTimeZoneByID(const UnicodeString& ID);
-
-    /**
-     * Create a <code>VTimeZone</code> instance by RFC2445 VTIMEZONE data
-     * 
-     * @param vtzdata The string including VTIMEZONE data block
-     * @param status Output param to filled in with a success or an error.
-     * @return A <code>VTimeZone</code> initialized by the VTIMEZONE data or
-     * NULL if failed to load the rule from the VTIMEZONE data.
-     * @stable ICU 4.0
-     */
-    static VTimeZone* createVTimeZone(const UnicodeString& vtzdata, UErrorCode& status);
-
-    /**
-     * Gets the RFC2445 TZURL property value.  When a <code>VTimeZone</code> instance was
-     * created from VTIMEZONE data, the initial value is set by the TZURL property value
-     * in the data.  Otherwise, the initial value is not set.
-     * @param url Receives the RFC2445 TZURL property value.
-     * @return TRUE if TZURL attribute is available and value is set.
-     * @stable ICU 4.0
-     */
-    UBool getTZURL(UnicodeString& url) const;
-
-    /**
-     * Sets the RFC2445 TZURL property value.
-     * @param url The TZURL property value.
-     * @stable ICU 4.0
-     */
-    void setTZURL(const UnicodeString& url);
-
-    /**
-     * Gets the RFC2445 LAST-MODIFIED property value.  When a <code>VTimeZone</code> instance
-     * was created from VTIMEZONE data, the initial value is set by the LAST-MODIFIED property
-     * value in the data.  Otherwise, the initial value is not set.
-     * @param lastModified Receives the last modified date.
-     * @return TRUE if lastModified attribute is available and value is set.
-     * @stable ICU 4.0
-     */
-    UBool getLastModified(UDate& lastModified) const;
-
-    /**
-     * Sets the RFC2445 LAST-MODIFIED property value.
-     * @param lastModified The LAST-MODIFIED date.
-     * @stable ICU 4.0
-     */
-    void setLastModified(UDate lastModified);
-
-    /**
-     * Writes RFC2445 VTIMEZONE data for this time zone
-     * @param result Output param to filled in with the VTIMEZONE data.
-     * @param status Output param to filled in with a success or an error.
-     * @stable ICU 4.0
-     */
-    void write(UnicodeString& result, UErrorCode& status) const;
-
-    /**
-     * Writes RFC2445 VTIMEZONE data for this time zone applicalbe
-     * for dates after the specified start time.
-     * @param start The start date.
-     * @param result Output param to filled in with the VTIMEZONE data.
-     * @param status Output param to filled in with a success or an error.
-     * @stable ICU 4.0
-     */
-    void write(UDate start, UnicodeString& result, UErrorCode& status) /*const*/;
-
-    /**
-     * Writes RFC2445 VTIMEZONE data applicalbe for the specified date.
-     * Some common iCalendar implementations can only handle a single time
-     * zone property or a pair of standard and daylight time properties using
-     * BYDAY rule with day of week (such as BYDAY=1SUN).  This method produce
-     * the VTIMEZONE data which can be handled these implementations.  The rules
-     * produced by this method can be used only for calculating time zone offset
-     * around the specified date.
-     * @param time The date used for rule extraction.
-     * @param result Output param to filled in with the VTIMEZONE data.
-     * @param status Output param to filled in with a success or an error.
-     * @stable ICU 4.0
-     */
-    void writeSimple(UDate time, UnicodeString& result, UErrorCode& status) /*const*/;
-
-    /**
-     * Clones TimeZone objects polymorphically. Clients are responsible for deleting
-     * the TimeZone object cloned.
-     * @return   A new copy of this TimeZone object.
-     * @stable ICU 4.0
-     */
-    virtual TimeZone* clone(void) const;
-
-    /**
-     * Returns the TimeZone's adjusted GMT offset (i.e., the number of milliseconds to add
-     * to GMT to get local time in this time zone, taking daylight savings time into
-     * account) as of a particular reference date.  The reference date is used to determine
-     * whether daylight savings time is in effect and needs to be figured into the offset
-     * that is returned (in other words, what is the adjusted GMT offset in this time zone
-     * at this particular date and time?).  For the time zones produced by createTimeZone(),
-     * the reference data is specified according to the Gregorian calendar, and the date
-     * and time fields are local standard time.
-     *
-     * <p>Note: Don't call this method. Instead, call the getOffset(UDate...) overload,
-     * which returns both the raw and the DST offset for a given time. This method
-     * is retained only for backward compatibility.
-     *
-     * @param era        The reference date's era
-     * @param year       The reference date's year
-     * @param month      The reference date's month (0-based; 0 is January)
-     * @param day        The reference date's day-in-month (1-based)
-     * @param dayOfWeek  The reference date's day-of-week (1-based; 1 is Sunday)
-     * @param millis     The reference date's milliseconds in day, local standard time
-     * @param status     Output param to filled in with a success or an error.
-     * @return           The offset in milliseconds to add to GMT to get local time.
-     * @stable ICU 4.0
-     */
-    virtual int32_t getOffset(uint8_t era, int32_t year, int32_t month, int32_t day,
-                              uint8_t dayOfWeek, int32_t millis, UErrorCode& status) const;
-
-    /**
-     * Gets the time zone offset, for current date, modified in case of
-     * daylight savings. This is the offset to add *to* UTC to get local time.
-     *
-     * <p>Note: Don't call this method. Instead, call the getOffset(UDate...) overload,
-     * which returns both the raw and the DST offset for a given time. This method
-     * is retained only for backward compatibility.
-     *
-     * @param era        The reference date's era
-     * @param year       The reference date's year
-     * @param month      The reference date's month (0-based; 0 is January)
-     * @param day        The reference date's day-in-month (1-based)
-     * @param dayOfWeek  The reference date's day-of-week (1-based; 1 is Sunday)
-     * @param millis     The reference date's milliseconds in day, local standard time
-     * @param monthLength The length of the given month in days.
-     * @param status     Output param to filled in with a success or an error.
-     * @return           The offset in milliseconds to add to GMT to get local time.
-     * @stable ICU 4.0
-     */
-    virtual int32_t getOffset(uint8_t era, int32_t year, int32_t month, int32_t day,
-                           uint8_t dayOfWeek, int32_t millis,
-                           int32_t monthLength, UErrorCode& status) const;
-
-    /**
-     * Returns the time zone raw and GMT offset for the given moment
-     * in time.  Upon return, local-millis = GMT-millis + rawOffset +
-     * dstOffset.  All computations are performed in the proleptic
-     * Gregorian calendar.  The default implementation in the TimeZone
-     * class delegates to the 8-argument getOffset().
-     *
-     * @param date moment in time for which to return offsets, in
-     * units of milliseconds from January 1, 1970 0:00 GMT, either GMT
-     * time or local wall time, depending on `local'.
-     * @param local if true, `date' is local wall time; otherwise it
-     * is in GMT time.
-     * @param rawOffset output parameter to receive the raw offset, that
-     * is, the offset not including DST adjustments
-     * @param dstOffset output parameter to receive the DST offset,
-     * that is, the offset to be added to `rawOffset' to obtain the
-     * total offset between local and GMT time. If DST is not in
-     * effect, this value is zero; otherwise it is a positive value,
-     * typically one hour.
-     * @param ec input-output error code
-     * @stable ICU 4.0
-     */
-    virtual void getOffset(UDate date, UBool local, int32_t& rawOffset,
-                           int32_t& dstOffset, UErrorCode& ec) const;
-
-    /**
-     * Sets the TimeZone's raw GMT offset (i.e., the number of milliseconds to add
-     * to GMT to get local time, before taking daylight savings time into account).
-     *
-     * @param offsetMillis  The new raw GMT offset for this time zone.
-     * @stable ICU 4.0
-     */
-    virtual void setRawOffset(int32_t offsetMillis);
-
-    /**
-     * Returns the TimeZone's raw GMT offset (i.e., the number of milliseconds to add
-     * to GMT to get local time, before taking daylight savings time into account).
-     *
-     * @return   The TimeZone's raw GMT offset.
-     * @stable ICU 4.0
-     */
-    virtual int32_t getRawOffset(void) const;
-
-    /**
-     * Queries if this time zone uses daylight savings time.
-     * @return true if this time zone uses daylight savings time,
-     * false, otherwise.
-     * @stable ICU 4.0
-     */
-    virtual UBool useDaylightTime(void) const;
-
-    /**
-     * Queries if the given date is in daylight savings time in
-     * this time zone.
-     * This method is wasteful since it creates a new GregorianCalendar and
-     * deletes it each time it is called. This is a deprecated method
-     * and provided only for Java compatibility.
-     *
-     * @param date the given UDate.
-     * @param status Output param filled in with success/error code.
-     * @return true if the given date is in daylight savings time,
-     * false, otherwise.
-     * @deprecated ICU 2.4. Use Calendar::inDaylightTime() instead.
-     */
-    virtual UBool inDaylightTime(UDate date, UErrorCode& status) const;
-
-    /**
-     * Returns true if this zone has the same rule and offset as another zone.
-     * That is, if this zone differs only in ID, if at all.
-     * @param other the <code>TimeZone</code> object to be compared with
-     * @return true if the given zone is the same as this one,
-     * with the possible exception of the ID
-     * @stable ICU 4.0
-     */
-    virtual UBool hasSameRules(const TimeZone& other) const;
-
-    /**
-     * Gets the first time zone transition after the base time.
-     * @param base      The base time.
-     * @param inclusive Whether the base time is inclusive or not.
-     * @param result    Receives the first transition after the base time.
-     * @return  TRUE if the transition is found.
-     * @stable ICU 4.0
-     */
-    virtual UBool getNextTransition(UDate base, UBool inclusive, TimeZoneTransition& result) /*const*/;
-
-    /**
-     * Gets the most recent time zone transition before the base time.
-     * @param base      The base time.
-     * @param inclusive Whether the base time is inclusive or not.
-     * @param result    Receives the most recent transition before the base time.
-     * @return  TRUE if the transition is found.
-     * @stable ICU 4.0
-     */
-    virtual UBool getPreviousTransition(UDate base, UBool inclusive, TimeZoneTransition& result) /*const*/;
-
-    /**
-     * Returns the number of <code>TimeZoneRule</code>s which represents time transitions,
-     * for this time zone, that is, all <code>TimeZoneRule</code>s for this time zone except
-     * <code>InitialTimeZoneRule</code>.  The return value range is 0 or any positive value.
-     * @param status    Receives error status code.
-     * @return The number of <code>TimeZoneRule</code>s representing time transitions.
-     * @stable ICU 4.0
-     */
-    virtual int32_t countTransitionRules(UErrorCode& status) /*const*/;
-
-    /**
-     * Gets the <code>InitialTimeZoneRule</code> and the set of <code>TimeZoneRule</code>
-     * which represent time transitions for this time zone.  On successful return,
-     * the argument initial points to non-NULL <code>InitialTimeZoneRule</code> and
-     * the array trsrules is filled with 0 or multiple <code>TimeZoneRule</code>
-     * instances up to the size specified by trscount.  The results are referencing the
-     * rule instance held by this time zone instance.  Therefore, after this time zone
-     * is destructed, they are no longer available.
-     * @param initial       Receives the initial timezone rule
-     * @param trsrules      Receives the timezone transition rules
-     * @param trscount      On input, specify the size of the array 'transitions' receiving
-     *                      the timezone transition rules.  On output, actual number of
-     *                      rules filled in the array will be set.
-     * @param status        Receives error status code.
-     * @stable ICU 4.0
-     */
-    virtual void getTimeZoneRules(const InitialTimeZoneRule*& initial,
-        const TimeZoneRule* trsrules[], int32_t& trscount, UErrorCode& status) /*const*/;
-
-private:
-    enum { DEFAULT_VTIMEZONE_LINES = 100 };
-
-    /**
-     * Default constructor.
-     */
-    VTimeZone();
-    static VTimeZone* createVTimeZone(VTZReader* reader);
-    void write(VTZWriter& writer, UErrorCode& status) const;
-    void write(UDate start, VTZWriter& writer, UErrorCode& status) /*const*/;
-    void writeSimple(UDate time, VTZWriter& writer, UErrorCode& status) /*const*/;
-    void load(VTZReader& reader, UErrorCode& status);
-    void parse(UErrorCode& status);
-
-    void writeZone(VTZWriter& w, BasicTimeZone& basictz, UVector* customProps,
-        UErrorCode& status) const;
-
-    void writeHeaders(VTZWriter& w, UErrorCode& status) const;
-    void writeFooter(VTZWriter& writer, UErrorCode& status) const;
-
-    void writeZonePropsByTime(VTZWriter& writer, UBool isDst, const UnicodeString& tzname,
-                              int32_t fromOffset, int32_t toOffset, UDate time, UBool withRDATE,
-                              UErrorCode& status) const;
-    void writeZonePropsByDOM(VTZWriter& writer, UBool isDst, const UnicodeString& tzname,
-                             int32_t fromOffset, int32_t toOffset,
-                             int32_t month, int32_t dayOfMonth, UDate startTime, UDate untilTime,
-                             UErrorCode& status) const;
-    void writeZonePropsByDOW(VTZWriter& writer, UBool isDst, const UnicodeString& tzname,
-                             int32_t fromOffset, int32_t toOffset,
-                             int32_t month, int32_t weekInMonth, int32_t dayOfWeek,
-                             UDate startTime, UDate untilTime, UErrorCode& status) const;
-    void writeZonePropsByDOW_GEQ_DOM(VTZWriter& writer, UBool isDst, const UnicodeString& tzname,
-                                     int32_t fromOffset, int32_t toOffset,
-                                     int32_t month, int32_t dayOfMonth, int32_t dayOfWeek,
-                                     UDate startTime, UDate untilTime, UErrorCode& status) const;
-    void writeZonePropsByDOW_GEQ_DOM_sub(VTZWriter& writer, int32_t month, int32_t dayOfMonth,
-                                         int32_t dayOfWeek, int32_t numDays,
-                                         UDate untilTime, int32_t fromOffset, UErrorCode& status) const;
-    void writeZonePropsByDOW_LEQ_DOM(VTZWriter& writer, UBool isDst, const UnicodeString& tzname,
-                                     int32_t fromOffset, int32_t toOffset,
-                                     int32_t month, int32_t dayOfMonth, int32_t dayOfWeek,
-                                     UDate startTime, UDate untilTime, UErrorCode& status) const;
-    void writeFinalRule(VTZWriter& writer, UBool isDst, const AnnualTimeZoneRule* rule,
-                        int32_t fromRawOffset, int32_t fromDSTSavings,
-                        UDate startTime, UErrorCode& status) const;
-
-    void beginZoneProps(VTZWriter& writer, UBool isDst, const UnicodeString& tzname,
-                        int32_t fromOffset, int32_t toOffset, UDate startTime, UErrorCode& status) const;
-    void endZoneProps(VTZWriter& writer, UBool isDst, UErrorCode& status) const;
-    void beginRRULE(VTZWriter& writer, int32_t month, UErrorCode& status) const;
-    void appendUNTIL(VTZWriter& writer, const UnicodeString& until, UErrorCode& status) const;
-
-    BasicTimeZone   *tz;
-    UVector         *vtzlines;
-    UnicodeString   tzurl;
-    UDate           lastmod;
-    UnicodeString   olsonzid;
-    UnicodeString   icutzver;
-
-public:
-    /**
-     * Return the class ID for this class. This is useful only for comparing to
-     * a return value from getDynamicClassID(). For example:
-     * <pre>
-     * .   Base* polymorphic_pointer = createPolymorphicObject();
-     * .   if (polymorphic_pointer->getDynamicClassID() ==
-     * .       erived::getStaticClassID()) ...
-     * </pre>
-     * @return          The class ID for all objects of this class.
-     * @stable ICU 4.0
-     */
-    static UClassID U_EXPORT2 getStaticClassID(void);
-
-    /**
-     * Returns a unique class ID POLYMORPHICALLY. Pure virtual override. This
-     * method is to implement a simple version of RTTI, since not all C++
-     * compilers support genuine RTTI. Polymorphic operator==() and clone()
-     * methods call this method.
-     *
-     * @return          The class ID for this object. All objects of a
-     *                  given class have the same class ID.  Objects of
-     *                  other classes have different class IDs.
-     * @stable ICU 4.0
-     */
-    virtual UClassID getDynamicClassID(void) const;
-};
-
-U_NAMESPACE_END
-
-#endif /* #if !UCONFIG_NO_FORMATTING */
-
-#endif // VTZONE_H
-//eof

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/rebar.config
----------------------------------------------------------------------
diff --git a/apps/couch_collate/rebar.config b/apps/couch_collate/rebar.config
deleted file mode 100644
index 7bfd49e..0000000
--- a/apps/couch_collate/rebar.config
+++ /dev/null
@@ -1,9 +0,0 @@
-%% -*- tab-width: 4;erlang-indent-level: 4;indent-tabs-mode: nil -*-
-%% ex: ft=erlang ts=4 sw=4 et
-
-{erl_opts, [
-        warnings_as_errors,
-        warn_export_all
-]}.
-
-{pre_hooks, [{clean, "rm -fr ebin priv erl_crash.dump"}]}.

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/rebar.config.script
----------------------------------------------------------------------
diff --git a/apps/couch_collate/rebar.config.script b/apps/couch_collate/rebar.config.script
deleted file mode 100644
index 21bb978..0000000
--- a/apps/couch_collate/rebar.config.script
+++ /dev/null
@@ -1,90 +0,0 @@
-%% -*- tab-width: 4;erlang-indent-level: 4;indent-tabs-mode: nil -*-
-%% ex: ft=erlang ts=4 sw=4 et
-
-%% Licensed 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.
-
-Arch = erlang:system_info(system_architecture),
-
-ICUConfig = fun(Args) ->
-    {0, Value} = eunit_lib:command("icu-config " ++ Args),
-    [C||C <- Value, C =/= $\n]
-end,
-
-GetFlag = fun(Name, Args) ->
-        case os:getenv(Name) of
-            false -> ICUConfig(Args);
-            Val -> Val
-        end
-    end,
-
-GetFlag1 = fun(Name, Default) ->
-        case os:getenv(Name) of
-            false -> Default;
-            Val -> Val
-        end
-    end,
-
-BuildStatic = os:getenv("COUCHDB_STATIC") =:= "1" andalso
-                os:getenv("USE_STATIC_ICU") =:= "1",
-
-
-IsDarwin = case os:type() of
-    {unix, darwin} -> true;
-    _ -> false
-end,
-
-UseSystemIcu = IsDarwin andalso os:getenv("USE_STATIC_ICU") /= "1",
-
-PortEnv = case {UseSystemIcu, BuildStatic} of
-    {true, _} ->
-        CFLAGS = GetFlag1("ICU_CFLAGS",
-                         "-Iplatform/osx/icu -I/usr/include -fPIC"),
-        LDFLAGS = GetFlag1("ICU_LDFLAGS",
-                          "-lpthread -lm  -licucore -lstdc++ -L/usr/lib " ++
-                          "$DRV_LDFLAGS -fPIC"),
-        [
-            {"CFLAGS", "$DRV_CFLAGS " ++ CFLAGS},
-            {"LDFLAGS", LDFLAGS}
-        ];
-
-    {_, true} ->
-        CFLAGS = GetFlag1("ICU_CFLAGS", "-I.libs/icu/include"),
-        LDFLAGS = GetFlag1("ICU_LDFLAGS", "-lstdc++ -fPIC " ++
-                                         ".libs/icu/lib/libicui18n.a " ++
-                                         ".libs/icu/lib/libicuuc.a " ++
-                                         ".libs/icu/lib/libicudata.a"),
-        [
-            {"DRV_CFLAGS", "$DRV_CFLAGS " ++ CFLAGS ++ " -D BSD_SOURCE"},
-            {"DRV_LDFLAGS", "$DRV_LDFLAGS " ++ LDFLAGS}
-        ];
-    {_, false} ->
-        ICUCFLAGS = GetFlag("ICU_CFLAGS", "--cflags"),
-        ICUCXXFLAGS = GetFlag("ICU_CXXFLAGS", "--cxxflags"),
-        ICULDFLAGS = GetFlag("ICU_LDFLAGS", "--ldflags"),
-        ICUINCPATH = GetFlag("ICU_INCPATH", "--cppflags-searchpath"),
-
-        [
-            {"CFLAGS",  ICUCFLAGS ++  " $CFLAGS " ++ ICUINCPATH},
-            {"CXXFLAGS", ICUCXXFLAGS ++ " $CXXFLAGS " ++ ICUINCPATH},
-            {"LDFLAGS",  ICULDFLAGS ++ " $LDFLAGS"}
-        ]
-end,
-
-PortInfo = [{port_env, PortEnv},
-            {port_specs, [
-                {filename:join(["priv", Arch, "couch_collate.so"]),
-                    ["c_src/*.c"]}]},
-            {pre_hooks, [{compile, "./build_icu.sh"}]},
-            {post_hooks, [{clean, "./build_icu.sh clean"}]}],
-
-lists:keymerge(1,lists:keysort(1, PortInfo), lists:keysort(1, CONFIG)).

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/src/couch_collate.app.src
----------------------------------------------------------------------
diff --git a/apps/couch_collate/src/couch_collate.app.src b/apps/couch_collate/src/couch_collate.app.src
deleted file mode 100644
index c41495c..0000000
--- a/apps/couch_collate/src/couch_collate.app.src
+++ /dev/null
@@ -1,13 +0,0 @@
-%% -*- tab-width: 4;erlang-indent-level: 4;indent-tabs-mode: nil -*-
-%% ex: ft=erlang ts=4 sw=4 et
-
-{application, couch_collate,
-    [
-        {description, "couchdb collation module"},
-        {vsn, "1.0.0"},
-        {registered, []},
-        {applications, [kernel,
-                        stdlib]},
-        {included_applications, []},
-        {env, []}
-]}.

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/src/couch_collate.erl
----------------------------------------------------------------------
diff --git a/apps/couch_collate/src/couch_collate.erl b/apps/couch_collate/src/couch_collate.erl
deleted file mode 100644
index 341510f..0000000
--- a/apps/couch_collate/src/couch_collate.erl
+++ /dev/null
@@ -1,62 +0,0 @@
-% Licensed 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.
-
--module(couch_collate).
-
--export([init/0]).
--export([collate/2, collate/3]).
-
--on_load(init/0).
-
--type collate_options() :: [nocase].
--export_type([collate_options/0]).
-
-init() ->
-    PrivDir = case code:priv_dir(?MODULE) of
-        {error, _} ->
-            EbinDir = filename:dirname(code:which(?MODULE)),
-            AppPath = filename:dirname(EbinDir),
-            filename:join(AppPath, "priv");
-        Path ->
-            Path
-    end,
-    NumScheds = erlang:system_info(schedulers),
-    Arch = erlang:system_info(system_architecture),
-    (catch erlang:load_nif(filename:join([PrivDir, Arch, ?MODULE]),
-                           NumScheds)),
-    case erlang:system_info(otp_release) of
-        "R13B03" -> true;
-        _ -> ok
-    end.
-
-%% @doc compare 2 string, result is -1 for lt, 0 for eq and 1 for gt.
--spec collate(binary(), binary()) -> 0 | -1 | 1.
-collate(A, B) ->
-    collate(A, B, []).
-
--spec collate(binary(), binary(), collate_options()) -> 0 | -1 | 1.
-collate(A, B, Options) when is_binary(A), is_binary(B) ->
-    HasNoCase = case lists:member(nocase, Options) of
-        true -> 1; % Case insensitive
-        false -> 0 % Case sensitive
-    end,
-    do_collate(A, B, HasNoCase).
-
-%% @private
-
-do_collate(BinaryA, BinaryB, 0) ->
-    collate_nif(BinaryA, BinaryB, 0);
-do_collate(BinaryA, BinaryB, 1) ->
-    collate_nif(BinaryA, BinaryB, 1).
-
-collate_nif(_BinaryA, _BinaryB, _HasCase) ->
-    exit(couch_collate_not_loaded).


[17/57] [abbrv] remove couch_collate

Posted by be...@apache.org.
http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/ucnv_cb.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/ucnv_cb.h b/apps/couch_collate/platform/osx/icu/unicode/ucnv_cb.h
deleted file mode 100644
index f0e67ba..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/ucnv_cb.h
+++ /dev/null
@@ -1,162 +0,0 @@
-/*
-**********************************************************************
-*   Copyright (C) 2000-2004, International Business Machines
-*   Corporation and others.  All Rights Reserved.
-**********************************************************************
- *  ucnv_cb.h:
- *  External APIs for the ICU's codeset conversion library
- *  Helena Shih
- * 
- * Modification History:
- *
- *   Date        Name        Description
- */
-
-/**
- * \file 
- * \brief C UConverter functions to aid the writers of callbacks
- *
- * <h2> Callback API for UConverter </h2>
- * 
- * These functions are provided here for the convenience of the callback
- * writer. If you are just looking for callback functions to use, please
- * see ucnv_err.h.  DO NOT call these functions directly when you are 
- * working with converters, unless your code has been called as a callback
- * via ucnv_setFromUCallback or ucnv_setToUCallback !!
- * 
- * A note about error codes and overflow.  Unlike other ICU functions,
- * these functions do not expect the error status to be U_ZERO_ERROR.
- * Callbacks must be much more careful about their error codes.
- * The error codes used here are in/out parameters, which should be passed
- * back in the callback's error parameter.
- * 
- * For example, if you call ucnv_cbfromUWriteBytes to write data out 
- * to the output codepage, it may return U_BUFFER_OVERFLOW_ERROR if 
- * the data did not fit in the target. But this isn't a failing error, 
- * in fact, ucnv_cbfromUWriteBytes may be called AGAIN with the error
- * status still U_BUFFER_OVERFLOW_ERROR to attempt to write further bytes,
- * which will also go into the internal overflow buffers.
- * 
- * Concerning offsets, the 'offset' parameters here are relative to the start
- * of SOURCE.  For example, Suppose the string "ABCD" was being converted 
- * from Unicode into a codepage which doesn't have a mapping for 'B'.
- * 'A' will be written out correctly, but
- * The FromU Callback will be called on an unassigned character for 'B'.
- * At this point, this is the state of the world:
- *    Target:    A [..]     [points after A]
- *    Source:  A B [C] D    [points to C - B has been consumed]
- *             0 1  2  3 
- *    codePoint = "B"       [the unassigned codepoint] 
- * 
- * Now, suppose a callback wants to write the substitution character '?' to
- * the target. It calls ucnv_cbFromUWriteBytes() to write the ?. 
- * It should pass ZERO as the offset, because the offset as far as the 
- * callback is concerned is relative to the SOURCE pointer [which points 
- * before 'C'.]  If the callback goes into the args and consumes 'C' also,
- * it would call FromUWriteBytes with an offset of 1 (and advance the source
- * pointer).
- *
- */
-
-#ifndef UCNV_CB_H
-#define UCNV_CB_H
-
-#include "unicode/utypes.h"
-
-#if !UCONFIG_NO_CONVERSION
-
-#include "unicode/ucnv.h"
-#include "unicode/ucnv_err.h"
-
-/**
- * ONLY used by FromU callback functions.
- * Writes out the specified byte output bytes to the target byte buffer or to converter internal buffers.
- *
- * @param args callback fromUnicode arguments
- * @param source source bytes to write
- * @param length length of bytes to write
- * @param offsetIndex the relative offset index from callback.
- * @param err error status. If <TT>U_BUFFER_OVERFLOW</TT> is returned, then U_BUFFER_OVERFLOW <STRONG>must</STRONG> 
- * be returned to the user, because it means that not all data could be written into the target buffer, and some is 
- * in the converter error buffer.
- * @see ucnv_cbFromUWriteSub
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2
-ucnv_cbFromUWriteBytes (UConverterFromUnicodeArgs *args,
-                        const char* source,
-                        int32_t length,
-                        int32_t offsetIndex,
-                        UErrorCode * err);
-
-/**
- * ONLY used by FromU callback functions.  
- * This function will write out the correct substitution character sequence 
- * to the target.
- *
- * @param args callback fromUnicode arguments
- * @param offsetIndex the relative offset index from the current source pointer to be used
- * @param err error status. If <TT>U_BUFFER_OVERFLOW</TT> is returned, then U_BUFFER_OVERFLOW <STRONG>must</STRONG> 
- * be returned to the user, because it means that not all data could be written into the target buffer, and some is 
- * in the converter error buffer.
- * @see ucnv_cbFromUWriteBytes
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2 
-ucnv_cbFromUWriteSub (UConverterFromUnicodeArgs *args,
-                      int32_t offsetIndex,
-                      UErrorCode * err);
-
-/**
- * ONLY used by fromU callback functions.  
- * This function will write out the error character(s) to the target UChar buffer.
- *
- * @param args callback fromUnicode arguments
- * @param source pointer to pointer to first UChar to write [on exit: 1 after last UChar processed]
- * @param sourceLimit pointer after last UChar to write
- * @param offsetIndex the relative offset index from callback which will be set
- * @param err error status <TT>U_BUFFER_OVERFLOW</TT>
- * @see ucnv_cbToUWriteSub
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2 ucnv_cbFromUWriteUChars(UConverterFromUnicodeArgs *args,
-                             const UChar** source,
-                             const UChar*  sourceLimit,
-                             int32_t offsetIndex,
-                             UErrorCode * err);
-
-/**
- * ONLY used by ToU callback functions.
- *  This function will write out the specified characters to the target 
- * UChar buffer.
- *
- * @param args callback toUnicode arguments
- * @param source source string to write
- * @param length the length of source string
- * @param offsetIndex the relative offset index which will be written.
- * @param err error status <TT>U_BUFFER_OVERFLOW</TT>
- * @see ucnv_cbToUWriteSub
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2 ucnv_cbToUWriteUChars (UConverterToUnicodeArgs *args,
-                                             const UChar* source,
-                                             int32_t length,
-                                             int32_t offsetIndex,
-                                             UErrorCode * err);
-
-/**
- * ONLY used by ToU  callback functions.  
- * This function will write out the Unicode substitution character (U+FFFD).
- *
- * @param args callback fromUnicode arguments
- * @param offsetIndex the relative offset index from callback.
- * @param err error status <TT>U_BUFFER_OVERFLOW</TT>
- * @see ucnv_cbToUWriteUChars
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2 ucnv_cbToUWriteSub (UConverterToUnicodeArgs *args,
-                       int32_t offsetIndex,
-                       UErrorCode * err);
-#endif
-
-#endif

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/ucnv_err.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/ucnv_err.h b/apps/couch_collate/platform/osx/icu/unicode/ucnv_err.h
deleted file mode 100644
index 6fde696..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/ucnv_err.h
+++ /dev/null
@@ -1,463 +0,0 @@
-/*
-**********************************************************************
-*   Copyright (C) 1999-2007, International Business Machines
-*   Corporation and others.  All Rights Reserved.
-**********************************************************************
- *
- *
- *   ucnv_err.h:
- */
-
-/**
- * \file
- * \brief C UConverter predefined error callbacks
- *
- *  <h2>Error Behaviour Functions</h2>
- *  Defines some error behaviour functions called by ucnv_{from,to}Unicode
- *  These are provided as part of ICU and many are stable, but they
- *  can also be considered only as an example of what can be done with
- *  callbacks.  You may of course write your own.
- *
- *  If you want to write your own, you may also find the functions from
- *  ucnv_cb.h useful when writing your own callbacks.
- *
- *  These functions, although public, should NEVER be called directly.
- *  They should be used as parameters to the ucnv_setFromUCallback
- *  and ucnv_setToUCallback functions, to set the behaviour of a converter
- *  when it encounters ILLEGAL/UNMAPPED/INVALID sequences.
- *
- *  usage example:  'STOP' doesn't need any context, but newContext
- *    could be set to something other than 'NULL' if needed. The available
- *    contexts in this header can modify the default behavior of the callback.
- *
- *  \code
- *  UErrorCode err = U_ZERO_ERROR;
- *  UConverter *myConverter = ucnv_open("ibm-949", &err);
- *  const void *oldContext;
- *  UConverterFromUCallback oldAction;
- *
- *
- *  if (U_SUCCESS(err))
- *  {
- *      ucnv_setFromUCallBack(myConverter,
- *                       UCNV_FROM_U_CALLBACK_STOP,
- *                       NULL,
- *                       &oldAction,
- *                       &oldContext,
- *                       &status);
- *  }
- *  \endcode
- *
- *  The code above tells "myConverter" to stop when it encounters an
- *  ILLEGAL/TRUNCATED/INVALID sequences when it is used to convert from
- *  Unicode -> Codepage. The behavior from Codepage to Unicode is not changed,
- *  and ucnv_setToUCallBack would need to be called in order to change
- *  that behavior too.
- *
- *  Here is an example with a context:
- *
- *  \code
- *  UErrorCode err = U_ZERO_ERROR;
- *  UConverter *myConverter = ucnv_open("ibm-949", &err);
- *  const void *oldContext;
- *  UConverterFromUCallback oldAction;
- *
- *
- *  if (U_SUCCESS(err))
- *  {
- *      ucnv_setToUCallBack(myConverter,
- *                       UCNV_TO_U_CALLBACK_SUBSTITUTE,
- *                       UCNV_SUB_STOP_ON_ILLEGAL,
- *                       &oldAction,
- *                       &oldContext,
- *                       &status);
- *  }
- *  \endcode
- *
- *  The code above tells "myConverter" to stop when it encounters an
- *  ILLEGAL/TRUNCATED/INVALID sequences when it is used to convert from
- *  Codepage -> Unicode. Any unmapped and legal characters will be
- *  substituted to be the default substitution character.
- */
-
-#ifndef UCNV_ERR_H
-#define UCNV_ERR_H
-
-#include "unicode/utypes.h"
-
-#if !UCONFIG_NO_CONVERSION
-
-/** Forward declaring the UConverter structure. @stable ICU 2.0 */
-struct UConverter;
-
-/** @stable ICU 2.0 */
-typedef struct UConverter UConverter;
-
-/**
- * FROM_U, TO_U context options for sub callback
- * @stable ICU 2.0
- */
-#define UCNV_SUB_STOP_ON_ILLEGAL "i"
-
-/**
- * FROM_U, TO_U context options for skip callback
- * @stable ICU 2.0
- */
-#define UCNV_SKIP_STOP_ON_ILLEGAL "i"
-
-/**
- * FROM_U_CALLBACK_ESCAPE context option to escape the code unit according to ICU (%UXXXX) 
- * @stable ICU 2.0
- */
-#define UCNV_ESCAPE_ICU       NULL
-/**
- * FROM_U_CALLBACK_ESCAPE context option to escape the code unit according to JAVA (\\uXXXX)
- * @stable ICU 2.0
- */
-#define UCNV_ESCAPE_JAVA      "J"
-/**
- * FROM_U_CALLBACK_ESCAPE context option to escape the code unit according to C (\\uXXXX \\UXXXXXXXX)
- * TO_U_CALLBACK_ESCAPE option to escape the character value accoding to C (\\xXXXX)
- * @stable ICU 2.0
- */
-#define UCNV_ESCAPE_C         "C"
-/**
- * FROM_U_CALLBACK_ESCAPE context option to escape the code unit according to XML Decimal escape \htmlonly(&amp;#DDDD;)\endhtmlonly
- * TO_U_CALLBACK_ESCAPE context option to escape the character value accoding to XML Decimal escape \htmlonly(&amp;#DDDD;)\endhtmlonly
- * @stable ICU 2.0
- */
-#define UCNV_ESCAPE_XML_DEC   "D"
-/**
- * FROM_U_CALLBACK_ESCAPE context option to escape the code unit according to XML Hex escape \htmlonly(&amp;#xXXXX;)\endhtmlonly
- * TO_U_CALLBACK_ESCAPE context option to escape the character value accoding to XML Hex escape \htmlonly(&amp;#xXXXX;)\endhtmlonly
- * @stable ICU 2.0
- */
-#define UCNV_ESCAPE_XML_HEX   "X"
-/**
- * FROM_U_CALLBACK_ESCAPE context option to escape the code unit according to Unicode (U+XXXXX)
- * @stable ICU 2.0
- */
-#define UCNV_ESCAPE_UNICODE   "U"
-
-/**
- * FROM_U_CALLBACK_ESCAPE context option to escape the code unit according to CSS2 conventions (\\HH..H<space>, that is,
- * a backslash, 1..6 hex digits, and a space)
- * @draft ICU 4.0
- */
-#define UCNV_ESCAPE_CSS2   "S"
-
-/** 
- * The process condition code to be used with the callbacks.  
- * Codes which are greater than UCNV_IRREGULAR should be 
- * passed on to any chained callbacks.
- * @stable ICU 2.0
- */
-typedef enum {
-    UCNV_UNASSIGNED = 0,  /**< The code point is unassigned.
-                             The error code U_INVALID_CHAR_FOUND will be set. */
-    UCNV_ILLEGAL = 1,     /**< The code point is illegal. For example, 
-                             \\x81\\x2E is illegal in SJIS because \\x2E
-                             is not a valid trail byte for the \\x81 
-                             lead byte.
-                             Also, starting with Unicode 3.0.1, non-shortest byte sequences
-                             in UTF-8 (like \\xC1\\xA1 instead of \\x61 for U+0061)
-                             are also illegal, not just irregular.
-                             The error code U_ILLEGAL_CHAR_FOUND will be set. */
-    UCNV_IRREGULAR = 2,   /**< The codepoint is not a regular sequence in 
-                             the encoding. For example, \\xED\\xA0\\x80..\\xED\\xBF\\xBF
-                             are irregular UTF-8 byte sequences for single surrogate
-                             code points.
-                             The error code U_INVALID_CHAR_FOUND will be set. */
-    UCNV_RESET = 3,       /**< The callback is called with this reason when a
-                             'reset' has occured. Callback should reset all
-                             state. */
-    UCNV_CLOSE = 4,        /**< Called when the converter is closed. The
-                             callback should release any allocated memory.*/
-    UCNV_CLONE = 5         /**< Called when ucnv_safeClone() is called on the
-                              converter. the pointer available as the
-                              'context' is an alias to the original converters'
-                              context pointer. If the context must be owned
-                              by the new converter, the callback must clone 
-                              the data and call ucnv_setFromUCallback 
-                              (or setToUCallback) with the correct pointer.
-                              @stable ICU 2.2
-                           */
-} UConverterCallbackReason;
-
-
-/**
- * The structure for the fromUnicode callback function parameter.
- * @stable ICU 2.0
- */
-typedef struct {
-    uint16_t size;              /**< The size of this struct. @stable ICU 2.0 */
-    UBool flush;                /**< The internal state of converter will be reset and data flushed if set to TRUE. @stable ICU 2.0    */
-    UConverter *converter;      /**< Pointer to the converter that is opened and to which this struct is passed as an argument. @stable ICU 2.0  */
-    const UChar *source;        /**< Pointer to the source source buffer. @stable ICU 2.0    */
-    const UChar *sourceLimit;   /**< Pointer to the limit (end + 1) of source buffer. @stable ICU 2.0    */
-    char *target;               /**< Pointer to the target buffer. @stable ICU 2.0    */
-    const char *targetLimit;    /**< Pointer to the limit (end + 1) of target buffer. @stable ICU 2.0     */
-    int32_t *offsets;           /**< Pointer to the buffer that recieves the offsets. *offset = blah ; offset++;. @stable ICU 2.0  */
-} UConverterFromUnicodeArgs;
-
-
-/**
- * The structure for the toUnicode callback function parameter.
- * @stable ICU 2.0
- */
-typedef struct {
-    uint16_t size;              /**< The size of this struct   @stable ICU 2.0 */
-    UBool flush;                /**< The internal state of converter will be reset and data flushed if set to TRUE. @stable ICU 2.0   */
-    UConverter *converter;      /**< Pointer to the converter that is opened and to which this struct is passed as an argument. @stable ICU 2.0 */
-    const char *source;         /**< Pointer to the source source buffer. @stable ICU 2.0    */
-    const char *sourceLimit;    /**< Pointer to the limit (end + 1) of source buffer. @stable ICU 2.0    */
-    UChar *target;              /**< Pointer to the target buffer. @stable ICU 2.0    */
-    const UChar *targetLimit;   /**< Pointer to the limit (end + 1) of target buffer. @stable ICU 2.0     */
-    int32_t *offsets;           /**< Pointer to the buffer that recieves the offsets. *offset = blah ; offset++;. @stable ICU 2.0  */
-} UConverterToUnicodeArgs;
-
-
-/**
- * DO NOT CALL THIS FUNCTION DIRECTLY!
- * This From Unicode callback STOPS at the ILLEGAL_SEQUENCE,
- * returning the error code back to the caller immediately.
- *
- * @param context Pointer to the callback's private data
- * @param fromUArgs Information about the conversion in progress
- * @param codeUnits Points to 'length' UChars of the concerned Unicode sequence
- * @param length Size (in bytes) of the concerned codepage sequence
- * @param codePoint Single UChar32 (UTF-32) containing the concerend Unicode codepoint.
- * @param reason Defines the reason the callback was invoked
- * @param err This should always be set to a failure status prior to calling.
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2 UCNV_FROM_U_CALLBACK_STOP (
-                  const void *context,
-                  UConverterFromUnicodeArgs *fromUArgs,
-                  const UChar* codeUnits,
-                  int32_t length,
-                  UChar32 codePoint,
-                  UConverterCallbackReason reason,
-                  UErrorCode * err);
-
-
-
-/**
- * DO NOT CALL THIS FUNCTION DIRECTLY!
- * This To Unicode callback STOPS at the ILLEGAL_SEQUENCE,
- * returning the error code back to the caller immediately.
- *
- * @param context Pointer to the callback's private data
- * @param toUArgs Information about the conversion in progress
- * @param codeUnits Points to 'length' bytes of the concerned codepage sequence
- * @param length Size (in bytes) of the concerned codepage sequence
- * @param reason Defines the reason the callback was invoked
- * @param err This should always be set to a failure status prior to calling.
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2 UCNV_TO_U_CALLBACK_STOP (
-                  const void *context,
-                  UConverterToUnicodeArgs *toUArgs,
-                  const char* codeUnits,
-                  int32_t length,
-                  UConverterCallbackReason reason,
-                  UErrorCode * err);
-
-/**
- * DO NOT CALL THIS FUNCTION DIRECTLY!
- * This From Unicode callback skips any ILLEGAL_SEQUENCE, or
- * skips only UNASSINGED_SEQUENCE depending on the context parameter
- * simply ignoring those characters. 
- *
- * @param context  The function currently recognizes the callback options:
- *                 UCNV_SKIP_STOP_ON_ILLEGAL: STOPS at the ILLEGAL_SEQUENCE,
- *                      returning the error code back to the caller immediately.
- *                 NULL: Skips any ILLEGAL_SEQUENCE
- * @param fromUArgs Information about the conversion in progress
- * @param codeUnits Points to 'length' UChars of the concerned Unicode sequence
- * @param length Size (in bytes) of the concerned codepage sequence
- * @param codePoint Single UChar32 (UTF-32) containing the concerend Unicode codepoint.
- * @param reason Defines the reason the callback was invoked
- * @param err Return value will be set to success if the callback was handled,
- *      otherwise this value will be set to a failure status.
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2 UCNV_FROM_U_CALLBACK_SKIP (
-                  const void *context,
-                  UConverterFromUnicodeArgs *fromUArgs,
-                  const UChar* codeUnits,
-                  int32_t length,
-                  UChar32 codePoint,
-                  UConverterCallbackReason reason,
-                  UErrorCode * err);
-
-/**
- * DO NOT CALL THIS FUNCTION DIRECTLY!
- * This From Unicode callback will Substitute the ILLEGAL SEQUENCE, or 
- * UNASSIGNED_SEQUENCE depending on context parameter, with the
- * current substitution string for the converter. This is the default
- * callback.
- *
- * @param context The function currently recognizes the callback options:
- *                 UCNV_SUB_STOP_ON_ILLEGAL: STOPS at the ILLEGAL_SEQUENCE,
- *                      returning the error code back to the caller immediately.
- *                 NULL: Substitutes any ILLEGAL_SEQUENCE
- * @param fromUArgs Information about the conversion in progress
- * @param codeUnits Points to 'length' UChars of the concerned Unicode sequence
- * @param length Size (in bytes) of the concerned codepage sequence
- * @param codePoint Single UChar32 (UTF-32) containing the concerend Unicode codepoint.
- * @param reason Defines the reason the callback was invoked
- * @param err Return value will be set to success if the callback was handled,
- *      otherwise this value will be set to a failure status.
- * @see ucnv_setSubstChars
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2 UCNV_FROM_U_CALLBACK_SUBSTITUTE (
-                  const void *context,
-                  UConverterFromUnicodeArgs *fromUArgs,
-                  const UChar* codeUnits,
-                  int32_t length,
-                  UChar32 codePoint,
-                  UConverterCallbackReason reason,
-                  UErrorCode * err);
-
-/**
- * DO NOT CALL THIS FUNCTION DIRECTLY!
- * This From Unicode callback will Substitute the ILLEGAL SEQUENCE with the
- * hexadecimal representation of the illegal codepoints
- *
- * @param context The function currently recognizes the callback options:
- *        <ul>
- *        <li>UCNV_ESCAPE_ICU: Substitues the  ILLEGAL SEQUENCE with the hexadecimal 
- *          representation in the format  %UXXXX, e.g. "%uFFFE%u00AC%uC8FE"). 
- *          In the Event the converter doesn't support the characters {%,U}[A-F][0-9], 
- *          it will  substitute  the illegal sequence with the substitution characters.
- *          Note that  codeUnit(32bit int eg: unit of a surrogate pair) is represented as
- *          %UD84D%UDC56</li>
- *        <li>UCNV_ESCAPE_JAVA: Substitues the  ILLEGAL SEQUENCE with the hexadecimal 
- *          representation in the format  \\uXXXX, e.g. "\\uFFFE\\u00AC\\uC8FE"). 
- *          In the Event the converter doesn't support the characters {\,u}[A-F][0-9], 
- *          it will  substitute  the illegal sequence with the substitution characters.
- *          Note that  codeUnit(32bit int eg: unit of a surrogate pair) is represented as
- *          \\uD84D\\uDC56</li>
- *        <li>UCNV_ESCAPE_C: Substitues the  ILLEGAL SEQUENCE with the hexadecimal 
- *          representation in the format  \\uXXXX, e.g. "\\uFFFE\\u00AC\\uC8FE"). 
- *          In the Event the converter doesn't support the characters {\,u,U}[A-F][0-9], 
- *          it will  substitute  the illegal sequence with the substitution characters.
- *          Note that  codeUnit(32bit int eg: unit of a surrogate pair) is represented as
- *          \\U00023456</li>
- *        <li>UCNV_ESCAPE_XML_DEC: Substitues the  ILLEGAL SEQUENCE with the decimal 
- *          representation in the format \htmlonly&amp;#DDDDDDDD;, e.g. "&amp;#65534;&amp;#172;&amp;#51454;")\endhtmlonly. 
- *          In the Event the converter doesn't support the characters {&amp;,#}[0-9], 
- *          it will  substitute  the illegal sequence with the substitution characters.
- *          Note that  codeUnit(32bit int eg: unit of a surrogate pair) is represented as
- *          &amp;#144470; and Zero padding is ignored.</li>
- *        <li>UCNV_ESCAPE_XML_HEX:Substitues the  ILLEGAL SEQUENCE with the decimal 
- *          representation in the format \htmlonly&amp;#xXXXX; e.g. "&amp;#xFFFE;&amp;#x00AC;&amp;#xC8FE;")\endhtmlonly. 
- *          In the Event the converter doesn't support the characters {&,#,x}[0-9], 
- *          it will  substitute  the illegal sequence with the substitution characters.
- *          Note that  codeUnit(32bit int eg: unit of a surrogate pair) is represented as
- *          \htmlonly&amp;#x23456;\endhtmlonly</li>
- *        </ul>
- * @param fromUArgs Information about the conversion in progress
- * @param codeUnits Points to 'length' UChars of the concerned Unicode sequence
- * @param length Size (in bytes) of the concerned codepage sequence
- * @param codePoint Single UChar32 (UTF-32) containing the concerend Unicode codepoint.
- * @param reason Defines the reason the callback was invoked
- * @param err Return value will be set to success if the callback was handled,
- *      otherwise this value will be set to a failure status.
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2 UCNV_FROM_U_CALLBACK_ESCAPE (
-                  const void *context,
-                  UConverterFromUnicodeArgs *fromUArgs,
-                  const UChar* codeUnits,
-                  int32_t length,
-                  UChar32 codePoint,
-                  UConverterCallbackReason reason,
-                  UErrorCode * err);
-
-
-/**
- * DO NOT CALL THIS FUNCTION DIRECTLY!
- * This To Unicode callback skips any ILLEGAL_SEQUENCE, or
- * skips only UNASSINGED_SEQUENCE depending on the context parameter
- * simply ignoring those characters. 
- *
- * @param context  The function currently recognizes the callback options:
- *                 UCNV_SKIP_STOP_ON_ILLEGAL: STOPS at the ILLEGAL_SEQUENCE,
- *                      returning the error code back to the caller immediately.
- *                 NULL: Skips any ILLEGAL_SEQUENCE
- * @param toUArgs Information about the conversion in progress
- * @param codeUnits Points to 'length' bytes of the concerned codepage sequence
- * @param length Size (in bytes) of the concerned codepage sequence
- * @param reason Defines the reason the callback was invoked
- * @param err Return value will be set to success if the callback was handled,
- *      otherwise this value will be set to a failure status.
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2 UCNV_TO_U_CALLBACK_SKIP (
-                  const void *context,
-                  UConverterToUnicodeArgs *toUArgs,
-                  const char* codeUnits,
-                  int32_t length,
-                  UConverterCallbackReason reason,
-                  UErrorCode * err);
-
-/**
- * DO NOT CALL THIS FUNCTION DIRECTLY!
- * This To Unicode callback will Substitute the ILLEGAL SEQUENCE,or 
- * UNASSIGNED_SEQUENCE depending on context parameter,  with the
- * Unicode substitution character, U+FFFD.
- *
- * @param context  The function currently recognizes the callback options:
- *                 UCNV_SUB_STOP_ON_ILLEGAL: STOPS at the ILLEGAL_SEQUENCE,
- *                      returning the error code back to the caller immediately.
- *                 NULL: Substitutes any ILLEGAL_SEQUENCE
- * @param toUArgs Information about the conversion in progress
- * @param codeUnits Points to 'length' bytes of the concerned codepage sequence
- * @param length Size (in bytes) of the concerned codepage sequence
- * @param reason Defines the reason the callback was invoked
- * @param err Return value will be set to success if the callback was handled,
- *      otherwise this value will be set to a failure status.
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2 UCNV_TO_U_CALLBACK_SUBSTITUTE (
-                  const void *context,
-                  UConverterToUnicodeArgs *toUArgs,
-                  const char* codeUnits,
-                  int32_t length,
-                  UConverterCallbackReason reason,
-                  UErrorCode * err);
-
-/**
- * DO NOT CALL THIS FUNCTION DIRECTLY!
- * This To Unicode callback will Substitute the ILLEGAL SEQUENCE with the
- * hexadecimal representation of the illegal bytes
- *  (in the format  %XNN, e.g. "%XFF%X0A%XC8%X03").
- *
- * @param context This function currently recognizes the callback options:
- *      UCNV_ESCAPE_ICU, UCNV_ESCAPE_JAVA, UCNV_ESCAPE_C, UCNV_ESCAPE_XML_DEC,
- *      UCNV_ESCAPE_XML_HEX and UCNV_ESCAPE_UNICODE.
- * @param toUArgs Information about the conversion in progress
- * @param codeUnits Points to 'length' bytes of the concerned codepage sequence
- * @param length Size (in bytes) of the concerned codepage sequence
- * @param reason Defines the reason the callback was invoked
- * @param err Return value will be set to success if the callback was handled,
- *      otherwise this value will be set to a failure status.
- * @stable ICU 2.0
- */
-
-U_STABLE void U_EXPORT2 UCNV_TO_U_CALLBACK_ESCAPE (
-                  const void *context,
-                  UConverterToUnicodeArgs *toUArgs,
-                  const char* codeUnits,
-                  int32_t length,
-                  UConverterCallbackReason reason,
-                  UErrorCode * err);
-
-#endif
-
-#endif
-
-/*UCNV_ERR_H*/ 

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/ucol.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/ucol.h b/apps/couch_collate/platform/osx/icu/unicode/ucol.h
deleted file mode 100644
index 9fd952e..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/ucol.h
+++ /dev/null
@@ -1,1132 +0,0 @@
-/*
-*******************************************************************************
-* Copyright (c) 1996-2008, International Business Machines Corporation and others.
-* All Rights Reserved.
-*******************************************************************************
-*/
-
-#ifndef UCOL_H
-#define UCOL_H
-
-#include "unicode/utypes.h"
-
-#if !UCONFIG_NO_COLLATION
-
-#include "unicode/unorm.h"
-#include "unicode/parseerr.h"
-#include "unicode/uloc.h"
-#include "unicode/uset.h"
-
-/**
- * \file
- * \brief C API: Collator 
- *
- * <h2> Collator C API </h2>
- *
- * The C API for Collator performs locale-sensitive
- * string comparison. You use this service to build
- * searching and sorting routines for natural language text.
- * <em>Important: </em>The ICU collation service has been reimplemented 
- * in order to achieve better performance and UCA compliance. 
- * For details, see the 
- * <a href="http://source.icu-project.org/repos/icu/icuhtml/trunk/design/collation/ICU_collation_design.htm">
- * collation design document</a>.
- * <p>
- * For more information about the collation service see 
- * <a href="http://icu-project.org/userguide/Collate_Intro.html">the users guide</a>.
- * <p>
- * Collation service provides correct sorting orders for most locales supported in ICU. 
- * If specific data for a locale is not available, the orders eventually falls back
- * to the <a href="http://www.unicode.org/unicode/reports/tr10/">UCA sort order</a>. 
- * <p>
- * Sort ordering may be customized by providing your own set of rules. For more on
- * this subject see the 
- * <a href="http://icu-project.org/userguide/Collate_Customization.html">
- * Collation customization</a> section of the users guide.
- * <p>
- * @see         UCollationResult
- * @see         UNormalizationMode
- * @see         UCollationStrength
- * @see         UCollationElements
- */
-
-/** A collator.
-*  For usage in C programs.
-*/
-struct UCollator;
-/** structure representing a collator object instance 
- * @stable ICU 2.0
- */
-typedef struct UCollator UCollator;
-
-
-/**
- * UCOL_LESS is returned if source string is compared to be less than target
- * string in the u_strcoll() method.
- * UCOL_EQUAL is returned if source string is compared to be equal to target
- * string in the u_strcoll() method.
- * UCOL_GREATER is returned if source string is compared to be greater than
- * target string in the u_strcoll() method.
- * @see u_strcoll()
- * <p>
- * Possible values for a comparison result 
- * @stable ICU 2.0
- */
-typedef enum {
-  /** string a == string b */
-  UCOL_EQUAL    = 0,
-  /** string a > string b */
-  UCOL_GREATER    = 1,
-  /** string a < string b */
-  UCOL_LESS    = -1
-} UCollationResult ;
-
-
-/** Enum containing attribute values for controling collation behavior.
- * Here are all the allowable values. Not every attribute can take every value. The only
- * universal value is UCOL_DEFAULT, which resets the attribute value to the predefined  
- * value for that locale 
- * @stable ICU 2.0
- */
-typedef enum {
-  /** accepted by most attributes */
-  UCOL_DEFAULT = -1,
-
-  /** Primary collation strength */
-  UCOL_PRIMARY = 0,
-  /** Secondary collation strength */
-  UCOL_SECONDARY = 1,
-  /** Tertiary collation strength */
-  UCOL_TERTIARY = 2,
-  /** Default collation strength */
-  UCOL_DEFAULT_STRENGTH = UCOL_TERTIARY,
-  UCOL_CE_STRENGTH_LIMIT,
-  /** Quaternary collation strength */
-  UCOL_QUATERNARY=3,
-  /** Identical collation strength */
-  UCOL_IDENTICAL=15,
-  UCOL_STRENGTH_LIMIT,
-
-  /** Turn the feature off - works for UCOL_FRENCH_COLLATION, 
-      UCOL_CASE_LEVEL, UCOL_HIRAGANA_QUATERNARY_MODE
-      & UCOL_DECOMPOSITION_MODE*/
-  UCOL_OFF = 16,
-  /** Turn the feature on - works for UCOL_FRENCH_COLLATION, 
-      UCOL_CASE_LEVEL, UCOL_HIRAGANA_QUATERNARY_MODE
-      & UCOL_DECOMPOSITION_MODE*/
-  UCOL_ON = 17,
-  
-  /** Valid for UCOL_ALTERNATE_HANDLING. Alternate handling will be shifted */
-  UCOL_SHIFTED = 20,
-  /** Valid for UCOL_ALTERNATE_HANDLING. Alternate handling will be non ignorable */
-  UCOL_NON_IGNORABLE = 21,
-
-  /** Valid for UCOL_CASE_FIRST - 
-      lower case sorts before upper case */
-  UCOL_LOWER_FIRST = 24,
-  /** upper case sorts before lower case */
-  UCOL_UPPER_FIRST = 25,
-
-  UCOL_ATTRIBUTE_VALUE_COUNT
-
-} UColAttributeValue;
-
-/**
- * Base letter represents a primary difference.  Set comparison
- * level to UCOL_PRIMARY to ignore secondary and tertiary differences.
- * Use this to set the strength of a Collator object.
- * Example of primary difference, "abc" &lt; "abd"
- * 
- * Diacritical differences on the same base letter represent a secondary
- * difference.  Set comparison level to UCOL_SECONDARY to ignore tertiary
- * differences. Use this to set the strength of a Collator object.
- * Example of secondary difference, "&auml;" >> "a".
- *
- * Uppercase and lowercase versions of the same character represents a
- * tertiary difference.  Set comparison level to UCOL_TERTIARY to include
- * all comparison differences. Use this to set the strength of a Collator
- * object.
- * Example of tertiary difference, "abc" &lt;&lt;&lt; "ABC".
- *
- * Two characters are considered "identical" when they have the same
- * unicode spellings.  UCOL_IDENTICAL.
- * For example, "&auml;" == "&auml;".
- *
- * UCollationStrength is also used to determine the strength of sort keys 
- * generated from UCollator objects
- * These values can be now found in the UColAttributeValue enum.
- * @stable ICU 2.0
- **/
-typedef UColAttributeValue UCollationStrength;
-
-/** Attributes that collation service understands. All the attributes can take UCOL_DEFAULT
- * value, as well as the values specific to each one. 
- * @stable ICU 2.0
- */
-typedef enum {
-     /** Attribute for direction of secondary weights - used in French.
-      * Acceptable values are UCOL_ON, which results in secondary weights
-      * being considered backwards and UCOL_OFF which treats secondary
-      * weights in the order they appear.*/
-     UCOL_FRENCH_COLLATION, 
-     /** Attribute for handling variable elements.
-      * Acceptable values are UCOL_NON_IGNORABLE (default)
-      * which treats all the codepoints with non-ignorable 
-      * primary weights in the same way,
-      * and UCOL_SHIFTED which causes codepoints with primary 
-      * weights that are equal or below the variable top value
-      * to be ignored on primary level and moved to the quaternary 
-      * level.*/
-     UCOL_ALTERNATE_HANDLING, 
-     /** Controls the ordering of upper and lower case letters.
-      * Acceptable values are UCOL_OFF (default), which orders
-      * upper and lower case letters in accordance to their tertiary
-      * weights, UCOL_UPPER_FIRST which forces upper case letters to 
-      * sort before lower case letters, and UCOL_LOWER_FIRST which does 
-      * the opposite. */
-     UCOL_CASE_FIRST, 
-     /** Controls whether an extra case level (positioned before the third
-      * level) is generated or not. Acceptable values are UCOL_OFF (default), 
-      * when case level is not generated, and UCOL_ON which causes the case
-      * level to be generated. Contents of the case level are affected by
-      * the value of UCOL_CASE_FIRST attribute. A simple way to ignore 
-      * accent differences in a string is to set the strength to UCOL_PRIMARY
-      * and enable case level. */
-     UCOL_CASE_LEVEL,
-     /** Controls whether the normalization check and necessary normalizations
-      * are performed. When set to UCOL_OFF (default) no normalization check
-      * is performed. The correctness of the result is guaranteed only if the 
-      * input data is in so-called FCD form (see users manual for more info).
-      * When set to UCOL_ON, an incremental check is performed to see whether
-      * the input data is in the FCD form. If the data is not in the FCD form,
-      * incremental NFD normalization is performed. */
-     UCOL_NORMALIZATION_MODE, 
-     /** An alias for UCOL_NORMALIZATION_MODE attribute */
-     UCOL_DECOMPOSITION_MODE = UCOL_NORMALIZATION_MODE,
-     /** The strength attribute. Can be either UCOL_PRIMARY, UCOL_SECONDARY,
-      * UCOL_TERTIARY, UCOL_QUATERNARY or UCOL_IDENTICAL. The usual strength
-      * for most locales (except Japanese) is tertiary. Quaternary strength 
-      * is useful when combined with shifted setting for alternate handling
-      * attribute and for JIS x 4061 collation, when it is used to distinguish
-      * between Katakana  and Hiragana (this is achieved by setting the 
-      * UCOL_HIRAGANA_QUATERNARY mode to on. Otherwise, quaternary level
-      * is affected only by the number of non ignorable code points in
-      * the string. Identical strength is rarely useful, as it amounts 
-      * to codepoints of the NFD form of the string. */
-     UCOL_STRENGTH,  
-     /** When turned on, this attribute positions Hiragana before all  
-      * non-ignorables on quaternary level This is a sneaky way to produce JIS
-      * sort order */
-     UCOL_HIRAGANA_QUATERNARY_MODE,
-     /** When turned on, this attribute generates a collation key
-      * for the numeric value of substrings of digits.
-      * This is a way to get '100' to sort AFTER '2'. */
-     UCOL_NUMERIC_COLLATION, 
-     UCOL_ATTRIBUTE_COUNT
-} UColAttribute;
-
-/** Options for retrieving the rule string 
- *  @stable ICU 2.0
- */
-typedef enum {
-  /** Retrieve tailoring only */
-  UCOL_TAILORING_ONLY, 
-  /** Retrieve UCA rules and tailoring */
-  UCOL_FULL_RULES 
-} UColRuleOption ;
-
-/**
- * Open a UCollator for comparing strings.
- * The UCollator pointer is used in all the calls to the Collation 
- * service. After finished, collator must be disposed of by calling
- * {@link #ucol_close }.
- * @param loc The locale containing the required collation rules. 
- *            Special values for locales can be passed in - 
- *            if NULL is passed for the locale, the default locale
- *            collation rules will be used. If empty string ("") or
- *            "root" are passed, UCA rules will be used.
- * @param status A pointer to an UErrorCode to receive any errors
- * @return A pointer to a UCollator, or 0 if an error occurred.
- * @see ucol_openRules
- * @see ucol_safeClone
- * @see ucol_close
- * @stable ICU 2.0
- */
-U_STABLE UCollator* U_EXPORT2 
-ucol_open(const char *loc, UErrorCode *status);
-
-/**
- * Produce an UCollator instance according to the rules supplied.
- * The rules are used to change the default ordering, defined in the
- * UCA in a process called tailoring. The resulting UCollator pointer
- * can be used in the same way as the one obtained by {@link #ucol_strcoll }.
- * @param rules A string describing the collation rules. For the syntax
- *              of the rules please see users guide.
- * @param rulesLength The length of rules, or -1 if null-terminated.
- * @param normalizationMode The normalization mode: One of
- *             UCOL_OFF     (expect the text to not need normalization),
- *             UCOL_ON      (normalize), or
- *             UCOL_DEFAULT (set the mode according to the rules)
- * @param strength The default collation strength; one of UCOL_PRIMARY, UCOL_SECONDARY,
- * UCOL_TERTIARY, UCOL_IDENTICAL,UCOL_DEFAULT_STRENGTH - can be also set in the rules.
- * @param parseError  A pointer to UParseError to recieve information about errors
- *                    occurred during parsing. This argument can currently be set
- *                    to NULL, but at users own risk. Please provide a real structure.
- * @param status A pointer to an UErrorCode to receive any errors
- * @return A pointer to a UCollator. It is not guaranteed that NULL be returned in case
- *         of error - please use status argument to check for errors.
- * @see ucol_open
- * @see ucol_safeClone
- * @see ucol_close
- * @stable ICU 2.0
- */
-U_STABLE UCollator* U_EXPORT2 
-ucol_openRules( const UChar        *rules,
-                int32_t            rulesLength,
-                UColAttributeValue normalizationMode,
-                UCollationStrength strength,
-                UParseError        *parseError,
-                UErrorCode         *status);
-
-/** 
- * Open a collator defined by a short form string.
- * The structure and the syntax of the string is defined in the "Naming collators"
- * section of the users guide: 
- * http://icu-project.org/userguide/Collate_Concepts.html#Naming_Collators
- * Attributes are overriden by the subsequent attributes. So, for "S2_S3", final
- * strength will be 3. 3066bis locale overrides individual locale parts.
- * The call to this function is equivalent to a call to ucol_open, followed by a 
- * series of calls to ucol_setAttribute and ucol_setVariableTop.
- * @param definition A short string containing a locale and a set of attributes. 
- *                   Attributes not explicitly mentioned are left at the default
- *                   state for a locale.
- * @param parseError if not NULL, structure that will get filled with error's pre
- *                   and post context in case of error.
- * @param forceDefaults if FALSE, the settings that are the same as the collator 
- *                   default settings will not be applied (for example, setting
- *                   French secondary on a French collator would not be executed). 
- *                   If TRUE, all the settings will be applied regardless of the 
- *                   collator default value. If the definition
- *                   strings are to be cached, should be set to FALSE.
- * @param status     Error code. Apart from regular error conditions connected to 
- *                   instantiating collators (like out of memory or similar), this
- *                   API will return an error if an invalid attribute or attribute/value
- *                   combination is specified.
- * @return           A pointer to a UCollator or 0 if an error occured (including an 
- *                   invalid attribute).
- * @see ucol_open
- * @see ucol_setAttribute
- * @see ucol_setVariableTop
- * @see ucol_getShortDefinitionString
- * @see ucol_normalizeShortDefinitionString
- * @stable ICU 3.0
- *
- */
-U_STABLE UCollator* U_EXPORT2
-ucol_openFromShortString( const char *definition,
-                          UBool forceDefaults,
-                          UParseError *parseError,
-                          UErrorCode *status);
-
-/**
- * Get a set containing the contractions defined by the collator. The set includes
- * both the UCA contractions and the contractions defined by the collator. This set
- * will contain only strings. If a tailoring explicitly suppresses contractions from 
- * the UCA (like Russian), removed contractions will not be in the resulting set.
- * @param coll collator 
- * @param conts the set to hold the result. It gets emptied before
- *              contractions are added. 
- * @param status to hold the error code
- * @return the size of the contraction set
- *
- * @deprecated ICU 3.4, use ucol_getContractionsAndExpansions instead
- */
-U_DEPRECATED int32_t U_EXPORT2
-ucol_getContractions( const UCollator *coll,
-                  USet *conts,
-                  UErrorCode *status);
-
-/**
- * Get a set containing the expansions defined by the collator. The set includes
- * both the UCA expansions and the expansions defined by the tailoring
- * @param coll collator
- * @param contractions if not NULL, the set to hold the contractions
- * @param expansions if not NULL, the set to hold the expansions
- * @param addPrefixes add the prefix contextual elements to contractions
- * @param status to hold the error code
- *
- * @stable ICU 3.4
- */
-U_STABLE void U_EXPORT2
-ucol_getContractionsAndExpansions( const UCollator *coll,
-                  USet *contractions, USet *expansions,
-                  UBool addPrefixes, UErrorCode *status);
-
-/** 
- * Close a UCollator.
- * Once closed, a UCollator should not be used. Every open collator should
- * be closed. Otherwise, a memory leak will result.
- * @param coll The UCollator to close.
- * @see ucol_open
- * @see ucol_openRules
- * @see ucol_safeClone
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2 
-ucol_close(UCollator *coll);
-
-/**
- * Compare two strings.
- * The strings will be compared using the options already specified.
- * @param coll The UCollator containing the comparison rules.
- * @param source The source string.
- * @param sourceLength The length of source, or -1 if null-terminated.
- * @param target The target string.
- * @param targetLength The length of target, or -1 if null-terminated.
- * @return The result of comparing the strings; one of UCOL_EQUAL,
- * UCOL_GREATER, UCOL_LESS
- * @see ucol_greater
- * @see ucol_greaterOrEqual
- * @see ucol_equal
- * @stable ICU 2.0
- */
-U_STABLE UCollationResult U_EXPORT2 
-ucol_strcoll(    const    UCollator    *coll,
-        const    UChar        *source,
-        int32_t            sourceLength,
-        const    UChar        *target,
-        int32_t            targetLength);
-
-/**
- * Determine if one string is greater than another.
- * This function is equivalent to {@link #ucol_strcoll } == UCOL_GREATER
- * @param coll The UCollator containing the comparison rules.
- * @param source The source string.
- * @param sourceLength The length of source, or -1 if null-terminated.
- * @param target The target string.
- * @param targetLength The length of target, or -1 if null-terminated.
- * @return TRUE if source is greater than target, FALSE otherwise.
- * @see ucol_strcoll
- * @see ucol_greaterOrEqual
- * @see ucol_equal
- * @stable ICU 2.0
- */
-U_STABLE UBool U_EXPORT2 
-ucol_greater(const UCollator *coll,
-             const UChar     *source, int32_t sourceLength,
-             const UChar     *target, int32_t targetLength);
-
-/**
- * Determine if one string is greater than or equal to another.
- * This function is equivalent to {@link #ucol_strcoll } != UCOL_LESS
- * @param coll The UCollator containing the comparison rules.
- * @param source The source string.
- * @param sourceLength The length of source, or -1 if null-terminated.
- * @param target The target string.
- * @param targetLength The length of target, or -1 if null-terminated.
- * @return TRUE if source is greater than or equal to target, FALSE otherwise.
- * @see ucol_strcoll
- * @see ucol_greater
- * @see ucol_equal
- * @stable ICU 2.0
- */
-U_STABLE UBool U_EXPORT2 
-ucol_greaterOrEqual(const UCollator *coll,
-                    const UChar     *source, int32_t sourceLength,
-                    const UChar     *target, int32_t targetLength);
-
-/**
- * Compare two strings for equality.
- * This function is equivalent to {@link #ucol_strcoll } == UCOL_EQUAL
- * @param coll The UCollator containing the comparison rules.
- * @param source The source string.
- * @param sourceLength The length of source, or -1 if null-terminated.
- * @param target The target string.
- * @param targetLength The length of target, or -1 if null-terminated.
- * @return TRUE if source is equal to target, FALSE otherwise
- * @see ucol_strcoll
- * @see ucol_greater
- * @see ucol_greaterOrEqual
- * @stable ICU 2.0
- */
-U_STABLE UBool U_EXPORT2 
-ucol_equal(const UCollator *coll,
-           const UChar     *source, int32_t sourceLength,
-           const UChar     *target, int32_t targetLength);
-
-/**
- * Compare two UTF-8 encoded trings.
- * The strings will be compared using the options already specified.
- * @param coll The UCollator containing the comparison rules.
- * @param sIter The source string iterator.
- * @param tIter The target string iterator.
- * @return The result of comparing the strings; one of UCOL_EQUAL,
- * UCOL_GREATER, UCOL_LESS
- * @param status A pointer to an UErrorCode to receive any errors
- * @see ucol_strcoll
- * @stable ICU 2.6
- */
-U_STABLE UCollationResult U_EXPORT2 
-ucol_strcollIter(  const    UCollator    *coll,
-                  UCharIterator *sIter,
-                  UCharIterator *tIter,
-                  UErrorCode *status);
-
-/**
- * Get the collation strength used in a UCollator.
- * The strength influences how strings are compared.
- * @param coll The UCollator to query.
- * @return The collation strength; one of UCOL_PRIMARY, UCOL_SECONDARY,
- * UCOL_TERTIARY, UCOL_QUATERNARY, UCOL_IDENTICAL
- * @see ucol_setStrength
- * @stable ICU 2.0
- */
-U_STABLE UCollationStrength U_EXPORT2 
-ucol_getStrength(const UCollator *coll);
-
-/**
- * Set the collation strength used in a UCollator.
- * The strength influences how strings are compared.
- * @param coll The UCollator to set.
- * @param strength The desired collation strength; one of UCOL_PRIMARY, 
- * UCOL_SECONDARY, UCOL_TERTIARY, UCOL_QUATERNARY, UCOL_IDENTICAL, UCOL_DEFAULT
- * @see ucol_getStrength
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2 
-ucol_setStrength(UCollator *coll,
-                 UCollationStrength strength);
-
-/**
- * Get the display name for a UCollator.
- * The display name is suitable for presentation to a user.
- * @param objLoc The locale of the collator in question.
- * @param dispLoc The locale for display.
- * @param result A pointer to a buffer to receive the attribute.
- * @param resultLength The maximum size of result.
- * @param status A pointer to an UErrorCode to receive any errors
- * @return The total buffer size needed; if greater than resultLength,
- * the output was truncated.
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2 
-ucol_getDisplayName(    const    char        *objLoc,
-            const    char        *dispLoc,
-            UChar             *result,
-            int32_t         resultLength,
-            UErrorCode        *status);
-
-/**
- * Get a locale for which collation rules are available.
- * A UCollator in a locale returned by this function will perform the correct
- * collation for the locale.
- * @param index The index of the desired locale.
- * @return A locale for which collation rules are available, or 0 if none.
- * @see ucol_countAvailable
- * @stable ICU 2.0
- */
-U_STABLE const char* U_EXPORT2 
-ucol_getAvailable(int32_t index);
-
-/**
- * Determine how many locales have collation rules available.
- * This function is most useful as determining the loop ending condition for
- * calls to {@link #ucol_getAvailable }.
- * @return The number of locales for which collation rules are available.
- * @see ucol_getAvailable
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2 
-ucol_countAvailable(void);
-
-#if !UCONFIG_NO_SERVICE
-/**
- * Create a string enumerator of all locales for which a valid
- * collator may be opened.
- * @param status input-output error code
- * @return a string enumeration over locale strings. The caller is
- * responsible for closing the result.
- * @stable ICU 3.0
- */
-U_STABLE UEnumeration* U_EXPORT2
-ucol_openAvailableLocales(UErrorCode *status);
-#endif
-
-/**
- * Create a string enumerator of all possible keywords that are relevant to
- * collation. At this point, the only recognized keyword for this
- * service is "collation".
- * @param status input-output error code
- * @return a string enumeration over locale strings. The caller is
- * responsible for closing the result.
- * @stable ICU 3.0
- */
-U_STABLE UEnumeration* U_EXPORT2
-ucol_getKeywords(UErrorCode *status);
-
-/**
- * Given a keyword, create a string enumeration of all values
- * for that keyword that are currently in use.
- * @param keyword a particular keyword as enumerated by
- * ucol_getKeywords. If any other keyword is passed in, *status is set
- * to U_ILLEGAL_ARGUMENT_ERROR.
- * @param status input-output error code
- * @return a string enumeration over collation keyword values, or NULL
- * upon error. The caller is responsible for closing the result.
- * @stable ICU 3.0
- */
-U_STABLE UEnumeration* U_EXPORT2
-ucol_getKeywordValues(const char *keyword, UErrorCode *status);
-
-/**
- * Return the functionally equivalent locale for the given
- * requested locale, with respect to given keyword, for the
- * collation service.  If two locales return the same result, then
- * collators instantiated for these locales will behave
- * equivalently.  The converse is not always true; two collators
- * may in fact be equivalent, but return different results, due to
- * internal details.  The return result has no other meaning than
- * that stated above, and implies nothing as to the relationship
- * between the two locales.  This is intended for use by
- * applications who wish to cache collators, or otherwise reuse
- * collators when possible.  The functional equivalent may change
- * over time.  For more information, please see the <a
- * href="http://icu-project.org/userguide/locale.html#services">
- * Locales and Services</a> section of the ICU User Guide.
- * @param result fillin for the functionally equivalent locale
- * @param resultCapacity capacity of the fillin buffer
- * @param keyword a particular keyword as enumerated by
- * ucol_getKeywords.
- * @param locale the requested locale
- * @param isAvailable if non-NULL, pointer to a fillin parameter that
- * indicates whether the requested locale was 'available' to the
- * collation service. A locale is defined as 'available' if it
- * physically exists within the collation locale data.
- * @param status pointer to input-output error code
- * @return the actual buffer size needed for the locale.  If greater
- * than resultCapacity, the returned full name will be truncated and
- * an error code will be returned.
- * @stable ICU 3.0
- */
-U_STABLE int32_t U_EXPORT2
-ucol_getFunctionalEquivalent(char* result, int32_t resultCapacity,
-                             const char* keyword, const char* locale,
-                             UBool* isAvailable, UErrorCode* status);
-
-/**
- * Get the collation rules from a UCollator.
- * The rules will follow the rule syntax.
- * @param coll The UCollator to query.
- * @param length 
- * @return The collation rules.
- * @stable ICU 2.0
- */
-U_STABLE const UChar* U_EXPORT2 
-ucol_getRules(    const    UCollator    *coll, 
-        int32_t            *length);
-
-/** Get the short definition string for a collator. This API harvests the collator's
- *  locale and the attribute set and produces a string that can be used for opening 
- *  a collator with the same properties using the ucol_openFromShortString API.
- *  This string will be normalized.
- *  The structure and the syntax of the string is defined in the "Naming collators"
- *  section of the users guide: 
- *  http://icu-project.org/userguide/Collate_Concepts.html#Naming_Collators
- *  This API supports preflighting.
- *  @param coll a collator
- *  @param locale a locale that will appear as a collators locale in the resulting
- *                short string definition. If NULL, the locale will be harvested 
- *                from the collator.
- *  @param buffer space to hold the resulting string
- *  @param capacity capacity of the buffer
- *  @param status for returning errors. All the preflighting errors are featured
- *  @return length of the resulting string
- *  @see ucol_openFromShortString
- *  @see ucol_normalizeShortDefinitionString
- *  @stable ICU 3.0
- */
-U_STABLE int32_t U_EXPORT2
-ucol_getShortDefinitionString(const UCollator *coll,
-                              const char *locale,
-                              char *buffer,
-                              int32_t capacity,
-                              UErrorCode *status);
-
-/** Verifies and normalizes short definition string.
- *  Normalized short definition string has all the option sorted by the argument name,
- *  so that equivalent definition strings are the same. 
- *  This API supports preflighting.
- *  @param source definition string
- *  @param destination space to hold the resulting string
- *  @param capacity capacity of the buffer
- *  @param parseError if not NULL, structure that will get filled with error's pre
- *                   and post context in case of error.
- *  @param status     Error code. This API will return an error if an invalid attribute 
- *                    or attribute/value combination is specified. All the preflighting 
- *                    errors are also featured
- *  @return length of the resulting normalized string.
- *
- *  @see ucol_openFromShortString
- *  @see ucol_getShortDefinitionString
- * 
- *  @stable ICU 3.0
- */
-
-U_STABLE int32_t U_EXPORT2
-ucol_normalizeShortDefinitionString(const char *source,
-                                    char *destination,
-                                    int32_t capacity,
-                                    UParseError *parseError,
-                                    UErrorCode *status);
-
-
-/**
- * Get a sort key for a string from a UCollator.
- * Sort keys may be compared using <TT>strcmp</TT>.
- * @param coll The UCollator containing the collation rules.
- * @param source The string to transform.
- * @param sourceLength The length of source, or -1 if null-terminated.
- * @param result A pointer to a buffer to receive the attribute.
- * @param resultLength The maximum size of result.
- * @return The size needed to fully store the sort key.
- *      If there was an internal error generating the sort key,
- *      a zero value is returned.
- * @see ucol_keyHashCode
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2 
-ucol_getSortKey(const    UCollator    *coll,
-        const    UChar        *source,
-        int32_t        sourceLength,
-        uint8_t        *result,
-        int32_t        resultLength);
-
-
-/** Gets the next count bytes of a sort key. Caller needs
- *  to preserve state array between calls and to provide
- *  the same type of UCharIterator set with the same string.
- *  The destination buffer provided must be big enough to store
- *  the number of requested bytes. Generated sortkey is not 
- *  compatible with sortkeys generated using ucol_getSortKey
- *  API, since we don't do any compression. If uncompressed
- *  sortkeys are required, this API can be used.
- *  @param coll The UCollator containing the collation rules.
- *  @param iter UCharIterator containing the string we need 
- *              the sort key to be calculated for.
- *  @param state Opaque state of sortkey iteration.
- *  @param dest Buffer to hold the resulting sortkey part
- *  @param count number of sort key bytes required.
- *  @param status error code indicator.
- *  @return the actual number of bytes of a sortkey. It can be
- *          smaller than count if we have reached the end of 
- *          the sort key.
- *  @stable ICU 2.6
- */
-U_STABLE int32_t U_EXPORT2 
-ucol_nextSortKeyPart(const UCollator *coll,
-                     UCharIterator *iter,
-                     uint32_t state[2],
-                     uint8_t *dest, int32_t count,
-                     UErrorCode *status);
-
-/** enum that is taken by ucol_getBound API 
- * See below for explanation                
- * do not change the values assigned to the 
- * members of this enum. Underlying code    
- * depends on them having these numbers     
- * @stable ICU 2.0
- */
-typedef enum {
-  /** lower bound */
-  UCOL_BOUND_LOWER = 0,
-  /** upper bound that will match strings of exact size */
-  UCOL_BOUND_UPPER = 1,
-  /** upper bound that will match all the strings that have the same initial substring as the given string */
-  UCOL_BOUND_UPPER_LONG = 2,
-  UCOL_BOUND_VALUE_COUNT
-} UColBoundMode;
-
-/**
- * Produce a bound for a given sortkey and a number of levels.
- * Return value is always the number of bytes needed, regardless of 
- * whether the result buffer was big enough or even valid.<br>
- * Resulting bounds can be used to produce a range of strings that are
- * between upper and lower bounds. For example, if bounds are produced
- * for a sortkey of string "smith", strings between upper and lower 
- * bounds with one level would include "Smith", "SMITH", "sMiTh".<br>
- * There are two upper bounds that can be produced. If UCOL_BOUND_UPPER
- * is produced, strings matched would be as above. However, if bound
- * produced using UCOL_BOUND_UPPER_LONG is used, the above example will
- * also match "Smithsonian" and similar.<br>
- * For more on usage, see example in cintltst/capitst.c in procedure
- * TestBounds.
- * Sort keys may be compared using <TT>strcmp</TT>.
- * @param source The source sortkey.
- * @param sourceLength The length of source, or -1 if null-terminated. 
- *                     (If an unmodified sortkey is passed, it is always null 
- *                      terminated).
- * @param boundType Type of bound required. It can be UCOL_BOUND_LOWER, which 
- *                  produces a lower inclusive bound, UCOL_BOUND_UPPER, that 
- *                  produces upper bound that matches strings of the same length 
- *                  or UCOL_BOUND_UPPER_LONG that matches strings that have the 
- *                  same starting substring as the source string.
- * @param noOfLevels  Number of levels required in the resulting bound (for most 
- *                    uses, the recommended value is 1). See users guide for 
- *                    explanation on number of levels a sortkey can have.
- * @param result A pointer to a buffer to receive the resulting sortkey.
- * @param resultLength The maximum size of result.
- * @param status Used for returning error code if something went wrong. If the 
- *               number of levels requested is higher than the number of levels
- *               in the source key, a warning (U_SORT_KEY_TOO_SHORT_WARNING) is 
- *               issued.
- * @return The size needed to fully store the bound. 
- * @see ucol_keyHashCode
- * @stable ICU 2.1
- */
-U_STABLE int32_t U_EXPORT2 
-ucol_getBound(const uint8_t       *source,
-        int32_t             sourceLength,
-        UColBoundMode       boundType,
-        uint32_t            noOfLevels,
-        uint8_t             *result,
-        int32_t             resultLength,
-        UErrorCode          *status);
-        
-/**
- * Gets the version information for a Collator. Version is currently
- * an opaque 32-bit number which depends, among other things, on major
- * versions of the collator tailoring and UCA.
- * @param coll The UCollator to query.
- * @param info the version # information, the result will be filled in
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2
-ucol_getVersion(const UCollator* coll, UVersionInfo info);
-
-/**
- * Gets the UCA version information for a Collator. Version is the
- * UCA version number (3.1.1, 4.0).
- * @param coll The UCollator to query.
- * @param info the version # information, the result will be filled in
- * @stable ICU 2.8
- */
-U_STABLE void U_EXPORT2
-ucol_getUCAVersion(const UCollator* coll, UVersionInfo info);
-
-/** 
- * Merge two sort keys. The levels are merged with their corresponding counterparts
- * (primaries with primaries, secondaries with secondaries etc.). Between the values
- * from the same level a separator is inserted.
- * example (uncompressed): 
- * 191B1D 01 050505 01 910505 00 and 1F2123 01 050505 01 910505 00
- * will be merged as 
- * 191B1D 02 1F212301 050505 02 050505 01 910505 02 910505 00
- * This allows for concatenating of first and last names for sorting, among other things.
- * If the destination buffer is not big enough, the results are undefined.
- * If any of source lengths are zero or any of source pointers are NULL/undefined, 
- * result is of size zero.
- * @param src1 pointer to the first sortkey
- * @param src1Length length of the first sortkey
- * @param src2 pointer to the second sortkey
- * @param src2Length length of the second sortkey
- * @param dest buffer to hold the result
- * @param destCapacity size of the buffer for the result
- * @return size of the result. If the buffer is big enough size is always
- *         src1Length+src2Length-1
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2 
-ucol_mergeSortkeys(const uint8_t *src1, int32_t src1Length,
-                   const uint8_t *src2, int32_t src2Length,
-                   uint8_t *dest, int32_t destCapacity);
-
-/**
- * Universal attribute setter
- * @param coll collator which attributes are to be changed
- * @param attr attribute type 
- * @param value attribute value
- * @param status to indicate whether the operation went on smoothly or there were errors
- * @see UColAttribute
- * @see UColAttributeValue
- * @see ucol_getAttribute
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2 
-ucol_setAttribute(UCollator *coll, UColAttribute attr, UColAttributeValue value, UErrorCode *status);
-
-/**
- * Universal attribute getter
- * @param coll collator which attributes are to be changed
- * @param attr attribute type
- * @return attribute value
- * @param status to indicate whether the operation went on smoothly or there were errors
- * @see UColAttribute
- * @see UColAttributeValue
- * @see ucol_setAttribute
- * @stable ICU 2.0
- */
-U_STABLE UColAttributeValue  U_EXPORT2 
-ucol_getAttribute(const UCollator *coll, UColAttribute attr, UErrorCode *status);
-
-/** Variable top
- * is a two byte primary value which causes all the codepoints with primary values that
- * are less or equal than the variable top to be shifted when alternate handling is set
- * to UCOL_SHIFTED.
- * Sets the variable top to a collation element value of a string supplied. 
- * @param coll collator which variable top needs to be changed
- * @param varTop one or more (if contraction) UChars to which the variable top should be set
- * @param len length of variable top string. If -1 it is considered to be zero terminated.
- * @param status error code. If error code is set, the return value is undefined. 
- *               Errors set by this function are: <br>
- *    U_CE_NOT_FOUND_ERROR if more than one character was passed and there is no such 
- *    a contraction<br>
- *    U_PRIMARY_TOO_LONG_ERROR if the primary for the variable top has more than two bytes
- * @return a 32 bit value containing the value of the variable top in upper 16 bits. 
- *         Lower 16 bits are undefined
- * @see ucol_getVariableTop
- * @see ucol_restoreVariableTop
- * @stable ICU 2.0
- */
-U_STABLE uint32_t U_EXPORT2 
-ucol_setVariableTop(UCollator *coll, 
-                    const UChar *varTop, int32_t len, 
-                    UErrorCode *status);
-
-/** 
- * Gets the variable top value of a Collator. 
- * Lower 16 bits are undefined and should be ignored.
- * @param coll collator which variable top needs to be retrieved
- * @param status error code (not changed by function). If error code is set, 
- *               the return value is undefined.
- * @return the variable top value of a Collator.
- * @see ucol_setVariableTop
- * @see ucol_restoreVariableTop
- * @stable ICU 2.0
- */
-U_STABLE uint32_t U_EXPORT2 ucol_getVariableTop(const UCollator *coll, UErrorCode *status);
-
-/** 
- * Sets the variable top to a collation element value supplied. Variable top is 
- * set to the upper 16 bits. 
- * Lower 16 bits are ignored.
- * @param coll collator which variable top needs to be changed
- * @param varTop CE value, as returned by ucol_setVariableTop or ucol)getVariableTop
- * @param status error code (not changed by function)
- * @see ucol_getVariableTop
- * @see ucol_setVariableTop
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2 
-ucol_restoreVariableTop(UCollator *coll, const uint32_t varTop, UErrorCode *status);
-
-/**
- * Thread safe cloning operation. The result is a clone of a given collator.
- * @param coll collator to be cloned
- * @param stackBuffer user allocated space for the new clone. 
- * If NULL new memory will be allocated. 
- *  If buffer is not large enough, new memory will be allocated.
- *  Clients can use the U_COL_SAFECLONE_BUFFERSIZE. 
- *  This will probably be enough to avoid memory allocations.
- * @param pBufferSize pointer to size of allocated space. 
- *  If *pBufferSize == 0, a sufficient size for use in cloning will 
- *  be returned ('pre-flighting')
- *  If *pBufferSize is not enough for a stack-based safe clone, 
- *  new memory will be allocated.
- * @param status to indicate whether the operation went on smoothly or there were errors
- *    An informational status value, U_SAFECLONE_ALLOCATED_ERROR, is used if any
- * allocations were necessary.
- * @return pointer to the new clone
- * @see ucol_open
- * @see ucol_openRules
- * @see ucol_close
- * @stable ICU 2.0
- */
-U_STABLE UCollator* U_EXPORT2 
-ucol_safeClone(const UCollator *coll,
-               void            *stackBuffer,
-               int32_t         *pBufferSize,
-               UErrorCode      *status);
-
-/** default memory size for the new clone. It needs to be this large for os/400 large pointers 
- * @stable ICU 2.0
- */
-#define U_COL_SAFECLONE_BUFFERSIZE 512
-
-/**
- * Returns current rules. Delta defines whether full rules are returned or just the tailoring. 
- * Returns number of UChars needed to store rules. If buffer is NULL or bufferLen is not enough 
- * to store rules, will store up to available space.
- * @param coll collator to get the rules from
- * @param delta one of UCOL_TAILORING_ONLY, UCOL_FULL_RULES. 
- * @param buffer buffer to store the result in. If NULL, you'll get no rules.
- * @param bufferLen lenght of buffer to store rules in. If less then needed you'll get only the part that fits in.
- * @return current rules
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2 
-ucol_getRulesEx(const UCollator *coll, UColRuleOption delta, UChar *buffer, int32_t bufferLen);
-
-/**
- * gets the locale name of the collator. If the collator
- * is instantiated from the rules, then this function returns
- * NULL.
- * @param coll The UCollator for which the locale is needed
- * @param type You can choose between requested, valid and actual
- *             locale. For description see the definition of
- *             ULocDataLocaleType in uloc.h
- * @param status error code of the operation
- * @return real locale name from which the collation data comes. 
- *         If the collator was instantiated from rules, returns
- *         NULL.
- * @deprecated ICU 2.8 Use ucol_getLocaleByType instead
- */
-U_DEPRECATED const char * U_EXPORT2
-ucol_getLocale(const UCollator *coll, ULocDataLocaleType type, UErrorCode *status);
-
-
-/**
- * gets the locale name of the collator. If the collator
- * is instantiated from the rules, then this function returns
- * NULL.
- * @param coll The UCollator for which the locale is needed
- * @param type You can choose between requested, valid and actual
- *             locale. For description see the definition of
- *             ULocDataLocaleType in uloc.h
- * @param status error code of the operation
- * @return real locale name from which the collation data comes. 
- *         If the collator was instantiated from rules, returns
- *         NULL.
- * @stable ICU 2.8
- */
-U_STABLE const char * U_EXPORT2
-ucol_getLocaleByType(const UCollator *coll, ULocDataLocaleType type, UErrorCode *status);
-
-/**
- * Get an Unicode set that contains all the characters and sequences tailored in 
- * this collator. The result must be disposed of by using uset_close.
- * @param coll        The UCollator for which we want to get tailored chars
- * @param status      error code of the operation
- * @return a pointer to newly created USet. Must be be disposed by using uset_close
- * @see ucol_openRules
- * @see uset_close
- * @stable ICU 2.4
- */
-U_STABLE USet * U_EXPORT2
-ucol_getTailoredSet(const UCollator *coll, UErrorCode *status);
-
-/**
- * Universal attribute getter that returns UCOL_DEFAULT if the value is default
- * @param coll collator which attributes are to be changed
- * @param attr attribute type
- * @return attribute value or UCOL_DEFAULT if the value is default
- * @param status to indicate whether the operation went on smoothly or there were errors
- * @see UColAttribute
- * @see UColAttributeValue
- * @see ucol_setAttribute
- * @internal ICU 3.0
- */
-U_INTERNAL UColAttributeValue  U_EXPORT2
-ucol_getAttributeOrDefault(const UCollator *coll, UColAttribute attr, UErrorCode *status);
-
-/** Check whether two collators are equal. Collators are considered equal if they
- *  will sort strings the same. This means that both the current attributes and the
- *  rules must be equivalent. Currently used for RuleBasedCollator::operator==.
- *  @param source first collator
- *  @param target second collator
- *  @return TRUE or FALSE
- *  @internal ICU 3.0
- */
-U_INTERNAL UBool U_EXPORT2
-ucol_equals(const UCollator *source, const UCollator *target);
-
-/** Calculates the set of unsafe code points, given a collator.
- *   A character is unsafe if you could append any character and cause the ordering to alter significantly.
- *   Collation sorts in normalized order, so anything that rearranges in normalization can cause this.
- *   Thus if you have a character like a_umlaut, and you add a lower_dot to it,
- *   then it normalizes to a_lower_dot + umlaut, and sorts differently.
- *  @param coll Collator
- *  @param unsafe a fill-in set to receive the unsafe points
- *  @param status for catching errors
- *  @return number of elements in the set
- *  @internal ICU 3.0
- */
-U_INTERNAL int32_t U_EXPORT2
-ucol_getUnsafeSet( const UCollator *coll,
-                  USet *unsafe,
-                  UErrorCode *status);
-
-/** Reset UCA's static pointers. You don't want to use this, unless your static memory can go away.
- * @internal ICU 3.2.1
- */
-U_INTERNAL void U_EXPORT2
-ucol_forgetUCA(void);
-
-/** Touches all resources needed for instantiating a collator from a short string definition,
- *  thus filling up the cache.
- * @param definition A short string containing a locale and a set of attributes. 
- *                   Attributes not explicitly mentioned are left at the default
- *                   state for a locale.
- * @param parseError if not NULL, structure that will get filled with error's pre
- *                   and post context in case of error.
- * @param forceDefaults if FALSE, the settings that are the same as the collator 
- *                   default settings will not be applied (for example, setting
- *                   French secondary on a French collator would not be executed). 
- *                   If TRUE, all the settings will be applied regardless of the 
- *                   collator default value. If the definition
- *                   strings are to be cached, should be set to FALSE.
- * @param status     Error code. Apart from regular error conditions connected to 
- *                   instantiating collators (like out of memory or similar), this
- *                   API will return an error if an invalid attribute or attribute/value
- *                   combination is specified.
- * @see ucol_openFromShortString
- * @internal ICU 3.2.1
- */
-U_INTERNAL void U_EXPORT2
-ucol_prepareShortStringOpen( const char *definition,
-                          UBool forceDefaults,
-                          UParseError *parseError,
-                          UErrorCode *status);
-
-/** Creates a binary image of a collator. This binary image can be stored and 
- *  later used to instantiate a collator using ucol_openBinary.
- *  This API supports preflighting.
- *  @param coll Collator
- *  @param buffer a fill-in buffer to receive the binary image
- *  @param capacity capacity of the destination buffer
- *  @param status for catching errors
- *  @return size of the image
- *  @see ucol_openBinary
- *  @stable ICU 3.2
- */
-U_STABLE int32_t U_EXPORT2
-ucol_cloneBinary(const UCollator *coll,
-                 uint8_t *buffer, int32_t capacity,
-                 UErrorCode *status);
-
-/** Opens a collator from a collator binary image created using
- *  ucol_cloneBinary. Binary image used in instantiation of the 
- *  collator remains owned by the user and should stay around for 
- *  the lifetime of the collator. The API also takes a base collator
- *  which usualy should be UCA.
- *  @param bin binary image owned by the user and required through the
- *             lifetime of the collator
- *  @param length size of the image. If negative, the API will try to
- *                figure out the length of the image
- *  @param base fallback collator, usually UCA. Base is required to be
- *              present through the lifetime of the collator. Currently 
- *              it cannot be NULL.
- *  @param status for catching errors
- *  @return newly created collator
- *  @see ucol_cloneBinary
- *  @stable ICU 3.2
- */
-U_STABLE UCollator* U_EXPORT2
-ucol_openBinary(const uint8_t *bin, int32_t length, 
-                const UCollator *base, 
-                UErrorCode *status);
-
-
-#endif /* #if !UCONFIG_NO_COLLATION */
-
-#endif
-


[27/57] [abbrv] remove couch_collate

Posted by be...@apache.org.
http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/smpdtfmt.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/smpdtfmt.h b/apps/couch_collate/platform/osx/icu/unicode/smpdtfmt.h
deleted file mode 100644
index e7ce15b..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/smpdtfmt.h
+++ /dev/null
@@ -1,975 +0,0 @@
-/*
-* Copyright (C) 1997-2009, International Business Machines Corporation and others. All Rights Reserved.
-*******************************************************************************
-*
-* File SMPDTFMT.H
-*
-* Modification History:
-*
-*   Date        Name        Description
-*   02/19/97    aliu        Converted from java.
-*   07/09/97    helena      Make ParsePosition into a class.
-*   07/21/98    stephen     Added GMT_PLUS, GMT_MINUS
-*                            Changed setTwoDigitStartDate to set2DigitYearStart
-*                            Changed getTwoDigitStartDate to get2DigitYearStart
-*                            Removed subParseLong
-*                            Removed getZoneIndex (added in DateFormatSymbols)
-*   06/14/99    stephen     Removed fgTimeZoneDataSuffix
-*   10/14/99    aliu        Updated class doc to describe 2-digit year parsing
-*                           {j28 4182066}.
-*******************************************************************************
-*/
-
-#ifndef SMPDTFMT_H
-#define SMPDTFMT_H
-
-#include "unicode/utypes.h"
-
-/**
- * \file 
- * \brief C++ API: Format and parse dates in a language-independent manner.
- */
- 
-#if !UCONFIG_NO_FORMATTING
-
-#include "unicode/datefmt.h"
-
-U_NAMESPACE_BEGIN
-
-class DateFormatSymbols;
-class DateFormat;
-class MessageFormat;
-
-/**
- *
- * SimpleDateFormat is a concrete class for formatting and parsing dates in a
- * language-independent manner. It allows for formatting (millis -> text),
- * parsing (text -> millis), and normalization. Formats/Parses a date or time,
- * which is the standard milliseconds since 24:00 GMT, Jan 1, 1970.
- * <P>
- * Clients are encouraged to create a date-time formatter using DateFormat::getInstance(),
- * getDateInstance(), getDateInstance(), or getDateTimeInstance() rather than
- * explicitly constructing an instance of SimpleDateFormat.  This way, the client
- * is guaranteed to get an appropriate formatting pattern for whatever locale the
- * program is running in.  However, if the client needs something more unusual than
- * the default patterns in the locales, he can construct a SimpleDateFormat directly
- * and give it an appropriate pattern (or use one of the factory methods on DateFormat
- * and modify the pattern after the fact with toPattern() and applyPattern().
- * <P>
- * Date/Time format syntax:
- * <P>
- * The date/time format is specified by means of a string time pattern. In this
- * pattern, all ASCII letters are reserved as pattern letters, which are defined
- * as the following:
- * <pre>
- * \code
- * Symbol   Meaning                 Presentation        Example
- * ------   -------                 ------------        -------
- * G        era designator          (Text)              AD
- * y        year                    (Number)            1996
- * Y        year (week of year)     (Number)            1997
- * u        extended year           (Number)            4601
- * Q        Quarter                 (Text & Number)     Q2 & 02
- * M        month in year           (Text & Number)     July & 07
- * d        day in month            (Number)            10
- * h        hour in am/pm (1~12)    (Number)            12
- * H        hour in day (0~23)      (Number)            0
- * m        minute in hour          (Number)            30
- * s        second in minute        (Number)            55
- * S        fractional second       (Number)            978
- * E        day of week             (Text)              Tuesday
- * e        day of week (local 1~7) (Text & Number)     Tues & 2
- * D        day in year             (Number)            189
- * F        day of week in month    (Number)            2 (2nd Wed in July)
- * w        week in year            (Number)            27
- * W        week in month           (Number)            2
- * a        am/pm marker            (Text)              PM
- * k        hour in day (1~24)      (Number)            24
- * K        hour in am/pm (0~11)    (Number)            0
- * z        time zone               (Time)              Pacific Standard Time
- * Z        time zone (RFC 822)     (Number)            -0800
- * v        time zone (generic)     (Text)              Pacific Time
- * V        time zone (abreviation) (Text)              PT
- * VVVV     time zone (location)    (Text)              United States (Los Angeles)
- * g        Julian day              (Number)            2451334
- * A        milliseconds in day     (Number)            69540000
- * q        stand alone quarter     (Text & Number)     Q2 & 02
- * L        stand alone month       (Text & Number)     July & 07
- * c        stand alone day of week (Text & Number)     Tuesday & 2
- * '        escape for text         (Delimiter)         'Date='
- * ''       single quote            (Literal)           'o''clock'
- * \endcode
- * </pre>
- * The count of pattern letters determine the format.
- * <P>
- * (Text): 4 or more, use full form, &lt;4, use short or abbreviated form if it
- * exists. (e.g., "EEEE" produces "Monday", "EEE" produces "Mon")
- * <P>
- * (Number): the minimum number of digits. Shorter numbers are zero-padded to
- * this amount (e.g. if "m" produces "6", "mm" produces "06"). Year is handled
- * specially; that is, if the count of 'y' is 2, the Year will be truncated to 2 digits.
- * (e.g., if "yyyy" produces "1997", "yy" produces "97".)
- * Unlike other fields, fractional seconds are padded on the right with zero.
- * <P>
- * (Text & Number): 3 or over, use text, otherwise use number.  (e.g., "M" produces "1",
- * "MM" produces "01", "MMM" produces "Jan", and "MMMM" produces "January".)
- * <P>
- * Any characters in the pattern that are not in the ranges of ['a'..'z'] and
- * ['A'..'Z'] will be treated as quoted text. For instance, characters
- * like ':', '.', ' ', '#' and '@' will appear in the resulting time text
- * even they are not embraced within single quotes.
- * <P>
- * A pattern containing any invalid pattern letter will result in a failing
- * UErrorCode result during formatting or parsing.
- * <P>
- * Examples using the US locale:
- * <pre>
- * \code
- *    Format Pattern                         Result
- *    --------------                         -------
- *    "yyyy.MM.dd G 'at' HH:mm:ss vvvv" ->>  1996.07.10 AD at 15:08:56 Pacific Time
- *    "EEE, MMM d, ''yy"                ->>  Wed, July 10, '96
- *    "h:mm a"                          ->>  12:08 PM
- *    "hh 'o''clock' a, zzzz"           ->>  12 o'clock PM, Pacific Daylight Time
- *    "K:mm a, vvv"                     ->>  0:00 PM, PT
- *    "yyyyy.MMMMM.dd GGG hh:mm aaa"    ->>  1996.July.10 AD 12:08 PM
- * \endcode
- * </pre>
- * Code Sample:
- * <pre>
- * \code
- *     UErrorCode success = U_ZERO_ERROR;
- *     SimpleTimeZone* pdt = new SimpleTimeZone(-8 * 60 * 60 * 1000, "PST");
- *     pdt->setStartRule( Calendar::APRIL, 1, Calendar::SUNDAY, 2*60*60*1000);
- *     pdt->setEndRule( Calendar::OCTOBER, -1, Calendar::SUNDAY, 2*60*60*1000);
- *
- *     // Format the current time.
- *     SimpleDateFormat* formatter
- *         = new SimpleDateFormat ("yyyy.MM.dd G 'at' hh:mm:ss a zzz", success );
- *     GregorianCalendar cal(success);
- *     UDate currentTime_1 = cal.getTime(success);
- *     FieldPosition fp(0);
- *     UnicodeString dateString;
- *     formatter->format( currentTime_1, dateString, fp );
- *     cout << "result: " << dateString << endl;
- *
- *     // Parse the previous string back into a Date.
- *     ParsePosition pp(0);
- *     UDate currentTime_2 = formatter->parse(dateString, pp );
- * \endcode
- * </pre>
- * In the above example, the time value "currentTime_2" obtained from parsing
- * will be equal to currentTime_1. However, they may not be equal if the am/pm
- * marker 'a' is left out from the format pattern while the "hour in am/pm"
- * pattern symbol is used. This information loss can happen when formatting the
- * time in PM.
- *
- * <p>
- * When parsing a date string using the abbreviated year pattern ("y" or "yy"),
- * SimpleDateFormat must interpret the abbreviated year
- * relative to some century.  It does this by adjusting dates to be
- * within 80 years before and 20 years after the time the SimpleDateFormat
- * instance is created. For example, using a pattern of "MM/dd/yy" and a
- * SimpleDateFormat instance created on Jan 1, 1997,  the string
- * "01/11/12" would be interpreted as Jan 11, 2012 while the string "05/04/64"
- * would be interpreted as May 4, 1964.
- * During parsing, only strings consisting of exactly two digits, as defined by
- * <code>Unicode::isDigit()</code>, will be parsed into the default century.
- * Any other numeric string, such as a one digit string, a three or more digit
- * string, or a two digit string that isn't all digits (for example, "-1"), is
- * interpreted literally.  So "01/02/3" or "01/02/003" are parsed, using the
- * same pattern, as Jan 2, 3 AD.  Likewise, "01/02/-3" is parsed as Jan 2, 4 BC.
- *
- * <p>
- * If the year pattern has more than two 'y' characters, the year is
- * interpreted literally, regardless of the number of digits.  So using the
- * pattern "MM/dd/yyyy", "01/11/12" parses to Jan 11, 12 A.D.
- *
- * <p>
- * When numeric fields abut one another directly, with no intervening delimiter
- * characters, they constitute a run of abutting numeric fields.  Such runs are
- * parsed specially.  For example, the format "HHmmss" parses the input text
- * "123456" to 12:34:56, parses the input text "12345" to 1:23:45, and fails to
- * parse "1234".  In other words, the leftmost field of the run is flexible,
- * while the others keep a fixed width.  If the parse fails anywhere in the run,
- * then the leftmost field is shortened by one character, and the entire run is
- * parsed again. This is repeated until either the parse succeeds or the
- * leftmost field is one character in length.  If the parse still fails at that
- * point, the parse of the run fails.
- *
- * <P>
- * For time zones that have no names, SimpleDateFormat uses strings GMT+hours:minutes or
- * GMT-hours:minutes.
- * <P>
- * The calendar defines what is the first day of the week, the first week of the
- * year, whether hours are zero based or not (0 vs 12 or 24), and the timezone.
- * There is one common number format to handle all the numbers; the digit count
- * is handled programmatically according to the pattern.
- *
- * <p><em>User subclasses are not supported.</em> While clients may write
- * subclasses, such code will not necessarily work and will not be
- * guaranteed to work stably from release to release.
- */
-class U_I18N_API SimpleDateFormat: public DateFormat {
-public:
-    /**
-     * Construct a SimpleDateFormat using the default pattern for the default
-     * locale.
-     * <P>
-     * [Note:] Not all locales support SimpleDateFormat; for full generality,
-     * use the factory methods in the DateFormat class.
-     * @param status    Output param set to success/failure code.
-     * @stable ICU 2.0
-     */
-    SimpleDateFormat(UErrorCode& status);
-
-    /**
-     * Construct a SimpleDateFormat using the given pattern and the default locale.
-     * The locale is used to obtain the symbols used in formatting (e.g., the
-     * names of the months), but not to provide the pattern.
-     * <P>
-     * [Note:] Not all locales support SimpleDateFormat; for full generality,
-     * use the factory methods in the DateFormat class.
-     * @param pattern    the pattern for the format.
-     * @param status     Output param set to success/failure code.
-     * @stable ICU 2.0
-     */
-    SimpleDateFormat(const UnicodeString& pattern,
-                     UErrorCode& status);
-
-    /**
-     * Construct a SimpleDateFormat using the given pattern and locale.
-     * The locale is used to obtain the symbols used in formatting (e.g., the
-     * names of the months), but not to provide the pattern.
-     * <P>
-     * [Note:] Not all locales support SimpleDateFormat; for full generality,
-     * use the factory methods in the DateFormat class.
-     * @param pattern    the pattern for the format.
-     * @param locale     the given locale.
-     * @param status     Output param set to success/failure code.
-     * @stable ICU 2.0
-     */
-    SimpleDateFormat(const UnicodeString& pattern,
-                     const Locale& locale,
-                     UErrorCode& status);
-
-    /**
-     * Construct a SimpleDateFormat using the given pattern and locale-specific
-     * symbol data.  The formatter takes ownership of the DateFormatSymbols object;
-     * the caller is no longer responsible for deleting it.
-     * @param pattern           the given pattern for the format.
-     * @param formatDataToAdopt the symbols to be adopted.
-     * @param status            Output param set to success/faulure code.
-     * @stable ICU 2.0
-     */
-    SimpleDateFormat(const UnicodeString& pattern,
-                     DateFormatSymbols* formatDataToAdopt,
-                     UErrorCode& status);
-
-    /**
-     * Construct a SimpleDateFormat using the given pattern and locale-specific
-     * symbol data.  The DateFormatSymbols object is NOT adopted; the caller
-     * remains responsible for deleting it.
-     * @param pattern           the given pattern for the format.
-     * @param formatData        the formatting symbols to be use.
-     * @param status            Output param set to success/faulure code.
-     * @stable ICU 2.0
-     */
-    SimpleDateFormat(const UnicodeString& pattern,
-                     const DateFormatSymbols& formatData,
-                     UErrorCode& status);
-
-    /**
-     * Copy constructor.
-     * @stable ICU 2.0
-     */
-    SimpleDateFormat(const SimpleDateFormat&);
-
-    /**
-     * Assignment operator.
-     * @stable ICU 2.0
-     */
-    SimpleDateFormat& operator=(const SimpleDateFormat&);
-
-    /**
-     * Destructor.
-     * @stable ICU 2.0
-     */
-    virtual ~SimpleDateFormat();
-
-    /**
-     * Clone this Format object polymorphically. The caller owns the result and
-     * should delete it when done.
-     * @return    A copy of the object.
-     * @stable ICU 2.0
-     */
-    virtual Format* clone(void) const;
-
-    /**
-     * Return true if the given Format objects are semantically equal. Objects
-     * of different subclasses are considered unequal.
-     * @param other    the object to be compared with.
-     * @return         true if the given Format objects are semantically equal.
-     * @stable ICU 2.0
-     */
-    virtual UBool operator==(const Format& other) const;
-
-    /**
-     * Format a date or time, which is the standard millis since 24:00 GMT, Jan
-     * 1, 1970. Overrides DateFormat pure virtual method.
-     * <P>
-     * Example: using the US locale: "yyyy.MM.dd e 'at' HH:mm:ss zzz" ->>
-     * 1996.07.10 AD at 15:08:56 PDT
-     *
-     * @param cal       Calendar set to the date and time to be formatted
-     *                  into a date/time string.
-     * @param appendTo  Output parameter to receive result.
-     *                  Result is appended to existing contents.
-     * @param pos       The formatting position. On input: an alignment field,
-     *                  if desired. On output: the offsets of the alignment field.
-     * @return          Reference to 'appendTo' parameter.
-     * @stable ICU 2.1
-     */
-    virtual UnicodeString& format(  Calendar& cal,
-                                    UnicodeString& appendTo,
-                                    FieldPosition& pos) const;
-
-    /**
-     * Format a date or time, which is the standard millis since 24:00 GMT, Jan
-     * 1, 1970. Overrides DateFormat pure virtual method.
-     * <P>
-     * Example: using the US locale: "yyyy.MM.dd e 'at' HH:mm:ss zzz" ->>
-     * 1996.07.10 AD at 15:08:56 PDT
-     *
-     * @param obj       A Formattable containing the date-time value to be formatted
-     *                  into a date-time string.  If the type of the Formattable
-     *                  is a numeric type, it is treated as if it were an
-     *                  instance of Date.
-     * @param appendTo  Output parameter to receive result.
-     *                  Result is appended to existing contents.
-     * @param pos       The formatting position. On input: an alignment field,
-     *                  if desired. On output: the offsets of the alignment field.
-     * @param status    Output param set to success/faulure code.
-     * @return          Reference to 'appendTo' parameter.
-     * @stable ICU 2.0
-     */
-    virtual UnicodeString& format(  const Formattable& obj,
-                                    UnicodeString& appendTo,
-                                    FieldPosition& pos,
-                                    UErrorCode& status) const;
-
-    /**
-     * Redeclared DateFormat method.
-     * @param date          the Date value to be formatted.
-     * @param appendTo      Output parameter to receive result.
-     *                      Result is appended to existing contents.
-     * @param fieldPosition The formatting position. On input: an alignment field,
-     *                      if desired. On output: the offsets of the alignment field.
-     * @return              Reference to 'appendTo' parameter.
-     * @stable ICU 2.1
-     */
-    UnicodeString& format(UDate date,
-                          UnicodeString& appendTo,
-                          FieldPosition& fieldPosition) const;
-
-    /**
-     * Redeclared DateFormat method.
-     * @param obj       Object to be formatted.
-     * @param appendTo  Output parameter to receive result.
-     *                  Result is appended to existing contents.
-     * @param status    Input/output success/failure code.
-     * @return          Reference to 'appendTo' parameter.
-     * @stable ICU 2.0
-     */
-    UnicodeString& format(const Formattable& obj,
-                          UnicodeString& appendTo,
-                          UErrorCode& status) const;
-
-    /**
-     * Redeclared DateFormat method.
-     * @param date      Date value to be formatted.
-     * @param appendTo  Output parameter to receive result.
-     *                  Result is appended to existing contents.
-     * @return          Reference to 'appendTo' parameter.
-     * @stable ICU 2.0
-     */
-    UnicodeString& format(UDate date, UnicodeString& appendTo) const;
-
-    /**
-     * Parse a date/time string beginning at the given parse position. For
-     * example, a time text "07/10/96 4:5 PM, PDT" will be parsed into a Date
-     * that is equivalent to Date(837039928046).
-     * <P>
-     * By default, parsing is lenient: If the input is not in the form used by
-     * this object's format method but can still be parsed as a date, then the
-     * parse succeeds. Clients may insist on strict adherence to the format by
-     * calling setLenient(false).
-     *
-     * @param text  The date/time string to be parsed
-     * @param cal   a Calendar set to the date and time to be formatted
-     *              into a date/time string.
-     * @param pos   On input, the position at which to start parsing; on
-     *              output, the position at which parsing terminated, or the
-     *              start position if the parse failed.
-     * @return      A valid UDate if the input could be parsed.
-     * @stable ICU 2.1
-     */
-    virtual void parse( const UnicodeString& text,
-                        Calendar& cal,
-                        ParsePosition& pos) const;
-
-    /**
-     * Parse a date/time string starting at the given parse position. For
-     * example, a time text "07/10/96 4:5 PM, PDT" will be parsed into a Date
-     * that is equivalent to Date(837039928046).
-     * <P>
-     * By default, parsing is lenient: If the input is not in the form used by
-     * this object's format method but can still be parsed as a date, then the
-     * parse succeeds. Clients may insist on strict adherence to the format by
-     * calling setLenient(false).
-     *
-     * @see DateFormat::setLenient(boolean)
-     *
-     * @param text  The date/time string to be parsed
-     * @param pos   On input, the position at which to start parsing; on
-     *              output, the position at which parsing terminated, or the
-     *              start position if the parse failed.
-     * @return      A valid UDate if the input could be parsed.
-     * @stable ICU 2.0
-     */
-    UDate parse( const UnicodeString& text,
-                 ParsePosition& pos) const;
-
-
-    /**
-     * Parse a date/time string. For example, a time text "07/10/96 4:5 PM, PDT"
-     * will be parsed into a UDate that is equivalent to Date(837039928046).
-     * Parsing begins at the beginning of the string and proceeds as far as
-     * possible.  Assuming no parse errors were encountered, this function
-     * doesn't return any information about how much of the string was consumed
-     * by the parsing.  If you need that information, use the version of
-     * parse() that takes a ParsePosition.
-     *
-     * @param text  The date/time string to be parsed
-     * @param status Filled in with U_ZERO_ERROR if the parse was successful, and with
-     *              an error value if there was a parse error.
-     * @return      A valid UDate if the input could be parsed.
-     * @stable ICU 2.0
-     */
-    virtual UDate parse( const UnicodeString& text,
-                        UErrorCode& status) const;
-
-    /**
-     * Set the start UDate used to interpret two-digit year strings.
-     * When dates are parsed having 2-digit year strings, they are placed within
-     * a assumed range of 100 years starting on the two digit start date.  For
-     * example, the string "24-Jan-17" may be in the year 1817, 1917, 2017, or
-     * some other year.  SimpleDateFormat chooses a year so that the resultant
-     * date is on or after the two digit start date and within 100 years of the
-     * two digit start date.
-     * <P>
-     * By default, the two digit start date is set to 80 years before the current
-     * time at which a SimpleDateFormat object is created.
-     * @param d      start UDate used to interpret two-digit year strings.
-     * @param status Filled in with U_ZERO_ERROR if the parse was successful, and with
-     *               an error value if there was a parse error.
-     * @stable ICU 2.0
-     */
-    virtual void set2DigitYearStart(UDate d, UErrorCode& status);
-
-    /**
-     * Get the start UDate used to interpret two-digit year strings.
-     * When dates are parsed having 2-digit year strings, they are placed within
-     * a assumed range of 100 years starting on the two digit start date.  For
-     * example, the string "24-Jan-17" may be in the year 1817, 1917, 2017, or
-     * some other year.  SimpleDateFormat chooses a year so that the resultant
-     * date is on or after the two digit start date and within 100 years of the
-     * two digit start date.
-     * <P>
-     * By default, the two digit start date is set to 80 years before the current
-     * time at which a SimpleDateFormat object is created.
-     * @param status Filled in with U_ZERO_ERROR if the parse was successful, and with
-     *               an error value if there was a parse error.
-     * @stable ICU 2.0
-     */
-    UDate get2DigitYearStart(UErrorCode& status) const;
-
-    /**
-     * Return a pattern string describing this date format.
-     * @param result Output param to receive the pattern.
-     * @return       A reference to 'result'.
-     * @stable ICU 2.0
-     */
-    virtual UnicodeString& toPattern(UnicodeString& result) const;
-
-    /**
-     * Return a localized pattern string describing this date format.
-     * In most cases, this will return the same thing as toPattern(),
-     * but a locale can specify characters to use in pattern descriptions
-     * in place of the ones described in this class's class documentation.
-     * (Presumably, letters that would be more mnemonic in that locale's
-     * language.)  This function would produce a pattern using those
-     * letters.
-     *
-     * @param result    Receives the localized pattern.
-     * @param status    Output param set to success/failure code on
-     *                  exit. If the pattern is invalid, this will be
-     *                  set to a failure result.
-     * @return          A reference to 'result'.
-     * @stable ICU 2.0
-     */
-    virtual UnicodeString& toLocalizedPattern(UnicodeString& result,
-                                              UErrorCode& status) const;
-
-    /**
-     * Apply the given unlocalized pattern string to this date format.
-     * (i.e., after this call, this formatter will format dates according to
-     * the new pattern)
-     *
-     * @param pattern   The pattern to be applied.
-     * @stable ICU 2.0
-     */
-    virtual void applyPattern(const UnicodeString& pattern);
-
-    /**
-     * Apply the given localized pattern string to this date format.
-     * (see toLocalizedPattern() for more information on localized patterns.)
-     *
-     * @param pattern   The localized pattern to be applied.
-     * @param status    Output param set to success/failure code on
-     *                  exit. If the pattern is invalid, this will be
-     *                  set to a failure result.
-     * @stable ICU 2.0
-     */
-    virtual void applyLocalizedPattern(const UnicodeString& pattern,
-                                       UErrorCode& status);
-
-    /**
-     * Gets the date/time formatting symbols (this is an object carrying
-     * the various strings and other symbols used in formatting: e.g., month
-     * names and abbreviations, time zone names, AM/PM strings, etc.)
-     * @return a copy of the date-time formatting data associated
-     * with this date-time formatter.
-     * @stable ICU 2.0
-     */
-    virtual const DateFormatSymbols* getDateFormatSymbols(void) const;
-
-    /**
-     * Set the date/time formatting symbols.  The caller no longer owns the
-     * DateFormatSymbols object and should not delete it after making this call.
-     * @param newFormatSymbols the given date-time formatting symbols to copy.
-     * @stable ICU 2.0
-     */
-    virtual void adoptDateFormatSymbols(DateFormatSymbols* newFormatSymbols);
-
-    /**
-     * Set the date/time formatting data.
-     * @param newFormatSymbols the given date-time formatting symbols to copy.
-     * @stable ICU 2.0
-     */
-    virtual void setDateFormatSymbols(const DateFormatSymbols& newFormatSymbols);
-
-    /**
-     * Return the class ID for this class. This is useful only for comparing to
-     * a return value from getDynamicClassID(). For example:
-     * <pre>
-     * .   Base* polymorphic_pointer = createPolymorphicObject();
-     * .   if (polymorphic_pointer->getDynamicClassID() ==
-     * .       erived::getStaticClassID()) ...
-     * </pre>
-     * @return          The class ID for all objects of this class.
-     * @stable ICU 2.0
-     */
-    static UClassID U_EXPORT2 getStaticClassID(void);
-
-    /**
-     * Returns a unique class ID POLYMORPHICALLY. Pure virtual override. This
-     * method is to implement a simple version of RTTI, since not all C++
-     * compilers support genuine RTTI. Polymorphic operator==() and clone()
-     * methods call this method.
-     *
-     * @return          The class ID for this object. All objects of a
-     *                  given class have the same class ID.  Objects of
-     *                  other classes have different class IDs.
-     * @stable ICU 2.0
-     */
-    virtual UClassID getDynamicClassID(void) const;
-
-    /**
-     * Set the calendar to be used by this date format. Initially, the default
-     * calendar for the specified or default locale is used.  The caller should
-     * not delete the Calendar object after it is adopted by this call.
-     * Adopting a new calendar will change to the default symbols.
-     *
-     * @param calendarToAdopt    Calendar object to be adopted.
-     * @stable ICU 2.0
-     */
-    virtual void adoptCalendar(Calendar* calendarToAdopt);
-
-    /**
-     * This is for ICU internal use only. Please do not use.
-     * Check whether the 'field' is smaller than all the fields covered in
-     * pattern, return TRUE if it is. The sequence of calendar field, 
-     * from large to small is: ERA, YEAR, MONTH, DATE, AM_PM, HOUR, MINUTE,...
-     * @param field    the calendar field need to check against
-     * @return         TRUE if the 'field' is smaller than all the fields 
-     *                 covered in pattern. FALSE otherwise.
-     * @internal ICU 4.0
-     */
-    UBool isFieldUnitIgnored(UCalendarDateFields field) const;
-
-
-    /**
-     * This is for ICU internal use only. Please do not use.
-     * Check whether the 'field' is smaller than all the fields covered in
-     * pattern, return TRUE if it is. The sequence of calendar field, 
-     * from large to small is: ERA, YEAR, MONTH, DATE, AM_PM, HOUR, MINUTE,...
-     * @param pattern  the pattern to check against
-     * @param field    the calendar field need to check against
-     * @return         TRUE if the 'field' is smaller than all the fields 
-     *                 covered in pattern. FALSE otherwise.
-     * @internal ICU 4.0
-     */
-    static UBool isFieldUnitIgnored(const UnicodeString& pattern, 
-                                    UCalendarDateFields field);
-
-
-
-    /**
-     * This is for ICU internal use only. Please do not use.
-     * Get the locale of this simple date formatter.
-     * It is used in DateIntervalFormat.
-     *
-     * @return   locale in this simple date formatter
-     * @internal ICU 4.0
-     */
-    const Locale& getSmpFmtLocale(void) const;
-
-
-private:
-    friend class DateFormat;
-
-    void initializeDefaultCentury(void);
-
-    SimpleDateFormat(); // default constructor not implemented
-
-    /**
-     * Used by the DateFormat factory methods to construct a SimpleDateFormat.
-     * @param timeStyle the time style.
-     * @param dateStyle the date style.
-     * @param locale    the given locale.
-     * @param status    Output param set to success/failure code on
-     *                  exit.
-     */
-    SimpleDateFormat(EStyle timeStyle, EStyle dateStyle, const Locale& locale, UErrorCode& status);
-
-    /**
-     * Construct a SimpleDateFormat for the given locale.  If no resource data
-     * is available, create an object of last resort, using hard-coded strings.
-     * This is an internal method, called by DateFormat.  It should never fail.
-     * @param locale    the given locale.
-     * @param status    Output param set to success/failure code on
-     *                  exit.
-     */
-    SimpleDateFormat(const Locale& locale, UErrorCode& status); // Use default pattern
-
-    /**
-     * Called by format() to format a single field.
-     *
-     * @param appendTo  Output parameter to receive result.
-     *                  Result is appended to existing contents.
-     * @param ch        The format character we encountered in the pattern.
-     * @param count     Number of characters in the current pattern symbol (e.g.,
-     *                  "yyyy" in the pattern would result in a call to this function
-     *                  with ch equal to 'y' and count equal to 4)
-     * @param pos       The FieldPosition being filled in by the format() call.  If
-     *                  this function is formatting the field specfied by pos, it
-     *                  will fill in pos with the beginning and ending offsets of the
-     *                  field.
-     * @param status    Receives a status code, which will be U_ZERO_ERROR if the operation
-     *                  succeeds.
-     */
-    void subFormat(             UnicodeString &appendTo,
-                                UChar ch,
-                                int32_t count,
-                                FieldPosition& pos,
-                                Calendar& cal,
-                                UErrorCode& status) const; // in case of illegal argument
-
-    /**
-     * Used by subFormat() to format a numeric value.
-     * Appends to toAppendTo a string representation of "value"
-     * having a number of digits between "minDigits" and
-     * "maxDigits".  Uses the DateFormat's NumberFormat.
-     *
-     * @param appendTo  Output parameter to receive result.
-     *                  Formatted number is appended to existing contents.
-     * @param value     Value to format.
-     * @param minDigits Minimum number of digits the result should have
-     * @param maxDigits Maximum number of digits the result should have
-     */
-    void zeroPaddingNumber(          UnicodeString &appendTo,
-                                     int32_t value,
-                                     int32_t minDigits,
-                                     int32_t maxDigits) const;
-
-    /**
-     * Return true if the given format character, occuring count
-     * times, represents a numeric field.
-     */
-    static UBool isNumeric(UChar formatChar, int32_t count);
-
-    /**
-     * initializes fCalendar from parameters.  Returns fCalendar as a convenience.
-     * @param adoptZone  Zone to be adopted, or NULL for TimeZone::createDefault().
-     * @param locale Locale of the calendar
-     * @param status Error code
-     * @return the newly constructed fCalendar
-     */
-    Calendar *initializeCalendar(TimeZone* adoptZone, const Locale& locale, UErrorCode& status);
-
-    /**
-     * initializes fSymbols from parameters.
-     * @param locale Locale of the symbols
-     * @param calendar Alias to Calendar that will be used.
-     * @param status Error code
-     */
-    void initializeSymbols(const Locale& locale, Calendar* calendar, UErrorCode& status);
-
-    /**
-     * Called by several of the constructors to load pattern data and formatting symbols
-     * out of a resource bundle and initialize the locale based on it.
-     * @param timeStyle     The time style, as passed to DateFormat::createDateInstance().
-     * @param dateStyle     The date style, as passed to DateFormat::createTimeInstance().
-     * @param locale        The locale to load the patterns from.
-     * @param status        Filled in with an error code if loading the data from the
-     *                      resources fails.
-     */
-    void construct(EStyle timeStyle, EStyle dateStyle, const Locale& locale, UErrorCode& status);
-
-    /**
-     * Called by construct() and the various constructors to set up the SimpleDateFormat's
-     * Calendar and NumberFormat objects.
-     * @param locale    The locale for which we want a Calendar and a NumberFormat.
-     * @param statuc    Filled in with an error code if creating either subobject fails.
-     */
-    void initialize(const Locale& locale, UErrorCode& status);
-
-    /**
-     * Private code-size reduction function used by subParse.
-     * @param text the time text being parsed.
-     * @param start where to start parsing.
-     * @param field the date field being parsed.
-     * @param stringArray the string array to parsed.
-     * @param stringArrayCount the size of the array.
-     * @param cal a Calendar set to the date and time to be formatted
-     *            into a date/time string.
-     * @return the new start position if matching succeeded; a negative number
-     * indicating matching failure, otherwise.
-     */
-    int32_t matchString(const UnicodeString& text, int32_t start, UCalendarDateFields field,
-                        const UnicodeString* stringArray, int32_t stringArrayCount, Calendar& cal) const;
-
-    /**
-     * Private code-size reduction function used by subParse.
-     * @param text the time text being parsed.
-     * @param start where to start parsing.
-     * @param field the date field being parsed.
-     * @param stringArray the string array to parsed.
-     * @param stringArrayCount the size of the array.
-     * @param cal a Calendar set to the date and time to be formatted
-     *            into a date/time string.
-     * @return the new start position if matching succeeded; a negative number
-     * indicating matching failure, otherwise.
-     */
-    int32_t matchQuarterString(const UnicodeString& text, int32_t start, UCalendarDateFields field,
-                               const UnicodeString* stringArray, int32_t stringArrayCount, Calendar& cal) const;
-    
-    /**
-     * Private function used by subParse to match literal pattern text.
-     *
-     * @param pattern the pattern string
-     * @param patternOffset the starting offset into the pattern text. On
-     *        outupt will be set the offset of the first non-literal character in the pattern
-     * @param text the text being parsed
-     * @param textOffset the starting offset into the text. On output
-     *                   will be set to the offset of the character after the match
-     * @param lenient <code>TRUE</code> if the parse is lenient, <code>FALSE</code> otherwise.
-     *
-     * @return <code>TRUE</code> if the literal text could be matched, <code>FALSE</code> otherwise.
-     */
-    static UBool matchLiterals(const UnicodeString &pattern, int32_t &patternOffset,
-                               const UnicodeString &text, int32_t &textOffset, UBool lenient);
-    
-    /**
-     * Private member function that converts the parsed date strings into
-     * timeFields. Returns -start (for ParsePosition) if failed.
-     * @param text the time text to be parsed.
-     * @param start where to start parsing.
-     * @param ch the pattern character for the date field text to be parsed.
-     * @param count the count of a pattern character.
-     * @param obeyCount if true then the count is strictly obeyed.
-     * @param ambiguousYear If true then the two-digit year == the default start year.
-     * @param cal a Calendar set to the date and time to be formatted
-     *            into a date/time string.
-     * @return the new start position if matching succeeded; a negative number
-     * indicating matching failure, otherwise.
-     */
-    int32_t subParse(const UnicodeString& text, int32_t& start, UChar ch, int32_t count,
-                     UBool obeyCount, UBool allowNegative, UBool ambiguousYear[], Calendar& cal) const;
-
-    void parseInt(const UnicodeString& text,
-                  Formattable& number,
-                  ParsePosition& pos,
-                  UBool allowNegative) const;
-
-    void parseInt(const UnicodeString& text,
-                  Formattable& number,
-                  int32_t maxDigits,
-                  ParsePosition& pos,
-                  UBool allowNegative) const;
-
-    /**
-     * Translate a pattern, mapping each character in the from string to the
-     * corresponding character in the to string. Return an error if the original
-     * pattern contains an unmapped character, or if a quote is unmatched.
-     * Quoted (single quotes only) material is not translated.
-     * @param originalPattern   the original pattern.
-     * @param translatedPattern Output param to receive the translited pattern.
-     * @param from              the characters to be translited from.
-     * @param to                the characters to be translited to.
-     * @param status            Receives a status code, which will be U_ZERO_ERROR
-     *                          if the operation succeeds.
-     */
-    static void translatePattern(const UnicodeString& originalPattern,
-                                UnicodeString& translatedPattern,
-                                const UnicodeString& from,
-                                const UnicodeString& to,
-                                UErrorCode& status);
-
-    /**
-     * Sets the starting date of the 100-year window that dates with 2-digit years
-     * are considered to fall within.
-     * @param startDate the start date
-     * @param status    Receives a status code, which will be U_ZERO_ERROR
-     *                  if the operation succeeds.
-     */
-    void         parseAmbiguousDatesAsAfter(UDate startDate, UErrorCode& status);
-    
-    /**
-     * Private methods for formatting/parsing GMT string
-     */
-    void appendGMT(UnicodeString &appendTo, Calendar& cal, UErrorCode& status) const;
-    void formatGMTDefault(UnicodeString &appendTo, int32_t offset) const;
-    int32_t parseGMT(const UnicodeString &text, ParsePosition &pos) const;
-    int32_t parseGMTDefault(const UnicodeString &text, ParsePosition &pos) const;
-    UBool isDefaultGMTFormat() const;
-
-    void formatRFC822TZ(UnicodeString &appendTo, int32_t offset) const;
-
-    /**
-     * Initialize MessageFormat instances used for GMT formatting/parsing
-     */
-    void initGMTFormatters(UErrorCode &status);
-
-    /**
-     * Used to map pattern characters to Calendar field identifiers.
-     */
-    static const UCalendarDateFields fgPatternIndexToCalendarField[];
-
-    /**
-     * Map index into pattern character string to DateFormat field number
-     */
-    static const UDateFormatField fgPatternIndexToDateFormatField[];
-
-    /**
-     * Used to map Calendar field to field level.
-     * The larger the level, the smaller the field unit.
-     * For example, UCAL_ERA level is 0, UCAL_YEAR level is 10,
-     * UCAL_MONTH level is 20.
-     */
-    static const int32_t fgCalendarFieldToLevel[];
-    static const int32_t fgPatternCharToLevel[];
-
-    /**
-     * The formatting pattern for this formatter.
-     */
-    UnicodeString       fPattern;
-
-    /**
-     * The original locale used (for reloading symbols)
-     */
-    Locale              fLocale;
-
-    /**
-     * A pointer to an object containing the strings to use in formatting (e.g.,
-     * month and day names, AM and PM strings, time zone names, etc.)
-     */
-    DateFormatSymbols*  fSymbols;   // Owned
-
-    /**
-     * If dates have ambiguous years, we map them into the century starting
-     * at defaultCenturyStart, which may be any date.  If defaultCenturyStart is
-     * set to SYSTEM_DEFAULT_CENTURY, which it is by default, then the system
-     * values are used.  The instance values defaultCenturyStart and
-     * defaultCenturyStartYear are only used if explicitly set by the user
-     * through the API method parseAmbiguousDatesAsAfter().
-     */
-    UDate                fDefaultCenturyStart;
-
-    /**
-     * See documentation for defaultCenturyStart.
-     */
-    /*transient*/ int32_t   fDefaultCenturyStartYear;
-
-    enum ParsedTZType {
-        TZTYPE_UNK,
-        TZTYPE_STD,
-        TZTYPE_DST
-    };
-
-    ParsedTZType tztype; // here to avoid api change
-
-    /*
-     * MessageFormat instances used for localized GMT format
-     */
-    MessageFormat   **fGMTFormatters;
-
-    UBool fHaveDefaultCentury;
-};
-
-inline UDate
-SimpleDateFormat::get2DigitYearStart(UErrorCode& /*status*/) const
-{
-    return fDefaultCenturyStart;
-}
-
-inline UnicodeString&
-SimpleDateFormat::format(const Formattable& obj,
-                         UnicodeString& appendTo,
-                         UErrorCode& status) const {
-    // Don't use Format:: - use immediate base class only,
-    // in case immediate base modifies behavior later.
-    return DateFormat::format(obj, appendTo, status);
-}
-
-inline UnicodeString&
-SimpleDateFormat::format(UDate date,
-                         UnicodeString& appendTo,
-                         FieldPosition& fieldPosition) const {
-    // Don't use Format:: - use immediate base class only,
-    // in case immediate base modifies behavior later.
-    return DateFormat::format(date, appendTo, fieldPosition);
-}
-
-inline UnicodeString&
-SimpleDateFormat::format(UDate date, UnicodeString& appendTo) const {
-    return DateFormat::format(date, appendTo);
-}
-
-U_NAMESPACE_END
-
-#endif /* #if !UCONFIG_NO_FORMATTING */
-
-#endif // _SMPDTFMT
-//eof

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/sortkey.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/sortkey.h b/apps/couch_collate/platform/osx/icu/unicode/sortkey.h
deleted file mode 100644
index ef202dd..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/sortkey.h
+++ /dev/null
@@ -1,324 +0,0 @@
-/*
- *****************************************************************************
- * Copyright (C) 1996-2006, International Business Machines Corporation and others.
- * All Rights Reserved.
- *****************************************************************************
- *
- * File sortkey.h
- *
- * Created by: Helena Shih
- *
- * Modification History:
- *
- *  Date         Name          Description
- *
- *  6/20/97     helena      Java class name change.
- *  8/18/97     helena      Added internal API documentation.
- *  6/26/98     erm         Changed to use byte arrays and memcmp.
- *****************************************************************************
- */
-
-#ifndef SORTKEY_H
-#define SORTKEY_H
-
-#include "unicode/utypes.h"
-
-/**
- * \file 
- * \brief C++ API: Keys for comparing strings multiple times. 
- */
- 
-#if !UCONFIG_NO_COLLATION
-
-#include "unicode/uobject.h"
-#include "unicode/unistr.h"
-#include "unicode/coll.h"
-
-U_NAMESPACE_BEGIN
-
-/* forward declaration */
-class RuleBasedCollator;
-
-/**
- *
- * Collation keys are generated by the Collator class.  Use the CollationKey objects
- * instead of Collator to compare strings multiple times.  A CollationKey
- * preprocesses the comparison information from the Collator object to
- * make the comparison faster.  If you are not going to comparing strings
- * multiple times, then using the Collator object is generally faster,
- * since it only processes as much of the string as needed to make a
- * comparison.
- * <p> For example (with strength == tertiary)
- * <p>When comparing "Abernathy" to "Baggins-Smythworthy", Collator
- * only needs to process a couple of characters, while a comparison
- * with CollationKeys will process all of the characters.  On the other hand,
- * if you are doing a sort of a number of fields, it is much faster to use
- * CollationKeys, since you will be comparing strings multiple times.
- * <p>Typical use of CollationKeys are in databases, where you store a CollationKey
- * in a hidden field, and use it for sorting or indexing.
- *
- * <p>Example of use:
- * <pre>
- * \code
- *     UErrorCode success = U_ZERO_ERROR;
- *     Collator* myCollator = Collator::createInstance(success);
- *     CollationKey* keys = new CollationKey [3];
- *     myCollator->getCollationKey("Tom", keys[0], success );
- *     myCollator->getCollationKey("Dick", keys[1], success );
- *     myCollator->getCollationKey("Harry", keys[2], success );
- *
- *     // Inside body of sort routine, compare keys this way:
- *     CollationKey tmp;
- *     if(keys[0].compareTo( keys[1] ) > 0 ) {
- *         tmp = keys[0]; keys[0] = keys[1]; keys[1] = tmp;
- *     }
- *     //...
- * \endcode
- * </pre>
- * <p>Because Collator::compare()'s algorithm is complex, it is faster to sort
- * long lists of words by retrieving collation keys with Collator::getCollationKey().
- * You can then cache the collation keys and compare them using CollationKey::compareTo().
- * <p>
- * <strong>Note:</strong> <code>Collator</code>s with different Locale,
- * CollationStrength and DecompositionMode settings will return different
- * CollationKeys for the same set of strings. Locales have specific
- * collation rules, and the way in which secondary and tertiary differences
- * are taken into account, for example, will result in different CollationKeys
- * for same strings.
- * <p>
-
- * @see          Collator
- * @see          RuleBasedCollator
- * @version      1.3 12/18/96
- * @author       Helena Shih
- * @deprecated ICU 2.8 Use Collator::getSortKey(...) instead
- */
-class U_I18N_API CollationKey : public UObject {
-public:
-    /**
-    * This creates an empty collation key based on the null string.  An empty
-    * collation key contains no sorting information.  When comparing two empty
-    * collation keys, the result is Collator::EQUAL.  Comparing empty collation key
-    * with non-empty collation key is always Collator::LESS.
-    * @deprecated ICU 2.8 Use Collator::getSortKey(...) instead
-    */
-    CollationKey();
-
-
-    /**
-    * Creates a collation key based on the collation key values.
-    * @param values the collation key values
-    * @param count number of collation key values, including trailing nulls.
-    * @deprecated ICU 2.8 Use Collator::getSortKey(...) instead
-    */
-    CollationKey(const  uint8_t*    values,
-                int32_t     count);
-
-    /**
-    * Copy constructor.
-    * @param other    the object to be copied.
-    * @deprecated ICU 2.8 Use Collator::getSortKey(...) instead
-    */
-    CollationKey(const CollationKey& other);
-
-    /**
-    * Sort key destructor.
-    * @deprecated ICU 2.8 Use Collator::getSortKey(...) instead
-    */
-    virtual ~CollationKey();
-
-    /**
-    * Assignment operator
-    * @param other    the object to be copied.
-    * @deprecated ICU 2.8 Use Collator::getSortKey(...) instead
-    */
-    const   CollationKey&   operator=(const CollationKey& other);
-
-    /**
-    * Compare if two collation keys are the same.
-    * @param source the collation key to compare to.
-    * @return Returns true if two collation keys are equal, false otherwise.
-    * @deprecated ICU 2.8 Use Collator::getSortKey(...) instead
-    */
-    UBool                   operator==(const CollationKey& source) const;
-
-    /**
-    * Compare if two collation keys are not the same.
-    * @param source the collation key to compare to.
-    * @return Returns TRUE if two collation keys are different, FALSE otherwise.
-    * @deprecated ICU 2.8 Use Collator::getSortKey(...) instead
-    */
-    UBool                   operator!=(const CollationKey& source) const;
-
-
-    /**
-    * Test to see if the key is in an invalid state. The key will be in an
-    * invalid state if it couldn't allocate memory for some operation.
-    * @return Returns TRUE if the key is in an invalid, FALSE otherwise.
-    * @deprecated ICU 2.8 Use Collator::getSortKey(...) instead
-    */
-    UBool                   isBogus(void) const;
-
-    /**
-    * Returns a pointer to the collation key values. The storage is owned
-    * by the collation key and the pointer will become invalid if the key
-    * is deleted.
-    * @param count the output parameter of number of collation key values,
-    * including any trailing nulls.
-    * @return a pointer to the collation key values.
-    * @deprecated ICU 2.8 Use Collator::getSortKey(...) instead
-    */
-    const    uint8_t*       getByteArray(int32_t& count) const;
-
-#ifdef U_USE_COLLATION_KEY_DEPRECATES
-    /**
-    * Extracts the collation key values into a new array. The caller owns
-    * this storage and should free it.
-    * @param count the output parameter of number of collation key values,
-    * including any trailing nulls.
-    * @obsolete ICU 2.6. Use getByteArray instead since this API will be removed in that release.
-    */
-    uint8_t*                toByteArray(int32_t& count) const;
-#endif
-
-    /**
-    * Convenience method which does a string(bit-wise) comparison of the
-    * two collation keys.
-    * @param target target collation key to be compared with
-    * @return Returns Collator::LESS if sourceKey &lt; targetKey,
-    * Collator::GREATER if sourceKey > targetKey and Collator::EQUAL
-    * otherwise.
-    * @deprecated ICU 2.6 use the overload with error code
-    */
-    Collator::EComparisonResult compareTo(const CollationKey& target) const;
-
-    /**
-    * Convenience method which does a string(bit-wise) comparison of the
-    * two collation keys.
-    * @param target target collation key to be compared with
-    * @param status error code
-    * @return Returns UCOL_LESS if sourceKey &lt; targetKey,
-    * UCOL_GREATER if sourceKey > targetKey and UCOL_EQUAL
-    * otherwise.
-    * @deprecated ICU 2.8 Use Collator::getSortKey(...) instead
-    */
-    UCollationResult compareTo(const CollationKey& target, UErrorCode &status) const;
-
-    /**
-    * Creates an integer that is unique to the collation key.  NOTE: this
-    * is not the same as String.hashCode.
-    * <p>Example of use:
-    * <pre>
-    * .    UErrorCode status = U_ZERO_ERROR;
-    * .    Collator *myCollation = Collator::createInstance(Locale::US, status);
-    * .    if (U_FAILURE(status)) return;
-    * .    CollationKey key1, key2;
-    * .    UErrorCode status1 = U_ZERO_ERROR, status2 = U_ZERO_ERROR;
-    * .    myCollation->getCollationKey("abc", key1, status1);
-    * .    if (U_FAILURE(status1)) { delete myCollation; return; }
-    * .    myCollation->getCollationKey("ABC", key2, status2);
-    * .    if (U_FAILURE(status2)) { delete myCollation; return; }
-    * .    // key1.hashCode() != key2.hashCode()
-    * </pre>
-    * @return the hash value based on the string's collation order.
-    * @see UnicodeString#hashCode
-    * @deprecated ICU 2.8 Use Collator::getSortKey(...) instead
-    */
-    int32_t                 hashCode(void) const;
-
-    /**
-     * ICU "poor man's RTTI", returns a UClassID for the actual class.
-     * @deprecated ICU 2.8 Use Collator::getSortKey(...) instead
-     */
-    virtual UClassID getDynamicClassID() const;
-
-    /**
-     * ICU "poor man's RTTI", returns a UClassID for this class.
-     * @deprecated ICU 2.8 Use Collator::getSortKey(...) instead
-     */
-    static UClassID U_EXPORT2 getStaticClassID();
-
-private:
-    /**
-    * Returns an array of the collation key values as 16-bit integers.
-    * The caller owns the storage and must delete it.
-    * @param values Output param of the collation key values.
-    * @param count output parameter of the number of collation key values
-    * @return a pointer to an array of 16-bit collation key values.
-    */
-    void adopt(uint8_t *values, int32_t count);
-
-    /*
-    * Creates a collation key with a string.
-    */
-
-    /**
-    * If this CollationKey has capacity less than newSize,
-    * its internal capacity will be increased to newSize.
-    * @param newSize minimum size this CollationKey has to have
-    * @return this CollationKey
-    */
-    CollationKey&           ensureCapacity(int32_t newSize);
-    /**
-    * Set the CollationKey to a "bogus" or invalid state
-    * @return this CollationKey
-    */
-    CollationKey&           setToBogus(void);
-    /**
-    * Resets this CollationKey to an empty state
-    * @return this CollationKey
-    */
-    CollationKey&           reset(void);
-    
-    /**
-    * Allow private access to RuleBasedCollator
-    */
-    friend  class           RuleBasedCollator;
-    /**
-    * Bogus status
-    */
-    UBool                   fBogus;
-    /**
-    * Size of fBytes used to store the sortkey. i.e. up till the 
-    * null-termination.
-    */
-    int32_t                 fCount;
-    /**
-    * Full size of the fBytes
-    */
-    int32_t                 fCapacity;
-    /**
-    * Unique hash value of this CollationKey
-    */
-    int32_t                 fHashCode;
-    /**
-    * Array to store the sortkey
-    */
-    uint8_t*                fBytes;
-
-};
-
-inline UBool
-CollationKey::operator!=(const CollationKey& other) const
-{
-    return !(*this == other);
-}
-
-inline UBool
-CollationKey::isBogus() const
-{
-    return fBogus;
-}
-
-inline const uint8_t*
-CollationKey::getByteArray(int32_t &count) const
-{
-    count = fCount;
-    return fBytes;
-}
-
-U_NAMESPACE_END
-
-#endif /* #if !UCONFIG_NO_COLLATION */
-
-#endif

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/strenum.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/strenum.h b/apps/couch_collate/platform/osx/icu/unicode/strenum.h
deleted file mode 100644
index ce42195..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/strenum.h
+++ /dev/null
@@ -1,271 +0,0 @@
-/*
-*******************************************************************************
-*
-*   Copyright (C) 2002-2007, International Business Machines
-*   Corporation and others.  All Rights Reserved.
-*
-*******************************************************************************
-*/
-
-#ifndef STRENUM_H
-#define STRENUM_H
-
-#include "unicode/uobject.h"
-#include "unicode/unistr.h"
-
-/**
- * \file 
- * \brief C++ API: String Enumeration
- */
- 
-U_NAMESPACE_BEGIN
-
-/**
- * Base class for 'pure' C++ implementations of uenum api.  Adds a
- * method that returns the next UnicodeString since in C++ this can
- * be a common storage format for strings.
- *
- * <p>The model is that the enumeration is over strings maintained by
- * a 'service.'  At any point, the service might change, invalidating
- * the enumerator (though this is expected to be rare).  The iterator
- * returns an error if this has occurred.  Lack of the error is no
- * guarantee that the service didn't change immediately after the
- * call, so the returned string still might not be 'valid' on
- * subsequent use.</p>
- *
- * <p>Strings may take the form of const char*, const UChar*, or const
- * UnicodeString*.  The type you get is determine by the variant of
- * 'next' that you call.  In general the StringEnumeration is
- * optimized for one of these types, but all StringEnumerations can
- * return all types.  Returned strings are each terminated with a NUL.
- * Depending on the service data, they might also include embedded NUL
- * characters, so API is provided to optionally return the true
- * length, counting the embedded NULs but not counting the terminating
- * NUL.</p>
- *
- * <p>The pointers returned by next, unext, and snext become invalid
- * upon any subsequent call to the enumeration's destructor, next,
- * unext, snext, or reset.</p>
- *
- * ICU 2.8 adds some default implementations and helper functions
- * for subclasses.
- *
- * @stable ICU 2.4 
- */
-class U_COMMON_API StringEnumeration : public UObject { 
-public:
-    /**
-     * Destructor.
-     * @stable ICU 2.4
-     */
-    virtual ~StringEnumeration();
-
-    /**
-     * Clone this object, an instance of a subclass of StringEnumeration.
-     * Clones can be used concurrently in multiple threads.
-     * If a subclass does not implement clone(), or if an error occurs,
-     * then NULL is returned.
-     * The clone functions in all subclasses return a base class pointer
-     * because some compilers do not support covariant (same-as-this)
-     * return types; cast to the appropriate subclass if necessary.
-     * The caller must delete the clone.
-     *
-     * @return a clone of this object
-     *
-     * @see getDynamicClassID
-     * @stable ICU 2.8
-     */
-    virtual StringEnumeration *clone() const;
-
-    /**
-     * <p>Return the number of elements that the iterator traverses.  If
-     * the iterator is out of sync with its service, status is set to
-     * U_ENUM_OUT_OF_SYNC_ERROR, and the return value is zero.</p>
-     *
-     * <p>The return value will not change except possibly as a result of
-     * a subsequent call to reset, or if the iterator becomes out of sync.</p>
-     *
-     * <p>This is a convenience function. It can end up being very
-     * expensive as all the items might have to be pre-fetched
-     * (depending on the storage format of the data being
-     * traversed).</p>
-     *
-     * @param status the error code.
-     * @return number of elements in the iterator.
-     *
-     * @stable ICU 2.4 */
-    virtual int32_t count(UErrorCode& status) const = 0;
-
-    /**
-     * <p>Returns the next element as a NUL-terminated char*.  If there
-     * are no more elements, returns NULL.  If the resultLength pointer
-     * is not NULL, the length of the string (not counting the
-     * terminating NUL) is returned at that address.  If an error
-     * status is returned, the value at resultLength is undefined.</p>
-     *
-     * <p>The returned pointer is owned by this iterator and must not be
-     * deleted by the caller.  The pointer is valid until the next call
-     * to next, unext, snext, reset, or the enumerator's destructor.</p>
-     *
-     * <p>If the iterator is out of sync with its service, status is set
-     * to U_ENUM_OUT_OF_SYNC_ERROR and NULL is returned.</p>
-     *
-     * <p>If the native service string is a UChar* string, it is
-     * converted to char* with the invariant converter.  If the
-     * conversion fails (because a character cannot be converted) then
-     * status is set to U_INVARIANT_CONVERSION_ERROR and the return
-     * value is undefined (though not NULL).</p>
-     *
-     * Starting with ICU 2.8, the default implementation calls snext()
-     * and handles the conversion.
-     *
-     * @param status the error code.
-     * @param resultLength a pointer to receive the length, can be NULL.
-     * @return a pointer to the string, or NULL.
-     *
-     * @stable ICU 2.4 
-     */
-    virtual const char* next(int32_t *resultLength, UErrorCode& status);
-
-    /**
-     * <p>Returns the next element as a NUL-terminated UChar*.  If there
-     * are no more elements, returns NULL.  If the resultLength pointer
-     * is not NULL, the length of the string (not counting the
-     * terminating NUL) is returned at that address.  If an error
-     * status is returned, the value at resultLength is undefined.</p>
-     *
-     * <p>The returned pointer is owned by this iterator and must not be
-     * deleted by the caller.  The pointer is valid until the next call
-     * to next, unext, snext, reset, or the enumerator's destructor.</p>
-     *
-     * <p>If the iterator is out of sync with its service, status is set
-     * to U_ENUM_OUT_OF_SYNC_ERROR and NULL is returned.</p>
-     *
-     * Starting with ICU 2.8, the default implementation calls snext()
-     * and handles the conversion.
-     *
-     * @param status the error code.
-     * @param resultLength a ponter to receive the length, can be NULL.
-     * @return a pointer to the string, or NULL.
-     *
-     * @stable ICU 2.4 
-     */
-    virtual const UChar* unext(int32_t *resultLength, UErrorCode& status);
-
-    /**
-     * <p>Returns the next element a UnicodeString*.  If there are no
-     * more elements, returns NULL.</p>
-     *
-     * <p>The returned pointer is owned by this iterator and must not be
-     * deleted by the caller.  The pointer is valid until the next call
-     * to next, unext, snext, reset, or the enumerator's destructor.</p>
-     *
-     * <p>If the iterator is out of sync with its service, status is set
-     * to U_ENUM_OUT_OF_SYNC_ERROR and NULL is returned.</p>
-     *
-     * @param status the error code.
-     * @return a pointer to the string, or NULL.
-     *
-     * @stable ICU 2.4 
-     */
-    virtual const UnicodeString* snext(UErrorCode& status) = 0;
-
-    /**
-     * <p>Resets the iterator.  This re-establishes sync with the
-     * service and rewinds the iterator to start at the first
-     * element.</p>
-     *
-     * <p>Previous pointers returned by next, unext, or snext become
-     * invalid, and the value returned by count might change.</p>
-     *
-     * @param status the error code.
-     *
-     * @stable ICU 2.4 
-     */
-    virtual void reset(UErrorCode& status) = 0;
-
-    /**
-     * Compares this enumeration to other to check if both are equal
-     *
-     * @param that The other string enumeration to compare this object to
-     * @return TRUE if the enumerations are equal. FALSE if not.
-     * @stable ICU 3.6 
-     */
-    virtual UBool operator==(const StringEnumeration& that)const;
-    /**
-     * Compares this enumeration to other to check if both are not equal
-     *
-     * @param that The other string enumeration to compare this object to
-     * @return TRUE if the enumerations are equal. FALSE if not.
-     * @stable ICU 3.6 
-     */
-    virtual UBool operator!=(const StringEnumeration& that)const;
-
-protected:
-    /**
-     * UnicodeString field for use with default implementations and subclasses.
-     * @stable ICU 2.8
-     */
-    UnicodeString unistr;
-    /**
-     * char * default buffer for use with default implementations and subclasses.
-     * @stable ICU 2.8
-     */
-    char charsBuffer[32];
-    /**
-     * char * buffer for use with default implementations and subclasses.
-     * Allocated in constructor and in ensureCharsCapacity().
-     * @stable ICU 2.8
-     */
-    char *chars;
-    /**
-     * Capacity of chars, for use with default implementations and subclasses.
-     * @stable ICU 2.8
-     */
-    int32_t charsCapacity;
-
-    /**
-     * Default constructor for use with default implementations and subclasses.
-     * @stable ICU 2.8
-     */
-    StringEnumeration();
-
-    /**
-     * Ensures that chars is at least as large as the requested capacity.
-     * For use with default implementations and subclasses.
-     *
-     * @param capacity Requested capacity.
-     * @param status ICU in/out error code.
-     * @stable ICU 2.8
-     */
-    void ensureCharsCapacity(int32_t capacity, UErrorCode &status);
-
-    /**
-     * Converts s to Unicode and sets unistr to the result.
-     * For use with default implementations and subclasses,
-     * especially for implementations of snext() in terms of next().
-     * This is provided with a helper function instead of a default implementation
-     * of snext() to avoid potential infinite loops between next() and snext().
-     *
-     * For example:
-     * \code
-     * const UnicodeString* snext(UErrorCode& status) {
-     *   int32_t resultLength=0;
-     *   const char *s=next(&resultLength, status);
-     *   return setChars(s, resultLength, status);
-     * }
-     * \endcode
-     *
-     * @param s String to be converted to Unicode.
-     * @param length Length of the string.
-     * @param status ICU in/out error code.
-     * @return A pointer to unistr.
-     * @stable ICU 2.8
-     */
-    UnicodeString *setChars(const char *s, int32_t length, UErrorCode &status);
-};
-
-U_NAMESPACE_END
-
-/* STRENUM_H */
-#endif


[49/57] [abbrv] remove couch_mrview

Posted by be...@apache.org.
http://git-wip-us.apache.org/repos/asf/couchdb/blob/75150a18/apps/couch_mrview/src/couch_mrview_updater.erl
----------------------------------------------------------------------
diff --git a/apps/couch_mrview/src/couch_mrview_updater.erl b/apps/couch_mrview/src/couch_mrview_updater.erl
deleted file mode 100644
index be1055c..0000000
--- a/apps/couch_mrview/src/couch_mrview_updater.erl
+++ /dev/null
@@ -1,424 +0,0 @@
-% Licensed 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.
-
--module(couch_mrview_updater).
-
--export([start_update/3, purge/4, process_doc/3, finish_update/1]).
-
--include_lib("couch/include/couch_db.hrl").
--include_lib("couch_mrview/include/couch_mrview.hrl").
-
-
-start_update(Partial, State, NumChanges) ->
-    QueueOpts = [{max_size, 100000}, {max_items, 500}],
-    {ok, DocQueue} = couch_work_queue:new(QueueOpts),
-    {ok, WriteQueue} = couch_work_queue:new(QueueOpts),
-
-    InitState = State#mrst{
-        first_build=State#mrst.update_seq==0,
-        partial_resp_pid=Partial,
-        doc_acc=[],
-        doc_queue=DocQueue,
-        write_queue=WriteQueue
-    },
-
-    Self = self(),
-    MapFun = fun() ->
-        couch_task_status:add_task([
-            {type, indexer},
-            {database, State#mrst.db_name},
-            {design_document, State#mrst.idx_name},
-            {progress, 0},
-            {changes_done, 0},
-            {total_changes, NumChanges}
-        ]),
-        couch_task_status:set_update_frequency(500),
-        map_docs(Self, InitState)
-    end,
-    WriteFun = fun() -> write_results(Self, InitState) end,
-
-    spawn_link(MapFun),
-    spawn_link(WriteFun),
-
-    {ok, InitState}.
-
-
-purge(_Db, PurgeSeq, PurgedIdRevs, State) ->
-    #mrst{
-        id_btree=IdBtree,
-        log_btree=LogBtree,
-        views=Views
-    } = State,
-
-    Ids = [Id || {Id, _Revs} <- PurgedIdRevs],
-    {ok, Lookups, LLookups, LogBtree2, IdBtree2} = case LogBtree of
-        nil ->
-            {ok, L, Bt} = couch_btree:query_modify(IdBtree, Ids, [], Ids),
-            {ok, L, [], nil, Bt};
-        _ ->
-            {ok, L, Bt} = couch_btree:query_modify(IdBtree, Ids, [], Ids),
-            {ok, LL, LBt} = couch_btree:query_modify(LogBtree, Ids, [], Ids),
-            {ok, L, LL, LBt, Bt}
-    end,
-
-    MakeDictFun = fun
-        ({ok, {DocId, ViewNumRowKeys}}, DictAcc) ->
-            FoldFun = fun
-                ({ViewNum, {Key, Seq, _Op}}, DictAcc2) ->
-                    dict:append(ViewNum, {Key, Seq, DocId}, DictAcc2);
-                ({ViewNum, RowKey}, DictAcc2) ->
-                    dict:append(ViewNum, {RowKey, DocId}, DictAcc2)
-            end,
-            lists:foldl(FoldFun, DictAcc, ViewNumRowKeys);
-        ({not_found, _}, DictAcc) ->
-            DictAcc
-    end,
-    KeysToRemove = lists:foldl(MakeDictFun, dict:new(), Lookups),
-    SeqsToRemove = lists:foldl(MakeDictFun, dict:new(), LLookups),
-
-    RemKeysFun = fun(#mrview{id_num=ViewId}=View) ->
-        ToRem = couch_util:dict_find(ViewId, KeysToRemove, []),
-        {ok, VBtree2} = couch_btree:add_remove(View#mrview.btree, [], ToRem),
-        NewPurgeSeq = case VBtree2 =/= View#mrview.btree of
-            true -> PurgeSeq;
-            _ -> View#mrview.purge_seq
-        end,
-        {SeqBtree2, KeyBySeqBtree2} = case View#mrview.seq_indexed of
-            true ->
-                SToRem = couch_util:dict_find(ViewId, SeqsToRemove, []),
-                SKs = [{Seq, Key} || {Key, Seq, _} <- SToRem],
-                KSs = [{[Seq, Key], DocId} || {Key, Seq, DocId} <- SToRem],
-                {ok, SBt} = couch_btree:add_remove(View#mrview.seq_btree,
-                                                   [], SKs),
-                {ok, KSbt} = couch_btree:add_remove(View#mrview.key_byseq_btree,
-                                                    [], KSs),
-                {SBt, KSbt};
-            _ -> {nil, nil}
-        end,
-        View#mrview{btree=VBtree2,
-                    seq_btree=SeqBtree2,
-                    key_byseq_btree=KeyBySeqBtree2,
-                    purge_seq=NewPurgeSeq}
-
-    end,
-
-    Views2 = lists:map(RemKeysFun, Views),
-    {ok, State#mrst{
-        id_btree=IdBtree2,
-        log_btree=LogBtree2,
-        views=Views2,
-        purge_seq=PurgeSeq
-    }}.
-
-
-process_doc(Doc, Seq, #mrst{doc_acc=Acc}=State) when length(Acc) > 100 ->
-    couch_work_queue:queue(State#mrst.doc_queue, lists:reverse(Acc)),
-    process_doc(Doc, Seq, State#mrst{doc_acc=[]});
-process_doc(nil, Seq, #mrst{doc_acc=Acc}=State) ->
-    {ok, State#mrst{doc_acc=[{nil, Seq, nil} | Acc]}};
-process_doc(#doc{id=Id, deleted=true}, Seq, #mrst{doc_acc=Acc}=State) ->
-    {ok, State#mrst{doc_acc=[{Id, Seq, deleted} | Acc]}};
-process_doc(#doc{id=Id}=Doc, Seq, #mrst{doc_acc=Acc}=State) ->
-    {ok, State#mrst{doc_acc=[{Id, Seq, Doc} | Acc]}}.
-
-
-finish_update(#mrst{doc_acc=Acc}=State) ->
-    if Acc /= [] ->
-        couch_work_queue:queue(State#mrst.doc_queue, Acc);
-        true -> ok
-    end,
-    couch_work_queue:close(State#mrst.doc_queue),
-    receive
-        {new_state, NewState} ->
-            {ok, NewState#mrst{
-                first_build=undefined,
-                partial_resp_pid=undefined,
-                doc_acc=undefined,
-                doc_queue=undefined,
-                write_queue=undefined,
-                qserver=nil
-            }}
-    end.
-
-
-map_docs(Parent, State0) ->
-    case couch_work_queue:dequeue(State0#mrst.doc_queue) of
-        closed ->
-            couch_query_servers:stop_doc_map(State0#mrst.qserver),
-            couch_work_queue:close(State0#mrst.write_queue);
-        {ok, Dequeued} ->
-            % Run all the non deleted docs through the view engine and
-            % then pass the results on to the writer process.
-            State1 = case State0#mrst.qserver of
-                nil -> start_query_server(State0);
-                _ -> State0
-            end,
-            QServer = State1#mrst.qserver,
-            DocFun = fun
-                ({nil, Seq, _}, {SeqAcc, Results}) ->
-                    {erlang:max(Seq, SeqAcc), Results};
-                ({Id, Seq, deleted}, {SeqAcc, Results}) ->
-                    {erlang:max(Seq, SeqAcc), [{Id, Seq, []} | Results]};
-                ({Id, Seq, Doc}, {SeqAcc, Results}) ->
-                    {ok, Res} = couch_query_servers:map_doc_raw(QServer, Doc),
-                    {erlang:max(Seq, SeqAcc), [{Id, Seq, Res} | Results]}
-            end,
-            FoldFun = fun(Docs, Acc) ->
-                update_task(length(Docs)),
-                lists:foldl(DocFun, Acc, Docs)
-            end,
-            Results = lists:foldl(FoldFun, {0, []}, Dequeued),
-            couch_work_queue:queue(State1#mrst.write_queue, Results),
-            map_docs(Parent, State1)
-    end.
-
-
-write_results(Parent, State) ->
-    case couch_work_queue:dequeue(State#mrst.write_queue) of
-        closed ->
-            Parent ! {new_state, State};
-        {ok, Info} ->
-            EmptyKVs = [{V#mrview.id_num, {[], []}} || V <- State#mrst.views],
-            {Seq, ViewKVs, DocIdKeys, Log} = merge_results(Info, 0, EmptyKVs,
-                                                           [], dict:new()),
-            NewState = write_kvs(State, Seq, ViewKVs, DocIdKeys, Log),
-            send_partial(NewState#mrst.partial_resp_pid, NewState),
-            write_results(Parent, NewState)
-    end.
-
-
-start_query_server(State) ->
-    #mrst{
-        language=Language,
-        lib=Lib,
-        views=Views
-    } = State,
-    Defs = [View#mrview.def || View <- Views],
-    {ok, QServer} = couch_query_servers:start_doc_map(Language, Defs, Lib),
-    State#mrst{qserver=QServer}.
-
-
-merge_results([], SeqAcc, ViewKVs, DocIdKeys, Log) ->
-    {SeqAcc, ViewKVs, DocIdKeys, Log};
-merge_results([{Seq, Results} | Rest], SeqAcc, ViewKVs, DocIdKeys, Log) ->
-    Fun = fun(RawResults, {VKV, DIK, Log2}) ->
-        merge_results(RawResults, VKV, DIK, Log2)
-    end,
-    {ViewKVs1, DocIdKeys1, Log1} = lists:foldl(Fun, {ViewKVs, DocIdKeys, Log},
-                                               Results),
-    merge_results(Rest, erlang:max(Seq, SeqAcc), ViewKVs1, DocIdKeys1,
-                  Log1).
-
-
-merge_results({DocId, _Seq, []}, ViewKVs, DocIdKeys, Log) ->
-    {ViewKVs, [{DocId, []} | DocIdKeys], dict:store(DocId, [], Log)};
-merge_results({DocId, Seq, RawResults}, ViewKVs, DocIdKeys, Log) ->
-    JsonResults = couch_query_servers:raw_to_ejson(RawResults),
-    Results = [[list_to_tuple(Res) || Res <- FunRs] || FunRs <- JsonResults],
-    {ViewKVs1, ViewIdKeys, Log1} = insert_results(DocId, Seq, Results, ViewKVs, [],
-                                            [], Log),
-    {ViewKVs1, [ViewIdKeys | DocIdKeys], Log1}.
-
-
-insert_results(DocId, _Seq, [], [], ViewKVs, ViewIdKeys, Log) ->
-    {lists:reverse(ViewKVs), {DocId, ViewIdKeys}, Log};
-insert_results(DocId, Seq, [KVs | RKVs], [{Id, {VKVs, SKVs}} | RVKVs], VKVAcc,
-               VIdKeys, Log) ->
-    CombineDupesFun = fun
-        ({Key, Val}, {[{Key, {dups, Vals}} | Rest], IdKeys, Log2}) ->
-            {[{Key, {dups, [Val | Vals]}} | Rest], IdKeys, Log2};
-        ({Key, Val1}, {[{Key, Val2} | Rest], IdKeys, Log2}) ->
-            {[{Key, {dups, [Val1, Val2]}} | Rest], IdKeys, Log2};
-        ({Key, _}=KV, {Rest, IdKeys, Log2}) ->
-            {[KV | Rest], [{Id, Key} | IdKeys],
-             dict:append(DocId, {Id, {Key, Seq, add}}, Log2)}
-    end,
-    InitAcc = {[], VIdKeys, Log},
-    {Duped, VIdKeys0, Log1} = lists:foldl(CombineDupesFun, InitAcc,
-                                          lists:sort(KVs)),
-    FinalKVs = [{{Key, DocId}, Val} || {Key, Val} <- Duped] ++ VKVs,
-    FinalSKVs = [{{Seq, Key}, {DocId, Val}} || {Key, Val} <- Duped] ++ SKVs,
-    insert_results(DocId, Seq, RKVs, RVKVs,
-                  [{Id, {FinalKVs, FinalSKVs}} | VKVAcc], VIdKeys0, Log1).
-
-
-write_kvs(State, UpdateSeq, ViewKVs, DocIdKeys, Log) ->
-    #mrst{
-        id_btree=IdBtree,
-        log_btree=LogBtree,
-        first_build=FirstBuild
-    } = State,
-
-    {ok, ToRemove, IdBtree2} = update_id_btree(IdBtree, DocIdKeys, FirstBuild),
-    ToRemByView = collapse_rem_keys(ToRemove, dict:new()),
-
-    {ok, SeqsToAdd, SeqsToRemove, LogBtree2} = case LogBtree of
-        nil -> {ok, undefined, undefined, nil};
-        _ -> update_log(LogBtree, Log, UpdateSeq, FirstBuild)
-    end,
-
-    UpdateView = fun(#mrview{id_num=ViewId}=View, {ViewId, {KVs, SKVs}}) ->
-        ToRem = couch_util:dict_find(ViewId, ToRemByView, []),
-        {ok, VBtree2} = couch_btree:add_remove(View#mrview.btree, KVs, ToRem),
-        NewUpdateSeq = case VBtree2 =/= View#mrview.btree of
-            true -> UpdateSeq;
-            _ -> View#mrview.update_seq
-        end,
-
-        %% store the view changes.
-        {SeqBtree2, KeyBySeqBtree2} = case View#mrview.seq_indexed of
-            true ->
-                SToRem = couch_util:dict_find(ViewId, SeqsToRemove, []),
-                SToAdd = couch_util:dict_find(ViewId, SeqsToAdd, []),
-                RemSKs = [{Seq, Key} || {Key, Seq, _} <- SToRem],
-                RemKSs = [{[Key, Seq], DocId} || {Key, Seq, DocId} <- SToRem],
-                SKVs1 = SKVs ++ SToAdd,
-                {ok, SBt} = couch_btree:add_remove(View#mrview.seq_btree,
-                                                   SKVs1, RemSKs),
-
-                {ok, KSbt} = couch_btree:add_remove(View#mrview.key_byseq_btree,
-                                                    couch_mrview_util:to_key_seq(SKVs1),
-                                                    RemKSs),
-                {SBt, KSbt};
-            _ -> {nil, nil}
-        end,
-        View#mrview{btree=VBtree2,
-                    seq_btree=SeqBtree2,
-                    key_byseq_btree=KeyBySeqBtree2,
-                    update_seq=NewUpdateSeq}
-    end,
-
-    State#mrst{
-        views=lists:zipwith(UpdateView, State#mrst.views, ViewKVs),
-        update_seq=UpdateSeq,
-        id_btree=IdBtree2,
-        log_btree=LogBtree2
-    }.
-
-
-update_id_btree(Btree, DocIdKeys, true) ->
-    ToAdd = [{Id, DIKeys} || {Id, DIKeys} <- DocIdKeys, DIKeys /= []],
-    couch_btree:query_modify(Btree, [], ToAdd, []);
-update_id_btree(Btree, DocIdKeys, _) ->
-    ToFind = [Id || {Id, _} <- DocIdKeys],
-    ToAdd = [{Id, DIKeys} || {Id, DIKeys} <- DocIdKeys, DIKeys /= []],
-    ToRem = [Id || {Id, DIKeys} <- DocIdKeys, DIKeys == []],
-    couch_btree:query_modify(Btree, ToFind, ToAdd, ToRem).
-
-walk_log(BTree, Fun, Acc, Ids) ->
-    WrapFun = fun(KV, _Offset, Acc2) ->
-            Fun(KV, Acc2)
-    end,
-    lists:foldl(fun(Id, Acc1) ->
-                Opt = [{start_key, Id}, {end_key, Id}],
-                {ok, _, A} = couch_btree:fold(BTree, WrapFun, Acc1, Opt),
-                A
-        end, Acc, Ids).
-
-update_log(Btree, Log, _UpdatedSeq, true) ->
-    ToAdd = [{Id, DIKeys} || {Id, DIKeys} <- dict:to_list(Log),
-                             DIKeys /= []],
-    {ok, LogBtree2} = couch_btree:add_remove(Btree, ToAdd, []),
-    {ok, dict:new(), dict:new(), LogBtree2};
-update_log(Btree, Log, UpdatedSeq, _) ->
-    %% build list of updated keys and Id
-    {ToLook, Updated} = dict:fold(fun
-                (Id, [], {IdsAcc, KeysAcc}) ->
-                    {[Id | IdsAcc], KeysAcc};
-                (Id, DIKeys, {IdsAcc, KeysAcc}) ->
-                    KeysAcc1 = lists:foldl(fun({ViewId, {Key, _Seq, _Op}},
-                                               KeysAcc2) ->
-                                    [{Id, ViewId, Key} | KeysAcc2]
-                            end, KeysAcc, DIKeys),
-                {[Id | IdsAcc], KeysAcc1} end, {[], []}, Log),
-
-    RemValue = {[{<<"_removed">>, true}]},
-    {Log1, AddAcc, DelAcc} = walk_log(Btree, fun({DocId, VIdKeys},
-                                                          {Log2, AddAcc2, DelAcc2}) ->
-
-                {Log3, AddAcc3, DelAcc3} = lists:foldl(fun({ViewId,{Key, Seq, Op}},
-                                                           {Log4, AddAcc4, DelAcc4}) ->
-
-                            case lists:member({DocId, ViewId, Key}, Updated) of
-                                true ->
-                                    %% the log is updated, deleted old
-                                    %% record from the view
-                                    DelAcc5 = dict:append(ViewId,
-                                                          {Key, Seq, DocId},
-                                                          DelAcc4),
-                                    {Log4, AddAcc4, DelAcc5};
-                                false when Op /= del ->
-                                    %% an update operation has been
-                                    %% logged for this key. We must now
-                                    %% record it as deleted in the
-                                    %% log, remove the old record in
-                                    %% the view and update the view
-                                    %% with a removed record.
-                                    Log5 = dict:append(DocId,
-                                                       {ViewId,
-                                                        {Key,UpdatedSeq, del}},
-                                                       Log4),
-                                    DelAcc5 = dict:append(ViewId,
-                                                          {Key, Seq, DocId},
-                                                          DelAcc4),
-                                    AddAcc5 = dict:append(ViewId,
-                                                          {{UpdatedSeq, Key},
-                                                           {DocId, RemValue}},
-                                                          AddAcc4),
-                                    {Log5, AddAcc5, DelAcc5};
-                                false ->
-                                    %% the key has already been
-                                    %% registered in the view as
-                                    %% deleted, make sure to add it
-                                    %% to the new log.
-                                    Log5 = dict:append(DocId,
-                                                       {ViewId,
-                                                        {Key, Seq, del}}, Log4),
-                                    {Log5, AddAcc4, DelAcc4}
-                            end
-                    end, {Log2, AddAcc2, DelAcc2}, VIdKeys),
-                    {ok, {Log3, AddAcc3, DelAcc3}}
-            end, {Log, dict:new(), dict:new()}, ToLook),
-
-    ToAdd = [{Id, DIKeys} || {Id, DIKeys} <- dict:to_list(Log1), DIKeys /= []],
-    %% store the new logs
-    {ok, LogBtree2} = couch_btree:add_remove(Btree, ToAdd, []),
-    {ok, AddAcc, DelAcc, LogBtree2}.
-
-collapse_rem_keys([], Acc) ->
-    Acc;
-collapse_rem_keys([{ok, {DocId, ViewIdKeys}} | Rest], Acc) ->
-    NewAcc = lists:foldl(fun({ViewId, Key}, Acc2) ->
-        dict:append(ViewId, {Key, DocId}, Acc2)
-    end, Acc, ViewIdKeys),
-    collapse_rem_keys(Rest, NewAcc);
-collapse_rem_keys([{not_found, _} | Rest], Acc) ->
-    collapse_rem_keys(Rest, Acc).
-
-
-send_partial(Pid, State) when is_pid(Pid) ->
-    gen_server:cast(Pid, {new_state, State});
-send_partial(_, _) ->
-    ok.
-
-
-update_task(NumChanges) ->
-    [Changes, Total] = couch_task_status:get([changes_done, total_changes]),
-    Changes2 = Changes + NumChanges,
-    Progress = case Total of
-        0 ->
-            % updater restart after compaction finishes
-            0;
-        _ ->
-            (Changes2 * 100) div Total
-    end,
-    couch_task_status:update([{progress, Progress}, {changes_done, Changes2}]).

http://git-wip-us.apache.org/repos/asf/couchdb/blob/75150a18/apps/couch_mrview/src/couch_mrview_util.erl
----------------------------------------------------------------------
diff --git a/apps/couch_mrview/src/couch_mrview_util.erl b/apps/couch_mrview/src/couch_mrview_util.erl
deleted file mode 100644
index a98f042..0000000
--- a/apps/couch_mrview/src/couch_mrview_util.erl
+++ /dev/null
@@ -1,950 +0,0 @@
-% Licensed 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.
-
--module(couch_mrview_util).
-
--export([get_view/4]).
--export([ddoc_to_mrst/2, init_state/4, reset_index/3]).
--export([make_header/1]).
--export([index_file/2, compaction_file/2, open_file/1]).
--export([delete_files/2, delete_index_file/2, delete_compaction_file/2]).
--export([get_row_count/1, all_docs_reduce_to_count/1, reduce_to_count/1]).
--export([get_view_changes_count/1]).
--export([all_docs_key_opts/1, all_docs_key_opts/2, key_opts/1, key_opts/2]).
--export([fold/4, fold_reduce/4]).
--export([temp_view_to_ddoc/1]).
--export([calculate_data_size/3]).
--export([validate_args/1]).
--export([maybe_load_doc/3, maybe_load_doc/4]).
--export([maybe_update_index_file/1]).
--export([changes_key_opts/2]).
--export([fold_changes/4]).
--export([to_key_seq/1]).
-
--define(MOD, couch_mrview_index).
-
--include_lib("couch/include/couch_db.hrl").
--include_lib("couch_mrview/include/couch_mrview.hrl").
-
-
-get_view(Db, DDoc, ViewName, Args0) ->
-    ArgCheck = fun(InitState) ->
-        Args1 = set_view_type(Args0, ViewName, InitState#mrst.views),
-        {ok, validate_args(Args1)}
-    end,
-    {ok, Pid, Args2} = couch_index_server:get_index(?MOD, Db, DDoc, ArgCheck),
-    DbUpdateSeq = couch_util:with_db(Db, fun(WDb) ->
-        couch_db:get_update_seq(WDb)
-    end),
-    MinSeq = case Args2#mrargs.stale of
-        ok -> 0; update_after -> 0; _ -> DbUpdateSeq
-    end,
-    {ok, State} = case couch_index:get_state(Pid, MinSeq) of
-        {ok, _} = Resp -> Resp;
-        Error -> throw(Error)
-    end,
-    couch_ref_counter:add(State#mrst.refc),
-    if Args2#mrargs.stale == update_after ->
-        spawn(fun() -> catch couch_index:get_state(Pid, DbUpdateSeq) end);
-        true -> ok
-    end,
-    #mrst{language=Lang, views=Views} = State,
-    {Type, View, Args3} = extract_view(Lang, Args2, ViewName, Views),
-    check_range(Args3, view_cmp(View)),
-    Sig = view_sig(Db, State, View, Args3),
-    {ok, {Type, View}, Sig, Args3}.
-
-
-ddoc_to_mrst(DbName, #doc{id=Id, body={Fields}}) ->
-    MakeDict = fun({Name, {MRFuns}}, DictBySrcAcc) ->
-        case couch_util:get_value(<<"map">>, MRFuns) of
-            MapSrc when is_binary(MapSrc) ->
-                RedSrc = couch_util:get_value(<<"reduce">>, MRFuns, null),
-                {ViewOpts} = couch_util:get_value(<<"options">>, MRFuns, {[]}),
-                View = case dict:find({MapSrc, ViewOpts}, DictBySrcAcc) of
-                    {ok, View0} -> View0;
-                    error -> #mrview{def=MapSrc, options=ViewOpts}
-                end,
-                {MapNames, RedSrcs} = case RedSrc of
-                    null ->
-                        MNames = [Name | View#mrview.map_names],
-                        {MNames, View#mrview.reduce_funs};
-                    _ ->
-                        RedFuns = [{Name, RedSrc} | View#mrview.reduce_funs],
-                        {View#mrview.map_names, RedFuns}
-                end,
-                View2 = View#mrview{map_names=MapNames, reduce_funs=RedSrcs},
-                dict:store({MapSrc, ViewOpts}, View2, DictBySrcAcc);
-            undefined ->
-                DictBySrcAcc
-        end
-    end,
-    {DesignOpts} = proplists:get_value(<<"options">>, Fields, {[]}),
-    SeqIndexed = proplists:get_value(<<"seq_indexed">>, DesignOpts, false),
-
-    {RawViews} = couch_util:get_value(<<"views">>, Fields, {[]}),
-    BySrc = lists:foldl(MakeDict, dict:new(), RawViews),
-
-    NumViews = fun({_, View}, N) ->
-            {View#mrview{id_num=N, seq_indexed=SeqIndexed}, N+1}
-    end,
-    {Views, _} = lists:mapfoldl(NumViews, 0, lists:sort(dict:to_list(BySrc))),
-
-    Language = couch_util:get_value(<<"language">>, Fields, <<"javascript">>),
-    Lib = couch_util:get_value(<<"lib">>, RawViews, {[]}),
-
-    IdxState = #mrst{
-        db_name=DbName,
-        idx_name=Id,
-        lib=Lib,
-        views=Views,
-        language=Language,
-        design_opts=DesignOpts,
-        seq_indexed=SeqIndexed
-    },
-    SigInfo = {Views, Language, DesignOpts, couch_index_util:sort_lib(Lib)},
-    {ok, IdxState#mrst{sig=couch_util:md5(term_to_binary(SigInfo))}}.
-
-
-set_view_type(_Args, _ViewName, []) ->
-    throw({not_found, missing_named_view});
-set_view_type(Args, ViewName, [View | Rest]) ->
-    RedNames = [N || {N, _} <- View#mrview.reduce_funs],
-    case lists:member(ViewName, RedNames) of
-        true ->
-            case Args#mrargs.reduce of
-                false -> Args#mrargs{view_type=map};
-                _ -> Args#mrargs{view_type=red}
-            end;
-        false ->
-            case lists:member(ViewName, View#mrview.map_names) of
-                true -> Args#mrargs{view_type=map};
-                false -> set_view_type(Args, ViewName, Rest)
-            end
-    end.
-
-
-extract_view(_Lang, _Args, _ViewName, []) ->
-    throw({not_found, missing_named_view});
-extract_view(Lang, #mrargs{view_type=map}=Args, Name, [View | Rest]) ->
-    Names = View#mrview.map_names ++ [N || {N, _} <- View#mrview.reduce_funs],
-    case lists:member(Name, Names) of
-        true -> {map, View, Args};
-        _ -> extract_view(Lang, Args, Name, Rest)
-    end;
-extract_view(Lang, #mrargs{view_type=red}=Args, Name, [View | Rest]) ->
-    RedNames = [N || {N, _} <- View#mrview.reduce_funs],
-    case lists:member(Name, RedNames) of
-        true -> {red, {index_of(Name, RedNames), Lang, View}, Args};
-        false -> extract_view(Lang, Args, Name, Rest)
-    end.
-
-
-view_sig(Db, State, View, #mrargs{include_docs=true}=Args) ->
-    BaseSig = view_sig(Db, State, View, Args#mrargs{include_docs=false}),
-    UpdateSeq = couch_db:get_update_seq(Db),
-    PurgeSeq = couch_db:get_purge_seq(Db),
-    Bin = term_to_binary({BaseSig, UpdateSeq, PurgeSeq,
-                          State#mrst.seq_indexed}),
-    couch_index_util:hexsig(couch_util:md5(Bin));
-view_sig(Db, State, {_Nth, _Lang, View}, Args) ->
-    view_sig(Db, State, View, Args);
-view_sig(_Db, State, View, Args0) ->
-    Sig = State#mrst.sig,
-    UpdateSeq = View#mrview.update_seq,
-    PurgeSeq = View#mrview.purge_seq,
-    SeqIndexed = View#mrview.seq_indexed,
-    Args = Args0#mrargs{
-        preflight_fun=undefined,
-        extra=[]
-    },
-    Bin = term_to_binary({Sig, UpdateSeq, PurgeSeq, SeqIndexed, Args}),
-    couch_index_util:hexsig(couch_util:md5(Bin)).
-
-
-init_state(Db, Fd, #mrst{views=Views}=State, nil) ->
-    Header = #mrheader{
-        seq=0,
-        purge_seq=couch_db:get_purge_seq(Db),
-        id_btree_state=nil,
-        log_btree_state=nil,
-        view_states=[{nil, nil, nil, 0, 0} || _ <- Views]
-    },
-    init_state(Db, Fd, State, Header);
-% read <= 1.2.x header record and transpile it to >=1.3.x
-% header record
-init_state(Db, Fd, State, #index_header{
-    seq=Seq,
-    purge_seq=PurgeSeq,
-    id_btree_state=IdBtreeState,
-    view_states=ViewStates}) ->
-    init_state(Db, Fd, State, #mrheader{
-        seq=Seq,
-        purge_seq=PurgeSeq,
-        id_btree_state=IdBtreeState,
-        log_btree_state=nil,
-        view_states=[{Bt, nil, nil, USeq, PSeq} || {Bt, USeq, PSeq} <- ViewStates]
-        });
-init_state(Db, Fd, State, Header) ->
-    #mrst{language=Lang, views=Views, seq_indexed=SeqIndexed} = State,
-    #mrheader{
-        seq=Seq,
-        purge_seq=PurgeSeq,
-        id_btree_state=IdBtreeState,
-        log_btree_state=LogBtreeState,
-        view_states=ViewStates
-    } = Header,
-
-    StateUpdate = fun
-        ({_, _, _, _, _}=St) -> St;
-        (St) -> {St, nil, nil, 0, 0}
-    end,
-    ViewStates2 = lists:map(StateUpdate, ViewStates),
-
-    IdBtOpts = [{compression, couch_db:compression(Db)}],
-    {ok, IdBtree} = couch_btree:open(IdBtreeState, Fd, IdBtOpts),
-    {ok, LogBtree} = case SeqIndexed of
-        true -> couch_btree:open(LogBtreeState, Fd, IdBtOpts);
-        false -> {ok, nil}
-    end,
-
-    OpenViewFun = fun(St, View) -> open_view(Db, Fd, Lang, St, View) end,
-    Views2 = lists:zipwith(OpenViewFun, ViewStates2, Views),
-
-    State#mrst{
-        fd=Fd,
-        update_seq=Seq,
-        purge_seq=PurgeSeq,
-        id_btree=IdBtree,
-        log_btree=LogBtree,
-        views=Views2
-    }.
-
-less_json_seqs({SeqA, _JsonA}, {SeqB, _JsonB}) ->
-    couch_ejson_compare:less(SeqA, SeqB) < 0.
-
-open_view(Db, Fd, Lang, {BTState, SeqBTState, KSeqBTState, USeq, PSeq}, View) ->
-    FunSrcs = [FunSrc || {_Name, FunSrc} <- View#mrview.reduce_funs],
-    ReduceFun =
-        fun(reduce, KVs) ->
-            KVs2 = detuple_kvs(expand_dups(KVs, []), []),
-            {ok, Result} = couch_query_servers:reduce(Lang, FunSrcs, KVs2),
-            {length(KVs2), Result};
-        (rereduce, Reds) ->
-            Count = lists:sum([Count0 || {Count0, _} <- Reds]),
-            UsrReds = [UsrRedsList || {_, UsrRedsList} <- Reds],
-            {ok, Result} = couch_query_servers:rereduce(Lang, FunSrcs, UsrReds),
-            {Count, Result}
-        end,
-
-    Less = case couch_util:get_value(<<"collation">>, View#mrview.options) of
-        <<"raw">> -> fun(A, B) -> A < B end;
-        _ -> fun couch_ejson_compare:less_json_ids/2
-    end,
-
-    ViewBtOpts = [
-        {less, Less},
-        {reduce, ReduceFun},
-        {compression, couch_db:compression(Db)}
-    ],
-    {ok, Btree} = couch_btree:open(BTState, Fd, ViewBtOpts),
-
-    {SeqBtree, KeyBySeqBtree} = case View#mrview.seq_indexed of
-        true ->
-            BySeqReduceFun = fun couch_db_updater:btree_by_seq_reduce/2,
-            ViewSeqBtOpts = [{less, fun less_json_seqs/2},
-                             {reduce, BySeqReduceFun},
-                             {compression, couch_db:compression(Db)}],
-            KeyBySeqBtOpts = [{less, Less},
-                              {reduce, BySeqReduceFun},
-                              {compression, couch_db:compression(Db)}],
-            {ok, SBt} = couch_btree:open(SeqBTState, Fd, ViewSeqBtOpts),
-            {ok, KSBt} = couch_btree:open(KSeqBTState, Fd, KeyBySeqBtOpts),
-            {SBt, KSBt};
-        false ->
-            {nil, nil}
-    end,
-
-    View#mrview{btree=Btree,
-                seq_btree=SeqBtree,
-                key_byseq_btree=KeyBySeqBtree,
-                update_seq=USeq,
-                purge_seq=PSeq}.
-
-
-temp_view_to_ddoc({Props}) ->
-    Language = couch_util:get_value(<<"language">>, Props, <<"javascript">>),
-    Options = couch_util:get_value(<<"options">>, Props, {[]}),
-    View0 = [{<<"map">>, couch_util:get_value(<<"map">>, Props)}],
-    View1 = View0 ++ case couch_util:get_value(<<"reduce">>, Props) of
-        RedSrc when is_binary(RedSrc) -> [{<<"reduce">>, RedSrc}];
-        _ -> []
-    end,
-    DDoc = {[
-        {<<"_id">>, couch_uuids:random()},
-        {<<"language">>, Language},
-        {<<"options">>, Options},
-        {<<"views">>, {[
-            {<<"temp">>, {View1}}
-        ]}}
-    ]},
-    couch_doc:from_json_obj(DDoc).
-
-
-get_row_count(#mrview{btree=Bt}) ->
-    {ok, {Count, _Reds}} = couch_btree:full_reduce(Bt),
-    {ok, Count}.
-
-
-all_docs_reduce_to_count(Reductions) ->
-    Reduce = fun couch_db_updater:btree_by_id_reduce/2,
-    {Count, _, _} = couch_btree:final_reduce(Reduce, Reductions),
-    Count.
-
-reduce_to_count(nil) ->
-    0;
-reduce_to_count(Reductions) ->
-    Reduce = fun
-        (reduce, KVs) ->
-            Counts = [
-                case V of {dups, Vals} -> length(Vals); _ -> 1 end
-                || {_,V} <- KVs
-            ],
-            {lists:sum(Counts), []};
-        (rereduce, Reds) ->
-            {lists:sum([Count0 || {Count0, _} <- Reds]), []}
-    end,
-    {Count, _} = couch_btree:final_reduce(Reduce, Reductions),
-    Count.
-
-%% @doc get all changes for a view
-get_view_changes_count(#mrview{seq_btree=Btree}) ->
-    couch_btree:fold_reduce(
-            Btree, fun(_SeqStart, PartialReds, 0) ->
-                    {ok, couch_btree:final_reduce(Btree, PartialReds)}
-            end,0, []).
-
-fold(#mrview{btree=Bt}, Fun, Acc, Opts) ->
-    WrapperFun = fun(KV, Reds, Acc2) ->
-        fold_fun(Fun, expand_dups([KV], []), Reds, Acc2)
-    end,
-    {ok, _LastRed, _Acc} = couch_btree:fold(Bt, WrapperFun, Acc, Opts).
-
-fold_fun(_Fun, [], _, Acc) ->
-    {ok, Acc};
-fold_fun(Fun, [KV|Rest], {KVReds, Reds}, Acc) ->
-    case Fun(KV, {KVReds, Reds}, Acc) of
-        {ok, Acc2} ->
-            fold_fun(Fun, Rest, {[KV|KVReds], Reds}, Acc2);
-        {stop, Acc2} ->
-            {stop, Acc2}
-    end.
-
-
-fold_changes(Bt, Fun, Acc, Opts) ->
-    WrapperFun = fun(KV, _Reds, Acc2) ->
-        fold_changes_fun(Fun, changes_expand_dups([KV], []), Acc2)
-    end,
-    {ok, _LastRed, _Acc} = couch_btree:fold(Bt, WrapperFun, Acc, Opts).
-
-fold_changes_fun(_Fun, [], Acc) ->
-    {ok, Acc};
-fold_changes_fun(Fun, [KV|Rest],  Acc) ->
-    case Fun(KV, Acc) of
-        {ok, Acc2} ->
-            fold_changes_fun(Fun, Rest, Acc2);
-        {stop, Acc2} ->
-            {stop, Acc2}
-    end.
-
-
-fold_reduce({NthRed, Lang, View}, Fun,  Acc, Options) ->
-    #mrview{
-        btree=Bt,
-        reduce_funs=RedFuns
-    } = View,
-    LPad = lists:duplicate(NthRed - 1, []),
-    RPad = lists:duplicate(length(RedFuns) - NthRed, []),
-    {_Name, FunSrc} = lists:nth(NthRed,RedFuns),
-
-    ReduceFun = fun
-        (reduce, KVs0) ->
-            KVs1 = detuple_kvs(expand_dups(KVs0, []), []),
-            {ok, Red} = couch_query_servers:reduce(Lang, [FunSrc], KVs1),
-            {0, LPad ++ Red ++ RPad};
-        (rereduce, Reds) ->
-            ExtractRed = fun({_, UReds0}) -> [lists:nth(NthRed, UReds0)] end,
-            UReds = lists:map(ExtractRed, Reds),
-            {ok, Red} = couch_query_servers:rereduce(Lang, [FunSrc], UReds),
-            {0, LPad ++ Red ++ RPad}
-    end,
-
-    WrapperFun = fun({GroupedKey, _}, PartialReds, Acc0) ->
-        {_, Reds} = couch_btree:final_reduce(ReduceFun, PartialReds),
-        Fun(GroupedKey, lists:nth(NthRed, Reds), Acc0)
-    end,
-
-    couch_btree:fold_reduce(Bt, WrapperFun, Acc, Options).
-
-
-validate_args(Args) ->
-    Reduce = Args#mrargs.reduce,
-    case Reduce == undefined orelse is_boolean(Reduce) of
-        true -> ok;
-        _ -> mrverror(<<"Invalid `reduce` value.">>)
-    end,
-
-    case {Args#mrargs.view_type, Reduce} of
-        {map, true} -> mrverror(<<"Reduce is invalid for map-only views.">>);
-        _ -> ok
-    end,
-
-    case {Args#mrargs.view_type, Args#mrargs.group_level, Args#mrargs.keys} of
-        {red, exact, _} -> ok;
-        {red, _, KeyList} when is_list(KeyList) ->
-            Msg = <<"Multi-key fetchs for reduce views must use `group=true`">>,
-            mrverror(Msg);
-        _ -> ok
-    end,
-
-    case Args#mrargs.keys of
-        Keys when is_list(Keys) -> ok;
-        undefined -> ok;
-        _ -> mrverror(<<"`keys` must be an array of strings.">>)
-    end,
-
-    case {Args#mrargs.keys, Args#mrargs.start_key} of
-        {undefined, _} -> ok;
-        {[], _} -> ok;
-        {[_|_], undefined} -> ok;
-        _ -> mrverror(<<"`start_key` is incompatible with `keys`">>)
-    end,
-
-    case Args#mrargs.start_key_docid of
-        undefined -> ok;
-        SKDocId0 when is_binary(SKDocId0) -> ok;
-        _ -> mrverror(<<"`start_key_docid` must be a string.">>)
-    end,
-
-    case {Args#mrargs.keys, Args#mrargs.end_key} of
-        {undefined, _} -> ok;
-        {[], _} -> ok;
-        {[_|_], undefined} -> ok;
-        _ -> mrverror(<<"`end_key` is incompatible with `keys`">>)
-    end,
-
-    case Args#mrargs.end_key_docid of
-        undefined -> ok;
-        EKDocId0 when is_binary(EKDocId0) -> ok;
-        _ -> mrverror(<<"`end_key_docid` must be a string.">>)
-    end,
-
-    case Args#mrargs.direction of
-        fwd -> ok;
-        rev -> ok;
-        _ -> mrverror(<<"Invalid direction.">>)
-    end,
-
-    case {Args#mrargs.limit >= 0, Args#mrargs.limit == undefined} of
-        {true, _} -> ok;
-        {_, true} -> ok;
-        _ -> mrverror(<<"`limit` must be a positive integer.">>)
-    end,
-
-    case Args#mrargs.skip < 0 of
-        true -> mrverror(<<"`skip` must be >= 0">>);
-        _ -> ok
-    end,
-
-    case {Args#mrargs.view_type, Args#mrargs.group_level} of
-        {red, exact} -> ok;
-        {_, 0} -> ok;
-        {red, Int} when is_integer(Int), Int >= 0 -> ok;
-        {red, _} -> mrverror(<<"`group_level` must be >= 0">>);
-        {map, _} -> mrverror(<<"Invalid use of grouping on a map view.">>)
-    end,
-
-    case Args#mrargs.stale of
-        ok -> ok;
-        update_after -> ok;
-        false -> ok;
-        _ -> mrverror(<<"Invalid value for `stale`.">>)
-    end,
-
-    case is_boolean(Args#mrargs.inclusive_end) of
-        true -> ok;
-        _ -> mrverror(<<"Invalid value for `inclusive_end`.">>)
-    end,
-
-    case {Args#mrargs.view_type, Args#mrargs.include_docs} of
-        {red, true} -> mrverror(<<"`include_docs` is invalid for reduce">>);
-        {_, ID} when is_boolean(ID) -> ok;
-        _ -> mrverror(<<"Invalid value for `include_docs`">>)
-    end,
-
-    case {Args#mrargs.view_type, Args#mrargs.conflicts} of
-        {_, undefined} -> ok;
-        {map, V} when is_boolean(V) -> ok;
-        {red, undefined} -> ok;
-        {map, _} -> mrverror(<<"Invalid value for `conflicts`.">>);
-        {red, _} -> mrverror(<<"`conflicts` is invalid for reduce views.">>)
-    end,
-
-    SKDocId = case {Args#mrargs.direction, Args#mrargs.start_key_docid} of
-        {fwd, undefined} -> <<>>;
-        {rev, undefined} -> <<255>>;
-        {_, SKDocId1} -> SKDocId1
-    end,
-
-    EKDocId = case {Args#mrargs.direction, Args#mrargs.end_key_docid} of
-        {fwd, undefined} -> <<255>>;
-        {rev, undefined} -> <<>>;
-        {_, EKDocId1} -> EKDocId1
-    end,
-
-    Args#mrargs{
-        start_key_docid=SKDocId,
-        end_key_docid=EKDocId
-    }.
-
-
-check_range(#mrargs{start_key=undefined}, _Cmp) ->
-    ok;
-check_range(#mrargs{end_key=undefined}, _Cmp) ->
-    ok;
-check_range(#mrargs{start_key=K, end_key=K}, _Cmp) ->
-    ok;
-check_range(Args, Cmp) ->
-    #mrargs{
-        direction=Dir,
-        start_key=SK,
-        start_key_docid=SKD,
-        end_key=EK,
-        end_key_docid=EKD
-    } = Args,
-    case {Dir, Cmp({SK, SKD}, {EK, EKD})} of
-        {fwd, false} ->
-            throw({query_parse_error,
-                <<"No rows can match your key range, reverse your ",
-                    "start_key and end_key or set descending=true">>});
-        {rev, true} ->
-            throw({query_parse_error,
-                <<"No rows can match your key range, reverse your ",
-                    "start_key and end_key or set descending=false">>});
-        _ -> ok
-    end.
-
-
-view_cmp({_Nth, _Lang, View}) ->
-    view_cmp(View);
-view_cmp(View) ->
-    fun(A, B) -> couch_btree:less(View#mrview.btree, A, B) end.
-
-
-make_header(State) ->
-    #mrst{
-        update_seq=Seq,
-        purge_seq=PurgeSeq,
-        id_btree=IdBtree,
-        log_btree=LogBtree,
-        views=Views
-    } = State,
-
-    ViewStates = lists:foldr(fun(V, Acc) ->
-                    {SeqBtState, KSeqBtState} = case V#mrview.seq_indexed of
-                        true ->
-                            {couch_btree:get_state(V#mrview.seq_btree),
-                             couch_btree:get_state(V#mrview.key_byseq_btree)};
-                        _ -> {nil, nil}
-                    end,
-                    [{couch_btree:get_state(V#mrview.btree),
-                      SeqBtState,
-                      KSeqBtState,
-                      V#mrview.update_seq,
-                      V#mrview.purge_seq} | Acc]
-            end, [], Views),
-
-    LogBtreeState = case LogBtree of
-        nil -> nil;
-        _ -> couch_btree:get_state(LogBtree)
-    end,
-
-    #mrheader{
-        seq=Seq,
-        purge_seq=PurgeSeq,
-        id_btree_state=couch_btree:get_state(IdBtree),
-        log_btree_state= LogBtreeState,
-        view_states=ViewStates
-    }.
-
-
-index_file(DbName, Sig) ->
-    FileName = couch_index_util:hexsig(Sig) ++ ".view",
-    couch_index_util:index_file(mrview, DbName, FileName).
-
-
-compaction_file(DbName, Sig) ->
-    FileName = couch_index_util:hexsig(Sig) ++ ".compact.view",
-    couch_index_util:index_file(mrview, DbName, FileName).
-
-
-open_file(FName) ->
-    case couch_file:open(FName, [nologifmissing]) of
-        {ok, Fd} -> {ok, Fd};
-        {error, enoent} -> couch_file:open(FName, [create]);
-        Error -> Error
-    end.
-
-
-delete_files(DbName, Sig) ->
-    delete_index_file(DbName, Sig),
-    delete_compaction_file(DbName, Sig).
-
-
-delete_index_file(DbName, Sig) ->
-    delete_file(index_file(DbName, Sig)).
-
-
-delete_compaction_file(DbName, Sig) ->
-    delete_file(compaction_file(DbName, Sig)).
-
-
-delete_file(FName) ->
-    case filelib:is_file(FName) of
-        true ->
-            RootDir = couch_index_util:root_dir(),
-            couch_file:delete(RootDir, FName);
-        _ ->
-            ok
-    end.
-
-
-reset_index(Db, Fd, #mrst{sig=Sig}=State) ->
-    ok = couch_file:truncate(Fd, 0),
-    ok = couch_file:write_header(Fd, {Sig, nil}),
-    init_state(Db, Fd, reset_state(State), nil).
-
-
-reset_state(State) ->
-    State#mrst{
-        fd=nil,
-        qserver=nil,
-        seq_indexed=State#mrst.seq_indexed,
-        update_seq=0,
-        id_btree=nil,
-        log_btree=nil,
-        views=[View#mrview{btree=nil, seq_btree=nil,
-                           key_byseq_btree=nil,
-                           seq_indexed=View#mrview.seq_indexed}
-               || View <- State#mrst.views]
-    }.
-
-
-all_docs_key_opts(Args) ->
-    all_docs_key_opts(Args, []).
-
-
-all_docs_key_opts(#mrargs{keys=undefined}=Args, Extra) ->
-    all_docs_key_opts(Args#mrargs{keys=[]}, Extra);
-all_docs_key_opts(#mrargs{keys=[], direction=Dir}=Args, Extra) ->
-    [[{dir, Dir}] ++ ad_skey_opts(Args) ++ ad_ekey_opts(Args) ++ Extra];
-all_docs_key_opts(#mrargs{keys=Keys, direction=Dir}=Args, Extra) ->
-    lists:map(fun(K) ->
-        [{dir, Dir}]
-        ++ ad_skey_opts(Args#mrargs{start_key=K})
-        ++ ad_ekey_opts(Args#mrargs{end_key=K})
-        ++ Extra
-    end, Keys).
-
-
-ad_skey_opts(#mrargs{start_key=SKey}) when is_binary(SKey) ->
-    [{start_key, SKey}];
-ad_skey_opts(#mrargs{start_key_docid=SKeyDocId}) ->
-    [{start_key, SKeyDocId}].
-
-
-ad_ekey_opts(#mrargs{end_key=EKey}=Args) when is_binary(EKey) ->
-    Type = if Args#mrargs.inclusive_end -> end_key; true -> end_key_gt end,
-    [{Type, EKey}];
-ad_ekey_opts(#mrargs{end_key_docid=EKeyDocId}=Args) ->
-    Type = if Args#mrargs.inclusive_end -> end_key; true -> end_key_gt end,
-    [{Type, EKeyDocId}].
-
-
-key_opts(Args) ->
-    key_opts(Args, []).
-
-key_opts(#mrargs{keys=undefined, direction=Dir}=Args, Extra) ->
-    [[{dir, Dir}] ++ skey_opts(Args) ++ ekey_opts(Args) ++ Extra];
-key_opts(#mrargs{keys=Keys, direction=Dir}=Args, Extra) ->
-    lists:map(fun(K) ->
-        [{dir, Dir}]
-        ++ skey_opts(Args#mrargs{start_key=K})
-        ++ ekey_opts(Args#mrargs{end_key=K})
-        ++ Extra
-    end, Keys).
-
-
-skey_opts(#mrargs{start_key=undefined}) ->
-    [];
-skey_opts(#mrargs{start_key=SKey, start_key_docid=SKeyDocId}) ->
-    [{start_key, {SKey, SKeyDocId}}].
-
-
-ekey_opts(#mrargs{end_key=undefined}) ->
-    [];
-ekey_opts(#mrargs{end_key=EKey, end_key_docid=EKeyDocId}=Args) ->
-    case Args#mrargs.inclusive_end of
-        true -> [{end_key, {EKey, EKeyDocId}}];
-        false -> [{end_key_gt, {EKey, reverse_key_default(EKeyDocId)}}]
-    end.
-
-
-reverse_key_default(<<>>) -> <<255>>;
-reverse_key_default(<<255>>) -> <<>>;
-reverse_key_default(Key) -> Key.
-
-
-changes_key_opts(StartSeq, Args) ->
-    changes_key_opts(StartSeq, Args, []).
-
-
-changes_key_opts(StartSeq, #mrargs{keys=undefined, direction=Dir}=Args, Extra) ->
-    [[{dir, Dir}] ++ changes_skey_opts(StartSeq, Args) ++
-     changes_ekey_opts(StartSeq, Args) ++ Extra];
-changes_key_opts(StartSeq, #mrargs{keys=Keys, direction=Dir}=Args, Extra) ->
-    lists:map(fun(K) ->
-        [{dir, Dir}]
-        ++ changes_skey_opts(StartSeq, Args#mrargs{start_key=K})
-        ++ changes_ekey_opts(StartSeq, Args#mrargs{end_key=K})
-        ++ Extra
-    end, Keys).
-
-
-changes_skey_opts(StartSeq, #mrargs{start_key=undefined}) ->
-    [{start_key, [<<>>, StartSeq+1]}];
-changes_skey_opts(StartSeq, #mrargs{start_key=SKey,
-                                    start_key_docid=SKeyDocId}) ->
-    [{start_key, {[SKey, StartSeq+1], SKeyDocId}}].
-
-
-changes_ekey_opts(_StartSeq, #mrargs{end_key=undefined}) ->
-    [];
-changes_ekey_opts(_StartSeq, #mrargs{end_key=EKey,
-                                    end_key_docid=EKeyDocId,
-                                    direction=Dir}=Args) ->
-    EndSeq = case Dir of
-        fwd -> 16#10000000;
-        rev -> 0
-    end,
-
-    case Args#mrargs.inclusive_end of
-        true -> [{end_key, {[EKey, EndSeq], EKeyDocId}}];
-        false -> [{end_key_gt, {[EKey, EndSeq], EKeyDocId}}]
-    end.
-
-
-
-calculate_data_size(IdBt, LogBt, Views) ->
-    SumFun = fun
-        (#mrview{btree=Bt, seq_btree=nil}, Acc) ->
-            sum_btree_sizes(Acc, couch_btree:size(Bt));
-        (#mrview{btree=Bt, seq_btree=SBt, key_byseq_btree=KSBt}, Acc) ->
-            Acc1 = sum_btree_sizes(Acc, couch_btree:size(Bt)),
-            Acc2 = sum_btree_sizes(Acc1, couch_btree:size(SBt)),
-            sum_btree_sizes(Acc2, couch_btree:size(KSBt))
-    end,
-    Size = case LogBt of
-        nil ->
-            lists:foldl(SumFun, couch_btree:size(IdBt), Views);
-        _ ->
-            lists:foldl(SumFun, couch_btree:size(IdBt) +
-                        couch_btree:size(LogBt), Views)
-    end,
-    {ok, Size}.
-
-
-sum_btree_sizes(nil, _) ->
-    null;
-sum_btree_sizes(_, nil) ->
-    null;
-sum_btree_sizes(Size1, Size2) ->
-    Size1 + Size2.
-
-
-detuple_kvs([], Acc) ->
-    lists:reverse(Acc);
-detuple_kvs([KV | Rest], Acc) ->
-    {{Key,Id},Value} = KV,
-    NKV = [[Key, Id], Value],
-    detuple_kvs(Rest, [NKV | Acc]).
-
-
-expand_dups([], Acc) ->
-    lists:reverse(Acc);
-expand_dups([{Key, {dups, Vals}} | Rest], Acc) ->
-    Expanded = [{Key, Val} || Val <- Vals],
-    expand_dups(Rest, Expanded ++ Acc);
-expand_dups([KV | Rest], Acc) ->
-    expand_dups(Rest, [KV | Acc]).
-
-
-changes_expand_dups([], Acc) ->
-    lists:reverse(Acc);
-changes_expand_dups([{{[Key, Seq], DocId}, {dups, Vals}} | Rest], Acc) ->
-    Expanded = [{{Seq, Key, DocId}, Val} || Val <- Vals],
-    changes_expand_dups(Rest, Expanded ++ Acc);
-changes_expand_dups([{{Seq, Key}, {DocId, {dups, Vals}}} | Rest], Acc) ->
-    Expanded = [{{Seq, Key, DocId}, Val} || Val <- Vals],
-    changes_expand_dups(Rest, Expanded ++ Acc);
-changes_expand_dups([{{[Key, Seq], DocId}, Val} | Rest], Acc) ->
-    changes_expand_dups(Rest, [{{Seq, Key, DocId}, Val} | Acc]);
-changes_expand_dups([{{Seq, Key}, {DocId, Val}} | Rest], Acc) ->
-    changes_expand_dups(Rest, [{{Seq, Key, DocId}, Val} | Acc]).
-
-maybe_load_doc(_Db, _DI, #mrargs{include_docs=false}) ->
-    [];
-maybe_load_doc(Db, #doc_info{}=DI, #mrargs{conflicts=true, doc_options=Opts}) ->
-    doc_row(couch_index_util:load_doc(Db, DI, [conflicts]), Opts);
-maybe_load_doc(Db, #doc_info{}=DI, #mrargs{doc_options=Opts}) ->
-    doc_row(couch_index_util:load_doc(Db, DI, []), Opts).
-
-
-maybe_load_doc(_Db, _Id, _Val, #mrargs{include_docs=false}) ->
-    [];
-maybe_load_doc(Db, Id, Val, #mrargs{conflicts=true, doc_options=Opts}) ->
-    doc_row(couch_index_util:load_doc(Db, docid_rev(Id, Val), [conflicts]), Opts);
-maybe_load_doc(Db, Id, Val, #mrargs{doc_options=Opts}) ->
-    doc_row(couch_index_util:load_doc(Db, docid_rev(Id, Val), []), Opts).
-
-
-doc_row(null, _Opts) ->
-    [{doc, null}];
-doc_row(Doc, Opts) ->
-    [{doc, couch_doc:to_json_obj(Doc, Opts)}].
-
-
-docid_rev(Id, {Props}) ->
-    DocId = couch_util:get_value(<<"_id">>, Props, Id),
-    Rev = case couch_util:get_value(<<"_rev">>, Props, nil) of
-        nil -> nil;
-        Rev0 -> couch_doc:parse_rev(Rev0)
-    end,
-    {DocId, Rev};
-docid_rev(Id, _) ->
-    {Id, nil}.
-
-
-index_of(Key, List) ->
-    index_of(Key, List, 1).
-
-
-index_of(_, [], _) ->
-    throw({error, missing_named_view});
-index_of(Key, [Key | _], Idx) ->
-    Idx;
-index_of(Key, [_ | Rest], Idx) ->
-    index_of(Key, Rest, Idx+1).
-
-
-mrverror(Mesg) ->
-    throw({query_parse_error, Mesg}).
-
-
-to_key_seq(L) ->
-    [{{[Key, Seq], DocId}, Val} || {{Seq, Key}, {DocId, Val}} <- L].
-
-%% Updates 1.2.x or earlier view files to 1.3.x or later view files
-%% transparently, the first time the 1.2.x view file is opened by
-%% 1.3.x or later.
-%%
-%% Here's how it works:
-%%
-%% Before opening a view index,
-%% If no matching index file is found in the new location:
-%%  calculate the <= 1.2.x view signature
-%%  if a file with that signature lives in the old location
-%%    rename it to the new location with the new signature in the name.
-%% Then proceed to open the view index as usual.
-%% After opening, read its header.
-%%
-%% If the header matches the <= 1.2.x style #index_header record:
-%%   upgrade the header to the new #mrheader record
-%% The next time the view is used, the new header is used.
-%%
-%% If we crash after the rename, but before the header upgrade,
-%%   the header upgrade is done on the next view opening.
-%%
-%% If we crash between upgrading to the new header and writing
-%%   that header to disk, we start with the old header again,
-%%   do the upgrade and write to disk.
-
-maybe_update_index_file(State) ->
-    DbName = State#mrst.db_name,
-    NewIndexFile = index_file(DbName, State#mrst.sig),
-    % open in read-only mode so we don't create
-    % the file if it doesn't exist.
-    case file:open(NewIndexFile, [read, raw]) of
-    {ok, Fd_Read} ->
-        % the new index file exists, there is nothing to do here.
-        file:close(Fd_Read);
-    _Error ->
-        update_index_file(State)
-    end.
-
-update_index_file(State) ->
-    Sig = sig_vsn_12x(State),
-    DbName = State#mrst.db_name,
-    FileName = couch_index_util:hexsig(Sig) ++ ".view",
-    IndexFile = couch_index_util:index_file("", DbName, FileName),
-
-    % If we have an old index, rename it to the new position.
-    case file:read_file_info(IndexFile) of
-    {ok, _FileInfo} ->
-        % Crash if the rename fails for any reason.
-        % If the target exists, e.g. the next request will find the
-        % new file and we are good. We might need to catch this
-        % further up to avoid a full server crash.
-        ?LOG_INFO("Attempting to update legacy view index file.", []),
-        NewIndexFile = index_file(DbName, State#mrst.sig),
-        ok = filelib:ensure_dir(NewIndexFile),
-        ok = file:rename(IndexFile, NewIndexFile),
-        ?LOG_INFO("Successfully updated legacy view index file.", []),
-        Sig;
-    _ ->
-        % Ignore missing index file
-        ok
-    end.
-
-sig_vsn_12x(State) ->
-    ViewInfo = [old_view_format(V) || V <- State#mrst.views],
-    SigData = case State#mrst.lib of
-    {[]} ->
-        {ViewInfo, State#mrst.language, State#mrst.design_opts};
-    _ ->
-        {ViewInfo, State#mrst.language, State#mrst.design_opts,
-            couch_index_util:sort_lib(State#mrst.lib)}
-    end,
-    couch_util:md5(term_to_binary(SigData)).
-
-old_view_format(View) ->
-{
-    view,
-    View#mrview.id_num,
-    View#mrview.map_names,
-    View#mrview.def,
-    View#mrview.btree,
-    View#mrview.reduce_funs,
-    View#mrview.options
-}.
-
-%% End of <= 1.2.x upgrade code.

http://git-wip-us.apache.org/repos/asf/couchdb/blob/75150a18/apps/couch_mrview/test/01-load.t
----------------------------------------------------------------------
diff --git a/apps/couch_mrview/test/01-load.t b/apps/couch_mrview/test/01-load.t
deleted file mode 100644
index cd49785..0000000
--- a/apps/couch_mrview/test/01-load.t
+++ /dev/null
@@ -1,35 +0,0 @@
-#!/usr/bin/env escript
-%% -*- erlang -*-
-%%! -pa ./deps/*/ebin -pa ./apps/*/ebin -pa ./test/etap
-
-% Licensed 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.
-
-% Test that we can load each module.
-
-main(_) ->
-    test_util:init_code_path(),
-    Modules = [
-        couch_mrview,
-        couch_mrview_compactor,
-        couch_mrview_http,
-        couch_mrview_index,
-        couch_mrview_updater,
-        couch_mrview_util
-    ],
-
-    etap:plan(length(Modules)),
-    lists:foreach(
-        fun(Module) ->
-            etap:loaded_ok(Module, lists:concat(["Loaded: ", Module]))
-        end, Modules),
-    etap:end_tests().

http://git-wip-us.apache.org/repos/asf/couchdb/blob/75150a18/apps/couch_mrview/test/02-map-views.t
----------------------------------------------------------------------
diff --git a/apps/couch_mrview/test/02-map-views.t b/apps/couch_mrview/test/02-map-views.t
deleted file mode 100644
index 4f87193..0000000
--- a/apps/couch_mrview/test/02-map-views.t
+++ /dev/null
@@ -1,131 +0,0 @@
-#!/usr/bin/env escript
-%% -*- erlang -*-
-%%! -pa ./deps/*/ebin -pa ./apps/*/ebin -pa ./test/etap
-
-% Licensed 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.
-
-main(_) ->
-    etap:plan(6),
-    case (catch test()) of
-        ok ->
-            etap:end_tests();
-        Other ->
-            etap:diag(io_lib:format("Test died abnormally: ~p", [Other])),
-            etap:bail(Other)
-    end,
-    timer:sleep(300),
-    ok.
-
-test() ->
-    test_util:start_couch(),
-
-    {ok, Db} = couch_mrview_test_util:init_db(<<"foo">>, map),
-
-    test_basic(Db),
-    test_range(Db),
-    test_rev_range(Db),
-    test_limit_and_skip(Db),
-    test_include_docs(Db),
-    test_empty_view(Db),
-
-    test_util:stop_couch(),
-    ok.
-
-
-test_basic(Db) ->
-    Result = run_query(Db, []),
-    Expect = {ok, [
-        {meta, [{total, 10}, {offset, 0}]},
-        {row, [{id, <<"1">>}, {key, 1}, {value, 1}]},
-        {row, [{id, <<"2">>}, {key, 2}, {value, 2}]},
-        {row, [{id, <<"3">>}, {key, 3}, {value, 3}]},
-        {row, [{id, <<"4">>}, {key, 4}, {value, 4}]},
-        {row, [{id, <<"5">>}, {key, 5}, {value, 5}]},
-        {row, [{id, <<"6">>}, {key, 6}, {value, 6}]},
-        {row, [{id, <<"7">>}, {key, 7}, {value, 7}]},
-        {row, [{id, <<"8">>}, {key, 8}, {value, 8}]},
-        {row, [{id, <<"9">>}, {key, 9}, {value, 9}]},
-        {row, [{id, <<"10">>}, {key, 10}, {value, 10}]}
-    ]},
-    etap:is(Result, Expect, "Simple view query worked.").
-
-
-test_range(Db) ->
-    Result = run_query(Db, [{start_key, 3}, {end_key, 5}]),
-    Expect = {ok, [
-        {meta, [{total, 10}, {offset, 2}]},
-        {row, [{id, <<"3">>}, {key, 3}, {value, 3}]},
-        {row, [{id, <<"4">>}, {key, 4}, {value, 4}]},
-        {row, [{id, <<"5">>}, {key, 5}, {value, 5}]}
-    ]},
-    etap:is(Result, Expect, "Query with range works.").
-
-
-test_rev_range(Db) ->
-    Result = run_query(Db, [
-        {direction, rev},
-        {start_key, 5}, {end_key, 3},
-        {inclusive_end, true}
-    ]),
-    Expect = {ok, [
-        {meta, [{total, 10}, {offset, 5}]},
-        {row, [{id, <<"5">>}, {key, 5}, {value, 5}]},
-        {row, [{id, <<"4">>}, {key, 4}, {value, 4}]},
-        {row, [{id, <<"3">>}, {key, 3}, {value, 3}]}
-    ]},
-    etap:is(Result, Expect, "Query with reversed range works.").
-
-
-test_limit_and_skip(Db) ->
-    Result = run_query(Db, [
-        {start_key, 2},
-        {limit, 3},
-        {skip, 3}
-    ]),
-    Expect = {ok, [
-        {meta, [{total, 10}, {offset, 4}]},
-        {row, [{id, <<"5">>}, {key, 5}, {value, 5}]},
-        {row, [{id, <<"6">>}, {key, 6}, {value, 6}]},
-        {row, [{id, <<"7">>}, {key, 7}, {value, 7}]}
-    ]},
-    etap:is(Result, Expect, "Query with limit and skip works.").
-
-
-test_include_docs(Db) ->
-    Result = run_query(Db, [
-        {start_key, 8},
-        {end_key, 8},
-        {include_docs, true}
-    ]),
-    Doc = {[
-        {<<"_id">>,<<"8">>},
-        {<<"_rev">>, <<"1-55b9a29311341e07ec0a7ca13bc1b59f">>},
-        {<<"val">>,8}
-    ]},
-    Expect = {ok, [
-        {meta, [{total, 10}, {offset, 7}]},
-        {row, [{id, <<"8">>}, {key, 8}, {value, 8}, {doc, Doc}]}
-    ]},
-    etap:is(Result, Expect, "Query with include docs works.").
-
-
-test_empty_view(Db) ->
-    Result = couch_mrview:query_view(Db, <<"_design/bar">>, <<"bing">>),
-    Expect = {ok, [
-        {meta, [{total, 0}, {offset, 0}]}
-    ]},
-    etap:is(Result, Expect, "Empty views are correct.").
-
-
-run_query(Db, Opts) ->
-    couch_mrview:query_view(Db, <<"_design/bar">>, <<"baz">>, Opts).

http://git-wip-us.apache.org/repos/asf/couchdb/blob/75150a18/apps/couch_mrview/test/03-red-views.t
----------------------------------------------------------------------
diff --git a/apps/couch_mrview/test/03-red-views.t b/apps/couch_mrview/test/03-red-views.t
deleted file mode 100644
index 594fdfd..0000000
--- a/apps/couch_mrview/test/03-red-views.t
+++ /dev/null
@@ -1,81 +0,0 @@
-#!/usr/bin/env escript
-%% -*- erlang -*-
-%%! -pa ./deps/*/ebin -pa ./apps/*/ebin -pa ./test/etap
-
-
-% Licensed 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.
-
-main(_) ->
-    test_util:run(4, fun() -> test() end).
-
-test() ->
-    test_util:start_couch(),
-
-    {ok, Db} = couch_mrview_test_util:init_db(<<"foo">>, red),
-
-    test_basic(Db),
-    test_key_range(Db),
-    test_group_level(Db),
-    test_group_exact(Db),
-
-    test_util:stop_couch(),
-    ok.
-
-
-test_basic(Db) ->
-    Result = run_query(Db, []),
-    Expect = {ok, [
-        {meta, []},
-        {row, [{key, null}, {value, 55}]}
-    ]},
-    etap:is(Result, Expect, "Simple reduce view works.").
-
-
-test_key_range(Db) ->
-    Result = run_query(Db, [{start_key, [0, 2]}, {end_key, [0, 4]}]),
-    Expect = {ok, [
-        {meta, []},
-        {row, [{key, null}, {value, 6}]}
-    ]},
-    etap:is(Result, Expect, "Reduce with key range works.").
-
-
-test_group_level(Db) ->
-    Result = run_query(Db, [{group_level, 1}]),
-    Expect = {ok, [
-        {meta, []},
-        {row, [{key, [0]}, {value, 30}]},
-        {row, [{key, [1]}, {value, 25}]}
-    ]},
-    etap:is(Result, Expect, "Group level works.").
-
-test_group_exact(Db) ->
-    Result = run_query(Db, [{group_level, exact}]),
-    Expect = {ok, [
-        {meta, []},
-        {row, [{key, [0, 2]}, {value, 2}]},
-        {row, [{key, [0, 4]}, {value, 4}]},
-        {row, [{key, [0, 6]}, {value, 6}]},
-        {row, [{key, [0, 8]}, {value, 8}]},
-        {row, [{key, [0, 10]}, {value, 10}]},
-        {row, [{key, [1, 1]}, {value, 1}]},
-        {row, [{key, [1, 3]}, {value, 3}]},
-        {row, [{key, [1, 5]}, {value, 5}]},
-        {row, [{key, [1, 7]}, {value, 7}]},
-        {row, [{key, [1, 9]}, {value, 9}]}
-    ]},
-    etap:is(Result, Expect, "Group exact works.").
-
-
-run_query(Db, Opts) ->
-    couch_mrview:query_view(Db, <<"_design/bar">>, <<"baz">>, Opts).

http://git-wip-us.apache.org/repos/asf/couchdb/blob/75150a18/apps/couch_mrview/test/04-index-info.t
----------------------------------------------------------------------
diff --git a/apps/couch_mrview/test/04-index-info.t b/apps/couch_mrview/test/04-index-info.t
deleted file mode 100644
index e95db1c..0000000
--- a/apps/couch_mrview/test/04-index-info.t
+++ /dev/null
@@ -1,62 +0,0 @@
-#!/usr/bin/env escript
-%% -*- erlang -*-
-%%! -pa ./deps/*/ebin -pa ./apps/*/ebin -pa ./test/etap
-
-% Licensed 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.
-
-main(_) ->
-    etap:plan(12),
-    case (catch test()) of
-        ok ->
-            etap:end_tests();
-        Other ->
-            etap:diag(io_lib:format("Test died abnormally: ~p", [Other])),
-            etap:bail(Other)
-    end,
-    timer:sleep(300),
-    ok.
-
-sig() -> <<"fdf04ef29c4a471f150acad075bdf47f">>.
-
-test() ->
-    test_util:start_couch(),
-
-    {ok, Db} = couch_mrview_test_util:init_db(<<"foo">>, map),
-    couch_mrview:query_view(Db, <<"_design/bar">>, <<"baz">>),
-
-    {ok, Info} = couch_mrview:get_info(Db, <<"_design/bar">>),
-
-    etap:is(getval(signature, Info), sig(), "Signature is ok."),
-    etap:is(getval(language, Info), <<"javascript">>, "Language is ok."),
-    etap:is_greater(getval(disk_size, Info), 0, "Disk size is ok."),
-    etap:is_greater(getval(data_size, Info), 0, "Data size is ok."),
-    etap:is(getval(update_seq, Info), 11, "Update seq is ok."),
-    etap:is(getval(purge_seq, Info), 0, "Purge seq is ok."),
-    etap:is(getval(updater_running, Info), false, "No updater running."),
-    etap:is(getval(compact_running, Info), false, "No compaction running."),
-    etap:is(getval(waiting_clients, Info), 0, "No waiting clients."),
-
-
-    {ok, ViewInfo} = couch_mrview:get_view_info(Db, <<"_design/bar">>,
-                                           <<"baz">>),
-    etap:is(getval(update_seq, ViewInfo), 11, "View Update seq is ok."),
-    etap:is(getval(purge_seq, ViewInfo), 0, "View Update seq is ok."),
-    etap:is(getval(total_rows, ViewInfo), 10, "View total rows is ok."),
-
-
-    test_util:stop_couch(),
-    ok.
-
-getval(Key, PL) ->
-    {value, {Key, Val}} = lists:keysearch(Key, 1, PL),
-    Val.

http://git-wip-us.apache.org/repos/asf/couchdb/blob/75150a18/apps/couch_mrview/test/05-collation.t
----------------------------------------------------------------------
diff --git a/apps/couch_mrview/test/05-collation.t b/apps/couch_mrview/test/05-collation.t
deleted file mode 100644
index 1ebbe9c..0000000
--- a/apps/couch_mrview/test/05-collation.t
+++ /dev/null
@@ -1,166 +0,0 @@
-#!/usr/bin/env escript
-%% -*- erlang -*-
-%%! -pa ./deps/*/ebin -pa ./apps/*/ebin -pa ./test/etap
-
-% Licensed 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.
-
-main(_) ->
-    test_util:run(9, fun() -> test() end).
-
-
-test() ->
-    test_util:start_couch(),
-
-    {ok, Db0} = couch_mrview_test_util:new_db(<<"foo">>, map),
-    {ok, Db1} = couch_mrview_test_util:save_docs(Db0, docs()),
-
-    test_collated_fwd(Db1),
-    test_collated_rev(Db1),
-    test_range_collation(Db1),
-    test_inclusive_end(Db1),
-    test_uninclusive_end(Db1),
-    test_with_endkey_docid(Db1),
-
-    test_util:stop_couch(),
-    ok.
-
-test_collated_fwd(Db) ->
-    {ok, Results} = run_query(Db, []),
-    Expect = [{meta, [{total, 26}, {offset, 0}]}] ++ rows(),
-    etap:is(Results, Expect, "Values were collated correctly.").
-
-
-test_collated_rev(Db) ->
-    {ok, Results} = run_query(Db, [{direction, rev}]),
-    Expect = [{meta, [{total, 26}, {offset, 0}]}] ++ lists:reverse(rows()),
-    etap:is(Results, Expect, "Values were collated correctly descending.").
-
-
-test_range_collation(Db) ->
-    {_, Error} = lists:foldl(fun(V, {Count, Error}) ->
-        {ok, Results} = run_query(Db, [{start_key, V}, {end_key, V}]),
-        Id = list_to_binary(integer_to_list(Count)),
-        Expect = [
-            {meta, [{total, 26}, {offset, Count}]},
-            {row, [{id, Id}, {key, V}, {value, 0}]}
-        ],
-        case Results == Expect of
-            true -> {Count+1, Error};
-            _ -> {Count+1, true}
-        end
-    end, {0, false}, vals()),
-    etap:is(Error, false, "Found each individual key correctly.").
-
-
-test_inclusive_end(Db) ->
-    Opts = [{end_key, <<"b">>}, {inclusive_end, true}],
-    {ok, Rows0} = run_query(Db, Opts),
-    LastRow0 = lists:last(Rows0),
-    Expect0 = {row, [{id,<<"10">>}, {key,<<"b">>}, {value,0}]},
-    etap:is(LastRow0, Expect0, "Inclusive end is correct."),
-
-    {ok, Rows1} = run_query(Db, Opts ++ [{direction, rev}]),
-    LastRow1 = lists:last(Rows1),
-    Expect1 = {row, [{id,<<"10">>}, {key,<<"b">>}, {value,0}]},
-    etap:is(LastRow1, Expect1,
-            "Inclusive end is correct with descending=true").
-
-test_uninclusive_end(Db) ->
-    Opts = [{end_key, <<"b">>}, {inclusive_end, false}],
-    {ok, Rows0} = run_query(Db, Opts),
-    LastRow0 = lists:last(Rows0),
-    Expect0 = {row, [{id,<<"9">>}, {key,<<"aa">>}, {value,0}]},
-    etap:is(LastRow0, Expect0, "Uninclusive end is correct."),
-
-    {ok, Rows1} = run_query(Db, Opts ++ [{direction, rev}]),
-    LastRow1 = lists:last(Rows1),
-    Expect1 = {row, [{id,<<"11">>}, {key,<<"B">>}, {value,0}]},
-    etap:is(LastRow1, Expect1,
-            "Uninclusive end is correct with descending=true").
-
-
-test_with_endkey_docid(Db) ->
-    {ok, Rows0} = run_query(Db, [
-        {end_key, <<"b">>}, {end_key_docid, <<"10">>},
-        {inclusive_end, false}
-    ]),
-    Result0 = lists:last(Rows0),
-    Expect0 = {row, [{id,<<"9">>}, {key,<<"aa">>}, {value,0}]},
-    etap:is(Result0, Expect0, "Uninclsuive end with endkey_docid set is ok."),
-
-    {ok, Rows1} = run_query(Db, [
-        {end_key, <<"b">>}, {end_key_docid, <<"11">>},
-        {inclusive_end, false}
-    ]),
-    Result1 = lists:last(Rows1),
-    Expect1 = {row, [{id,<<"10">>}, {key,<<"b">>}, {value,0}]},
-    etap:is(Result1, Expect1, "Uninclsuive end with endkey_docid set is ok.").
-
-
-run_query(Db, Opts) ->
-    couch_mrview:query_view(Db, <<"_design/bar">>, <<"zing">>, Opts).
-
-
-docs() ->
-    {Docs, _} = lists:foldl(fun(V, {Docs0, Count}) ->
-        Doc = couch_doc:from_json_obj({[
-            {<<"_id">>, list_to_binary(integer_to_list(Count))},
-            {<<"foo">>, V}
-        ]}),
-        {[Doc | Docs0], Count+1}
-    end, {[], 0}, vals()),
-    Docs.
-
-
-rows() ->
-    {Rows, _} = lists:foldl(fun(V, {Rows0, Count}) ->
-        Id = list_to_binary(integer_to_list(Count)),
-        Row = {row, [{id, Id}, {key, V}, {value, 0}]},
-        {[Row | Rows0], Count+1}
-    end, {[], 0}, vals()),
-    lists:reverse(Rows).
-
-
-vals() ->
-    [
-        null,
-        false,
-        true,
-
-        1,
-        2,
-        3.0,
-        4,
-
-        <<"a">>,
-        <<"A">>,
-        <<"aa">>,
-        <<"b">>,
-        <<"B">>,
-        <<"ba">>,
-        <<"bb">>,
-
-        [<<"a">>],
-        [<<"b">>],
-        [<<"b">>, <<"c">>],
-        [<<"b">>, <<"c">>, <<"a">>],
-        [<<"b">>, <<"d">>],
-        [<<"b">>, <<"d">>, <<"e">>],
-
-        {[{<<"a">>, 1}]},
-        {[{<<"a">>, 2}]},
-        {[{<<"b">>, 1}]},
-        {[{<<"b">>, 2}]},
-        {[{<<"b">>, 2}, {<<"a">>, 1}]},
-        {[{<<"b">>, 2}, {<<"c">>, 2}]}
-    ].

http://git-wip-us.apache.org/repos/asf/couchdb/blob/75150a18/apps/couch_mrview/test/06-all-docs.t
----------------------------------------------------------------------
diff --git a/apps/couch_mrview/test/06-all-docs.t b/apps/couch_mrview/test/06-all-docs.t
deleted file mode 100644
index 0916568..0000000
--- a/apps/couch_mrview/test/06-all-docs.t
+++ /dev/null
@@ -1,129 +0,0 @@
-#!/usr/bin/env escript
-%% -*- erlang -*-
-%%! -pa ./deps/*/ebin -pa ./apps/*/ebin -pa ./test/etap
-
-% Licensed 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.
-
-main(_) ->
-    test_util:run(6, fun() -> test() end).
-
-
-test() ->
-    test_util:start_couch(),
-
-    {ok, Db} = couch_mrview_test_util:init_db(<<"foo">>, map),
-
-    test_basic(Db),
-    test_range(Db),
-    test_rev_range(Db),
-    test_limit_and_skip(Db),
-    test_include_docs(Db),
-    test_empty_view(Db),
-
-    test_util:stop_couch(),
-    ok.
-
-
-test_basic(Db) ->
-    Result = run_query(Db, []),
-    Expect = {ok, [
-        {meta, [{total, 11}, {offset, 0}]},
-        mk_row(<<"1">>, <<"1-08d53a5760b95fce6df2e2c5b008be39">>),
-        mk_row(<<"10">>, <<"1-a05b6ea2bc0243949f103d5b4f15f71e">>),
-        mk_row(<<"2">>, <<"1-b57c77a9e6f7574ca6469f0d6dcd78bb">>),
-        mk_row(<<"3">>, <<"1-7fbf84d56f8017880974402d60f5acd6">>),
-        mk_row(<<"4">>, <<"1-fcaf5852c08ffb239ac8ce16c409f253">>),
-        mk_row(<<"5">>, <<"1-aaac5d460fd40f9286e57b9bf12e23d2">>),
-        mk_row(<<"6">>, <<"1-aca21c2e7bc5f8951424fcfc5d1209d8">>),
-        mk_row(<<"7">>, <<"1-4374aeec17590d82f16e70f318116ad9">>),
-        mk_row(<<"8">>, <<"1-55b9a29311341e07ec0a7ca13bc1b59f">>),
-        mk_row(<<"9">>, <<"1-558c8487d9aee25399a91b5d31d90fe2">>),
-        mk_row(<<"_design/bar">>, <<"1-a44e1dd1994a7717bf89c894ebd1f081">>)
-    ]},
-    etap:is(Result, Expect, "Simple view query worked.").
-
-
-test_range(Db) ->
-    Result = run_query(Db, [{start_key, <<"3">>}, {end_key, <<"5">>}]),
-    Expect = {ok, [
-        {meta, [{total, 11}, {offset, 3}]},
-        mk_row(<<"3">>, <<"1-7fbf84d56f8017880974402d60f5acd6">>),
-        mk_row(<<"4">>, <<"1-fcaf5852c08ffb239ac8ce16c409f253">>),
-        mk_row(<<"5">>, <<"1-aaac5d460fd40f9286e57b9bf12e23d2">>)
-    ]},
-    etap:is(Result, Expect, "Query with range works.").
-
-
-test_rev_range(Db) ->
-    Result = run_query(Db, [
-        {direction, rev},
-        {start_key, <<"5">>}, {end_key, <<"3">>},
-        {inclusive_end, true}
-    ]),
-    Expect = {ok, [
-        {meta, [{total, 11}, {offset, 5}]},
-        mk_row(<<"5">>, <<"1-aaac5d460fd40f9286e57b9bf12e23d2">>),
-        mk_row(<<"4">>, <<"1-fcaf5852c08ffb239ac8ce16c409f253">>),
-        mk_row(<<"3">>, <<"1-7fbf84d56f8017880974402d60f5acd6">>)
-    ]},
-    etap:is(Result, Expect, "Query with reversed range works.").
-
-
-test_limit_and_skip(Db) ->
-    Result = run_query(Db, [
-        {start_key, <<"2">>},
-        {limit, 3},
-        {skip, 3}
-    ]),
-    Expect = {ok, [
-        {meta, [{total, 11}, {offset, 5}]},
-        mk_row(<<"5">>, <<"1-aaac5d460fd40f9286e57b9bf12e23d2">>),
-        mk_row(<<"6">>, <<"1-aca21c2e7bc5f8951424fcfc5d1209d8">>),
-        mk_row(<<"7">>, <<"1-4374aeec17590d82f16e70f318116ad9">>)
-    ]},
-    etap:is(Result, Expect, "Query with limit and skip works.").
-
-
-test_include_docs(Db) ->
-    Result = run_query(Db, [
-        {start_key, <<"8">>},
-        {end_key, <<"8">>},
-        {include_docs, true}
-    ]),
-    Doc = {[
-        {<<"_id">>,<<"8">>},
-        {<<"_rev">>, <<"1-55b9a29311341e07ec0a7ca13bc1b59f">>},
-        {<<"val">>, 8}
-    ]},
-    Val = {[{rev, <<"1-55b9a29311341e07ec0a7ca13bc1b59f">>}]},
-    Expect = {ok, [
-        {meta, [{total, 11}, {offset, 8}]},
-        {row, [{id, <<"8">>}, {key, <<"8">>}, {value, Val}, {doc, Doc}]}
-    ]},
-    etap:is(Result, Expect, "Query with include docs works.").
-
-
-test_empty_view(Db) ->
-    Result = couch_mrview:query_view(Db, <<"_design/bar">>, <<"bing">>),
-    Expect = {ok, [
-        {meta, [{total, 0}, {offset, 0}]}
-    ]},
-    etap:is(Result, Expect, "Empty views are correct.").
-
-
-mk_row(Id, Rev) ->
-    {row, [{id, Id}, {key, Id}, {value, {[{rev, Rev}]}}]}.
-
-
-run_query(Db, Opts) ->
-    couch_mrview:query_all_docs(Db, Opts).

http://git-wip-us.apache.org/repos/asf/couchdb/blob/75150a18/apps/couch_mrview/test/07-compact-swap.t
----------------------------------------------------------------------
diff --git a/apps/couch_mrview/test/07-compact-swap.t b/apps/couch_mrview/test/07-compact-swap.t
deleted file mode 100644
index ba8e438..0000000
--- a/apps/couch_mrview/test/07-compact-swap.t
+++ /dev/null
@@ -1,62 +0,0 @@
-#!/usr/bin/env escript
-%% -*- erlang -*-
-%%! -pa ./deps/*/ebin -pa ./apps/*/ebin -pa ./test/etap
-
-
-% Licensed 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.
-
-main(_) ->
-    test_util:run(1, fun() -> test() end).
-
-
-test() ->
-    test_util:start_couch(),
-
-    {ok, Db} = couch_mrview_test_util:init_db(<<"foo">>, map, 1000),
-    couch_mrview:query_view(Db, <<"_design/bar">>, <<"baz">>),
-    test_swap(Db),
-
-    test_util:stop_couch(),
-    ok.
-
-
-test_swap(Db) ->
-    {ok, QPid} = start_query(Db),
-    {ok, MonRef} = couch_mrview:compact(Db, <<"_design/bar">>, [monitor]),
-    receive
-        {'DOWN', MonRef, process, _, _} -> ok
-    after 1000 ->
-        throw(compaction_failed)
-    end,
-    QPid ! {self(), continue},
-    receive
-        {QPid, Count} ->
-            etap:is(Count, 1000, "View finished successfully.")
-    after 1000 ->
-        throw("query failed")
-    end.
-
-
-start_query(Db) ->
-    Self = self(),
-    Pid = spawn(fun() ->
-        CB = fun
-            (_, wait) -> receive {Self, continue} -> {ok, 0} end;
-            ({row, _}, Count) -> {ok, Count+1};
-            (_, Count) -> {ok, Count}
-        end,
-        {ok, Result} =
-        couch_mrview:query_view(Db, <<"_design/bar">>, <<"baz">>, [], CB, wait),
-        Self ! {self(), Result}
-    end),
-    {ok, Pid}.

http://git-wip-us.apache.org/repos/asf/couchdb/blob/75150a18/apps/couch_mrview/test/08-changes_since.t
----------------------------------------------------------------------
diff --git a/apps/couch_mrview/test/08-changes_since.t b/apps/couch_mrview/test/08-changes_since.t
deleted file mode 100644
index 58c92e9..0000000
--- a/apps/couch_mrview/test/08-changes_since.t
+++ /dev/null
@@ -1,157 +0,0 @@
-#!/usr/bin/env escript
-%% -*- erlang -*-
-%%! -pa ./deps/*/ebin -pa ./apps/*/ebin -pa ./test/etap
-
-% Licensed 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.
-
-main(_) ->
-    etap:plan(14),
-    case (catch test()) of
-        ok ->
-            etap:end_tests();
-        Other ->
-            etap:diag(io_lib:format("Test died abnormally: ~p", [Other])),
-            etap:bail(Other)
-    end,
-    timer:sleep(300),
-    ok.
-
-test() ->
-    test_util:start_couch(),
-
-    {ok, Db} = couch_mrview_test_util:init_db(<<"foo">>, changes),
-
-    test_basic(Db),
-    test_range(Db),
-    test_basic_since(Db),
-    test_range_since(Db),
-    test_basic_count(Db),
-    test_range_count(Db),
-    test_basic_count_since(Db),
-    test_range_count_since(Db),
-    test_compact(Db),
-    test_remove_key(Db),
-    catch test_util:stop_couch(),
-    ok.
-
-
-test_basic(Db) ->
-    Result = run_query(Db, 0, []),
-    Expect = {ok, [
-                {{2, 1, <<"1">>}, 1},
-                {{3, 10, <<"10">>}, 10},
-                {{4, 2, <<"2">>}, 2},
-                {{5, 3, <<"3">>}, 3},
-                {{6, 4, <<"4">>}, 4},
-                {{7, 5, <<"5">>}, 5},
-                {{8, 6, <<"6">>}, 6},
-                {{9, 7, <<"7">>}, 7},
-                {{10, 8, <<"8">>}, 8},
-                {{11, 9, <<"9">>}, 9}
-    ]},
-    etap:is(Result, Expect, "Simple view query worked.").
-
-
-test_range(Db) ->
-    Result = run_query(Db, 0, [{start_key, 3}, {end_key, 5}]),
-    Expect = {ok, [
-                {{5, 3, <<"3">>}, 3},
-                {{6, 4, <<"4">>}, 4},
-                {{7, 5, <<"5">>}, 5}
-    ]},
-    etap:is(Result, Expect, "Query with range works.").
-
-test_basic_since(Db) ->
-    Result = run_query(Db, 5, []),
-    Expect = {ok, [
-                {{6, 4, <<"4">>}, 4},
-                {{7, 5, <<"5">>}, 5},
-                {{8, 6, <<"6">>}, 6},
-                {{9, 7, <<"7">>}, 7},
-                {{10, 8, <<"8">>}, 8},
-                {{11, 9, <<"9">>}, 9}
-    ]},
-    etap:is(Result, Expect, "Simple view query since 5 worked.").
-
-test_range_since(Db) ->
-    Result = run_query(Db, 5, [{start_key, 3}, {end_key, 5}]),
-    Expect = {ok, [
-                {{6, 4, <<"4">>}, 4},
-                {{7, 5, <<"5">>}, 5}
-    ]},
-    etap:is(Result, Expect, "Query with range since 5 works.").
-
-test_basic_count(Db) ->
-    Result = run_count_query(Db, 0, []),
-    etap:is(Result, 10, "Simple view count worked.").
-
-test_range_count(Db) ->
-    Result = run_count_query(Db, 0, [{start_key, 3}, {end_key, 5}]),
-    etap:is(Result, 3, "Count with range works.").
-
-test_basic_count_since(Db) ->
-    Result = run_count_query(Db, 5, []),
-    etap:is(Result, 6, "Simple view count since 5 worked.").
-
-test_range_count_since(Db) ->
-    Result = run_count_query(Db, 5, [{start_key, 3}, {end_key, 5}]),
-    etap:is(Result, 2, "Count with range since 5 works.").
-
-test_compact(Db) ->
-    Result = couch_mrview:compact(Db, <<"_design/bar">>),
-    etap:is(Result, ok, "compact view is OK"),
-    Count = run_count_query(Db, 0, []),
-    etap:is(Count, 10, "compact view worked.").
-
-test_remove_key(Db) ->
-    %% add new doc
-    Doc = couch_mrview_test_util:doc(11),
-    {ok, Rev} = couch_db:update_doc(Db, Doc, []),
-    RevStr = couch_doc:rev_to_str(Rev),
-    {ok, _} =  couch_db:ensure_full_commit(Db),
-    {ok, Db1} = couch_db:reopen(Db),
-    Result = run_count_query(Db1, 0, []),
-    etap:is(Result, 11, "Add new doc worked."),
-    %% check new view key
-    Result1 = run_query(Db1, 0, [{start_key, 11}, {end_key, 11}]),
-    Expect = {ok, [
-                {{12, 11, <<"11">>}, 11}
-    ]},
-    etap:is(Result1, Expect, "added key OK."),
-
-    %% delete doc
-    Doc2 = couch_doc:from_json_obj({[
-                {<<"_id">>, <<"11">>},
-                {<<"_rev">>, RevStr},
-                {<<"_deleted">>, true}
-    ]}),
-    {ok, _} = couch_db:update_doc(Db1, Doc2, []),
-    {ok, Db2} = couch_db:reopen(Db1),
-    Result2 = run_count_query(Db2, 0, []),
-    etap:is(Result2, 11, "removed key saved."),
-    %% check new view key
-    Result3 = run_query(Db2, 0, [{start_key, 11}, {end_key, 11}]),
-    Expect2 = {ok, [
-                {{13, 11, <<"11">>}, {[{<<"_removed">>, true}]}}
-    ]},
-    etap:is(Result3, Expect2, "removed key OK.").
-
-run_query(Db, Since, Opts) ->
-    Fun = fun(KV, Acc) -> {ok, [KV | Acc]} end,
-    {ok, R} = couch_mrview:view_changes_since(Db, <<"_design/bar">>, <<"baz">>,
-                                              Since, Fun, Opts, []),
-    {ok, lists:reverse(R)}.
-
-run_count_query(Db, Since, Opts) ->
-    couch_mrview:count_view_changes_since(Db, <<"_design/bar">>, <<"baz">>,
-                                          Since, Opts).

http://git-wip-us.apache.org/repos/asf/couchdb/blob/75150a18/apps/couch_mrview/test/09-index-events.t
----------------------------------------------------------------------
diff --git a/apps/couch_mrview/test/09-index-events.t b/apps/couch_mrview/test/09-index-events.t
deleted file mode 100644
index 6cc1e9c..0000000
--- a/apps/couch_mrview/test/09-index-events.t
+++ /dev/null
@@ -1,74 +0,0 @@
-#!/usr/bin/env escript
-%% -*- erlang -*-
-%%! -pa ./deps/*/ebin -pa ./apps/*/ebin -pa ./test/etap
-
-% Licensed 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.
-
-main(_) ->
-    etap:plan(5),
-    case (catch test()) of
-        ok ->
-            etap:end_tests();
-        Other ->
-            etap:diag(io_lib:format("Test died abnormally: ~p", [Other])),
-            etap:bail(Other)
-    end,
-    timer:sleep(300),
-    ok.
-
-test() ->
-    test_util:start_couch(),
-    {ok, Db} = couch_mrview_test_util:init_db(<<"foo">>, changes),
-    test_info(Db),
-    test_update_event(Db),
-    test_delete_event(Db),
-    test_util:stop_couch(),
-    ok.
-
-test_info(Db) ->
-    {ok, Info} = couch_mrview:get_info(Db, <<"_design/bar">>),
-    etap:is(getval(update_options, Info), [<<"seq_indexed">>],
-            "update options OK"),
-    ok.
-
-test_update_event(Db) ->
-    {ok, Pid} = couch_index_event:start_link(self()),
-    etap:ok(is_pid(Pid), "event handler added"),
-    ok = couch_mrview:refresh(Db, <<"_design/bar">>),
-    Expect = {index_update, {<<"foo">>, <<"_design/bar">>,
-                             couch_mrview_index}},
-    receive
-        Event ->
-            etap:is(Event, Expect, "index update events OK")
-    end,
-    couch_index_event:stop(Pid).
-
-test_delete_event(Db) ->
-    ok = couch_mrview:refresh(Db, <<"_design/bar">>),
-    timer:sleep(300),
-    {ok, Pid} = couch_index_event:start_link(self()),
-    etap:ok(is_pid(Pid), "delete event handler added"),
-
-
-    catch couch_mrview_test_util:delete_db(<<"foo">>),
-    Expect = {index_delete, {<<"foo">>, <<"_design/bar">>,
-                             couch_mrview_index}},
-    receive
-        Event ->
-            etap:is(Event, Expect, "index delete events OK")
-    end,
-    couch_index_event:stop(Pid).
-
-getval(Key, PL) ->
-    {value, {Key, Val}} = lists:keysearch(Key, 1, PL),
-    Val.


[52/57] [abbrv] remove couch_httpd

Posted by be...@apache.org.
http://git-wip-us.apache.org/repos/asf/couchdb/blob/c0855434/apps/couch_httpd/src/couch_httpd_oauth.erl
----------------------------------------------------------------------
diff --git a/apps/couch_httpd/src/couch_httpd_oauth.erl b/apps/couch_httpd/src/couch_httpd_oauth.erl
deleted file mode 100644
index 07229d3..0000000
--- a/apps/couch_httpd/src/couch_httpd_oauth.erl
+++ /dev/null
@@ -1,387 +0,0 @@
-% Licensed 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.
-
--module(couch_httpd_oauth).
-
--include_lib("couch/include/couch_db.hrl").
--include_lib("couch/include/couch_js_functions.hrl").
-
--export([oauth_authentication_handler/1, handle_oauth_req/1]).
-
--define(OAUTH_DDOC_ID, <<"_design/oauth">>).
--define(OAUTH_VIEW_NAME, <<"oauth_credentials">>).
-
--record(callback_params, {
-    consumer,
-    token,
-    token_secret,
-    url,
-    signature,
-    params,
-    username
-}).
-
-% OAuth auth handler using per-node user db
-oauth_authentication_handler(Req) ->
-    serve_oauth(Req, fun oauth_auth_callback/2, true).
-
-
-oauth_auth_callback(Req, #callback_params{token_secret = undefined}) ->
-    couch_httpd:send_error(
-         Req, 400, <<"invalid_token">>, <<"Invalid OAuth token.">>);
-
-oauth_auth_callback(#httpd{mochi_req = MochiReq} = Req, CbParams) ->
-    Method = atom_to_list(MochiReq:get(method)),
-    #callback_params{
-        consumer = Consumer,
-        token_secret = TokenSecret,
-        url = Url,
-        signature = Sig,
-        params = Params,
-        username = User
-    } = CbParams,
-    case oauth:verify(Sig, Method, Url, Params, Consumer, TokenSecret) of
-    true ->
-        set_user_ctx(Req, User);
-    false ->
-        ?LOG_DEBUG("OAuth handler: signature verification failed for user `~p`~n"
-            "Received signature is `~p`~n"
-            "HTTP method is `~p`~n"
-            "URL is `~p`~n"
-            "Parameters are `~p`~n"
-            "Consumer is `~p`, token secret is `~p`~n"
-            "Expected signature was `~p`~n",
-            [User, Sig, Method, Url, Params, Consumer, TokenSecret,
-                oauth:signature(Method, Url, Params, Consumer, TokenSecret)]),
-        Req
-    end.
-
-
-% Look up the consumer key and get the roles to give the consumer
-set_user_ctx(_Req, undefined) ->
-    throw({bad_request, unknown_oauth_token});
-set_user_ctx(Req, Name) ->
-    case couch_auth_cache:get_user_creds(Name) of
-        nil ->
-            ?LOG_DEBUG("OAuth handler: user `~p` credentials not found", [Name]),
-            Req;
-        User ->
-            Roles = couch_util:get_value(<<"roles">>, User, []),
-            Req#httpd{user_ctx=#user_ctx{name=Name, roles=Roles}}
-    end.
-
-% OAuth request_token
-handle_oauth_req(#httpd{path_parts=[_OAuth, <<"request_token">>], method=Method}=Req1) ->
-    serve_oauth(Req1, fun(Req, CbParams) ->
-        #callback_params{
-            consumer = Consumer,
-            token_secret = TokenSecret,
-            url = Url,
-            signature = Sig,
-            params = Params
-        } = CbParams,
-        case oauth:verify(
-            Sig, atom_to_list(Method), Url, Params, Consumer, TokenSecret) of
-        true ->
-            ok(Req, <<"oauth_token=requestkey&oauth_token_secret=requestsecret">>);
-        false ->
-            invalid_signature(Req)
-        end
-    end, false);
-handle_oauth_req(#httpd{path_parts=[_OAuth, <<"authorize">>]}=Req) ->
-    {ok, serve_oauth_authorize(Req)};
-handle_oauth_req(#httpd{path_parts=[_OAuth, <<"access_token">>], method='GET'}=Req1) ->
-    serve_oauth(Req1, fun(Req, CbParams) ->
-        #callback_params{
-            consumer = Consumer,
-            token = Token,
-            url = Url,
-            signature = Sig,
-            params = Params
-        } = CbParams,
-        case Token of
-        "requestkey" ->
-            case oauth:verify(
-                Sig, "GET", Url, Params, Consumer, "requestsecret") of
-            true ->
-                ok(Req,
-                    <<"oauth_token=accesskey&oauth_token_secret=accesssecret">>);
-            false ->
-                invalid_signature(Req)
-            end;
-        _ ->
-            couch_httpd:send_error(
-                Req, 400, <<"invalid_token">>, <<"Invalid OAuth token.">>)
-        end
-    end, false);
-handle_oauth_req(#httpd{path_parts=[_OAuth, <<"access_token">>]}=Req) ->
-    couch_httpd:send_method_not_allowed(Req, "GET").
-
-invalid_signature(Req) ->
-    couch_httpd:send_error(Req, 400, <<"invalid_signature">>, <<"Invalid signature value.">>).
-
-% This needs to be protected i.e. force user to login using HTTP Basic Auth or form-based login.
-serve_oauth_authorize(#httpd{method=Method}=Req1) ->
-    case Method of
-        'GET' ->
-            % Confirm with the User that they want to authenticate the Consumer
-            serve_oauth(Req1, fun(Req, CbParams) ->
-                #callback_params{
-                    consumer = Consumer,
-                    token_secret = TokenSecret,
-                    url = Url,
-                    signature = Sig,
-                    params = Params
-                } = CbParams,
-                case oauth:verify(
-                    Sig, "GET", Url, Params, Consumer, TokenSecret) of
-                true ->
-                    ok(Req, <<"oauth_token=requestkey&",
-                        "oauth_token_secret=requestsecret">>);
-                false ->
-                    invalid_signature(Req)
-                end
-            end, false);
-        'POST' ->
-            % If the User has confirmed, we direct the User back to the Consumer with a verification code
-            serve_oauth(Req1, fun(Req, CbParams) ->
-                #callback_params{
-                    consumer = Consumer,
-                    token_secret = TokenSecret,
-                    url = Url,
-                    signature = Sig,
-                    params = Params
-                } = CbParams,
-                case oauth:verify(
-                    Sig, "POST", Url, Params, Consumer, TokenSecret) of
-                true ->
-                    %redirect(oauth_callback, oauth_token, oauth_verifier),
-                    ok(Req, <<"oauth_token=requestkey&",
-                        "oauth_token_secret=requestsecret">>);
-                false ->
-                    invalid_signature(Req)
-                end
-            end, false);
-        _ ->
-            couch_httpd:send_method_not_allowed(Req1, "GET,POST")
-    end.
-
-serve_oauth(#httpd{mochi_req=MochiReq}=Req, Fun, FailSilently) ->
-    % 1. In the HTTP Authorization header as defined in OAuth HTTP Authorization Scheme.
-    % 2. As the HTTP POST request body with a content-type of application/x-www-form-urlencoded.
-    % 3. Added to the URLs in the query part (as defined by [RFC3986] section 3).
-    AuthHeader = case MochiReq:get_header_value("authorization") of
-        undefined ->
-            "";
-        Else ->
-            [Head | Tail] = re:split(Else, "\\s", [{parts, 2}, {return, list}]),
-            case [string:to_lower(Head) | Tail] of
-                ["oauth", Rest] -> Rest;
-                _ -> ""
-            end
-    end,
-    HeaderParams = oauth:header_params_decode(AuthHeader),
-    %Realm = couch_util:get_value("realm", HeaderParams),
-
-    % get requested path
-    RequestedPath = case MochiReq:get_header_value("x-couchdb-requested-path") of
-        undefined ->
-            case MochiReq:get_header_value("x-couchdb-vhost-path") of
-                undefined ->
-                    MochiReq:get(raw_path);
-                VHostPath ->
-                    VHostPath
-            end;
-        RequestedPath0 ->
-           RequestedPath0
-    end,
-    {_, QueryString, _} = mochiweb_util:urlsplit_path(RequestedPath),
-
-    Params = proplists:delete("realm", HeaderParams) ++ mochiweb_util:parse_qs(QueryString),
-
-    ?LOG_DEBUG("OAuth Params: ~p", [Params]),
-    case couch_util:get_value("oauth_version", Params, "1.0") of
-        "1.0" ->
-            case couch_util:get_value("oauth_consumer_key", Params, undefined) of
-                undefined ->
-                    case FailSilently of
-                        true -> Req;
-                        false -> couch_httpd:send_error(Req, 400, <<"invalid_consumer">>, <<"Invalid consumer.">>)
-                    end;
-                ConsumerKey ->
-                    Url = couch_httpd:absolute_uri(Req, RequestedPath),
-                    case get_callback_params(ConsumerKey, Params, Url) of
-                        {ok, CallbackParams} ->
-                            Fun(Req, CallbackParams);
-                        invalid_consumer_token_pair ->
-                            couch_httpd:send_error(
-                                Req, 400,
-                                <<"invalid_consumer_token_pair">>,
-                                <<"Invalid consumer and token pair.">>);
-                        {error, {Error, Reason}} ->
-                            couch_httpd:send_error(Req, 400, Error, Reason)
-                    end
-            end;
-        _ ->
-            couch_httpd:send_error(Req, 400, <<"invalid_oauth_version">>, <<"Invalid OAuth version.">>)
-    end.
-
-
-get_callback_params(ConsumerKey, Params, Url) ->
-    Token = couch_util:get_value("oauth_token", Params),
-    SigMethod = sig_method(Params),
-    CbParams0 = #callback_params{
-        token = Token,
-        signature = couch_util:get_value("oauth_signature", Params),
-        params = proplists:delete("oauth_signature", Params),
-        url = Url
-    },
-    case oauth_credentials_info(Token, ConsumerKey) of
-    nil ->
-        invalid_consumer_token_pair;
-    {error, _} = Err ->
-        Err;
-    {OauthCreds} ->
-        User = couch_util:get_value(<<"username">>, OauthCreds, []),
-        ConsumerSecret = ?b2l(couch_util:get_value(
-            <<"consumer_secret">>, OauthCreds, <<>>)),
-        TokenSecret = ?b2l(couch_util:get_value(
-            <<"token_secret">>, OauthCreds, <<>>)),
-        case (User =:= []) orelse (ConsumerSecret =:= []) orelse
-            (TokenSecret =:= []) of
-        true ->
-            invalid_consumer_token_pair;
-        false ->
-            CbParams = CbParams0#callback_params{
-                consumer = {ConsumerKey, ConsumerSecret, SigMethod},
-                token_secret = TokenSecret,
-                username = User
-            },
-            ?LOG_DEBUG("Got OAuth credentials, for ConsumerKey `~p` and "
-                "Token `~p`, from the views, User: `~p`, "
-                "ConsumerSecret: `~p`, TokenSecret: `~p`",
-                [ConsumerKey, Token, User, ConsumerSecret, TokenSecret]),
-            {ok, CbParams}
-        end
-    end.
-
-
-sig_method(Params) ->
-    sig_method_1(couch_util:get_value("oauth_signature_method", Params)).
-sig_method_1("PLAINTEXT") ->
-    plaintext;
-% sig_method_1("RSA-SHA1") ->
-%    rsa_sha1;
-sig_method_1("HMAC-SHA1") ->
-    hmac_sha1;
-sig_method_1(_) ->
-    undefined.
-
-
-ok(#httpd{mochi_req=MochiReq}, Body) ->
-    {ok, MochiReq:respond({200, [], Body})}.
-
-
-oauth_credentials_info(Token, ConsumerKey) ->
-    case use_auth_db() of
-    {ok, Db} ->
-        Result = case query_oauth_view(Db, [?l2b(ConsumerKey), ?l2b(Token)]) of
-        [] ->
-            nil;
-        [Creds] ->
-            Creds;
-        [_ | _] ->
-            Reason = iolist_to_binary(
-                io_lib:format("Found multiple OAuth credentials for the pair "
-                    " (consumer_key: `~p`, token: `~p`)", [ConsumerKey, Token])),
-            {error, {<<"oauth_token_consumer_key_pair">>, Reason}}
-        end,
-        couch_db:close(Db),
-        Result;
-    nil ->
-        {
-            case couch_config:get("oauth_consumer_secrets", ConsumerKey) of
-            undefined -> [];
-            ConsumerSecret -> [{<<"consumer_secret">>, ?l2b(ConsumerSecret)}]
-            end
-            ++
-            case couch_config:get("oauth_token_secrets", Token) of
-            undefined -> [];
-            TokenSecret -> [{<<"token_secret">>, ?l2b(TokenSecret)}]
-            end
-            ++
-            case couch_config:get("oauth_token_users", Token) of
-            undefined -> [];
-            User -> [{<<"username">>, ?l2b(User)}]
-            end
-        }
-    end.
-
-
-use_auth_db() ->
-    case couch_config:get("couch_httpd_oauth", "use_users_db", "false") of
-    "false" ->
-        nil;
-    "true" ->
-        AuthDb = open_auth_db(),
-        {ok, _AuthDb2} = ensure_oauth_views_exist(AuthDb)
-    end.
-
-
-open_auth_db() ->
-    DbName = ?l2b(couch_config:get("couch_httpd_auth", "authentication_db")),
-    DbOptions = [{user_ctx, #user_ctx{roles = [<<"_admin">>]}}],
-    {ok, AuthDb} = couch_db:open_int(DbName, DbOptions),
-    AuthDb.
-
-
-ensure_oauth_views_exist(AuthDb) ->
-    case couch_db:open_doc(AuthDb, ?OAUTH_DDOC_ID, []) of
-    {ok, _DDoc} ->
-        {ok, AuthDb};
-    _ ->
-        {ok, DDoc} = get_oauth_ddoc(),
-        {ok, _Rev} = couch_db:update_doc(AuthDb, DDoc, []),
-        {ok, _AuthDb2} = couch_db:reopen(AuthDb)
-    end.
-
-
-get_oauth_ddoc() ->
-    Json = {[
-        {<<"_id">>, ?OAUTH_DDOC_ID},
-        {<<"language">>, <<"javascript">>},
-        {<<"views">>,
-            {[
-                {?OAUTH_VIEW_NAME,
-                    {[
-                        {<<"map">>, ?OAUTH_MAP_FUN}
-                    ]}
-                }
-            ]}
-        }
-    ]},
-    {ok, couch_doc:from_json_obj(Json)}.
-
-
-query_oauth_view(Db, Key) ->
-    ViewOptions = [
-        {start_key, Key},
-        {end_key, Key}
-    ],
-    Callback = fun({row, Row}, Acc) ->
-            {ok, [couch_util:get_value(value, Row) | Acc]};
-        (_, Acc) ->
-            {ok, Acc}
-    end,
-    {ok, Result} = couch_mrview:query_view(
-        Db, ?OAUTH_DDOC_ID, ?OAUTH_VIEW_NAME, ViewOptions, Callback, []),
-    Result.

http://git-wip-us.apache.org/repos/asf/couchdb/blob/c0855434/apps/couch_httpd/src/couch_httpd_proxy.erl
----------------------------------------------------------------------
diff --git a/apps/couch_httpd/src/couch_httpd_proxy.erl b/apps/couch_httpd/src/couch_httpd_proxy.erl
deleted file mode 100644
index bce2c7f..0000000
--- a/apps/couch_httpd/src/couch_httpd_proxy.erl
+++ /dev/null
@@ -1,426 +0,0 @@
-% Licensed 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.
--module(couch_httpd_proxy).
-
--export([handle_proxy_req/2]).
-
--include_lib("couch/include/couch_db.hrl").
--include_lib("ibrowse/include/ibrowse.hrl").
-
--define(TIMEOUT, infinity).
--define(PKT_SIZE, 4096).
-
-
-handle_proxy_req(Req, ProxyDest) ->
-    Method = get_method(Req),
-    Url = get_url(Req, ProxyDest),
-    Version = get_version(Req),
-    Headers = get_headers(Req),
-    Body = get_body(Req),
-    Options = [
-        {http_vsn, Version},
-        {headers_as_is, true},
-        {response_format, binary},
-        {stream_to, {self(), once}}
-    ],
-    case ibrowse:send_req(Url, Headers, Method, Body, Options, ?TIMEOUT) of
-        {ibrowse_req_id, ReqId} ->
-            stream_response(Req, ProxyDest, ReqId);
-        {error, Reason} ->
-            throw({error, Reason})
-    end.
-
-
-get_method(#httpd{mochi_req=MochiReq}) ->
-    case MochiReq:get(method) of
-        Method when is_atom(Method) ->
-            list_to_atom(string:to_lower(atom_to_list(Method)));
-        Method when is_list(Method) ->
-            list_to_atom(string:to_lower(Method));
-        Method when is_binary(Method) ->
-            list_to_atom(string:to_lower(?b2l(Method)))
-    end.
-
-
-get_url(Req, ProxyDest) when is_binary(ProxyDest) ->
-    get_url(Req, ?b2l(ProxyDest));
-get_url(#httpd{mochi_req=MochiReq}=Req, ProxyDest) ->
-    BaseUrl = case mochiweb_util:partition(ProxyDest, "/") of
-        {[], "/", _} -> couch_httpd:absolute_uri(Req, ProxyDest);
-        _ -> ProxyDest
-    end,
-    ProxyPrefix = "/" ++ ?b2l(hd(Req#httpd.path_parts)),
-    RequestedPath = MochiReq:get(raw_path),
-    case mochiweb_util:partition(RequestedPath, ProxyPrefix) of
-        {[], ProxyPrefix, []} ->
-            BaseUrl;
-        {[], ProxyPrefix, [$/ | DestPath]} ->
-            remove_trailing_slash(BaseUrl) ++ "/" ++ DestPath;
-        {[], ProxyPrefix, DestPath} ->
-            remove_trailing_slash(BaseUrl) ++ "/" ++ DestPath;
-        _Else ->
-            throw({invalid_url_path, {ProxyPrefix, RequestedPath}})
-    end.
-
-get_version(#httpd{mochi_req=MochiReq}) ->
-    MochiReq:get(version).
-
-
-get_headers(#httpd{mochi_req=MochiReq}) ->
-    to_ibrowse_headers(mochiweb_headers:to_list(MochiReq:get(headers)), []).
-
-to_ibrowse_headers([], Acc) ->
-    lists:reverse(Acc);
-to_ibrowse_headers([{K, V} | Rest], Acc) when is_atom(K) ->
-    to_ibrowse_headers([{atom_to_list(K), V} | Rest], Acc);
-to_ibrowse_headers([{K, V} | Rest], Acc) when is_list(K) ->
-    case string:to_lower(K) of
-        "content-length" ->
-            to_ibrowse_headers(Rest, [{content_length, V} | Acc]);
-        % This appears to make ibrowse too smart.
-        %"transfer-encoding" ->
-        %    to_ibrowse_headers(Rest, [{transfer_encoding, V} | Acc]);
-        _ ->
-            to_ibrowse_headers(Rest, [{K, V} | Acc])
-    end.
-
-get_body(#httpd{method='GET'}) ->
-    fun() -> eof end;
-get_body(#httpd{method='HEAD'}) ->
-    fun() -> eof end;
-get_body(#httpd{method='DELETE'}) ->
-    fun() -> eof end;
-get_body(#httpd{mochi_req=MochiReq}) ->
-    case MochiReq:get(body_length) of
-        undefined ->
-            <<>>;
-        {unknown_transfer_encoding, Unknown} ->
-            exit({unknown_transfer_encoding, Unknown});
-        chunked ->
-            {fun stream_chunked_body/1, {init, MochiReq, 0}};
-        0 ->
-            <<>>;
-        Length when is_integer(Length) andalso Length > 0 ->
-            {fun stream_length_body/1, {init, MochiReq, Length}};
-        Length ->
-            exit({invalid_body_length, Length})
-    end.
-
-
-remove_trailing_slash(Url) ->
-    rem_slash(lists:reverse(Url)).
-
-rem_slash([]) ->
-    [];
-rem_slash([$\s | RevUrl]) ->
-    rem_slash(RevUrl);
-rem_slash([$\t | RevUrl]) ->
-    rem_slash(RevUrl);
-rem_slash([$\r | RevUrl]) ->
-    rem_slash(RevUrl);
-rem_slash([$\n | RevUrl]) ->
-    rem_slash(RevUrl);
-rem_slash([$/ | RevUrl]) ->
-    rem_slash(RevUrl);
-rem_slash(RevUrl) ->
-    lists:reverse(RevUrl).
-
-
-stream_chunked_body({init, MReq, 0}) ->
-    % First chunk, do expect-continue dance.
-    init_body_stream(MReq),
-    stream_chunked_body({stream, MReq, 0, [], ?PKT_SIZE});
-stream_chunked_body({stream, MReq, 0, Buf, BRem}) ->
-    % Finished a chunk, get next length. If next length
-    % is 0, its time to try and read trailers.
-    {CRem, Data} = read_chunk_length(MReq),
-    case CRem of
-        0 ->
-            BodyData = lists:reverse(Buf, Data),
-            {ok, BodyData, {trailers, MReq, [], ?PKT_SIZE}};
-        _ ->
-            stream_chunked_body(
-                {stream, MReq, CRem, [Data | Buf], BRem-size(Data)}
-            )
-    end;
-stream_chunked_body({stream, MReq, CRem, Buf, BRem}) when BRem =< 0 ->
-    % Time to empty our buffers to the upstream socket.
-    BodyData = lists:reverse(Buf),
-    {ok, BodyData, {stream, MReq, CRem, [], ?PKT_SIZE}};
-stream_chunked_body({stream, MReq, CRem, Buf, BRem}) ->
-    % Buffer some more data from the client.
-    Length = lists:min([CRem, BRem]),
-    Socket = MReq:get(socket),
-    NewState = case mochiweb_socket:recv(Socket, Length, ?TIMEOUT) of
-        {ok, Data} when size(Data) == CRem ->
-            case mochiweb_socket:recv(Socket, 2, ?TIMEOUT) of
-                {ok, <<"\r\n">>} ->
-                    {stream, MReq, 0, [<<"\r\n">>, Data | Buf], BRem-Length-2};
-                _ ->
-                    exit(normal)
-            end;
-        {ok, Data} ->
-            {stream, MReq, CRem-Length, [Data | Buf], BRem-Length};
-        _ ->
-            exit(normal)
-    end,
-    stream_chunked_body(NewState);
-stream_chunked_body({trailers, MReq, Buf, BRem}) when BRem =< 0 ->
-    % Empty our buffers and send data upstream.
-    BodyData = lists:reverse(Buf),
-    {ok, BodyData, {trailers, MReq, [], ?PKT_SIZE}};
-stream_chunked_body({trailers, MReq, Buf, BRem}) ->
-    % Read another trailer into the buffer or stop on an
-    % empty line.
-    Socket = MReq:get(socket),
-    mochiweb_socket:setopts(Socket, [{packet, line}]),
-    case mochiweb_socket:recv(Socket, 0, ?TIMEOUT) of
-        {ok, <<"\r\n">>} ->
-            mochiweb_socket:setopts(Socket, [{packet, raw}]),
-            BodyData = lists:reverse(Buf, <<"\r\n">>),
-            {ok, BodyData, eof};
-        {ok, Footer} ->
-            mochiweb_socket:setopts(Socket, [{packet, raw}]),
-            NewState = {trailers, MReq, [Footer | Buf], BRem-size(Footer)},
-            stream_chunked_body(NewState);
-        _ ->
-            exit(normal)
-    end;
-stream_chunked_body(eof) ->
-    % Tell ibrowse we're done sending data.
-    eof.
-
-
-stream_length_body({init, MochiReq, Length}) ->
-    % Do the expect-continue dance
-    init_body_stream(MochiReq),
-    stream_length_body({stream, MochiReq, Length});
-stream_length_body({stream, _MochiReq, 0}) ->
-    % Finished streaming.
-    eof;
-stream_length_body({stream, MochiReq, Length}) ->
-    BufLen = lists:min([Length, ?PKT_SIZE]),
-    case MochiReq:recv(BufLen) of
-        <<>> -> eof;
-        Bin -> {ok, Bin, {stream, MochiReq, Length-BufLen}}
-    end.
-
-
-init_body_stream(MochiReq) ->
-    Expect = case MochiReq:get_header_value("expect") of
-        undefined ->
-            undefined;
-        Value when is_list(Value) ->
-            string:to_lower(Value)
-    end,
-    case Expect of
-        "100-continue" ->
-            MochiReq:start_raw_response({100, gb_trees:empty()});
-        _Else ->
-            ok
-    end.
-
-
-read_chunk_length(MochiReq) ->
-    Socket = MochiReq:get(socket),
-    mochiweb_socket:setopts(Socket, [{packet, line}]),
-    case mochiweb_socket:recv(Socket, 0, ?TIMEOUT) of
-        {ok, Header} ->
-            mochiweb_socket:setopts(Socket, [{packet, raw}]),
-            Splitter = fun(C) ->
-                C =/= $\r andalso C =/= $\n andalso C =/= $\s
-            end,
-            {Hex, _Rest} = lists:splitwith(Splitter, ?b2l(Header)),
-            {mochihex:to_int(Hex), Header};
-        _ ->
-            exit(normal)
-    end.
-
-
-stream_response(Req, ProxyDest, ReqId) ->
-    receive
-        {ibrowse_async_headers, ReqId, "100", _} ->
-            % ibrowse doesn't handle 100 Continue responses which
-            % means we have to discard them so the proxy client
-            % doesn't get confused.
-            ibrowse:stream_next(ReqId),
-            stream_response(Req, ProxyDest, ReqId);
-        {ibrowse_async_headers, ReqId, Status, Headers} ->
-            {Source, Dest} = get_urls(Req, ProxyDest),
-            FixedHeaders = fix_headers(Source, Dest, Headers, []),
-            case body_length(FixedHeaders) of
-                chunked ->
-                    {ok, Resp} = couch_httpd:start_chunked_response(
-                        Req, list_to_integer(Status), FixedHeaders
-                    ),
-                    ibrowse:stream_next(ReqId),
-                    stream_chunked_response(Req, ReqId, Resp),
-                    {ok, Resp};
-                Length when is_integer(Length) ->
-                    {ok, Resp} = couch_httpd:start_response_length(
-                        Req, list_to_integer(Status), FixedHeaders, Length
-                    ),
-                    ibrowse:stream_next(ReqId),
-                    stream_length_response(Req, ReqId, Resp),
-                    {ok, Resp};
-                _ ->
-                    {ok, Resp} = couch_httpd:start_response(
-                        Req, list_to_integer(Status), FixedHeaders
-                    ),
-                    ibrowse:stream_next(ReqId),
-                    stream_length_response(Req, ReqId, Resp),
-                    % XXX: MochiWeb apparently doesn't look at the
-                    % response to see if it must force close the
-                    % connection. So we help it out here.
-                    erlang:put(mochiweb_request_force_close, true),
-                    {ok, Resp}
-            end
-    end.
-
-
-stream_chunked_response(Req, ReqId, Resp) ->
-    receive
-        {ibrowse_async_response, ReqId, {error, Reason}} ->
-            throw({error, Reason});
-        {ibrowse_async_response, ReqId, Chunk} ->
-            couch_httpd:send_chunk(Resp, Chunk),
-            ibrowse:stream_next(ReqId),
-            stream_chunked_response(Req, ReqId, Resp);
-        {ibrowse_async_response_end, ReqId} ->
-            couch_httpd:last_chunk(Resp)
-    end.
-
-
-stream_length_response(Req, ReqId, Resp) ->
-    receive
-        {ibrowse_async_response, ReqId, {error, Reason}} ->
-            throw({error, Reason});
-        {ibrowse_async_response, ReqId, Chunk} ->
-            couch_httpd:send(Resp, Chunk),
-            ibrowse:stream_next(ReqId),
-            stream_length_response(Req, ReqId, Resp);
-        {ibrowse_async_response_end, ReqId} ->
-            ok
-    end.
-
-
-get_urls(Req, ProxyDest) ->
-    SourceUrl = couch_httpd:absolute_uri(Req, "/" ++ hd(Req#httpd.path_parts)),
-    Source = parse_url(?b2l(iolist_to_binary(SourceUrl))),
-    case (catch parse_url(ProxyDest)) of
-        Dest when is_record(Dest, url) ->
-            {Source, Dest};
-        _ ->
-            DestUrl = couch_httpd:absolute_uri(Req, ProxyDest),
-            {Source, parse_url(DestUrl)}
-    end.
-
-
-fix_headers(_, _, [], Acc) ->
-    lists:reverse(Acc);
-fix_headers(Source, Dest, [{K, V} | Rest], Acc) ->
-    Fixed = case string:to_lower(K) of
-        "location" -> rewrite_location(Source, Dest, V);
-        "content-location" -> rewrite_location(Source, Dest, V);
-        "uri" -> rewrite_location(Source, Dest, V);
-        "destination" -> rewrite_location(Source, Dest, V);
-        "set-cookie" -> rewrite_cookie(Source, Dest, V);
-        _ -> V
-    end,
-    fix_headers(Source, Dest, Rest, [{K, Fixed} | Acc]).
-
-
-rewrite_location(Source, #url{host=Host, port=Port, protocol=Proto}, Url) ->
-    case (catch parse_url(Url)) of
-        #url{host=Host, port=Port, protocol=Proto} = Location ->
-            DestLoc = #url{
-                protocol=Source#url.protocol,
-                host=Source#url.host,
-                port=Source#url.port,
-                path=join_url_path(Source#url.path, Location#url.path)
-            },
-            url_to_url(DestLoc);
-        #url{} ->
-            Url;
-        _ ->
-            url_to_url(Source#url{path=join_url_path(Source#url.path, Url)})
-    end.
-
-
-rewrite_cookie(_Source, _Dest, Cookie) ->
-    Cookie.
-
-
-parse_url(Url) when is_binary(Url) ->
-    ibrowse_lib:parse_url(?b2l(Url));
-parse_url(Url) when is_list(Url) ->
-    ibrowse_lib:parse_url(?b2l(iolist_to_binary(Url))).
-
-
-join_url_path(Src, Dst) ->
-    Src2 = case lists:reverse(Src) of
-        "/" ++ RestSrc -> lists:reverse(RestSrc);
-        _ -> Src
-    end,
-    Dst2 = case Dst of
-        "/" ++ RestDst -> RestDst;
-        _ -> Dst
-    end,
-    Src2 ++ "/" ++ Dst2.
-
-
-url_to_url(#url{host=Host, port=Port, path=Path, protocol=Proto} = Url) ->
-    LPort = case {Proto, Port} of
-        {http, 80} -> "";
-        {https, 443} -> "";
-        _ -> ":" ++ integer_to_list(Port)
-    end,
-    LPath = case Path of
-        "/" ++ _RestPath -> Path;
-        _ -> "/" ++ Path
-    end,
-    HostPart = case Url#url.host_type of
-        ipv6_address ->
-            "[" ++ Host ++ "]";
-        _ ->
-            Host
-    end,
-    atom_to_list(Proto) ++ "://" ++ HostPart ++ LPort ++ LPath.
-
-
-body_length(Headers) ->
-    case is_chunked(Headers) of
-        true -> chunked;
-        _ -> content_length(Headers)
-    end.
-
-
-is_chunked([]) ->
-    false;
-is_chunked([{K, V} | Rest]) ->
-    case string:to_lower(K) of
-        "transfer-encoding" ->
-            string:to_lower(V) == "chunked";
-        _ ->
-            is_chunked(Rest)
-    end.
-
-content_length([]) ->
-    undefined;
-content_length([{K, V} | Rest]) ->
-    case string:to_lower(K) of
-        "content-length" ->
-            list_to_integer(V);
-        _ ->
-            content_length(Rest)
-    end.
-

http://git-wip-us.apache.org/repos/asf/couchdb/blob/c0855434/apps/couch_httpd/src/couch_httpd_rewrite.erl
----------------------------------------------------------------------
diff --git a/apps/couch_httpd/src/couch_httpd_rewrite.erl b/apps/couch_httpd/src/couch_httpd_rewrite.erl
deleted file mode 100644
index 011c3c8..0000000
--- a/apps/couch_httpd/src/couch_httpd_rewrite.erl
+++ /dev/null
@@ -1,480 +0,0 @@
-% Licensed 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.
-%
-% bind_path is based on bind method from Webmachine
-
-
-%% @doc Module for URL rewriting by pattern matching.
-
--module(couch_httpd_rewrite).
--export([handle_rewrite_req/3]).
--include_lib("couch/include/couch_db.hrl").
-
--define(SEPARATOR, $\/).
--define(MATCH_ALL, {bind, <<"*">>}).
-
-
-%% doc The http rewrite handler. All rewriting is done from
-%% /dbname/_design/ddocname/_rewrite by default.
-%%
-%% each rules should be in rewrites member of the design doc.
-%% Ex of a complete rule :
-%%
-%%  {
-%%      ....
-%%      "rewrites": [
-%%      {
-%%          "from": "",
-%%          "to": "index.html",
-%%          "method": "GET",
-%%          "query": {}
-%%      }
-%%      ]
-%%  }
-%%
-%%  from: is the path rule used to bind current uri to the rule. It
-%% use pattern matching for that.
-%%
-%%  to: rule to rewrite an url. It can contain variables depending on binding
-%% variables discovered during pattern matching and query args (url args and from
-%% the query member.)
-%%
-%%  method: method to bind the request method to the rule. by default "*"
-%%  query: query args you want to define they can contain dynamic variable
-%% by binding the key to the bindings
-%%
-%%
-%% to and from are path with  patterns. pattern can be string starting with ":" or
-%% "*". ex:
-%% /somepath/:var/*
-%%
-%% This path is converted in erlang list by splitting "/". Each var are
-%% converted in atom. "*" is converted to '*' atom. The pattern matching is done
-%% by splitting "/" in request url in a list of token. A string pattern will
-%% match equal token. The star atom ('*' in single quotes) will match any number
-%% of tokens, but may only be present as the last pathtern in a pathspec. If all
-%% tokens are matched and all pathterms are used, then the pathspec matches. It works
-%% like webmachine. Each identified token will be reused in to rule and in query
-%%
-%% The pattern matching is done by first matching the request method to a rule. by
-%% default all methods match a rule. (method is equal to "*" by default). Then
-%% It will try to match the path to one rule. If no rule match, then a 404 error
-%% is displayed.
-%%
-%% Once a rule is found we rewrite the request url using the "to" and
-%% "query" members. The identified token are matched to the rule and
-%% will replace var. if '*' is found in the rule it will contain the remaining
-%% part if it exists.
-%%
-%% Examples:
-%%
-%% Dispatch rule            URL             TO                  Tokens
-%%
-%% {"from": "/a/b",         /a/b?k=v        /some/b?k=v         var =:= b
-%% "to": "/some/"}                                              k = v
-%%
-%% {"from": "/a/b",         /a/b            /some/b?var=b       var =:= b
-%% "to": "/some/:var"}
-%%
-%% {"from": "/a",           /a              /some
-%% "to": "/some/*"}
-%%
-%% {"from": "/a/*",         /a/b/c          /some/b/c
-%% "to": "/some/*"}
-%%
-%% {"from": "/a",           /a              /some
-%% "to": "/some/*"}
-%%
-%% {"from": "/a/:foo/*",    /a/b/c          /some/b/c?foo=b     foo =:= b
-%% "to": "/some/:foo/*"}
-%%
-%% {"from": "/a/:foo",     /a/b             /some/?k=b&foo=b    foo =:= b
-%% "to": "/some",
-%%  "query": {
-%%      "k": ":foo"
-%%  }}
-%%
-%% {"from": "/a",           /a?foo=b        /some/b             foo =:= b
-%% "to": "/some/:foo",
-%%  }}
-
-
-
-handle_rewrite_req(#httpd{
-        path_parts=[DbName, <<"_design">>, DesignName, _Rewrite|PathParts],
-        method=Method,
-        mochi_req=MochiReq}=Req, _Db, DDoc) ->
-
-    % we are in a design handler
-    DesignId = <<"_design/", DesignName/binary>>,
-    Prefix = <<"/", (?l2b(couch_util:url_encode(DbName)))/binary, "/", DesignId/binary>>,
-    QueryList = lists:map(fun decode_query_value/1, couch_httpd:qs(Req)),
-
-    RewritesSoFar = erlang:get(?REWRITE_COUNT),
-    MaxRewrites = list_to_integer(couch_config:get("httpd", "rewrite_limit", "100")),
-    case RewritesSoFar >= MaxRewrites of
-        true ->
-            throw({bad_request, <<"Exceeded rewrite recursion limit">>});
-        false ->
-            erlang:put(?REWRITE_COUNT, RewritesSoFar + 1)
-    end,
-
-    #doc{body={Props}} = DDoc,
-
-    % get rules from ddoc
-    case couch_util:get_value(<<"rewrites">>, Props) of
-        undefined ->
-            couch_httpd:send_error(Req, 404, <<"rewrite_error">>,
-                <<"Invalid path.">>);
-        Bin when is_binary(Bin) ->
-            couch_httpd:send_error(Req, 400, <<"rewrite_error">>,
-                <<"Rewrite rules are a String. They must be a JSON Array.">>);
-        Rules ->
-            % create dispatch list from rules
-            DispatchList =  [make_rule(Rule) || {Rule} <- Rules],
-            Method1 = couch_util:to_binary(Method),
-
-            % get raw path by matching url to a rule. Throws not_found.
-            {NewPathParts0, Bindings0} =
-                try_bind_path(DispatchList, Method1, PathParts, QueryList),
-            NewPathParts = [quote_plus(X) || X <- NewPathParts0],
-            Bindings = maybe_encode_bindings(Bindings0),
-
-            Path0 = string:join(NewPathParts, [?SEPARATOR]),
-
-            % if path is relative detect it and rewrite path
-            Path1 = case mochiweb_util:safe_relative_path(Path0) of
-                undefined ->
-                    ?b2l(Prefix) ++ "/" ++ Path0;
-                P1 ->
-                    ?b2l(Prefix) ++ "/" ++ P1
-            end,
-
-            Path2 = normalize_path(Path1),
-
-            Path3 = case Bindings of
-                [] ->
-                    Path2;
-                _ ->
-                    [Path2, "?", mochiweb_util:urlencode(Bindings)]
-            end,
-
-            RawPath1 = ?b2l(iolist_to_binary(Path3)),
-
-            % In order to do OAuth correctly, we have to save the
-            % requested path. We use default so chained rewriting
-            % wont replace the original header.
-            Headers = mochiweb_headers:default("x-couchdb-requested-path",
-                                             MochiReq:get(raw_path),
-                                             MochiReq:get(headers)),
-
-            ?LOG_DEBUG("rewrite to ~p ~n", [RawPath1]),
-
-            % build a new mochiweb request
-            MochiReq1 = mochiweb_request:new(MochiReq:get(socket),
-                                             MochiReq:get(method),
-                                             RawPath1,
-                                             MochiReq:get(version),
-                                             Headers),
-
-            % cleanup, It force mochiweb to reparse raw uri.
-            MochiReq1:cleanup(),
-
-            #httpd{
-                db_url_handlers = DbUrlHandlers,
-                design_url_handlers = DesignUrlHandlers,
-                default_fun = DefaultFun,
-                url_handlers = UrlHandlers,
-                user_ctx = UserCtx,
-               auth = Auth
-            } = Req,
-
-            erlang:put(pre_rewrite_auth, Auth),
-            erlang:put(pre_rewrite_user_ctx, UserCtx),
-            couch_httpd:handle_request_int(MochiReq1, DefaultFun,
-                    UrlHandlers, DbUrlHandlers, DesignUrlHandlers)
-        end.
-
-quote_plus({bind, X}) ->
-    mochiweb_util:quote_plus(X);
-quote_plus(X) ->
-    mochiweb_util:quote_plus(X).
-
-%% @doc Try to find a rule matching current url. If none is found
-%% 404 error not_found is raised
-try_bind_path([], _Method, _PathParts, _QueryList) ->
-    throw(not_found);
-try_bind_path([Dispatch|Rest], Method, PathParts, QueryList) ->
-    [{PathParts1, Method1}, RedirectPath, QueryArgs, Formats] = Dispatch,
-    case bind_method(Method1, Method) of
-        true ->
-            case bind_path(PathParts1, PathParts, []) of
-                {ok, Remaining, Bindings} ->
-                    Bindings1 = Bindings ++ QueryList,
-                    % we parse query args from the rule and fill
-                    % it eventually with bindings vars
-                    QueryArgs1 = make_query_list(QueryArgs, Bindings1,
-                        Formats, []),
-                    % remove params in QueryLists1 that are already in
-                    % QueryArgs1
-                    Bindings2 = lists:foldl(fun({K, V}, Acc) ->
-                        K1 = to_binding(K),
-                        KV = case couch_util:get_value(K1, QueryArgs1) of
-                            undefined -> [{K1, V}];
-                            _V1 -> []
-                        end,
-                        Acc ++ KV
-                    end, [], Bindings1),
-
-                    FinalBindings = Bindings2 ++ QueryArgs1,
-                    NewPathParts = make_new_path(RedirectPath, FinalBindings,
-                                    Remaining, []),
-                    {NewPathParts, FinalBindings};
-                fail ->
-                    try_bind_path(Rest, Method, PathParts, QueryList)
-            end;
-        false ->
-            try_bind_path(Rest, Method, PathParts, QueryList)
-    end.
-
-%% rewriting dynamically the quey list given as query member in
-%% rewrites. Each value is replaced by one binding or an argument
-%% passed in url.
-make_query_list([], _Bindings, _Formats, Acc) ->
-    Acc;
-make_query_list([{Key, {Value}}|Rest], Bindings, Formats, Acc) ->
-    Value1 = {Value},
-    make_query_list(Rest, Bindings, Formats, [{to_binding(Key), Value1}|Acc]);
-make_query_list([{Key, Value}|Rest], Bindings, Formats, Acc) when is_binary(Value) ->
-    Value1 = replace_var(Value, Bindings, Formats),
-    make_query_list(Rest, Bindings, Formats, [{to_binding(Key), Value1}|Acc]);
-make_query_list([{Key, Value}|Rest], Bindings, Formats, Acc) when is_list(Value) ->
-    Value1 = replace_var(Value, Bindings, Formats),
-    make_query_list(Rest, Bindings, Formats, [{to_binding(Key), Value1}|Acc]);
-make_query_list([{Key, Value}|Rest], Bindings, Formats, Acc) ->
-    make_query_list(Rest, Bindings, Formats, [{to_binding(Key), Value}|Acc]).
-
-replace_var(<<"*">>=Value, Bindings, Formats) ->
-    get_var(Value, Bindings, Value, Formats);
-replace_var(<<":", Var/binary>> = Value, Bindings, Formats) ->
-    get_var(Var, Bindings, Value, Formats);
-replace_var(Value, _Bindings, _Formats) when is_binary(Value) ->
-    Value;
-replace_var(Value, Bindings, Formats) when is_list(Value) ->
-    lists:reverse(lists:foldl(fun
-                (<<":", Var/binary>>=Value1, Acc) ->
-                    [get_var(Var, Bindings, Value1, Formats)|Acc];
-                (Value1, Acc) ->
-                    [Value1|Acc]
-            end, [], Value));
-replace_var(Value, _Bindings, _Formats) ->
-    Value.
-
-maybe_json(Key, Value) ->
-    case lists:member(Key, [<<"key">>, <<"startkey">>, <<"start_key">>,
-                <<"endkey">>, <<"end_key">>, <<"keys">>]) of
-        true ->
-            ?JSON_ENCODE(Value);
-        false ->
-            Value
-    end.
-
-get_var(VarName, Props, Default, Formats) ->
-    VarName1 = to_binding(VarName),
-    Val = couch_util:get_value(VarName1, Props, Default),
-    maybe_format(VarName, Val, Formats).
-
-maybe_format(VarName, Value, Formats) ->
-    case couch_util:get_value(VarName, Formats) of
-        undefined ->
-             Value;
-        Format ->
-            format(Format, Value)
-    end.
-
-format(<<"int">>, Value) when is_integer(Value) ->
-    Value;
-format(<<"int">>, Value) when is_binary(Value) ->
-    format(<<"int">>, ?b2l(Value));
-format(<<"int">>, Value) when is_list(Value) ->
-    case (catch list_to_integer(Value)) of
-        IntVal when is_integer(IntVal) ->
-            IntVal;
-        _ ->
-            Value
-    end;
-format(<<"bool">>, Value) when is_binary(Value) ->
-    format(<<"bool">>, ?b2l(Value));
-format(<<"bool">>, Value) when is_list(Value) ->
-    case string:to_lower(Value) of
-        "true" -> true;
-        "false" -> false;
-        _ -> Value
-    end;
-format(_Format, Value) ->
-   Value.
-
-%% doc: build new patch from bindings. bindings are query args
-%% (+ dynamic query rewritten if needed) and bindings found in
-%% bind_path step.
-make_new_path([], _Bindings, _Remaining, Acc) ->
-    lists:reverse(Acc);
-make_new_path([?MATCH_ALL], _Bindings, Remaining, Acc) ->
-    Acc1 = lists:reverse(Acc) ++ Remaining,
-    Acc1;
-make_new_path([?MATCH_ALL|_Rest], _Bindings, Remaining, Acc) ->
-    Acc1 = lists:reverse(Acc) ++ Remaining,
-    Acc1;
-make_new_path([{bind, P}|Rest], Bindings, Remaining, Acc) ->
-    P2 = case couch_util:get_value({bind, P}, Bindings) of
-        undefined -> << "undefined">>;
-        P1 ->
-            iolist_to_binary(P1)
-    end,
-    make_new_path(Rest, Bindings, Remaining, [P2|Acc]);
-make_new_path([P|Rest], Bindings, Remaining, Acc) ->
-    make_new_path(Rest, Bindings, Remaining, [P|Acc]).
-
-
-%% @doc If method of the query fith the rule method. If the
-%% method rule is '*', which is the default, all
-%% request method will bind. It allows us to make rules
-%% depending on HTTP method.
-bind_method(?MATCH_ALL, _Method ) ->
-    true;
-bind_method({bind, Method}, Method) ->
-    true;
-bind_method(_, _) ->
-    false.
-
-
-%% @doc bind path. Using the rule from we try to bind variables given
-%% to the current url by pattern matching
-bind_path([], [], Bindings) ->
-    {ok, [], Bindings};
-bind_path([?MATCH_ALL], [Match|_RestMatch]=Rest, Bindings) ->
-    {ok, Rest, [{?MATCH_ALL, Match}|Bindings]};
-bind_path(_, [], _) ->
-    fail;
-bind_path([{bind, Token}|RestToken],[Match|RestMatch],Bindings) ->
-    bind_path(RestToken, RestMatch, [{{bind, Token}, Match}|Bindings]);
-bind_path([Token|RestToken], [Token|RestMatch], Bindings) ->
-    bind_path(RestToken, RestMatch, Bindings);
-bind_path(_, _, _) ->
-    fail.
-
-
-%% normalize path.
-normalize_path(Path)  ->
-    "/" ++ string:join(normalize_path1(string:tokens(Path,
-                "/"), []), [?SEPARATOR]).
-
-
-normalize_path1([], Acc) ->
-    lists:reverse(Acc);
-normalize_path1([".."|Rest], Acc) ->
-    Acc1 = case Acc of
-        [] -> [".."|Acc];
-        [T|_] when T =:= ".." -> [".."|Acc];
-        [_|R] -> R
-    end,
-    normalize_path1(Rest, Acc1);
-normalize_path1(["."|Rest], Acc) ->
-    normalize_path1(Rest, Acc);
-normalize_path1([Path|Rest], Acc) ->
-    normalize_path1(Rest, [Path|Acc]).
-
-
-%% @doc transform json rule in erlang for pattern matching
-make_rule(Rule) ->
-    Method = case couch_util:get_value(<<"method">>, Rule) of
-        undefined -> ?MATCH_ALL;
-        M -> to_binding(M)
-    end,
-    QueryArgs = case couch_util:get_value(<<"query">>, Rule) of
-        undefined -> [];
-        {Args} -> Args
-        end,
-    FromParts  = case couch_util:get_value(<<"from">>, Rule) of
-        undefined -> [?MATCH_ALL];
-        From ->
-            parse_path(From)
-        end,
-    ToParts  = case couch_util:get_value(<<"to">>, Rule) of
-        undefined ->
-            throw({error, invalid_rewrite_target});
-        To ->
-            parse_path(To)
-        end,
-    Formats = case couch_util:get_value(<<"formats">>, Rule) of
-        undefined -> [];
-        {Fmts} -> Fmts
-    end,
-    [{FromParts, Method}, ToParts, QueryArgs, Formats].
-
-parse_path(Path) ->
-    {ok, SlashRE} = re:compile(<<"\\/">>),
-    path_to_list(re:split(Path, SlashRE), [], 0).
-
-%% @doc convert a path rule (from or to) to an erlang list
-%% * and path variable starting by ":" are converted
-%% in erlang atom.
-path_to_list([], Acc, _DotDotCount) ->
-    lists:reverse(Acc);
-path_to_list([<<>>|R], Acc, DotDotCount) ->
-    path_to_list(R, Acc, DotDotCount);
-path_to_list([<<"*">>|R], Acc, DotDotCount) ->
-    path_to_list(R, [?MATCH_ALL|Acc], DotDotCount);
-path_to_list([<<"..">>|R], Acc, DotDotCount) when DotDotCount == 2 ->
-    case couch_config:get("httpd", "secure_rewrites", "true") of
-    "false" ->
-        path_to_list(R, [<<"..">>|Acc], DotDotCount+1);
-    _Else ->
-        ?LOG_INFO("insecure_rewrite_rule ~p blocked", [lists:reverse(Acc) ++ [<<"..">>] ++ R]),
-        throw({insecure_rewrite_rule, "too many ../.. segments"})
-    end;
-path_to_list([<<"..">>|R], Acc, DotDotCount) ->
-    path_to_list(R, [<<"..">>|Acc], DotDotCount+1);
-path_to_list([P|R], Acc, DotDotCount) ->
-    P1 = case P of
-        <<":", Var/binary>> ->
-            to_binding(Var);
-        _ -> P
-    end,
-    path_to_list(R, [P1|Acc], DotDotCount).
-
-maybe_encode_bindings([]) ->
-    [];
-maybe_encode_bindings(Props) ->
-    lists:foldl(fun
-            ({{bind, <<"*">>}, _V}, Acc) ->
-                Acc;
-            ({{bind, K}, V}, Acc) ->
-                V1 = iolist_to_binary(maybe_json(K, V)),
-                [{K, V1}|Acc]
-        end, [], Props).
-
-decode_query_value({K,V}) ->
-    case lists:member(K, ["key", "startkey", "start_key",
-                "endkey", "end_key", "keys"]) of
-        true ->
-            {to_binding(K), ?JSON_DECODE(V)};
-        false ->
-            {to_binding(K), ?l2b(V)}
-    end.
-
-to_binding({bind, V}) ->
-    {bind, V};
-to_binding(V) when is_list(V) ->
-    to_binding(?l2b(V));
-to_binding(V) ->
-    {bind, V}.

http://git-wip-us.apache.org/repos/asf/couchdb/blob/c0855434/apps/couch_httpd/src/couch_httpd_stats_handlers.erl
----------------------------------------------------------------------
diff --git a/apps/couch_httpd/src/couch_httpd_stats_handlers.erl b/apps/couch_httpd/src/couch_httpd_stats_handlers.erl
deleted file mode 100644
index cd357ea..0000000
--- a/apps/couch_httpd/src/couch_httpd_stats_handlers.erl
+++ /dev/null
@@ -1,56 +0,0 @@
-% Licensed 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.
-
--module(couch_httpd_stats_handlers).
--include_lib("couch/include/couch_db.hrl").
-
--export([handle_stats_req/1]).
--import(couch_httpd, [
-    send_json/2, send_json/3, send_json/4, send_method_not_allowed/2,
-    start_json_response/2, send_chunk/2, end_json_response/1,
-    start_chunked_response/3, send_error/4
-]).
-
-handle_stats_req(#httpd{method='GET', path_parts=[_]}=Req) ->
-    flush(Req),
-    send_json(Req, couch_stats_aggregator:all(range(Req)));
-
-handle_stats_req(#httpd{method='GET', path_parts=[_, _Mod]}) ->
-    throw({bad_request, <<"Stat names must have exactly two parts.">>});
-
-handle_stats_req(#httpd{method='GET', path_parts=[_, Mod, Key]}=Req) ->
-    flush(Req),
-    Stats = couch_stats_aggregator:get_json({list_to_atom(binary_to_list(Mod)),
-        list_to_atom(binary_to_list(Key))}, range(Req)),
-    send_json(Req, {[{Mod, {[{Key, Stats}]}}]});
-
-handle_stats_req(#httpd{method='GET', path_parts=[_, _Mod, _Key | _Extra]}) ->
-    throw({bad_request, <<"Stat names must have exactly two parts.">>});
-
-handle_stats_req(Req) ->
-    send_method_not_allowed(Req, "GET").
-
-range(Req) ->
-    case couch_util:get_value("range", couch_httpd:qs(Req)) of
-        undefined ->
-            0;
-        Value ->
-            list_to_integer(Value)
-    end.
-
-flush(Req) ->
-    case couch_util:get_value("flush", couch_httpd:qs(Req)) of
-        "true" ->
-            couch_stats_aggregator:collect_sample();
-        _Else ->
-            ok
-    end.

http://git-wip-us.apache.org/repos/asf/couchdb/blob/c0855434/apps/couch_httpd/src/couch_httpd_sup.erl
----------------------------------------------------------------------
diff --git a/apps/couch_httpd/src/couch_httpd_sup.erl b/apps/couch_httpd/src/couch_httpd_sup.erl
deleted file mode 100644
index 1ce53f1..0000000
--- a/apps/couch_httpd/src/couch_httpd_sup.erl
+++ /dev/null
@@ -1,112 +0,0 @@
-% Licensed 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.
-%
--module(couch_httpd_sup).
--behaviour(supervisor).
-
--export([start_link/0]).
--export([upgrade/0]).
--export([reload_listener/1,
-         reload_listeners/0]).
-
-
-%% internal API
--export([init/1]).
--export([config_change/2]).
-
-
--spec start_link() -> ignore | {error, term()} | {ok, pid()}.
-start_link() ->
-    {ok, Pid} = supervisor:start_link({local, ?MODULE}, ?MODULE, []),
-
-    %% register to config events
-    ok  = couch_config:register(fun ?MODULE:config_change/2, Pid),
-
-    %% display uris
-    couch_httpd_util:display_uris(),
-
-    %% write_uris
-    couch_httpd_util:write_uri_file(),
-
-    {ok, Pid}.
-
-
-%% @spec upgrade() -> ok
-%% @doc Add processes if necessary.
-upgrade() ->
-    {ok, {_, Specs}} = init([]),
-
-    Old = sets:from_list(
-            [Name || {Name, _, _, _} <- supervisor:which_children(?MODULE)]),
-    New = sets:from_list([Name || {Name, _, _, _, _, _} <- Specs]),
-    Kill = sets:subtract(Old, New),
-
-    sets:fold(fun (Id, ok) ->
-                      supervisor:terminate_child(?MODULE, Id),
-                      supervisor:delete_child(?MODULE, Id),
-                      ok
-              end, ok, Kill),
-
-    [supervisor:start_child(?MODULE, Spec) || Spec <- Specs],
-    ok.
-
-%% @doc upgrade  a listener
--spec reload_listener(atom()) -> {ok, pid()} | {error, term()}.
-reload_listener(Id) ->
-    %% stop the listener and remove it from the supervision temporarely
-    supervisor:terminate_child(?MODULE, Id),
-    supervisor:delete_child(?MODULE, Id),
-
-    %% restart the listener
-    supervisor:start_child(?MODULE, listener_spec(Id)),
-    couch_httpd_util:display_uris([Id]),
-    ok.
-
-%% upgrade all listeners
--spec reload_listeners() -> ok.
-reload_listeners() ->
-    [reload_listener(Id) || Id <- couch_httpd_util:get_listeners()],
-    ok.
-
-
--spec init([]) -> {ok, {{one_for_one, 5, 10}, [supervisor:child_spec()]}}.
-init([]) ->
-    Listeners = [listener_spec(Id) || Id <- couch_httpd_util:get_listeners()],
-    Vhost = {couch_httpd_vhost,
-             {couch_httpd_vhost, start_link, []},
-             permanent, brutal_kill, worker, [couch_httpd_vhost]},
-    {ok, {{one_for_one, 9, 10}, Listeners ++ [Vhost]}}.
-
-
-listener_spec(Id) ->
-    {Id,
-     {couch_httpd, start_link, [Id]},
-     permanent, brutal_kill, worker, [couch_httpd]}.
-
-config_change("httpd", "bind_address") ->
-    ?MODULE:reload_listeners();
-config_change("httpd", "port") ->
-    ?MODULE:reload_listener(couch_http);
-config_change("httpd", "default_handler") ->
-    ?MODULE:reload_listeners();
-config_change("httpd", "server_options") ->
-    ?MODULE:reload_listeners();
-config_change("httpd", "socket_options") ->
-    ?MODULE:reload_listeners();
-config_change("httpd", "authentication_handlers") ->
-    couch_httpd:set_auth_handlers();
-config_change("httpd_global_handlers", _) ->
-    ?MODULE:reload_listeners();
-config_change("httpd_db_handlers", _) ->
-    ?MODULE:reload_listeners();
-config_change("ssl", _) ->
-    ?MODULE:reload_listener(couch_https).

http://git-wip-us.apache.org/repos/asf/couchdb/blob/c0855434/apps/couch_httpd/src/couch_httpd_util.erl
----------------------------------------------------------------------
diff --git a/apps/couch_httpd/src/couch_httpd_util.erl b/apps/couch_httpd/src/couch_httpd_util.erl
deleted file mode 100644
index a3ba075..0000000
--- a/apps/couch_httpd/src/couch_httpd_util.erl
+++ /dev/null
@@ -1,80 +0,0 @@
-% Licensed 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.
-%
--module(couch_httpd_util).
-
--export([display_uris/0, display_uris/1,
-         write_uri_file/0,
-         get_listeners/0,
-         get_uri/2,
-         get_scheme/1,
-         get_port/1]).
-
--include_lib("couch/include/couch_db.hrl").
-
-
-display_uris() ->
-    display_uris(get_listeners()).
-
-display_uris(Bindings) ->
-    Ip = couch_config:get("httpd", "bind_address"),
-    lists:foreach(fun(Binding) ->
-                Uri = get_uri(Binding, Ip),
-                ?LOG_INFO("HTTP API started on ~p~n", [Uri])
-        end, Bindings).
-
-write_uri_file() ->
-    Ip = couch_config:get("httpd", "bind_address"),
-    Listeners = get_listeners(),
-    Uris = [get_uri(Name, Ip) || Name <- Listeners],
-    case couch_config:get("couchdb", "uri_file", null) of
-        null -> ok;
-        UriFile ->
-            Lines = [begin case Uri of
-                            undefined -> [];
-                            Uri -> io_lib:format("~s~n", [Uri])
-                        end end || Uri <- Uris],
-            case file:write_file(UriFile, Lines) of
-                ok -> ok;
-                {error, eacces} ->
-                    ?LOG_INFO("Permission error when writing to URI file ~s",
-                              [UriFile]),
-                    throw({file_permission_error, UriFile});
-                Error2 ->
-                    ?LOG_INFO("Failed to write to URI file ~s: ~p~n",
-                              [UriFile, Error2]),
-                    throw(Error2)
-            end
-    end.
-
-get_listeners() ->
-    SchemeStr = couch_config:get("httpd", "scheme", "http"),
-    SchemeList = re:split(SchemeStr, "\\s*,\\s*",[{return, list}]),
-
-    lists:foldl(fun(S, Acc) ->
-                [list_to_atom("couch_" ++ S) | Acc]
-        end, [], lists:reverse(SchemeList)).
-
-get_uri(Name, Ip) ->
-    Port = get_port(Name),
-    Scheme = get_scheme(Name),
-    Scheme ++ "://" ++ Ip ++ ":" ++ integer_to_list(Port) ++ "/".
-
-get_scheme(couch_http) -> "http";
-get_scheme(couch_https) -> "https".
-
-get_port(Ref) ->
-    try
-        mochiweb_socket_server:get(Ref, port)
-    catch
-        exit:{noproc, _} -> undefined
-    end.

http://git-wip-us.apache.org/repos/asf/couchdb/blob/c0855434/apps/couch_httpd/src/couch_httpd_vhost.erl
----------------------------------------------------------------------
diff --git a/apps/couch_httpd/src/couch_httpd_vhost.erl b/apps/couch_httpd/src/couch_httpd_vhost.erl
deleted file mode 100644
index 258f4eb..0000000
--- a/apps/couch_httpd/src/couch_httpd_vhost.erl
+++ /dev/null
@@ -1,383 +0,0 @@
-% Licensed 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.
-
--module(couch_httpd_vhost).
--behaviour(gen_server).
-
--export([start_link/0, config_change/2, reload/0, get_state/0, dispatch_host/1]).
--export([urlsplit_netloc/2, redirect_to_vhost/2]).
--export([host/1, split_host_port/1]).
-
--export([init/1, handle_call/3, handle_cast/2, handle_info/2, terminate/2, code_change/3]).
-
--include_lib("couch/include/couch_db.hrl").
-
--define(SEPARATOR, $\/).
--define(MATCH_ALL, {bind, '*'}).
-
--record(vhosts_state, {
-        vhosts,
-        vhost_globals,
-        vhosts_fun}).
-
-%% doc the vhost manager.
-%% This gen_server keep state of vhosts added to the ini and try to
-%% match the Host header (or forwarded) against rules built against
-%% vhost list.
-%%
-%% Declaration of vhosts take place in the configuration file :
-%%
-%% [vhosts]
-%% example.com = /example
-%% *.example.com = /example
-%%
-%% The first line will rewrite the rquest to display the content of the
-%% example database. This rule works only if the Host header is
-%% 'example.com' and won't work for CNAMEs. Second rule on the other hand
-%% match all CNAMES to example db. So www.example.com or db.example.com
-%% will work.
-%%
-%% The wildcard ('*') should always be the last in the cnames:
-%%
-%%      "*.db.example.com = /"  will match all cname on top of db
-%% examples to the root of the machine.
-%%
-%%
-%% Rewriting Hosts to path
-%% -----------------------
-%%
-%% Like in the _rewrite handler you could match some variable and use
-%them to create the target path. Some examples:
-%%
-%%    [vhosts]
-%%    *.example.com = /*
-%%    :dbname.example.com = /:dbname
-%%    :ddocname.:dbname.example.com = /:dbname/_design/:ddocname/_rewrite
-%%
-%% First rule pass wildcard as dbname, second do the same but use a
-%% variable name and the third one allows you to use any app with
-%% @ddocname in any db with @dbname .
-%%
-%% You could also change the default function to handle request by
-%% changing the setting `redirect_vhost_handler` in `httpd` section of
-%% the Ini:
-%%
-%%    [httpd]
-%%    redirect_vhost_handler = {Module, Fun}
-%%
-%% The function take 2 args : the mochiweb request object and the target
-%%% path.
-
-start_link() ->
-    gen_server:start_link({local, ?MODULE}, ?MODULE, [], []).
-
-%% @doc reload vhosts rules
-reload() ->
-    gen_server:call(?MODULE, reload).
-
-get_state() ->
-    gen_server:call(?MODULE, get_state).
-
-%% @doc Try to find a rule matching current Host heade. some rule is
-%% found it rewrite the Mochiweb Request else it return current Request.
-dispatch_host(MochiReq) ->
-    #vhosts_state{
-        vhost_globals = VHostGlobals,
-        vhosts = VHosts,
-        vhosts_fun=Fun} = get_state(),
-
-    {"/" ++ VPath, Query, Fragment} = mochiweb_util:urlsplit_path(MochiReq:get(raw_path)),
-    VPathParts =  string:tokens(VPath, "/"),
-
-    VHost = host(MochiReq),
-    {VHostParts, VhostPort} = split_host_port(VHost),
-    FinalMochiReq = case try_bind_vhost(VHosts, lists:reverse(VHostParts),
-            VhostPort, VPathParts) of
-        no_vhost_matched -> MochiReq;
-        {VhostTarget, NewPath} ->
-            case vhost_global(VHostGlobals, MochiReq) of
-                true ->
-                    MochiReq;
-                _Else ->
-                    NewPath1 = mochiweb_util:urlunsplit_path({NewPath, Query,
-                                          Fragment}),
-                    MochiReq1 = mochiweb_request:new(MochiReq:get(socket),
-                                      MochiReq:get(method),
-                                      NewPath1,
-                                      MochiReq:get(version),
-                                      MochiReq:get(headers)),
-                    Fun(MochiReq1, VhostTarget)
-            end
-    end,
-    FinalMochiReq.
-
-append_path("/"=_Target, "/"=_Path) ->
-    "/";
-append_path(Target, Path) ->
-    Target ++ Path.
-
-% default redirect vhost handler
-redirect_to_vhost(MochiReq, VhostTarget) ->
-    Path = MochiReq:get(raw_path),
-    Target = append_path(VhostTarget, Path),
-
-    ?LOG_DEBUG("Vhost Target: '~p'~n", [Target]),
-
-    Headers = mochiweb_headers:enter("x-couchdb-vhost-path", Path,
-        MochiReq:get(headers)),
-
-    % build a new mochiweb request
-    MochiReq1 = mochiweb_request:new(MochiReq:get(socket),
-                                      MochiReq:get(method),
-                                      Target,
-                                      MochiReq:get(version),
-                                      Headers),
-    % cleanup, It force mochiweb to reparse raw uri.
-    MochiReq1:cleanup(),
-    MochiReq1.
-
-%% if so, then it will not be rewritten, but will run as a normal couchdb request.
-%* normally you'd use this for _uuids _utils and a few of the others you want to
-%% keep available on vhosts. You can also use it to make databases 'global'.
-vhost_global( VhostGlobals, MochiReq) ->
-    RawUri = MochiReq:get(raw_path),
-    {"/" ++ Path, _, _} = mochiweb_util:urlsplit_path(RawUri),
-
-    Front = case couch_httpd:partition(Path) of
-    {"", "", ""} ->
-        "/"; % Special case the root url handler
-    {FirstPart, _, _} ->
-        FirstPart
-    end,
-    [true] == [true||V <- VhostGlobals, V == Front].
-
-%% bind host
-%% first it try to bind the port then the hostname.
-try_bind_vhost([], _HostParts, _Port, _PathParts) ->
-    no_vhost_matched;
-try_bind_vhost([VhostSpec|Rest], HostParts, Port, PathParts) ->
-    {{VHostParts, VPort, VPath}, Path} = VhostSpec,
-    case bind_port(VPort, Port) of
-        ok ->
-            case bind_vhost(lists:reverse(VHostParts), HostParts, []) of
-                {ok, Bindings, Remainings} ->
-                    case bind_path(VPath, PathParts) of
-                        {ok, PathParts1} ->
-                            Path1 = make_target(Path, Bindings, Remainings, []),
-                            {make_path(Path1), make_path(PathParts1)};
-                        fail ->
-                            try_bind_vhost(Rest, HostParts, Port,
-                                PathParts)
-                    end;
-                fail -> try_bind_vhost(Rest, HostParts, Port, PathParts)
-            end;
-        fail ->  try_bind_vhost(Rest, HostParts, Port, PathParts)
-    end.
-
-%% doc: build new patch from bindings. bindings are query args
-%% (+ dynamic query rewritten if needed) and bindings found in
-%% bind_path step.
-%% TODO: merge code with rewrite. But we need to make sure we are
-%% in string here.
-make_target([], _Bindings, _Remaining, Acc) ->
-    lists:reverse(Acc);
-make_target([?MATCH_ALL], _Bindings, Remaining, Acc) ->
-    Acc1 = lists:reverse(Acc) ++ Remaining,
-    Acc1;
-make_target([?MATCH_ALL|_Rest], _Bindings, Remaining, Acc) ->
-    Acc1 = lists:reverse(Acc) ++ Remaining,
-    Acc1;
-make_target([{bind, P}|Rest], Bindings, Remaining, Acc) ->
-    P2 = case couch_util:get_value({bind, P}, Bindings) of
-        undefined ->  "undefined";
-        P1 -> P1
-    end,
-    make_target(Rest, Bindings, Remaining, [P2|Acc]);
-make_target([P|Rest], Bindings, Remaining, Acc) ->
-    make_target(Rest, Bindings, Remaining, [P|Acc]).
-
-%% bind port
-bind_port(Port, Port) -> ok;
-bind_port('*', _) -> ok;
-bind_port(_,_) -> fail.
-
-%% bind bhost
-bind_vhost([],[], Bindings) -> {ok, Bindings, []};
-bind_vhost([?MATCH_ALL], [], _Bindings) -> fail;
-bind_vhost([?MATCH_ALL], Rest, Bindings) -> {ok, Bindings, Rest};
-bind_vhost([], _HostParts, _Bindings) -> fail;
-bind_vhost([{bind, Token}|Rest], [Match|RestHost], Bindings) ->
-    bind_vhost(Rest, RestHost, [{{bind, Token}, Match}|Bindings]);
-bind_vhost([Cname|Rest], [Cname|RestHost], Bindings) ->
-    bind_vhost(Rest, RestHost, Bindings);
-bind_vhost(_, _, _) -> fail.
-
-%% bind path
-bind_path([], PathParts) ->
-    {ok, PathParts};
-bind_path(_VPathParts, []) ->
-    fail;
-bind_path([Path|VRest],[Path|Rest]) ->
-   bind_path(VRest, Rest);
-bind_path(_, _) ->
-    fail.
-
-% utilities
-
-
-%% create vhost list from ini
-
-host(MochiReq) ->
-    XHost = couch_config:get("httpd", "x_forwarded_host",
-                             "X-Forwarded-Host"),
-    case MochiReq:get_header_value(XHost) of
-        undefined ->
-            case MochiReq:get_header_value("Host") of
-                undefined -> [];
-                Value1 -> Value1
-            end;
-        Value -> Value
-    end.
-
-make_vhosts() ->
-    Vhosts = lists:foldl(fun
-                ({_, ""}, Acc) ->
-                    Acc;
-                ({Vhost, Path}, Acc) ->
-                    [{parse_vhost(Vhost), split_path(Path)}|Acc]
-            end, [], couch_config:get("vhosts")),
-
-    lists:reverse(lists:usort(Vhosts)).
-
-
-parse_vhost(Vhost) ->
-    case urlsplit_netloc(Vhost, []) of
-        {[], Path} ->
-            {make_spec("*", []), '*', Path};
-        {HostPort, []} ->
-            {H, P} = split_host_port(HostPort),
-            H1 = make_spec(H, []),
-            {H1, P, []};
-        {HostPort, Path} ->
-            {H, P} = split_host_port(HostPort),
-            H1 = make_spec(H, []),
-            {H1, P, string:tokens(Path, "/")}
-    end.
-
-
-split_host_port(HostAsString) ->
-    case string:rchr(HostAsString, $:) of
-        0 ->
-            {split_host(HostAsString), '*'};
-        N ->
-            HostPart = string:substr(HostAsString, 1, N-1),
-            case (catch erlang:list_to_integer(string:substr(HostAsString,
-                            N+1, length(HostAsString)))) of
-                {'EXIT', _} ->
-                    {split_host(HostAsString), '*'};
-                Port ->
-                    {split_host(HostPart), Port}
-            end
-    end.
-
-split_host(HostAsString) ->
-    string:tokens(HostAsString, "\.").
-
-split_path(Path) ->
-    make_spec(string:tokens(Path, "/"), []).
-
-
-make_spec([], Acc) ->
-    lists:reverse(Acc);
-make_spec([""|R], Acc) ->
-    make_spec(R, Acc);
-make_spec(["*"|R], Acc) ->
-    make_spec(R, [?MATCH_ALL|Acc]);
-make_spec([P|R], Acc) ->
-    P1 = parse_var(P),
-    make_spec(R, [P1|Acc]).
-
-
-parse_var(P) ->
-    case P of
-        ":" ++ Var ->
-            {bind, Var};
-        _ -> P
-    end.
-
-
-% mochiweb doesn't export it.
-urlsplit_netloc("", Acc) ->
-    {lists:reverse(Acc), ""};
-urlsplit_netloc(Rest=[C | _], Acc) when C =:= $/; C =:= $?; C =:= $# ->
-    {lists:reverse(Acc), Rest};
-urlsplit_netloc([C | Rest], Acc) ->
-    urlsplit_netloc(Rest, [C | Acc]).
-
-make_path(Parts) ->
-     "/" ++ string:join(Parts,[?SEPARATOR]).
-
-init(_) ->
-    ok = couch_config:register(fun ?MODULE:config_change/2),
-
-    %% load configuration
-    {VHostGlobals, VHosts, Fun} = load_conf(),
-    State = #vhosts_state{
-        vhost_globals=VHostGlobals,
-        vhosts=VHosts,
-        vhosts_fun=Fun},
-    {ok, State}.
-
-handle_call(reload, _From, _State) ->
-    {VHostGlobals, VHosts, Fun} = load_conf(),
-    {reply, ok, #vhosts_state{
-            vhost_globals=VHostGlobals,
-            vhosts=VHosts,
-            vhosts_fun=Fun}};
-handle_call(get_state, _From, State) ->
-    {reply, State, State};
-handle_call(_Msg, _From, State) ->
-    {noreply, State}.
-
-handle_cast(_Msg, State) ->
-    {noreply, State}.
-
-handle_info(_Info, State) ->
-    {noreply, State}.
-
-terminate(_Reason, _State) ->
-    ok.
-
-code_change(_OldVsn, State, _Extra) ->
-    {ok, State}.
-
-config_change("httpd", "vhost_global_handlers") ->
-    ?MODULE:reload();
-config_change("httpd", "redirect_vhost_handler") ->
-    ?MODULE:reload();
-config_change("vhosts", _) ->
-    ?MODULE:reload().
-
-load_conf() ->
-    %% get vhost globals
-    VHostGlobals = re:split(couch_config:get("httpd",
-            "vhost_global_handlers",""), "\\s*,\\s*",[{return, list}]),
-
-    %% build vhosts matching rules
-    VHosts = make_vhosts(),
-
-    %% build vhosts handler fun
-    DefaultVHostFun = "{couch_httpd_vhost, redirect_to_vhost}",
-    Fun = couch_httpd:make_arity_2_fun(couch_config:get("httpd",
-            "redirect_vhost_handler", DefaultVHostFun)),
-
-    {VHostGlobals, VHosts, Fun}.


[39/57] [abbrv] remove couch_collate

Posted by be...@apache.org.
http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/coll.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/coll.h b/apps/couch_collate/platform/osx/icu/unicode/coll.h
deleted file mode 100644
index 5733f58..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/coll.h
+++ /dev/null
@@ -1,1035 +0,0 @@
-/*
-******************************************************************************
-*   Copyright (C) 1996-2008, International Business Machines                 *
-*   Corporation and others.  All Rights Reserved.                            *
-******************************************************************************
-*/
-
-/**
- * \file 
- * \brief C++ API: Collation Service.
- */
- 
-/**
-* File coll.h
-*
-* Created by: Helena Shih
-*
-* Modification History:
-*
-*  Date        Name        Description
-* 02/5/97      aliu        Modified createDefault to load collation data from
-*                          binary files when possible.  Added related methods
-*                          createCollationFromFile, chopLocale, createPathName.
-* 02/11/97     aliu        Added members addToCache, findInCache, and fgCache.
-* 02/12/97     aliu        Modified to create objects from RuleBasedCollator cache.
-*                          Moved cache out of Collation class.
-* 02/13/97     aliu        Moved several methods out of this class and into
-*                          RuleBasedCollator, with modifications.  Modified
-*                          createDefault() to call new RuleBasedCollator(Locale&)
-*                          constructor.  General clean up and documentation.
-* 02/20/97     helena      Added clone, operator==, operator!=, operator=, copy
-*                          constructor and getDynamicClassID.
-* 03/25/97     helena      Updated with platform independent data types.
-* 05/06/97     helena      Added memory allocation error detection.
-* 06/20/97     helena      Java class name change.
-* 09/03/97     helena      Added createCollationKeyValues().
-* 02/10/98     damiba      Added compare() with length as parameter.
-* 04/23/99     stephen     Removed EDecompositionMode, merged with
-*                          Normalizer::EMode.
-* 11/02/99     helena      Collator performance enhancements.  Eliminates the
-*                          UnicodeString construction and special case for NO_OP.
-* 11/23/99     srl         More performance enhancements. Inlining of
-*                          critical accessors.
-* 05/15/00     helena      Added version information API.
-* 01/29/01     synwee      Modified into a C++ wrapper which calls C apis
-*                          (ucoll.h).
-*/
-
-#ifndef COLL_H
-#define COLL_H
-
-#include "unicode/utypes.h"
-
-#if !UCONFIG_NO_COLLATION
-
-#include "unicode/uobject.h"
-#include "unicode/ucol.h"
-#include "unicode/normlzr.h"
-#include "unicode/locid.h"
-#include "unicode/uniset.h"
-#include "unicode/umisc.h"
-
-U_NAMESPACE_BEGIN
-
-class StringEnumeration;
-
-#if !UCONFIG_NO_SERVICE
-/**
- * @stable ICU 2.6
- */
-class CollatorFactory;
-#endif
-
-/**
-* @stable ICU 2.0
-*/
-class CollationKey;
-
-/**
-* The <code>Collator</code> class performs locale-sensitive string
-* comparison.<br>
-* You use this class to build searching and sorting routines for natural
-* language text.<br>
-* <em>Important: </em>The ICU collation service has been reimplemented
-* in order to achieve better performance and UCA compliance.
-* For details, see the
-* <a href="http://source.icu-project.org/repos/icu/icuhtml/trunk/design/collation/ICU_collation_design.htm">
-* collation design document</a>.
-* <p>
-* <code>Collator</code> is an abstract base class. Subclasses implement
-* specific collation strategies. One subclass,
-* <code>RuleBasedCollator</code>, is currently provided and is applicable
-* to a wide set of languages. Other subclasses may be created to handle more
-* specialized needs.
-* <p>
-* Like other locale-sensitive classes, you can use the static factory method,
-* <code>createInstance</code>, to obtain the appropriate
-* <code>Collator</code> object for a given locale. You will only need to
-* look at the subclasses of <code>Collator</code> if you need to
-* understand the details of a particular collation strategy or if you need to
-* modify that strategy.
-* <p>
-* The following example shows how to compare two strings using the
-* <code>Collator</code> for the default locale.
-* \htmlonly<blockquote>\endhtmlonly
-* <pre>
-* \code
-* // Compare two strings in the default locale
-* UErrorCode success = U_ZERO_ERROR;
-* Collator* myCollator = Collator::createInstance(success);
-* if (myCollator->compare("abc", "ABC") < 0)
-*   cout << "abc is less than ABC" << endl;
-* else
-*   cout << "abc is greater than or equal to ABC" << endl;
-* \endcode
-* </pre>
-* \htmlonly</blockquote>\endhtmlonly
-* <p>
-* You can set a <code>Collator</code>'s <em>strength</em> property to
-* determine the level of difference considered significant in comparisons.
-* Five strengths are provided: <code>PRIMARY</code>, <code>SECONDARY</code>,
-* <code>TERTIARY</code>, <code>QUATERNARY</code> and <code>IDENTICAL</code>.
-* The exact assignment of strengths to language features is locale dependant.
-* For example, in Czech, "e" and "f" are considered primary differences,
-* while "e" and "\u00EA" are secondary differences, "e" and "E" are tertiary
-* differences and "e" and "e" are identical. The following shows how both case
-* and accents could be ignored for US English.
-* \htmlonly<blockquote>\endhtmlonly
-* <pre>
-* \code
-* //Get the Collator for US English and set its strength to PRIMARY
-* UErrorCode success = U_ZERO_ERROR;
-* Collator* usCollator = Collator::createInstance(Locale::US, success);
-* usCollator->setStrength(Collator::PRIMARY);
-* if (usCollator->compare("abc", "ABC") == 0)
-*     cout << "'abc' and 'ABC' strings are equivalent with strength PRIMARY" << endl;
-* \endcode
-* </pre>
-* \htmlonly</blockquote>\endhtmlonly
-* <p>
-* For comparing strings exactly once, the <code>compare</code> method
-* provides the best performance. When sorting a list of strings however, it
-* is generally necessary to compare each string multiple times. In this case,
-* sort keys provide better performance. The <code>getSortKey</code> methods
-* convert a string to a series of bytes that can be compared bitwise against
-* other sort keys using <code>strcmp()</code>. Sort keys are written as
-* zero-terminated byte strings. They consist of several substrings, one for
-* each collation strength level, that are delimited by 0x01 bytes.
-* If the string code points are appended for UCOL_IDENTICAL, then they are
-* processed for correct code point order comparison and may contain 0x01
-* bytes but not zero bytes.
-* </p>
-* <p>
-* An older set of APIs returns a <code>CollationKey</code> object that wraps
-* the sort key bytes instead of returning the bytes themselves.
-* Its use is deprecated, but it is still available for compatibility with
-* Java.
-* </p>
-* <p>
-* <strong>Note:</strong> <code>Collator</code>s with different Locale,
-* and CollationStrength settings will return different sort
-* orders for the same set of strings. Locales have specific collation rules,
-* and the way in which secondary and tertiary differences are taken into
-* account, for example, will result in a different sorting order for same
-* strings.
-* </p>
-* @see         RuleBasedCollator
-* @see         CollationKey
-* @see         CollationElementIterator
-* @see         Locale
-* @see         Normalizer
-* @version     2.0 11/15/01
-*/
-
-class U_I18N_API Collator : public UObject {
-public:
-
-    // Collator public enums -----------------------------------------------
-
-    /**
-     * Base letter represents a primary difference. Set comparison level to
-     * PRIMARY to ignore secondary and tertiary differences.<br>
-     * Use this to set the strength of a Collator object.<br>
-     * Example of primary difference, "abc" &lt; "abd"
-     *
-     * Diacritical differences on the same base letter represent a secondary
-     * difference. Set comparison level to SECONDARY to ignore tertiary
-     * differences. Use this to set the strength of a Collator object.<br>
-     * Example of secondary difference, "&auml;" >> "a".
-     *
-     * Uppercase and lowercase versions of the same character represents a
-     * tertiary difference.  Set comparison level to TERTIARY to include all
-     * comparison differences. Use this to set the strength of a Collator
-     * object.<br>
-     * Example of tertiary difference, "abc" &lt;&lt;&lt; "ABC".
-     *
-     * Two characters are considered "identical" when they have the same unicode
-     * spellings.<br>
-     * For example, "&auml;" == "&auml;".
-     *
-     * UCollationStrength is also used to determine the strength of sort keys
-     * generated from Collator objects.
-     * @stable ICU 2.0
-     */
-    enum ECollationStrength
-    {
-        PRIMARY    = 0,
-        SECONDARY  = 1,
-        TERTIARY   = 2,
-        QUATERNARY = 3,
-        IDENTICAL  = 15
-    };
-
-    /**
-     * LESS is returned if source string is compared to be less than target
-     * string in the compare() method.
-     * EQUAL is returned if source string is compared to be equal to target
-     * string in the compare() method.
-     * GREATER is returned if source string is compared to be greater than
-     * target string in the compare() method.
-     * @see Collator#compare
-     * @deprecated ICU 2.6. Use C enum UCollationResult defined in ucol.h
-     */
-    enum EComparisonResult
-    {
-        LESS = -1,
-        EQUAL = 0,
-        GREATER = 1
-    };
-
-    // Collator public destructor -----------------------------------------
-
-    /**
-     * Destructor
-     * @stable ICU 2.0
-     */
-    virtual ~Collator();
-
-    // Collator public methods --------------------------------------------
-
-    /**
-     * Returns true if "other" is the same as "this"
-     * @param other Collator object to be compared
-     * @return true if other is the same as this.
-     * @stable ICU 2.0
-     */
-    virtual UBool operator==(const Collator& other) const;
-
-    /**
-     * Returns true if "other" is not the same as "this".
-     * @param other Collator object to be compared
-     * @return true if other is not the same as this.
-     * @stable ICU 2.0
-     */
-    virtual UBool operator!=(const Collator& other) const;
-
-    /**
-     * Makes a shallow copy of the current object.
-     * @return a copy of this object
-     * @stable ICU 2.0
-     */
-    virtual Collator* clone(void) const = 0;
-
-    /**
-     * Creates the Collator object for the current default locale.
-     * The default locale is determined by Locale::getDefault.
-     * The UErrorCode& err parameter is used to return status information to the user.
-     * To check whether the construction succeeded or not, you should check the
-     * value of U_SUCCESS(err).  If you wish more detailed information, you can
-     * check for informational error results which still indicate success.
-     * U_USING_FALLBACK_ERROR indicates that a fall back locale was used. For
-     * example, 'de_CH' was requested, but nothing was found there, so 'de' was
-     * used. U_USING_DEFAULT_ERROR indicates that the default locale data was
-     * used; neither the requested locale nor any of its fall back locales
-     * could be found.
-     * The caller owns the returned object and is responsible for deleting it.
-     *
-     * @param err    the error code status.
-     * @return       the collation object of the default locale.(for example, en_US)
-     * @see Locale#getDefault
-     * @stable ICU 2.0
-     */
-    static Collator* U_EXPORT2 createInstance(UErrorCode&  err);
-
-    /**
-     * Gets the table-based collation object for the desired locale. The
-     * resource of the desired locale will be loaded by ResourceLoader.
-     * Locale::ENGLISH is the base collation table and all other languages are
-     * built on top of it with additional language-specific modifications.
-     * The UErrorCode& err parameter is used to return status information to the user.
-     * To check whether the construction succeeded or not, you should check
-     * the value of U_SUCCESS(err).  If you wish more detailed information, you
-     * can check for informational error results which still indicate success.
-     * U_USING_FALLBACK_ERROR indicates that a fall back locale was used.  For
-     * example, 'de_CH' was requested, but nothing was found there, so 'de' was
-     * used.  U_USING_DEFAULT_ERROR indicates that the default locale data was
-     * used; neither the requested locale nor any of its fall back locales
-     * could be found.
-     * The caller owns the returned object and is responsible for deleting it.
-     * @param loc    The locale ID for which to open a collator.
-     * @param err    the error code status.
-     * @return       the created table-based collation object based on the desired
-     *               locale.
-     * @see Locale
-     * @see ResourceLoader
-     * @stable ICU 2.2
-     */
-    static Collator* U_EXPORT2 createInstance(const Locale& loc, UErrorCode& err);
-
-#ifdef U_USE_COLLATION_OBSOLETE_2_6
-    /**
-     * Create a Collator with a specific version.
-     * This is the same as createInstance(loc, err) except that getVersion() of
-     * the returned object is guaranteed to be the same as the version
-     * parameter.
-     * This is designed to be used to open the same collator for a given
-     * locale even when ICU is updated.
-     * The same locale and version guarantees the same sort keys and
-     * comparison results.
-     * <p>
-     * Note: this API will be removed in a future release.  Use
-     * <tt>createInstance(const Locale&, UErrorCode&) instead.</tt></p>
-     *
-     * @param loc The locale ID for which to open a collator.
-     * @param version The requested collator version.
-     * @param err A reference to a UErrorCode,
-     *            must not indicate a failure before calling this function.
-     * @return A pointer to a Collator, or 0 if an error occurred
-     *         or a collator with the requested version is not available.
-     *
-     * @see getVersion
-     * @obsolete ICU 2.6
-     */
-    static Collator *createInstance(const Locale &loc, UVersionInfo version, UErrorCode &err);
-#endif
-
-    /**
-     * The comparison function compares the character data stored in two
-     * different strings. Returns information about whether a string is less
-     * than, greater than or equal to another string.
-     * @param source the source string to be compared with.
-     * @param target the string that is to be compared with the source string.
-     * @return Returns a byte value. GREATER if source is greater
-     * than target; EQUAL if source is equal to target; LESS if source is less
-     * than target
-     * @deprecated ICU 2.6 use the overload with UErrorCode &
-     */
-    virtual EComparisonResult compare(const UnicodeString& source,
-                                      const UnicodeString& target) const;
-
-    /**
-     * The comparison function compares the character data stored in two
-     * different strings. Returns information about whether a string is less
-     * than, greater than or equal to another string.
-     * @param source the source string to be compared with.
-     * @param target the string that is to be compared with the source string.
-     * @param status possible error code
-     * @return Returns an enum value. UCOL_GREATER if source is greater
-     * than target; UCOL_EQUAL if source is equal to target; UCOL_LESS if source is less
-     * than target
-     * @stable ICU 2.6
-     */
-    virtual UCollationResult compare(const UnicodeString& source,
-                                      const UnicodeString& target,
-                                      UErrorCode &status) const = 0;
-
-    /**
-     * Does the same thing as compare but limits the comparison to a specified
-     * length
-     * @param source the source string to be compared with.
-     * @param target the string that is to be compared with the source string.
-     * @param length the length the comparison is limited to
-     * @return Returns a byte value. GREATER if source (up to the specified
-     *         length) is greater than target; EQUAL if source (up to specified
-     *         length) is equal to target; LESS if source (up to the specified
-     *         length) is less  than target.
-     * @deprecated ICU 2.6 use the overload with UErrorCode &
-     */
-    virtual EComparisonResult compare(const UnicodeString& source,
-                                      const UnicodeString& target,
-                                      int32_t length) const;
-
-    /**
-     * Does the same thing as compare but limits the comparison to a specified
-     * length
-     * @param source the source string to be compared with.
-     * @param target the string that is to be compared with the source string.
-     * @param length the length the comparison is limited to
-     * @param status possible error code
-     * @return Returns an enum value. UCOL_GREATER if source (up to the specified
-     *         length) is greater than target; UCOL_EQUAL if source (up to specified
-     *         length) is equal to target; UCOL_LESS if source (up to the specified
-     *         length) is less  than target.
-     * @stable ICU 2.6
-     */
-    virtual UCollationResult compare(const UnicodeString& source,
-                                      const UnicodeString& target,
-                                      int32_t length,
-                                      UErrorCode &status) const = 0;
-
-    /**
-     * The comparison function compares the character data stored in two
-     * different string arrays. Returns information about whether a string array
-     * is less than, greater than or equal to another string array.
-     * @param source the source string array to be compared with.
-     * @param sourceLength the length of the source string array.  If this value
-     *        is equal to -1, the string array is null-terminated.
-     * @param target the string that is to be compared with the source string.
-     * @param targetLength the length of the target string array.  If this value
-     *        is equal to -1, the string array is null-terminated.
-     * @return Returns a byte value. GREATER if source is greater than target;
-     *         EQUAL if source is equal to target; LESS if source is less than
-     *         target
-     * @deprecated ICU 2.6 use the overload with UErrorCode &
-     */
-    virtual EComparisonResult compare(const UChar* source, int32_t sourceLength,
-                                      const UChar* target, int32_t targetLength)
-                                      const;
-
-    /**
-     * The comparison function compares the character data stored in two
-     * different string arrays. Returns information about whether a string array
-     * is less than, greater than or equal to another string array.
-     * @param source the source string array to be compared with.
-     * @param sourceLength the length of the source string array.  If this value
-     *        is equal to -1, the string array is null-terminated.
-     * @param target the string that is to be compared with the source string.
-     * @param targetLength the length of the target string array.  If this value
-     *        is equal to -1, the string array is null-terminated.
-     * @param status possible error code
-     * @return Returns an enum value. UCOL_GREATER if source is greater
-     * than target; UCOL_EQUAL if source is equal to target; UCOL_LESS if source is less
-     * than target
-     * @stable ICU 2.6
-     */
-    virtual UCollationResult compare(const UChar* source, int32_t sourceLength,
-                                      const UChar* target, int32_t targetLength,
-                                      UErrorCode &status) const = 0;
-
-    /**
-     * Transforms the string into a series of characters that can be compared
-     * with CollationKey::compareTo. It is not possible to restore the original
-     * string from the chars in the sort key.  The generated sort key handles
-     * only a limited number of ignorable characters.
-     * <p>Use CollationKey::equals or CollationKey::compare to compare the
-     * generated sort keys.
-     * If the source string is null, a null collation key will be returned.
-     * @param source the source string to be transformed into a sort key.
-     * @param key the collation key to be filled in
-     * @param status the error code status.
-     * @return the collation key of the string based on the collation rules.
-     * @see CollationKey#compare
-     * @deprecated ICU 2.8 Use getSortKey(...) instead
-     */
-    virtual CollationKey& getCollationKey(const UnicodeString&  source,
-                                          CollationKey& key,
-                                          UErrorCode& status) const = 0;
-
-    /**
-     * Transforms the string into a series of characters that can be compared
-     * with CollationKey::compareTo. It is not possible to restore the original
-     * string from the chars in the sort key.  The generated sort key handles
-     * only a limited number of ignorable characters.
-     * <p>Use CollationKey::equals or CollationKey::compare to compare the
-     * generated sort keys.
-     * <p>If the source string is null, a null collation key will be returned.
-     * @param source the source string to be transformed into a sort key.
-     * @param sourceLength length of the collation key
-     * @param key the collation key to be filled in
-     * @param status the error code status.
-     * @return the collation key of the string based on the collation rules.
-     * @see CollationKey#compare
-     * @deprecated ICU 2.8 Use getSortKey(...) instead
-     */
-    virtual CollationKey& getCollationKey(const UChar*source,
-                                          int32_t sourceLength,
-                                          CollationKey& key,
-                                          UErrorCode& status) const = 0;
-    /**
-     * Generates the hash code for the collation object
-     * @stable ICU 2.0
-     */
-    virtual int32_t hashCode(void) const = 0;
-
-    /**
-     * Gets the locale of the Collator
-     *
-     * @param type can be either requested, valid or actual locale. For more
-     *             information see the definition of ULocDataLocaleType in
-     *             uloc.h
-     * @param status the error code status.
-     * @return locale where the collation data lives. If the collator
-     *         was instantiated from rules, locale is empty.
-     * @deprecated ICU 2.8 This API is under consideration for revision
-     * in ICU 3.0.
-     */
-    virtual const Locale getLocale(ULocDataLocaleType type, UErrorCode& status) const = 0;
-
-    /**
-     * Convenience method for comparing two strings based on the collation rules.
-     * @param source the source string to be compared with.
-     * @param target the target string to be compared with.
-     * @return true if the first string is greater than the second one,
-     *         according to the collation rules. false, otherwise.
-     * @see Collator#compare
-     * @stable ICU 2.0
-     */
-    UBool greater(const UnicodeString& source, const UnicodeString& target)
-                  const;
-
-    /**
-     * Convenience method for comparing two strings based on the collation rules.
-     * @param source the source string to be compared with.
-     * @param target the target string to be compared with.
-     * @return true if the first string is greater than or equal to the second
-     *         one, according to the collation rules. false, otherwise.
-     * @see Collator#compare
-     * @stable ICU 2.0
-     */
-    UBool greaterOrEqual(const UnicodeString& source,
-                         const UnicodeString& target) const;
-
-    /**
-     * Convenience method for comparing two strings based on the collation rules.
-     * @param source the source string to be compared with.
-     * @param target the target string to be compared with.
-     * @return true if the strings are equal according to the collation rules.
-     *         false, otherwise.
-     * @see Collator#compare
-     * @stable ICU 2.0
-     */
-    UBool equals(const UnicodeString& source, const UnicodeString& target) const;
-
-    /**
-     * Determines the minimum strength that will be use in comparison or
-     * transformation.
-     * <p>E.g. with strength == SECONDARY, the tertiary difference is ignored
-     * <p>E.g. with strength == PRIMARY, the secondary and tertiary difference
-     * are ignored.
-     * @return the current comparison level.
-     * @see Collator#setStrength
-     * @deprecated ICU 2.6 Use getAttribute(UCOL_STRENGTH...) instead
-     */
-    virtual ECollationStrength getStrength(void) const = 0;
-
-    /**
-     * Sets the minimum strength to be used in comparison or transformation.
-     * <p>Example of use:
-     * <pre>
-     *  \code
-     *  UErrorCode status = U_ZERO_ERROR;
-     *  Collator*myCollation = Collator::createInstance(Locale::US, status);
-     *  if (U_FAILURE(status)) return;
-     *  myCollation->setStrength(Collator::PRIMARY);
-     *  // result will be "abc" == "ABC"
-     *  // tertiary differences will be ignored
-     *  Collator::ComparisonResult result = myCollation->compare("abc", "ABC");
-     * \endcode
-     * </pre>
-     * @see Collator#getStrength
-     * @param newStrength the new comparison level.
-     * @deprecated ICU 2.6 Use setAttribute(UCOL_STRENGTH...) instead
-     */
-    virtual void setStrength(ECollationStrength newStrength) = 0;
-
-    /**
-     * Get name of the object for the desired Locale, in the desired langauge
-     * @param objectLocale must be from getAvailableLocales
-     * @param displayLocale specifies the desired locale for output
-     * @param name the fill-in parameter of the return value
-     * @return display-able name of the object for the object locale in the
-     *         desired language
-     * @stable ICU 2.0
-     */
-    static UnicodeString& U_EXPORT2 getDisplayName(const Locale& objectLocale,
-                                         const Locale& displayLocale,
-                                         UnicodeString& name);
-
-    /**
-    * Get name of the object for the desired Locale, in the langauge of the
-    * default locale.
-    * @param objectLocale must be from getAvailableLocales
-    * @param name the fill-in parameter of the return value
-    * @return name of the object for the desired locale in the default language
-    * @stable ICU 2.0
-    */
-    static UnicodeString& U_EXPORT2 getDisplayName(const Locale& objectLocale,
-                                         UnicodeString& name);
-
-    /**
-     * Get the set of Locales for which Collations are installed.
-     *
-     * <p>Note this does not include locales supported by registered collators.
-     * If collators might have been registered, use the overload of getAvailableLocales
-     * that returns a StringEnumeration.</p>
-     *
-     * @param count the output parameter of number of elements in the locale list
-     * @return the list of available locales for which collations are installed
-     * @stable ICU 2.0
-     */
-    static const Locale* U_EXPORT2 getAvailableLocales(int32_t& count);
-
-    /**
-     * Return a StringEnumeration over the locales available at the time of the call,
-     * including registered locales.  If a severe error occurs (such as out of memory
-     * condition) this will return null. If there is no locale data, an empty enumeration
-     * will be returned.
-     * @return a StringEnumeration over the locales available at the time of the call
-     * @stable ICU 2.6
-     */
-    static StringEnumeration* U_EXPORT2 getAvailableLocales(void);
-
-    /**
-     * Create a string enumerator of all possible keywords that are relevant to
-     * collation. At this point, the only recognized keyword for this
-     * service is "collation".
-     * @param status input-output error code
-     * @return a string enumeration over locale strings. The caller is
-     * responsible for closing the result.
-     * @stable ICU 3.0
-     */
-    static StringEnumeration* U_EXPORT2 getKeywords(UErrorCode& status);
-
-    /**
-     * Given a keyword, create a string enumeration of all values
-     * for that keyword that are currently in use.
-     * @param keyword a particular keyword as enumerated by
-     * ucol_getKeywords. If any other keyword is passed in, status is set
-     * to U_ILLEGAL_ARGUMENT_ERROR.
-     * @param status input-output error code
-     * @return a string enumeration over collation keyword values, or NULL
-     * upon error. The caller is responsible for deleting the result.
-     * @stable ICU 3.0
-     */
-    static StringEnumeration* U_EXPORT2 getKeywordValues(const char *keyword, UErrorCode& status);
-
-    /**
-     * Return the functionally equivalent locale for the given
-     * requested locale, with respect to given keyword, for the
-     * collation service.  If two locales return the same result, then
-     * collators instantiated for these locales will behave
-     * equivalently.  The converse is not always true; two collators
-     * may in fact be equivalent, but return different results, due to
-     * internal details.  The return result has no other meaning than
-     * that stated above, and implies nothing as to the relationship
-     * between the two locales.  This is intended for use by
-     * applications who wish to cache collators, or otherwise reuse
-     * collators when possible.  The functional equivalent may change
-     * over time.  For more information, please see the <a
-     * href="http://icu-project.org/userguide/locale.html#services">
-     * Locales and Services</a> section of the ICU User Guide.
-     * @param keyword a particular keyword as enumerated by
-     * ucol_getKeywords.
-     * @param locale the requested locale
-     * @param isAvailable reference to a fillin parameter that
-     * indicates whether the requested locale was 'available' to the
-     * collation service. A locale is defined as 'available' if it
-     * physically exists within the collation locale data.
-     * @param status reference to input-output error code
-     * @return the functionally equivalent collation locale, or the root
-     * locale upon error.
-     * @stable ICU 3.0
-     */
-    static Locale U_EXPORT2 getFunctionalEquivalent(const char* keyword, const Locale& locale,
-                                          UBool& isAvailable, UErrorCode& status);
-
-#if !UCONFIG_NO_SERVICE
-    /**
-     * Register a new Collator.  The collator will be adopted.
-     * @param toAdopt the Collator instance to be adopted
-     * @param locale the locale with which the collator will be associated
-     * @param status the in/out status code, no special meanings are assigned
-     * @return a registry key that can be used to unregister this collator
-     * @stable ICU 2.6
-     */
-    static URegistryKey U_EXPORT2 registerInstance(Collator* toAdopt, const Locale& locale, UErrorCode& status);
-
-    /**
-     * Register a new CollatorFactory.  The factory will be adopted.
-     * @param toAdopt the CollatorFactory instance to be adopted
-     * @param status the in/out status code, no special meanings are assigned
-     * @return a registry key that can be used to unregister this collator
-     * @stable ICU 2.6
-     */
-    static URegistryKey U_EXPORT2 registerFactory(CollatorFactory* toAdopt, UErrorCode& status);
-
-    /**
-     * Unregister a previously-registered Collator or CollatorFactory
-     * using the key returned from the register call.  Key becomes
-     * invalid after a successful call and should not be used again.
-     * The object corresponding to the key will be deleted.
-     * @param key the registry key returned by a previous call to registerInstance
-     * @param status the in/out status code, no special meanings are assigned
-     * @return TRUE if the collator for the key was successfully unregistered
-     * @stable ICU 2.6
-     */
-    static UBool U_EXPORT2 unregister(URegistryKey key, UErrorCode& status);
-#endif /* UCONFIG_NO_SERVICE */
-
-    /**
-     * Gets the version information for a Collator.
-     * @param info the version # information, the result will be filled in
-     * @stable ICU 2.0
-     */
-    virtual void getVersion(UVersionInfo info) const = 0;
-
-    /**
-     * Returns a unique class ID POLYMORPHICALLY. Pure virtual method.
-     * This method is to implement a simple version of RTTI, since not all C++
-     * compilers support genuine RTTI. Polymorphic operator==() and clone()
-     * methods call this method.
-     * @return The class ID for this object. All objects of a given class have
-     *         the same class ID.  Objects of other classes have different class
-     *         IDs.
-     * @stable ICU 2.0
-     */
-    virtual UClassID getDynamicClassID(void) const = 0;
-
-    /**
-     * Universal attribute setter
-     * @param attr attribute type
-     * @param value attribute value
-     * @param status to indicate whether the operation went on smoothly or
-     *        there were errors
-     * @stable ICU 2.2
-     */
-    virtual void setAttribute(UColAttribute attr, UColAttributeValue value,
-                              UErrorCode &status) = 0;
-
-    /**
-     * Universal attribute getter
-     * @param attr attribute type
-     * @param status to indicate whether the operation went on smoothly or
-     *        there were errors
-     * @return attribute value
-     * @stable ICU 2.2
-     */
-    virtual UColAttributeValue getAttribute(UColAttribute attr,
-                                            UErrorCode &status) = 0;
-
-    /**
-     * Sets the variable top to a collation element value of a string supplied.
-     * @param varTop one or more (if contraction) UChars to which the variable top should be set
-     * @param len length of variable top string. If -1 it is considered to be zero terminated.
-     * @param status error code. If error code is set, the return value is undefined. Errors set by this function are: <br>
-     *    U_CE_NOT_FOUND_ERROR if more than one character was passed and there is no such a contraction<br>
-     *    U_PRIMARY_TOO_LONG_ERROR if the primary for the variable top has more than two bytes
-     * @return a 32 bit value containing the value of the variable top in upper 16 bits. Lower 16 bits are undefined
-     * @stable ICU 2.0
-     */
-    virtual uint32_t setVariableTop(const UChar *varTop, int32_t len, UErrorCode &status) = 0;
-
-    /**
-     * Sets the variable top to a collation element value of a string supplied.
-     * @param varTop an UnicodeString size 1 or more (if contraction) of UChars to which the variable top should be set
-     * @param status error code. If error code is set, the return value is undefined. Errors set by this function are: <br>
-     *    U_CE_NOT_FOUND_ERROR if more than one character was passed and there is no such a contraction<br>
-     *    U_PRIMARY_TOO_LONG_ERROR if the primary for the variable top has more than two bytes
-     * @return a 32 bit value containing the value of the variable top in upper 16 bits. Lower 16 bits are undefined
-     * @stable ICU 2.0
-     */
-    virtual uint32_t setVariableTop(const UnicodeString varTop, UErrorCode &status) = 0;
-
-    /**
-     * Sets the variable top to a collation element value supplied. Variable top is set to the upper 16 bits.
-     * Lower 16 bits are ignored.
-     * @param varTop CE value, as returned by setVariableTop or ucol)getVariableTop
-     * @param status error code (not changed by function)
-     * @stable ICU 2.0
-     */
-    virtual void setVariableTop(const uint32_t varTop, UErrorCode &status) = 0;
-
-    /**
-     * Gets the variable top value of a Collator.
-     * Lower 16 bits are undefined and should be ignored.
-     * @param status error code (not changed by function). If error code is set, the return value is undefined.
-     * @stable ICU 2.0
-     */
-    virtual uint32_t getVariableTop(UErrorCode &status) const = 0;
-
-    /**
-     * Get an UnicodeSet that contains all the characters and sequences
-     * tailored in this collator.
-     * @param status      error code of the operation
-     * @return a pointer to a UnicodeSet object containing all the
-     *         code points and sequences that may sort differently than
-     *         in the UCA. The object must be disposed of by using delete
-     * @stable ICU 2.4
-     */
-    virtual UnicodeSet *getTailoredSet(UErrorCode &status) const;
-
-
-    /**
-     * Thread safe cloning operation
-     * @return pointer to the new clone, user should remove it.
-     * @stable ICU 2.2
-     */
-    virtual Collator* safeClone(void) = 0;
-
-    /**
-     * Get the sort key as an array of bytes from an UnicodeString.
-     * Sort key byte arrays are zero-terminated and can be compared using
-     * strcmp().
-     * @param source string to be processed.
-     * @param result buffer to store result in. If NULL, number of bytes needed
-     *        will be returned.
-     * @param resultLength length of the result buffer. If if not enough the
-     *        buffer will be filled to capacity.
-     * @return Number of bytes needed for storing the sort key
-     * @stable ICU 2.2
-     */
-    virtual int32_t getSortKey(const UnicodeString& source,
-                              uint8_t* result,
-                              int32_t resultLength) const = 0;
-
-    /**
-     * Get the sort key as an array of bytes from an UChar buffer.
-     * Sort key byte arrays are zero-terminated and can be compared using
-     * strcmp().
-     * @param source string to be processed.
-     * @param sourceLength length of string to be processed.
-     *        If -1, the string is 0 terminated and length will be decided by the
-     *        function.
-     * @param result buffer to store result in. If NULL, number of bytes needed
-     *        will be returned.
-     * @param resultLength length of the result buffer. If if not enough the
-     *        buffer will be filled to capacity.
-     * @return Number of bytes needed for storing the sort key
-     * @stable ICU 2.2
-     */
-    virtual int32_t getSortKey(const UChar*source, int32_t sourceLength,
-                               uint8_t*result, int32_t resultLength) const = 0;
-
-    /**
-     * Produce a bound for a given sortkey and a number of levels.
-     * Return value is always the number of bytes needed, regardless of
-     * whether the result buffer was big enough or even valid.<br>
-     * Resulting bounds can be used to produce a range of strings that are
-     * between upper and lower bounds. For example, if bounds are produced
-     * for a sortkey of string "smith", strings between upper and lower
-     * bounds with one level would include "Smith", "SMITH", "sMiTh".<br>
-     * There are two upper bounds that can be produced. If UCOL_BOUND_UPPER
-     * is produced, strings matched would be as above. However, if bound
-     * produced using UCOL_BOUND_UPPER_LONG is used, the above example will
-     * also match "Smithsonian" and similar.<br>
-     * For more on usage, see example in cintltst/capitst.c in procedure
-     * TestBounds.
-     * Sort keys may be compared using <TT>strcmp</TT>.
-     * @param source The source sortkey.
-     * @param sourceLength The length of source, or -1 if null-terminated.
-     *                     (If an unmodified sortkey is passed, it is always null
-     *                      terminated).
-     * @param boundType Type of bound required. It can be UCOL_BOUND_LOWER, which
-     *                  produces a lower inclusive bound, UCOL_BOUND_UPPER, that
-     *                  produces upper bound that matches strings of the same length
-     *                  or UCOL_BOUND_UPPER_LONG that matches strings that have the
-     *                  same starting substring as the source string.
-     * @param noOfLevels  Number of levels required in the resulting bound (for most
-     *                    uses, the recommended value is 1). See users guide for
-     *                    explanation on number of levels a sortkey can have.
-     * @param result A pointer to a buffer to receive the resulting sortkey.
-     * @param resultLength The maximum size of result.
-     * @param status Used for returning error code if something went wrong. If the
-     *               number of levels requested is higher than the number of levels
-     *               in the source key, a warning (U_SORT_KEY_TOO_SHORT_WARNING) is
-     *               issued.
-     * @return The size needed to fully store the bound.
-     * @see ucol_keyHashCode
-     * @stable ICU 2.1
-     */
-    static int32_t U_EXPORT2 getBound(const uint8_t       *source,
-            int32_t             sourceLength,
-            UColBoundMode       boundType,
-            uint32_t            noOfLevels,
-            uint8_t             *result,
-            int32_t             resultLength,
-            UErrorCode          &status);
-
-
-protected:
-
-    // Collator protected constructors -------------------------------------
-
-    /**
-    * Default constructor.
-    * Constructor is different from the old default Collator constructor.
-    * The task for determing the default collation strength and normalization
-    * mode is left to the child class.
-    * @stable ICU 2.0
-    */
-    Collator();
-
-    /**
-    * Constructor.
-    * Empty constructor, does not handle the arguments.
-    * This constructor is done for backward compatibility with 1.7 and 1.8.
-    * The task for handling the argument collation strength and normalization
-    * mode is left to the child class.
-    * @param collationStrength collation strength
-    * @param decompositionMode
-    * @deprecated ICU 2.4. Subclasses should use the default constructor
-    * instead and handle the strength and normalization mode themselves.
-    */
-    Collator(UCollationStrength collationStrength,
-             UNormalizationMode decompositionMode);
-
-    /**
-    * Copy constructor.
-    * @param other Collator object to be copied from
-    * @stable ICU 2.0
-    */
-    Collator(const Collator& other);
-
-    // Collator protected methods -----------------------------------------
-
-
-   /**
-    * Used internally by registraton to define the requested and valid locales.
-    * @param requestedLocale the requsted locale
-    * @param validLocale the valid locale
-    * @internal
-    */
-    virtual void setLocales(const Locale& requestedLocale, const Locale& validLocale, const Locale& actualLocale);
-
-public:
-#if !UCONFIG_NO_SERVICE
-    /**
-     * used only by ucol_open, not for public use
-     * @internal
-     */
-    static UCollator* createUCollator(const char* loc, UErrorCode* status);
-#endif
-private:
-    /**
-     * Assignment operator. Private for now.
-     * @internal
-     */
-    Collator& operator=(const Collator& other);
-
-    friend class CFactory;
-    friend class SimpleCFactory;
-    friend class ICUCollatorFactory;
-    friend class ICUCollatorService;
-    static Collator* makeInstance(const Locale& desiredLocale,
-                                  UErrorCode& status);
-
-    // Collator private data members ---------------------------------------
-
-    /*
-    synwee : removed as attributes to be handled by child class
-    UCollationStrength  strength;
-    Normalizer::EMode  decmp;
-    */
-    /* This is useless information */
-/*  static const UVersionInfo fVersion;*/
-};
-
-#if !UCONFIG_NO_SERVICE
-/**
- * A factory, used with registerFactory, the creates multiple collators and provides
- * display names for them.  A factory supports some number of locales-- these are the
- * locales for which it can create collators.  The factory can be visible, in which
- * case the supported locales will be enumerated by getAvailableLocales, or invisible,
- * in which they are not.  Invisible locales are still supported, they are just not
- * listed by getAvailableLocales.
- * <p>
- * If standard locale display names are sufficient, Collator instances can
- * be registered using registerInstance instead.</p>
- * <p>
- * Note: if the collators are to be used from C APIs, they must be instances
- * of RuleBasedCollator.</p>
- *
- * @stable ICU 2.6
- */
-class U_I18N_API CollatorFactory : public UObject {
-public:
-
-    /**
-     * Destructor
-     * @stable ICU 3.0
-     */
-    virtual ~CollatorFactory();
-
-    /**
-     * Return true if this factory is visible.  Default is true.
-     * If not visible, the locales supported by this factory will not
-     * be listed by getAvailableLocales.
-     * @return true if the factory is visible.
-     * @stable ICU 2.6
-     */
-    virtual UBool visible(void) const;
-
-    /**
-     * Return a collator for the provided locale.  If the locale
-     * is not supported, return NULL.
-     * @param loc the locale identifying the collator to be created.
-     * @return a new collator if the locale is supported, otherwise NULL.
-     * @stable ICU 2.6
-     */
-    virtual Collator* createCollator(const Locale& loc) = 0;
-
-    /**
-     * Return the name of the collator for the objectLocale, localized for the displayLocale.
-     * If objectLocale is not supported, or the factory is not visible, set the result string
-     * to bogus.
-     * @param objectLocale the locale identifying the collator
-     * @param displayLocale the locale for which the display name of the collator should be localized
-     * @param result an output parameter for the display name, set to bogus if not supported.
-     * @return the display name
-     * @stable ICU 2.6
-     */
-    virtual  UnicodeString& getDisplayName(const Locale& objectLocale,
-                                           const Locale& displayLocale,
-                                           UnicodeString& result);
-
-    /**
-     * Return an array of all the locale names directly supported by this factory.
-     * The number of names is returned in count.  This array is owned by the factory.
-     * Its contents must never change.
-     * @param count output parameter for the number of locales supported by the factory
-     * @param status the in/out error code
-     * @return a pointer to an array of count UnicodeStrings.
-     * @stable ICU 2.6
-     */
-    virtual const UnicodeString * getSupportedIDs(int32_t &count, UErrorCode& status) = 0;
-};
-#endif /* UCONFIG_NO_SERVICE */
-
-// Collator inline methods -----------------------------------------------
-
-U_NAMESPACE_END
-
-#endif /* #if !UCONFIG_NO_COLLATION */
-
-#endif

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/curramt.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/curramt.h b/apps/couch_collate/platform/osx/icu/unicode/curramt.h
deleted file mode 100644
index c33e6f1..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/curramt.h
+++ /dev/null
@@ -1,130 +0,0 @@
-/*
-**********************************************************************
-* Copyright (c) 2004-2006, International Business Machines
-* Corporation and others.  All Rights Reserved.
-**********************************************************************
-* Author: Alan Liu
-* Created: April 26, 2004
-* Since: ICU 3.0
-**********************************************************************
-*/
-#ifndef __CURRENCYAMOUNT_H__
-#define __CURRENCYAMOUNT_H__
-
-#include "unicode/utypes.h"
-
-#if !UCONFIG_NO_FORMATTING
-
-#include "unicode/measure.h"
-#include "unicode/currunit.h"
-
-/**
- * \file 
- * \brief C++ API: Currency Amount Object.
- */
- 
-U_NAMESPACE_BEGIN
-
-/**
- *
- * A currency together with a numeric amount, such as 200 USD.
- *
- * @author Alan Liu
- * @stable ICU 3.0
- */
-class U_I18N_API CurrencyAmount: public Measure {
- public:
-    /**
-     * Construct an object with the given numeric amount and the given
-     * ISO currency code.
-     * @param amount a numeric object; amount.isNumeric() must be TRUE
-     * @param isoCode the 3-letter ISO 4217 currency code; must not be
-     * NULL and must have length 3
-     * @param ec input-output error code. If the amount or the isoCode
-     * is invalid, then this will be set to a failing value.
-     * @stable ICU 3.0
-     */
-    CurrencyAmount(const Formattable& amount, const UChar* isoCode,
-                   UErrorCode &ec);
-
-    /**
-     * Construct an object with the given numeric amount and the given
-     * ISO currency code.
-     * @param amount the amount of the given currency
-     * @param isoCode the 3-letter ISO 4217 currency code; must not be
-     * NULL and must have length 3
-     * @param ec input-output error code. If the isoCode is invalid,
-     * then this will be set to a failing value.
-     * @stable ICU 3.0
-     */
-    CurrencyAmount(double amount, const UChar* isoCode,
-                   UErrorCode &ec);
-
-    /**
-     * Copy constructor
-     * @stable ICU 3.0
-     */
-    CurrencyAmount(const CurrencyAmount& other);
- 
-    /**
-     * Assignment operator
-     * @stable ICU 3.0
-     */
-    CurrencyAmount& operator=(const CurrencyAmount& other);
-
-    /**
-     * Return a polymorphic clone of this object.  The result will
-     * have the same class as returned by getDynamicClassID().
-     * @stable ICU 3.0
-     */
-    virtual UObject* clone() const;
-
-    /**
-     * Destructor
-     * @stable ICU 3.0
-     */
-    virtual ~CurrencyAmount();
-    
-    /**
-     * Returns a unique class ID for this object POLYMORPHICALLY.
-     * This method implements a simple form of RTTI used by ICU.
-     * @return The class ID for this object. All objects of a given
-     * class have the same class ID.  Objects of other classes have
-     * different class IDs.
-     * @stable ICU 3.0
-     */
-    virtual UClassID getDynamicClassID() const;
-
-    /**
-     * Returns the class ID for this class. This is used to compare to
-     * the return value of getDynamicClassID().
-     * @return The class ID for all objects of this class.
-     * @stable ICU 3.0
-     */
-    static UClassID U_EXPORT2 getStaticClassID();
-
-    /**
-     * Return the currency unit object of this object.
-     * @stable ICU 3.0
-     */
-    inline const CurrencyUnit& getCurrency() const;
-
-    /**
-     * Return the ISO currency code of this object.
-     * @stable ICU 3.0
-     */
-    inline const UChar* getISOCurrency() const;
-};
-
-inline const CurrencyUnit& CurrencyAmount::getCurrency() const {
-    return (const CurrencyUnit&) getUnit();
-}
-
-inline const UChar* CurrencyAmount::getISOCurrency() const {
-    return getCurrency().getISOCurrency();
-}
-
-U_NAMESPACE_END
-
-#endif // !UCONFIG_NO_FORMATTING
-#endif // __CURRENCYAMOUNT_H__

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/currunit.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/currunit.h b/apps/couch_collate/platform/osx/icu/unicode/currunit.h
deleted file mode 100644
index ecd9411..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/currunit.h
+++ /dev/null
@@ -1,117 +0,0 @@
-/*
-**********************************************************************
-* Copyright (c) 2004-2006, International Business Machines
-* Corporation and others.  All Rights Reserved.
-**********************************************************************
-* Author: Alan Liu
-* Created: April 26, 2004
-* Since: ICU 3.0
-**********************************************************************
-*/
-#ifndef __CURRENCYUNIT_H__
-#define __CURRENCYUNIT_H__
-
-#include "unicode/utypes.h"
-
-#if !UCONFIG_NO_FORMATTING
-
-#include "unicode/measunit.h"
-
-/**
- * \file 
- * \brief C++ API: Currency Unit Information.
- */
- 
-U_NAMESPACE_BEGIN
-
-/**
- * A unit of currency, such as USD (U.S. dollars) or JPY (Japanese
- * yen).  This class is a thin wrapper over a UChar string that
- * subclasses MeasureUnit, for use with Measure and MeasureFormat.
- *
- * @author Alan Liu
- * @stable ICU 3.0
- */
-class U_I18N_API CurrencyUnit: public MeasureUnit {
- public:
-    /**
-     * Construct an object with the given ISO currency code.
-     * @param isoCode the 3-letter ISO 4217 currency code; must not be
-     * NULL and must have length 3
-     * @param ec input-output error code. If the isoCode is invalid,
-     * then this will be set to a failing value.
-     * @stable ICU 3.0
-     */
-    CurrencyUnit(const UChar* isoCode, UErrorCode &ec);
-
-    /**
-     * Copy constructor
-     * @stable ICU 3.0
-     */
-    CurrencyUnit(const CurrencyUnit& other);
-
-    /**
-     * Assignment operator
-     * @stable ICU 3.0
-     */
-    CurrencyUnit& operator=(const CurrencyUnit& other);
-
-    /**
-     * Return a polymorphic clone of this object.  The result will
-     * have the same class as returned by getDynamicClassID().
-     * @stable ICU 3.0
-     */
-    virtual UObject* clone() const;
-
-    /**
-     * Destructor
-     * @stable ICU 3.0
-     */
-    virtual ~CurrencyUnit();
-
-    /**
-     * Equality operator.  Return true if this object is equal
-     * to the given object.
-     * @stable ICU 3.0
-     */
-    UBool operator==(const UObject& other) const;
-
-    /**
-     * Returns a unique class ID for this object POLYMORPHICALLY.
-     * This method implements a simple form of RTTI used by ICU.
-     * @return The class ID for this object. All objects of a given
-     * class have the same class ID.  Objects of other classes have
-     * different class IDs.
-     * @stable ICU 3.0
-     */
-    virtual UClassID getDynamicClassID() const;
-
-    /**
-     * Returns the class ID for this class. This is used to compare to
-     * the return value of getDynamicClassID().
-     * @return The class ID for all objects of this class.
-     * @stable ICU 3.0
-     */
-    static UClassID U_EXPORT2 getStaticClassID();
-
-    /**
-     * Return the ISO currency code of this object.
-     * @stable ICU 3.0
-     */
-    inline const UChar* getISOCurrency() const;
-
- private:
-    /**
-     * The ISO 4217 code of this object.
-     */
-    UChar isoCode[4];
-};
-
-inline const UChar* CurrencyUnit::getISOCurrency() const {
-    return isoCode;
-}
-
-U_NAMESPACE_END
-
-#endif // !UCONFIG_NO_FORMATTING
-#endif // __CURRENCYUNIT_H__

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/datefmt.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/datefmt.h b/apps/couch_collate/platform/osx/icu/unicode/datefmt.h
deleted file mode 100644
index 7aeab2c..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/datefmt.h
+++ /dev/null
@@ -1,700 +0,0 @@
-/*
- ********************************************************************************
- *   Copyright (C) 1997-2008, International Business Machines
- *   Corporation and others.  All Rights Reserved.
- ********************************************************************************
- *
- * File DATEFMT.H
- *
- * Modification History:
- *
- *   Date        Name        Description
- *   02/19/97    aliu        Converted from java.
- *   04/01/97    aliu        Added support for centuries.
- *   07/23/98    stephen     JDK 1.2 sync
- *   11/15/99    weiv        Added support for week of year/day of week formatting
- ********************************************************************************
- */
-
-#ifndef DATEFMT_H
-#define DATEFMT_H
-
-#include "unicode/utypes.h"
-
-#if !UCONFIG_NO_FORMATTING
-
-#include "unicode/udat.h"
-#include "unicode/calendar.h"
-#include "unicode/numfmt.h"
-#include "unicode/format.h"
-#include "unicode/locid.h"
-
-/**
- * \file 
- * \brief C++ API: Abstract class for converting dates.
- */
-
-U_NAMESPACE_BEGIN
-
-class TimeZone;
-
-/**
- * DateFormat is an abstract class for a family of classes that convert dates and
- * times from their internal representations to textual form and back again in a
- * language-independent manner. Converting from the internal representation (milliseconds
- * since midnight, January 1, 1970) to text is known as "formatting," and converting
- * from text to millis is known as "parsing."  We currently define only one concrete
- * subclass of DateFormat: SimpleDateFormat, which can handle pretty much all normal
- * date formatting and parsing actions.
- * <P>
- * DateFormat helps you to format and parse dates for any locale. Your code can
- * be completely independent of the locale conventions for months, days of the
- * week, or even the calendar format: lunar vs. solar.
- * <P>
- * To format a date for the current Locale, use one of the static factory
- * methods:
- * <pre>
- * \code
- *      DateFormat* dfmt = DateFormat::createDateInstance();
- *      UDate myDate = Calendar::getNow();
- *      UnicodeString myString;
- *      myString = dfmt->format( myDate, myString );
- * \endcode
- * </pre>
- * If you are formatting multiple numbers, it is more efficient to get the
- * format and use it multiple times so that the system doesn't have to fetch the
- * information about the local language and country conventions multiple times.
- * <pre>
- * \code
- *      DateFormat* df = DateFormat::createDateInstance();
- *      UnicodeString myString;
- *      UDate myDateArr[] = { 0.0, 100000000.0, 2000000000.0 }; // test values
- *      for (int32_t i = 0; i < 3; ++i) {
- *          myString.remove();
- *          cout << df->format( myDateArr[i], myString ) << endl;
- *      }
- * \endcode
- * </pre>
- * To get specific fields of a date, you can use UFieldPosition to
- * get specific fields.
- * <pre>
- * \code
- *      DateFormat* dfmt = DateFormat::createDateInstance();
- *      FieldPosition pos(DateFormat::YEAR_FIELD);
- *      UnicodeString myString;
- *      myString = dfmt->format( myDate, myString );
- *      cout << myString << endl;
- *      cout << pos.getBeginIndex() << "," << pos. getEndIndex() << endl;
- * \endcode
- * </pre>
- * To format a date for a different Locale, specify it in the call to
- * createDateInstance().
- * <pre>
- * \code
- *       DateFormat* df =
- *           DateFormat::createDateInstance( DateFormat::SHORT, Locale::getFrance());
- * \endcode
- * </pre>
- * You can use a DateFormat to parse also.
- * <pre>
- * \code
- *       UErrorCode status = U_ZERO_ERROR;
- *       UDate myDate = df->parse(myString, status);
- * \endcode
- * </pre>
- * Use createDateInstance() to produce the normal date format for that country.
- * There are other static factory methods available. Use createTimeInstance()
- * to produce the normal time format for that country. Use createDateTimeInstance()
- * to produce a DateFormat that formats both date and time. You can pass in
- * different options to these factory methods to control the length of the
- * result; from SHORT to MEDIUM to LONG to FULL. The exact result depends on the
- * locale, but generally:
- * <ul type=round>
- *   <li>   SHORT is completely numeric, such as 12/13/52 or 3:30pm
- *   <li>   MEDIUM is longer, such as Jan 12, 1952
- *   <li>   LONG is longer, such as January 12, 1952 or 3:30:32pm
- *   <li>   FULL is pretty completely specified, such as
- *          Tuesday, April 12, 1952 AD or 3:30:42pm PST.
- * </ul>
- * You can also set the time zone on the format if you wish. If you want even
- * more control over the format or parsing, (or want to give your users more
- * control), you can try casting the DateFormat you get from the factory methods
- * to a SimpleDateFormat. This will work for the majority of countries; just
- * remember to chck getDynamicClassID() before carrying out the cast.
- * <P>
- * You can also use forms of the parse and format methods with ParsePosition and
- * FieldPosition to allow you to
- * <ul type=round>
- *   <li>   Progressively parse through pieces of a string.
- *   <li>   Align any particular field, or find out where it is for selection
- *          on the screen.
- * </ul>
- *
- * <p><em>User subclasses are not supported.</em> While clients may write
- * subclasses, such code will not necessarily work and will not be
- * guaranteed to work stably from release to release.
- */
-class U_I18N_API DateFormat : public Format {
-public:
-
-    /**
-     * Constants for various style patterns. These reflect the order of items in
-     * the DateTimePatterns resource. There are 4 time patterns, 4 date patterns,
-     * and then the date-time pattern. Each block of 4 values in the resource occurs
-     * in the order full, long, medium, short.
-     * @stable ICU 2.4
-     */
-    enum EStyle
-    {
-        kNone   = -1,
-
-        kFull   = 0,
-        kLong   = 1,
-        kMedium = 2,
-        kShort  = 3,
-
-        kDateOffset   = kShort + 1,
-     // kFull   + kDateOffset = 4
-     // kLong   + kDateOffset = 5
-     // kMedium + kDateOffset = 6
-     // kShort  + kDateOffset = 7
-
-        kDateTime             = 8,
-        
-
-        // relative dates
-        kRelative = (1 << 7),
-        
-        kFullRelative = (kFull | kRelative),
-            
-        kLongRelative = kLong | kRelative,
-        
-        kMediumRelative = kMedium | kRelative,
-        
-        kShortRelative = kShort | kRelative,
-        
-
-        kDefault      = kMedium,
-
-
-
-    /**
-     * These constants are provided for backwards compatibility only.
-     * Please use the C++ style constants defined above.
-     */
-        FULL        = kFull,
-        LONG        = kLong,
-        MEDIUM        = kMedium,
-        SHORT        = kShort,
-        DEFAULT        = kDefault,
-        DATE_OFFSET    = kDateOffset,
-        NONE        = kNone,
-        DATE_TIME    = kDateTime
-    };
-
-    /**
-     * Destructor.
-     * @stable ICU 2.0
-     */
-    virtual ~DateFormat();
-
-    /**
-     * Equality operator.  Returns true if the two formats have the same behavior.
-     * @stable ICU 2.0
-     */
-    virtual UBool operator==(const Format&) const;
-
-    /**
-     * Format an object to produce a string. This method handles Formattable
-     * objects with a UDate type. If a the Formattable object type is not a Date,
-     * then it returns a failing UErrorCode.
-     *
-     * @param obj       The object to format. Must be a Date.
-     * @param appendTo  Output parameter to receive result.
-     *                  Result is appended to existing contents.
-     * @param pos       On input: an alignment field, if desired.
-     *                  On output: the offsets of the alignment field.
-     * @param status    Output param filled with success/failure status.
-     * @return          Reference to 'appendTo' parameter.
-     * @stable ICU 2.0
-     */
-    virtual UnicodeString& format(const Formattable& obj,
-                                  UnicodeString& appendTo,
-                                  FieldPosition& pos,
-                                  UErrorCode& status) const;
-
-    /**
-     * Formats a date into a date/time string. This is an abstract method which
-     * concrete subclasses must implement.
-     * <P>
-     * On input, the FieldPosition parameter may have its "field" member filled with
-     * an enum value specifying a field.  On output, the FieldPosition will be filled
-     * in with the text offsets for that field.
-     * <P> For example, given a time text
-     * "1996.07.10 AD at 15:08:56 PDT", if the given fieldPosition.field is
-     * UDAT_YEAR_FIELD, the offsets fieldPosition.beginIndex and
-     * statfieldPositionus.getEndIndex will be set to 0 and 4, respectively.
-     * <P> Notice
-     * that if the same time field appears more than once in a pattern, the status will
-     * be set for the first occurence of that time field. For instance,
-     * formatting a UDate to the time string "1 PM PDT (Pacific Daylight Time)"
-     * using the pattern "h a z (zzzz)" and the alignment field
-     * DateFormat::TIMEZONE_FIELD, the offsets fieldPosition.beginIndex and
-     * fieldPosition.getEndIndex will be set to 5 and 8, respectively, for the first
-     * occurence of the timezone pattern character 'z'.
-     *
-     * @param cal           Calendar set to the date and time to be formatted
-     *                      into a date/time string.
-     * @param appendTo      Output parameter to receive result.
-     *                      Result is appended to existing contents.
-     * @param fieldPosition On input: an alignment field, if desired (see examples above)
-     *                      On output: the offsets of the alignment field (see examples above)
-     * @return              Reference to 'appendTo' parameter.
-     * @stable ICU 2.1
-     */
-    virtual UnicodeString& format(  Calendar& cal,
-                                    UnicodeString& appendTo,
-                                    FieldPosition& fieldPosition) const = 0;
-
-    /**
-     * Formats a UDate into a date/time string.
-     * <P>
-     * On input, the FieldPosition parameter may have its "field" member filled with
-     * an enum value specifying a field.  On output, the FieldPosition will be filled
-     * in with the text offsets for that field.
-     * <P> For example, given a time text
-     * "1996.07.10 AD at 15:08:56 PDT", if the given fieldPosition.field is
-     * UDAT_YEAR_FIELD, the offsets fieldPosition.beginIndex and
-     * statfieldPositionus.getEndIndex will be set to 0 and 4, respectively.
-     * <P> Notice
-     * that if the same time field appears more than once in a pattern, the status will
-     * be set for the first occurence of that time field. For instance,
-     * formatting a UDate to the time string "1 PM PDT (Pacific Daylight Time)"
-     * using the pattern "h a z (zzzz)" and the alignment field
-     * DateFormat::TIMEZONE_FIELD, the offsets fieldPosition.beginIndex and
-     * fieldPosition.getEndIndex will be set to 5 and 8, respectively, for the first
-     * occurence of the timezone pattern character 'z'.
-     *
-     * @param date          UDate to be formatted into a date/time string.
-     * @param appendTo      Output parameter to receive result.
-     *                      Result is appended to existing contents.
-     * @param fieldPosition On input: an alignment field, if desired (see examples above)
-     *                      On output: the offsets of the alignment field (see examples above)
-     * @return              Reference to 'appendTo' parameter.
-     * @stable ICU 2.0
-     */
-    UnicodeString& format(  UDate date,
-                            UnicodeString& appendTo,
-                            FieldPosition& fieldPosition) const;
-
-    /**
-     * Formats a UDate into a date/time string. If there is a problem, you won't
-     * know, using this method. Use the overloaded format() method which takes a
-     * FieldPosition& to detect formatting problems.
-     *
-     * @param date      The UDate value to be formatted into a string.
-     * @param appendTo  Output parameter to receive result.
-     *                  Result is appended to existing contents.
-     * @return          Reference to 'appendTo' parameter.
-     * @stable ICU 2.0
-     */
-    UnicodeString& format(UDate date, UnicodeString& appendTo) const;
-
-    /**
-     * Redeclared Format method.
-     *
-     * @param obj       The object to be formatted into a string.
-     * @param appendTo  Output parameter to receive result.
-     *                  Result is appended to existing contents.
-     * @param status    Output param filled with success/failure status.
-     * @return          Reference to 'appendTo' parameter.
-     * @stable ICU 2.0
-     */
-    UnicodeString& format(const Formattable& obj,
-                          UnicodeString& appendTo,
-                          UErrorCode& status) const;
-
-    /**
-     * Parse a date/time string.
-     *
-     * @param text      The string to be parsed into a UDate value.
-     * @param status    Output param to be set to success/failure code. If
-     *                  'text' cannot be parsed, it will be set to a failure
-     *                  code.
-     * @result          The parsed UDate value, if successful.
-     * @stable ICU 2.0
-     */
-    virtual UDate parse( const UnicodeString& text,
-                        UErrorCode& status) const;
-
-    /**
-     * Parse a date/time string beginning at the given parse position. For
-     * example, a time text "07/10/96 4:5 PM, PDT" will be parsed into a Date
-     * that is equivalent to Date(837039928046).
-     * <P>
-     * By default, parsing is lenient: If the input is not in the form used by
-     * this object's format method but can still be parsed as a date, then the
-     * parse succeeds. Clients may insist on strict adherence to the format by
-     * calling setLenient(false).
-     *
-     * @see DateFormat::setLenient(boolean)
-     *
-     * @param text  The date/time string to be parsed
-     * @param cal   a Calendar set to the date and time to be formatted
-     *              into a date/time string.
-     * @param pos   On input, the position at which to start parsing; on
-     *              output, the position at which parsing terminated, or the
-     *              start position if the parse failed.
-     * @return      A valid UDate if the input could be parsed.
-     * @stable ICU 2.1
-     */
-    virtual void parse( const UnicodeString& text,
-                        Calendar& cal,
-                        ParsePosition& pos) const = 0;
-
-    /**
-     * Parse a date/time string beginning at the given parse position. For
-     * example, a time text "07/10/96 4:5 PM, PDT" will be parsed into a Date
-     * that is equivalent to Date(837039928046).
-     * <P>
-     * By default, parsing is lenient: If the input is not in the form used by
-     * this object's format method but can still be parsed as a date, then the
-     * parse succeeds. Clients may insist on strict adherence to the format by
-     * calling setLenient(false).
-     *
-     * @see DateFormat::setLenient(boolean)
-     *
-     * @param text  The date/time string to be parsed
-     * @param pos   On input, the position at which to start parsing; on
-     *              output, the position at which parsing terminated, or the
-     *              start position if the parse failed.
-     * @return      A valid UDate if the input could be parsed.
-     * @stable ICU 2.0
-     */
-    UDate parse( const UnicodeString& text,
-                 ParsePosition& pos) const;
-
-    /**
-     * Parse a string to produce an object. This methods handles parsing of
-     * date/time strings into Formattable objects with UDate types.
-     * <P>
-     * Before calling, set parse_pos.index to the offset you want to start
-     * parsing at in the source. After calling, parse_pos.index is the end of
-     * the text you parsed. If error occurs, index is unchanged.
-     * <P>
-     * When parsing, leading whitespace is discarded (with a successful parse),
-     * while trailing whitespace is left as is.
-     * <P>
-     * See Format::parseObject() for more.
-     *
-     * @param source    The string to be parsed into an object.
-     * @param result    Formattable to be set to the parse result.
-     *                  If parse fails, return contents are undefined.
-     * @param parse_pos The position to start parsing at. Upon return
-     *                  this param is set to the position after the
-     *                  last character successfully parsed. If the
-     *                  source is not parsed successfully, this param
-     *                  will remain unchanged.
-     * @return          A newly created Formattable* object, or NULL
-     *                  on failure.  The caller owns this and should
-     *                  delete it when done.
-     * @stable ICU 2.0
-     */
-    virtual void parseObject(const UnicodeString& source,
-                             Formattable& result,
-                             ParsePosition& parse_pos) const;
-
-    /**
-     * Create a default date/time formatter that uses the SHORT style for both
-     * the date and the time.
-     *
-     * @return A date/time formatter which the caller owns.
-     * @stable ICU 2.0
-     */
-    static DateFormat* U_EXPORT2 createInstance(void);
-
-    /**
-     * This is for ICU internal use only. Please do not use.
-     * Create a date/time formatter from skeleton and a given locale.
-     *
-     * Users are encouraged to use the skeleton macros defined in udat.h.
-     * For example, MONTH_WEEKDAY_DAY, which is "MMMMEEEEd",
-     * and which means the pattern should have day, month, and day-of-week 
-     * fields, and follow the long date format defined in date time pattern.
-     * For example, for English, the full pattern should be 
-     * "EEEE, MMMM d".
-     * 
-     * Temporarily, this is an internal API, used by DateIntevalFormat only.
-     * There will be a new set of APIs for the same purpose coming soon.
-     * After which, this API will be replaced.
-     *
-     * @param skeleton  the skeleton on which date format based.
-     * @param locale    the given locale.
-     * @param status    Output param to be set to success/failure code.
-     *                  If it is failure, the returned date formatter will
-     *                  be NULL.
-     * @return          a simple date formatter which the caller owns.
-     * @internal ICU 4.0
-     */
-    static DateFormat* U_EXPORT2 createPatternInstance(
-                                                const UnicodeString& skeleton,
-                                                const Locale& locale,
-                                                UErrorCode& status);
-
-    /**
-     * Creates a time formatter with the given formatting style for the given
-     * locale.
-     *
-     * @param style     The given formatting style. For example,
-     *                  SHORT for "h:mm a" in the US locale.
-     * @param aLocale   The given locale.
-     * @return          A time formatter which the caller owns.
-     * @stable ICU 2.0
-     */
-    static DateFormat* U_EXPORT2 createTimeInstance(EStyle style = kDefault,
-                                          const Locale& aLocale = Locale::getDefault());
-
-    /**
-     * Creates a date formatter with the given formatting style for the given
-     * const locale.
-     *
-     * @param style     The given formatting style. For example,
-     *                  SHORT for "M/d/yy" in the US locale.
-     * @param aLocale   The given locale.
-     * @return          A date formatter which the caller owns.
-     * @stable ICU 2.0
-     */
-    static DateFormat* U_EXPORT2 createDateInstance(EStyle style = kDefault,
-                                          const Locale& aLocale = Locale::getDefault());
-
-    /**
-     * Creates a date/time formatter with the given formatting styles for the
-     * given locale.
-     *
-     * @param dateStyle The given formatting style for the date portion of the result.
-     *                  For example, SHORT for "M/d/yy" in the US locale.
-     * @param timeStyle The given formatting style for the time portion of the result.
-     *                  For example, SHORT for "h:mm a" in the US locale.
-     * @param aLocale   The given locale.
-     * @return          A date/time formatter which the caller owns.
-     * @stable ICU 2.0
-     */
-    static DateFormat* U_EXPORT2 createDateTimeInstance(EStyle dateStyle = kDefault,
-                                              EStyle timeStyle = kDefault,
-                                              const Locale& aLocale = Locale::getDefault());
-
-    /**
-     * Gets the set of locales for which DateFormats are installed.
-     * @param count Filled in with the number of locales in the list that is returned.
-     * @return the set of locales for which DateFormats are installed.  The caller
-     *  does NOT own this list and must not delete it.
-     * @stable ICU 2.0
-     */
-    static const Locale* U_EXPORT2 getAvailableLocales(int32_t& count);
-
-    /**
-     * Returns true if the formatter is set for lenient parsing.
-     * @stable ICU 2.0
-     */
-    virtual UBool isLenient(void) const;
-
-    /**
-     * Specify whether or not date/time parsing is to be lenient. With lenient
-     * parsing, the parser may use heuristics to interpret inputs that do not
-     * precisely match this object's format. With strict parsing, inputs must
-     * match this object's format.
-     *
-     * @param lenient  True specifies date/time interpretation to be lenient.
-     * @see Calendar::setLenient
-     * @stable ICU 2.0
-     */
-    virtual void setLenient(UBool lenient);
-
-    /**
-     * Gets the calendar associated with this date/time formatter.
-     * @return the calendar associated with this date/time formatter.
-     * @stable ICU 2.0
-     */
-    virtual const Calendar* getCalendar(void) const;
-
-    /**
-     * Set the calendar to be used by this date format. Initially, the default
-     * calendar for the specified or default locale is used.  The caller should
-     * not delete the Calendar object after it is adopted by this call.
-     * Adopting a new calendar will change to the default symbols.
-     *
-     * @param calendarToAdopt    Calendar object to be adopted.
-     * @stable ICU 2.0
-     */
-    virtual void adoptCalendar(Calendar* calendarToAdopt);
-
-    /**
-     * Set the calendar to be used by this date format. Initially, the default
-     * calendar for the specified or default locale is used.
-     *
-     * @param newCalendar Calendar object to be set.
-     * @stable ICU 2.0
-     */
-    virtual void setCalendar(const Calendar& newCalendar);
-
-
-    /**
-     * Gets the number formatter which this date/time formatter uses to format
-     * and parse the numeric portions of the pattern.
-     * @return the number formatter which this date/time formatter uses.
-     * @stable ICU 2.0
-     */
-    virtual const NumberFormat* getNumberFormat(void) const;
-
-    /**
-     * Allows you to set the number formatter.  The caller should
-     * not delete the NumberFormat object after it is adopted by this call.
-     * @param formatToAdopt     NumberFormat object to be adopted.
-     * @stable ICU 2.0
-     */
-    virtual void adoptNumberFormat(NumberFormat* formatToAdopt);
-
-    /**
-     * Allows you to set the number formatter.
-     * @param newNumberFormat  NumberFormat object to be set.
-     * @stable ICU 2.0
-     */
-    virtual void setNumberFormat(const NumberFormat& newNumberFormat);
-
-    /**
-     * Returns a reference to the TimeZone used by this DateFormat's calendar.
-     * @return the time zone associated with the calendar of DateFormat.
-     * @stable ICU 2.0
-     */
-    virtual const TimeZone& getTimeZone(void) const;
-
-    /**
-     * Sets the time zone for the calendar of this DateFormat object. The caller
-     * no longer owns the TimeZone object and should not delete it after this call.
-     * @param zoneToAdopt the TimeZone to be adopted.
-     * @stable ICU 2.0
-     */
-    virtual void adoptTimeZone(TimeZone* zoneToAdopt);
-
-    /**
-     * Sets the time zone for the calendar of this DateFormat object.
-     * @param zone the new time zone.
-     * @stable ICU 2.0
-     */
-    virtual void setTimeZone(const TimeZone& zone);
-
-protected:
-    /**
-     * Default constructor.  Creates a DateFormat with no Calendar or NumberFormat
-     * associated with it.  This constructor depends on the subclasses to fill in
-     * the calendar and numberFormat fields.
-     * @stable ICU 2.0
-     */
-    DateFormat();
-
-    /**
-     * Copy constructor.
-     * @stable ICU 2.0
-     */
-    DateFormat(const DateFormat&);
-
-    /**
-     * Default assignment operator.
-     * @stable ICU 2.0
-     */
-    DateFormat& operator=(const DateFormat&);
-
-    /**
-     * The calendar that DateFormat uses to produce the time field values needed
-     * to implement date/time formatting. Subclasses should generally initialize
-     * this to the default calendar for the locale associated with this DateFormat.
-     * @stable ICU 2.4
-     */
-    Calendar* fCalendar;
-
-    /**
-     * The number formatter that DateFormat uses to format numbers in dates and
-     * times. Subclasses should generally initialize this to the default number
-     * format for the locale associated with this DateFormat.
-     * @stable ICU 2.4
-     */
-    NumberFormat* fNumberFormat;
-
-private:
-    /**
-     * Gets the date/time formatter with the given formatting styles for the
-     * given locale.
-     * @param dateStyle the given date formatting style.
-     * @param timeStyle the given time formatting style.
-     * @param inLocale the given locale.
-     * @return a date/time formatter, or 0 on failure.
-     */
-    static DateFormat* U_EXPORT2 create(EStyle timeStyle, EStyle dateStyle, const Locale&);
-
-public:
-    /**
-     * Field selector for FieldPosition for DateFormat fields.
-     * @obsolete ICU 3.4 use UDateFormatField instead, since this API will be
-     * removed in that release
-     */
-    enum EField
-    {
-        // Obsolete; use UDateFormatField instead
-        kEraField = UDAT_ERA_FIELD,
-        kYearField = UDAT_YEAR_FIELD,
-        kMonthField = UDAT_MONTH_FIELD,
-        kDateField = UDAT_DATE_FIELD,
-        kHourOfDay1Field = UDAT_HOUR_OF_DAY1_FIELD,
-        kHourOfDay0Field = UDAT_HOUR_OF_DAY0_FIELD,
-        kMinuteField = UDAT_MINUTE_FIELD,
-        kSecondField = UDAT_SECOND_FIELD,
-        kMillisecondField = UDAT_FRACTIONAL_SECOND_FIELD,
-        kDayOfWeekField = UDAT_DAY_OF_WEEK_FIELD,
-        kDayOfYearField = UDAT_DAY_OF_YEAR_FIELD,
-        kDayOfWeekInMonthField = UDAT_DAY_OF_WEEK_IN_MONTH_FIELD,
-        kWeekOfYearField = UDAT_WEEK_OF_YEAR_FIELD,
-        kWeekOfMonthField = UDAT_WEEK_OF_MONTH_FIELD,
-        kAmPmField = UDAT_AM_PM_FIELD,
-        kHour1Field = UDAT_HOUR1_FIELD,
-        kHour0Field = UDAT_HOUR0_FIELD,
-        kTimezoneField = UDAT_TIMEZONE_FIELD,
-        kYearWOYField = UDAT_YEAR_WOY_FIELD,
-        kDOWLocalField = UDAT_DOW_LOCAL_FIELD,
-        kExtendedYearField = UDAT_EXTENDED_YEAR_FIELD,
-        kJulianDayField = UDAT_JULIAN_DAY_FIELD,
-        kMillisecondsInDayField = UDAT_MILLISECONDS_IN_DAY_FIELD,
-
-        // Obsolete; use UDateFormatField instead
-        ERA_FIELD = UDAT_ERA_FIELD,
-        YEAR_FIELD = UDAT_YEAR_FIELD,
-        MONTH_FIELD = UDAT_MONTH_FIELD,
-        DATE_FIELD = UDAT_DATE_FIELD,
-        HOUR_OF_DAY1_FIELD = UDAT_HOUR_OF_DAY1_FIELD,
-        HOUR_OF_DAY0_FIELD = UDAT_HOUR_OF_DAY0_FIELD,
-        MINUTE_FIELD = UDAT_MINUTE_FIELD,
-        SECOND_FIELD = UDAT_SECOND_FIELD,
-        MILLISECOND_FIELD = UDAT_FRACTIONAL_SECOND_FIELD,
-        DAY_OF_WEEK_FIELD = UDAT_DAY_OF_WEEK_FIELD,
-        DAY_OF_YEAR_FIELD = UDAT_DAY_OF_YEAR_FIELD,
-        DAY_OF_WEEK_IN_MONTH_FIELD = UDAT_DAY_OF_WEEK_IN_MONTH_FIELD,
-        WEEK_OF_YEAR_FIELD = UDAT_WEEK_OF_YEAR_FIELD,
-        WEEK_OF_MONTH_FIELD = UDAT_WEEK_OF_MONTH_FIELD,
-        AM_PM_FIELD = UDAT_AM_PM_FIELD,
-        HOUR1_FIELD = UDAT_HOUR1_FIELD,
-        HOUR0_FIELD = UDAT_HOUR0_FIELD,
-        TIMEZONE_FIELD = UDAT_TIMEZONE_FIELD
-    };
-};
-
-inline UnicodeString&
-DateFormat::format(const Formattable& obj,
-                   UnicodeString& appendTo,
-                   UErrorCode& status) const {
-    return Format::format(obj, appendTo, status);
-}
-U_NAMESPACE_END
-
-#endif /* #if !UCONFIG_NO_FORMATTING */
-
-#endif // _DATEFMT
-//eof

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/dbbi.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/dbbi.h b/apps/couch_collate/platform/osx/icu/unicode/dbbi.h
deleted file mode 100644
index c7984ef..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/dbbi.h
+++ /dev/null
@@ -1,41 +0,0 @@
-/*
-**********************************************************************
-*   Copyright (C) 1999-2006 IBM Corp. All rights reserved.
-**********************************************************************
-*   Date        Name        Description
-*   12/1/99    rgillam     Complete port from Java.
-*   01/13/2000 helena      Added UErrorCode to ctors.
-**********************************************************************
-*/
-
-#ifndef DBBI_H
-#define DBBI_H
-
-#include "unicode/rbbi.h"
-
-#if !UCONFIG_NO_BREAK_ITERATION
-
-/**
- * \file
- * \brief C++ API: Dictionary Based Break Iterator
- */
- 
-U_NAMESPACE_BEGIN
-
-/**
- * An obsolete subclass of RuleBasedBreakIterator. Handling of dictionary-
- * based break iteration has been folded into the base class. This class
- * is deprecated as of ICU 3.6.
- */
- 
-#ifndef U_HIDE_DEPRECATED_API
-
-typedef RuleBasedBreakIterator DictionaryBasedBreakIterator;
-
-#endif
-
-U_NAMESPACE_END
-
-#endif /* #if !UCONFIG_NO_BREAK_ITERATION */
-
-#endif


[30/57] [abbrv] remove couch_collate

Posted by be...@apache.org.
http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/rbnf.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/rbnf.h b/apps/couch_collate/platform/osx/icu/unicode/rbnf.h
deleted file mode 100644
index 030565e..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/rbnf.h
+++ /dev/null
@@ -1,1049 +0,0 @@
-/*
-*******************************************************************************
-* Copyright (C) 1997-2006, International Business Machines Corporation and others.
-* All Rights Reserved.
-*******************************************************************************
-*/
-
-#ifndef RBNF_H
-#define RBNF_H
-
-#include "unicode/utypes.h"
-
-/**
- * \file 
- * \brief C++ API: Rule Based Number Format
- */
-
-/**
- * \def U_HAVE_RBNF
- * This will be 0 if RBNF support is not included in ICU
- * and 1 if it is.
- *
- * @stable ICU 2.4
- */
-#if UCONFIG_NO_FORMATTING
-#define U_HAVE_RBNF 0
-#else
-#define U_HAVE_RBNF 1
-
-#include "unicode/coll.h"
-#include "unicode/dcfmtsym.h"
-#include "unicode/fmtable.h"
-#include "unicode/locid.h"
-#include "unicode/numfmt.h"
-#include "unicode/unistr.h"
-#include "unicode/strenum.h"
-
-U_NAMESPACE_BEGIN
-
-class NFRuleSet;
-class LocalizationInfo;
-
-/**
- * Tags for the predefined rulesets.
- *
- * @stable ICU 2.2
- */
-enum URBNFRuleSetTag {
-    URBNF_SPELLOUT,
-    URBNF_ORDINAL,
-    URBNF_DURATION,
-    URBNF_COUNT
-};
-
-#if UCONFIG_NO_COLLATION
-class Collator;
-#endif
-
-/**
- * The RuleBasedNumberFormat class formats numbers according to a set of rules. This number formatter is
- * typically used for spelling out numeric values in words (e.g., 25,3476 as
- * &quot;twenty-five thousand three hundred seventy-six&quot; or &quot;vingt-cinq mille trois
- * cents soixante-seize&quot; or
- * &quot;f&uuml;nfundzwanzigtausenddreihundertsechsundsiebzig&quot;), but can also be used for
- * other complicated formatting tasks, such as formatting a number of seconds as hours,
- * minutes and seconds (e.g., 3,730 as &quot;1:02:10&quot;).
- *
- * <p>The resources contain three predefined formatters for each locale: spellout, which
- * spells out a value in words (123 is &quot;one hundred twenty-three&quot;); ordinal, which
- * appends an ordinal suffix to the end of a numeral (123 is &quot;123rd&quot;); and
- * duration, which shows a duration in seconds as hours, minutes, and seconds (123 is
- * &quot;2:03&quot;).&nbsp; The client can also define more specialized <tt>RuleBasedNumberFormat</tt>s
- * by supplying programmer-defined rule sets.</p>
- *
- * <p>The behavior of a <tt>RuleBasedNumberFormat</tt> is specified by a textual description
- * that is either passed to the constructor as a <tt>String</tt> or loaded from a resource
- * bundle. In its simplest form, the description consists of a semicolon-delimited list of <em>rules.</em>
- * Each rule has a string of output text and a value or range of values it is applicable to.
- * In a typical spellout rule set, the first twenty rules are the words for the numbers from
- * 0 to 19:</p>
- *
- * <pre>zero; one; two; three; four; five; six; seven; eight; nine;
- * ten; eleven; twelve; thirteen; fourteen; fifteen; sixteen; seventeen; eighteen; nineteen;</pre>
- *
- * <p>For larger numbers, we can use the preceding set of rules to format the ones place, and
- * we only have to supply the words for the multiples of 10:</p>
- *
- * <pre> 20: twenty[-&gt;&gt;];
- * 30: thirty[-&gt;&gt;];
- * 40: forty[-&gt;&gt;];
- * 50: fifty[-&gt;&gt;];
- * 60: sixty[-&gt;&gt;];
- * 70: seventy[-&gt;&gt;];
- * 80: eighty[-&gt;&gt;];
- * 90: ninety[-&gt;&gt;];</pre>
- *
- * <p>In these rules, the <em>base value</em> is spelled out explicitly and set off from the
- * rule's output text with a colon. The rules are in a sorted list, and a rule is applicable
- * to all numbers from its own base value to one less than the next rule's base value. The
- * &quot;&gt;&gt;&quot; token is called a <em>substitution</em> and tells the fomatter to
- * isolate the number's ones digit, format it using this same set of rules, and place the
- * result at the position of the &quot;&gt;&gt;&quot; token. Text in brackets is omitted if
- * the number being formatted is an even multiple of 10 (the hyphen is a literal hyphen; 24
- * is &quot;twenty-four,&quot; not &quot;twenty four&quot;).</p>
- *
- * <p>For even larger numbers, we can actually look up several parts of the number in the
- * list:</p>
- *
- * <pre>100: &lt;&lt; hundred[ &gt;&gt;];</pre>
- *
- * <p>The &quot;&lt;&lt;&quot; represents a new kind of substitution. The &lt;&lt; isolates
- * the hundreds digit (and any digits to its left), formats it using this same rule set, and
- * places the result where the &quot;&lt;&lt;&quot; was. Notice also that the meaning of
- * &gt;&gt; has changed: it now refers to both the tens and the ones digits. The meaning of
- * both substitutions depends on the rule's base value. The base value determines the rule's <em>divisor,</em>
- * which is the highest power of 10 that is less than or equal to the base value (the user
- * can change this). To fill in the substitutions, the formatter divides the number being
- * formatted by the divisor. The integral quotient is used to fill in the &lt;&lt;
- * substitution, and the remainder is used to fill in the &gt;&gt; substitution. The meaning
- * of the brackets changes similarly: text in brackets is omitted if the value being
- * formatted is an even multiple of the rule's divisor. The rules are applied recursively, so
- * if a substitution is filled in with text that includes another substitution, that
- * substitution is also filled in.</p>
- *
- * <p>This rule covers values up to 999, at which point we add another rule:</p>
- *
- * <pre>1000: &lt;&lt; thousand[ &gt;&gt;];</pre>
- *
- * <p>Again, the meanings of the brackets and substitution tokens shift because the rule's
- * base value is a higher power of 10, changing the rule's divisor. This rule can actually be
- * used all the way up to 999,999. This allows us to finish out the rules as follows:</p>
- *
- * <pre> 1,000,000: &lt;&lt; million[ &gt;&gt;];
- * 1,000,000,000: &lt;&lt; billion[ &gt;&gt;];
- * 1,000,000,000,000: &lt;&lt; trillion[ &gt;&gt;];
- * 1,000,000,000,000,000: OUT OF RANGE!;</pre>
- *
- * <p>Commas, periods, and spaces can be used in the base values to improve legibility and
- * are ignored by the rule parser. The last rule in the list is customarily treated as an
- * &quot;overflow rule,&quot; applying to everything from its base value on up, and often (as
- * in this example) being used to print out an error message or default representation.
- * Notice also that the size of the major groupings in large numbers is controlled by the
- * spacing of the rules: because in English we group numbers by thousand, the higher rules
- * are separated from each other by a factor of 1,000.</p>
- *
- * <p>To see how these rules actually work in practice, consider the following example:
- * Formatting 25,430 with this rule set would work like this:</p>
- *
- * <table border="0" width="100%">
- *   <tr>
- *     <td><strong>&lt;&lt; thousand &gt;&gt;</strong></td>
- *     <td>[the rule whose base value is 1,000 is applicable to 25,340]</td>
- *   </tr>
- *   <tr>
- *     <td><strong>twenty-&gt;&gt;</strong> thousand &gt;&gt;</td>
- *     <td>[25,340 over 1,000 is 25. The rule for 20 applies.]</td>
- *   </tr>
- *   <tr>
- *     <td>twenty-<strong>five</strong> thousand &gt;&gt;</td>
- *     <td>[25 mod 10 is 5. The rule for 5 is &quot;five.&quot;</td>
- *   </tr>
- *   <tr>
- *     <td>twenty-five thousand <strong>&lt;&lt; hundred &gt;&gt;</strong></td>
- *     <td>[25,340 mod 1,000 is 340. The rule for 100 applies.]</td>
- *   </tr>
- *   <tr>
- *     <td>twenty-five thousand <strong>three</strong> hundred &gt;&gt;</td>
- *     <td>[340 over 100 is 3. The rule for 3 is &quot;three.&quot;]</td>
- *   </tr>
- *   <tr>
- *     <td>twenty-five thousand three hundred <strong>forty</strong></td>
- *     <td>[340 mod 100 is 40. The rule for 40 applies. Since 40 divides
- *     evenly by 10, the hyphen and substitution in the brackets are omitted.]</td>
- *   </tr>
- * </table>
- *
- * <p>The above syntax suffices only to format positive integers. To format negative numbers,
- * we add a special rule:</p>
- *
- * <pre>-x: minus &gt;&gt;;</pre>
- *
- * <p>This is called a <em>negative-number rule,</em> and is identified by &quot;-x&quot;
- * where the base value would be. This rule is used to format all negative numbers. the
- * &gt;&gt; token here means &quot;find the number's absolute value, format it with these
- * rules, and put the result here.&quot;</p>
- *
- * <p>We also add a special rule called a <em>fraction rule </em>for numbers with fractional
- * parts:</p>
- *
- * <pre>x.x: &lt;&lt; point &gt;&gt;;</pre>
- *
- * <p>This rule is used for all positive non-integers (negative non-integers pass through the
- * negative-number rule first and then through this rule). Here, the &lt;&lt; token refers to
- * the number's integral part, and the &gt;&gt; to the number's fractional part. The
- * fractional part is formatted as a series of single-digit numbers (e.g., 123.456 would be
- * formatted as &quot;one hundred twenty-three point four five six&quot;).</p>
- *
- * <p>To see how this rule syntax is applied to various languages, examine the resource data.</p>
- *
- * <p>There is actually much more flexibility built into the rule language than the
- * description above shows. A formatter may own multiple rule sets, which can be selected by
- * the caller, and which can use each other to fill in their substitutions. Substitutions can
- * also be filled in with digits, using a DecimalFormat object. There is syntax that can be
- * used to alter a rule's divisor in various ways. And there is provision for much more
- * flexible fraction handling. A complete description of the rule syntax follows:</p>
- *
- * <hr>
- *
- * <p>The description of a <tt>RuleBasedNumberFormat</tt>'s behavior consists of one or more <em>rule
- * sets.</em> Each rule set consists of a name, a colon, and a list of <em>rules.</em> A rule
- * set name must begin with a % sign. Rule sets with names that begin with a single % sign
- * are <em>public:</em> the caller can specify that they be used to format and parse numbers.
- * Rule sets with names that begin with %% are <em>private:</em> they exist only for the use
- * of other rule sets. If a formatter only has one rule set, the name may be omitted.</p>
- *
- * <p>The user can also specify a special &quot;rule set&quot; named <tt>%%lenient-parse</tt>.
- * The body of <tt>%%lenient-parse</tt> isn't a set of number-formatting rules, but a <tt>RuleBasedCollator</tt>
- * description which is used to define equivalences for lenient parsing. For more information
- * on the syntax, see <tt>RuleBasedCollator</tt>. For more information on lenient parsing,
- * see <tt>setLenientParse()</tt>.  <em>Note:</em> symbols that have syntactic meaning
- * in collation rules, such as '&amp;', have no particular meaning when appearing outside
- * of the <tt>lenient-parse</tt> rule set.</p>
- *
- * <p>The body of a rule set consists of an ordered, semicolon-delimited list of <em>rules.</em>
- * Internally, every rule has a base value, a divisor, rule text, and zero, one, or two <em>substitutions.</em>
- * These parameters are controlled by the description syntax, which consists of a <em>rule
- * descriptor,</em> a colon, and a <em>rule body.</em></p>
- *
- * <p>A rule descriptor can take one of the following forms (text in <em>italics</em> is the
- * name of a token):</p>
- *
- * <table border="0" width="100%">
- *   <tr>
- *     <td><em>bv</em>:</td>
- *     <td><em>bv</em> specifies the rule's base value. <em>bv</em> is a decimal
- *     number expressed using ASCII digits. <em>bv</em> may contain spaces, period, and commas,
- *     which are ignored. The rule's divisor is the highest power of 10 less than or equal to
- *     the base value.</td>
- *   </tr>
- *   <tr>
- *     <td><em>bv</em>/<em>rad</em>:</td>
- *     <td><em>bv</em> specifies the rule's base value. The rule's divisor is the
- *     highest power of <em>rad</em> less than or equal to the base value.</td>
- *   </tr>
- *   <tr>
- *     <td><em>bv</em>&gt;:</td>
- *     <td><em>bv</em> specifies the rule's base value. To calculate the divisor,
- *     let the radix be 10, and the exponent be the highest exponent of the radix that yields a
- *     result less than or equal to the base value. Every &gt; character after the base value
- *     decreases the exponent by 1. If the exponent is positive or 0, the divisor is the radix
- *     raised to the power of the exponent; otherwise, the divisor is 1.</td>
- *   </tr>
- *   <tr>
- *     <td><em>bv</em>/<em>rad</em>&gt;:</td>
- *     <td><em>bv</em> specifies the rule's base value. To calculate the divisor,
- *     let the radix be <em>rad</em>, and the exponent be the highest exponent of the radix that
- *     yields a result less than or equal to the base value. Every &gt; character after the radix
- *     decreases the exponent by 1. If the exponent is positive or 0, the divisor is the radix
- *     raised to the power of the exponent; otherwise, the divisor is 1.</td>
- *   </tr>
- *   <tr>
- *     <td>-x:</td>
- *     <td>The rule is a negative-number rule.</td>
- *   </tr>
- *   <tr>
- *     <td>x.x:</td>
- *     <td>The rule is an <em>improper fraction rule.</em></td>
- *   </tr>
- *   <tr>
- *     <td>0.x:</td>
- *     <td>The rule is a <em>proper fraction rule.</em></td>
- *   </tr>
- *   <tr>
- *     <td>x.0:</td>
- *     <td>The rule is a <em>master rule.</em></td>
- *   </tr>
- *   <tr>
- *     <td><em>nothing</em></td>
- *     <td>If the rule's rule descriptor is left out, the base value is one plus the
- *     preceding rule's base value (or zero if this is the first rule in the list) in a normal
- *     rule set.&nbsp; In a fraction rule set, the base value is the same as the preceding rule's
- *     base value.</td>
- *   </tr>
- * </table>
- *
- * <p>A rule set may be either a regular rule set or a <em>fraction rule set,</em> depending
- * on whether it is used to format a number's integral part (or the whole number) or a
- * number's fractional part. Using a rule set to format a rule's fractional part makes it a
- * fraction rule set.</p>
- *
- * <p>Which rule is used to format a number is defined according to one of the following
- * algorithms: If the rule set is a regular rule set, do the following:
- *
- * <ul>
- *   <li>If the rule set includes a master rule (and the number was passed in as a <tt>double</tt>),
- *     use the master rule.&nbsp; (If the number being formatted was passed in as a <tt>long</tt>,
- *     the master rule is ignored.)</li>
- *   <li>If the number is negative, use the negative-number rule.</li>
- *   <li>If the number has a fractional part and is greater than 1, use the improper fraction
- *     rule.</li>
- *   <li>If the number has a fractional part and is between 0 and 1, use the proper fraction
- *     rule.</li>
- *   <li>Binary-search the rule list for the rule with the highest base value less than or equal
- *     to the number. If that rule has two substitutions, its base value is not an even multiple
- *     of its divisor, and the number <em>is</em> an even multiple of the rule's divisor, use the
- *     rule that precedes it in the rule list. Otherwise, use the rule itself.</li>
- * </ul>
- *
- * <p>If the rule set is a fraction rule set, do the following:
- *
- * <ul>
- *   <li>Ignore negative-number and fraction rules.</li>
- *   <li>For each rule in the list, multiply the number being formatted (which will always be
- *     between 0 and 1) by the rule's base value. Keep track of the distance between the result
- *     the nearest integer.</li>
- *   <li>Use the rule that produced the result closest to zero in the above calculation. In the
- *     event of a tie or a direct hit, use the first matching rule encountered. (The idea here is
- *     to try each rule's base value as a possible denominator of a fraction. Whichever
- *     denominator produces the fraction closest in value to the number being formatted wins.) If
- *     the rule following the matching rule has the same base value, use it if the numerator of
- *     the fraction is anything other than 1; if the numerator is 1, use the original matching
- *     rule. (This is to allow singular and plural forms of the rule text without a lot of extra
- *     hassle.)</li>
- * </ul>
- *
- * <p>A rule's body consists of a string of characters terminated by a semicolon. The rule
- * may include zero, one, or two <em>substitution tokens,</em> and a range of text in
- * brackets. The brackets denote optional text (and may also include one or both
- * substitutions). The exact meanings of the substitution tokens, and under what conditions
- * optional text is omitted, depend on the syntax of the substitution token and the context.
- * The rest of the text in a rule body is literal text that is output when the rule matches
- * the number being formatted.</p>
- *
- * <p>A substitution token begins and ends with a <em>token character.</em> The token
- * character and the context together specify a mathematical operation to be performed on the
- * number being formatted. An optional <em>substitution descriptor </em>specifies how the
- * value resulting from that operation is used to fill in the substitution. The position of
- * the substitution token in the rule body specifies the location of the resultant text in
- * the original rule text.</p>
- *
- * <p>The meanings of the substitution token characters are as follows:</p>
- *
- * <table border="0" width="100%">
- *   <tr>
- *     <td>&gt;&gt;</td>
- *     <td>in normal rule</td>
- *     <td>Divide the number by the rule's divisor and format the remainder</td>
- *   </tr>
- *   <tr>
- *     <td></td>
- *     <td>in negative-number rule</td>
- *     <td>Find the absolute value of the number and format the result</td>
- *   </tr>
- *   <tr>
- *     <td></td>
- *     <td>in fraction or master rule</td>
- *     <td>Isolate the number's fractional part and format it.</td>
- *   </tr>
- *   <tr>
- *     <td></td>
- *     <td>in rule in fraction rule set</td>
- *     <td>Not allowed.</td>
- *   </tr>
- *   <tr>
- *     <td>&gt;&gt;&gt;</td>
- *     <td>in normal rule</td>
- *     <td>Divide the number by the rule's divisor and format the remainder,
- *       but bypass the normal rule-selection process and just use the
- *       rule that precedes this one in this rule list.</td>
- *   </tr>
- *   <tr>
- *     <td></td>
- *     <td>in all other rules</td>
- *     <td>Not allowed.</td>
- *   </tr>
- *   <tr>
- *     <td>&lt;&lt;</td>
- *     <td>in normal rule</td>
- *     <td>Divide the number by the rule's divisor and format the quotient</td>
- *   </tr>
- *   <tr>
- *     <td></td>
- *     <td>in negative-number rule</td>
- *     <td>Not allowed.</td>
- *   </tr>
- *   <tr>
- *     <td></td>
- *     <td>in fraction or master rule</td>
- *     <td>Isolate the number's integral part and format it.</td>
- *   </tr>
- *   <tr>
- *     <td></td>
- *     <td>in rule in fraction rule set</td>
- *     <td>Multiply the number by the rule's base value and format the result.</td>
- *   </tr>
- *   <tr>
- *     <td>==</td>
- *     <td>in all rule sets</td>
- *     <td>Format the number unchanged</td>
- *   </tr>
- *   <tr>
- *     <td>[]</td>
- *     <td>in normal rule</td>
- *     <td>Omit the optional text if the number is an even multiple of the rule's divisor</td>
- *   </tr>
- *   <tr>
- *     <td></td>
- *     <td>in negative-number rule</td>
- *     <td>Not allowed.</td>
- *   </tr>
- *   <tr>
- *     <td></td>
- *     <td>in improper-fraction rule</td>
- *     <td>Omit the optional text if the number is between 0 and 1 (same as specifying both an
- *     x.x rule and a 0.x rule)</td>
- *   </tr>
- *   <tr>
- *     <td></td>
- *     <td>in master rule</td>
- *     <td>Omit the optional text if the number is an integer (same as specifying both an x.x
- *     rule and an x.0 rule)</td>
- *   </tr>
- *   <tr>
- *     <td></td>
- *     <td>in proper-fraction rule</td>
- *     <td>Not allowed.</td>
- *   </tr>
- *   <tr>
- *     <td></td>
- *     <td>in rule in fraction rule set</td>
- *     <td>Omit the optional text if multiplying the number by the rule's base value yields 1.</td>
- *   </tr>
- * </table>
- *
- * <p>The substitution descriptor (i.e., the text between the token characters) may take one
- * of three forms:</p>
- *
- * <table border="0" width="100%">
- *   <tr>
- *     <td>a rule set name</td>
- *     <td>Perform the mathematical operation on the number, and format the result using the
- *     named rule set.</td>
- *   </tr>
- *   <tr>
- *     <td>a DecimalFormat pattern</td>
- *     <td>Perform the mathematical operation on the number, and format the result using a
- *     DecimalFormat with the specified pattern.&nbsp; The pattern must begin with 0 or #.</td>
- *   </tr>
- *   <tr>
- *     <td>nothing</td>
- *     <td>Perform the mathematical operation on the number, and format the result using the rule
- *     set containing the current rule, except:
- *     <ul>
- *       <li>You can't have an empty substitution descriptor with a == substitution.</li>
- *       <li>If you omit the substitution descriptor in a &gt;&gt; substitution in a fraction rule,
- *         format the result one digit at a time using the rule set containing the current rule.</li>
- *       <li>If you omit the substitution descriptor in a &lt;&lt; substitution in a rule in a
- *         fraction rule set, format the result using the default rule set for this formatter.</li>
- *     </ul>
- *     </td>
- *   </tr>
- * </table>
- *
- * <p>Whitespace is ignored between a rule set name and a rule set body, between a rule
- * descriptor and a rule body, or between rules. If a rule body begins with an apostrophe,
- * the apostrophe is ignored, but all text after it becomes significant (this is how you can
- * have a rule's rule text begin with whitespace). There is no escape function: the semicolon
- * is not allowed in rule set names or in rule text, and the colon is not allowed in rule set
- * names. The characters beginning a substitution token are always treated as the beginning
- * of a substitution token.</p>
- *
- * <p>See the resource data and the demo program for annotated examples of real rule sets
- * using these features.</p>
- *
- * <p><em>User subclasses are not supported.</em> While clients may write
- * subclasses, such code will not necessarily work and will not be
- * guaranteed to work stably from release to release.
- *
- * <p><b>Localizations</b></p>
- * <p>Constructors are available that allow the specification of localizations for the
- * public rule sets (and also allow more control over what public rule sets are available).
- * Localization data is represented as a textual description.  The description represents
- * an array of arrays of string.  The first element is an array of the public rule set names,
- * each of these must be one of the public rule set names that appear in the rules.  Only
- * names in this array will be treated as public rule set names by the API.  Each subsequent
- * element is an array of localizations of these names.  The first element of one of these
- * subarrays is the locale name, and the remaining elements are localizations of the
- * public rule set names, in the same order as they were listed in the first arrray.</p>
- * <p>In the syntax, angle brackets '<', '>' are used to delimit the arrays, and comma ',' is used
- * to separate elements of an array.  Whitespace is ignored, unless quoted.</p>
- * <p>For example:<pre>
- * < < %foo, %bar, %baz >, 
- *   < en, Foo, Bar, Baz >, 
- *   < fr, 'le Foo', 'le Bar', 'le Baz' > 
- *   < zh, \\u7532, \\u4e59, \\u4e19 > >
- * </pre></p>
- * @author Richard Gillam
- * @see NumberFormat
- * @see DecimalFormat
- * @stable ICU 2.0
- */
-class U_I18N_API RuleBasedNumberFormat : public NumberFormat {
-public:
-
-  //-----------------------------------------------------------------------
-  // constructors
-  //-----------------------------------------------------------------------
-
-    /**
-     * Creates a RuleBasedNumberFormat that behaves according to the description
-     * passed in.  The formatter uses the default locale.
-     * @param rules A description of the formatter's desired behavior.
-     * See the class documentation for a complete explanation of the description
-     * syntax.
-     * @param perror The parse error if an error was encountered.
-     * @param status The status indicating whether the constructor succeeded.
-     * @stable ICU 3.2
-     */
-    RuleBasedNumberFormat(const UnicodeString& rules, UParseError& perror, UErrorCode& status);
-
-    /**
-     * Creates a RuleBasedNumberFormat that behaves according to the description
-     * passed in.  The formatter uses the default locale.  
-     * <p>
-     * The localizations data provides information about the public
-     * rule sets and their localized display names for different
-     * locales. The first element in the list is an array of the names
-     * of the public rule sets.  The first element in this array is
-     * the initial default ruleset.  The remaining elements in the
-     * list are arrays of localizations of the names of the public
-     * rule sets.  Each of these is one longer than the initial array,
-     * with the first String being the ULocale ID, and the remaining
-     * Strings being the localizations of the rule set names, in the
-     * same order as the initial array.  Arrays are NULL-terminated.
-     * @param rules A description of the formatter's desired behavior.
-     * See the class documentation for a complete explanation of the description
-     * syntax.
-     * @param localizations the localization information.
-     * names in the description.  These will be copied by the constructor.
-     * @param perror The parse error if an error was encountered.
-     * @param status The status indicating whether the constructor succeeded.
-     * @stable ICU 3.2
-     */
-    RuleBasedNumberFormat(const UnicodeString& rules, const UnicodeString& localizations,
-                        UParseError& perror, UErrorCode& status);
-
-  /**
-   * Creates a RuleBasedNumberFormat that behaves according to the rules
-   * passed in.  The formatter uses the specified locale to determine the
-   * characters to use when formatting numerals, and to define equivalences
-   * for lenient parsing.
-   * @param rules The formatter rules.
-   * See the class documentation for a complete explanation of the rule
-   * syntax.
-   * @param locale A locale that governs which characters are used for
-   * formatting values in numerals and which characters are equivalent in
-   * lenient parsing.
-   * @param perror The parse error if an error was encountered.
-   * @param status The status indicating whether the constructor succeeded.
-   * @stable ICU 2.0
-   */
-  RuleBasedNumberFormat(const UnicodeString& rules, const Locale& locale,
-                        UParseError& perror, UErrorCode& status);
-
-    /**
-     * Creates a RuleBasedNumberFormat that behaves according to the description
-     * passed in.  The formatter uses the default locale.  
-     * <p>
-     * The localizations data provides information about the public
-     * rule sets and their localized display names for different
-     * locales. The first element in the list is an array of the names
-     * of the public rule sets.  The first element in this array is
-     * the initial default ruleset.  The remaining elements in the
-     * list are arrays of localizations of the names of the public
-     * rule sets.  Each of these is one longer than the initial array,
-     * with the first String being the ULocale ID, and the remaining
-     * Strings being the localizations of the rule set names, in the
-     * same order as the initial array.  Arrays are NULL-terminated.
-     * @param rules A description of the formatter's desired behavior.
-     * See the class documentation for a complete explanation of the description
-     * syntax.
-     * @param localizations a list of localizations for the rule set
-     * names in the description.  These will be copied by the constructor.
-     * @param locale A locale that governs which characters are used for
-     * formatting values in numerals and which characters are equivalent in
-     * lenient parsing.
-     * @param perror The parse error if an error was encountered.
-     * @param status The status indicating whether the constructor succeeded.
-     * @stable ICU 3.2
-     */
-    RuleBasedNumberFormat(const UnicodeString& rules, const UnicodeString& localizations,
-                        const Locale& locale, UParseError& perror, UErrorCode& status);
-
-  /**
-   * Creates a RuleBasedNumberFormat from a predefined ruleset.  The selector
-   * code choosed among three possible predefined formats: spellout, ordinal,
-   * and duration.
-   * @param tag A selector code specifying which kind of formatter to create for that
-   * locale.  There are three legal values: URBNF_SPELLOUT, which creates a formatter that
-   * spells out a value in words in the desired language, URBNF_ORDINAL, which attaches
-   * an ordinal suffix from the desired language to the end of a number (e.g. "123rd"),
-   * and URBNF_DURATION, which formats a duration in seconds as hours, minutes, and seconds.
-   * @param locale The locale for the formatter.
-   * @param status The status indicating whether the constructor succeeded.
-   * @stable ICU 2.0
-   */
-  RuleBasedNumberFormat(URBNFRuleSetTag tag, const Locale& locale, UErrorCode& status);
-
-  //-----------------------------------------------------------------------
-  // boilerplate
-  //-----------------------------------------------------------------------
-
-  /**
-   * Copy constructor
-   * @param rhs    the object to be copied from.
-   * @stable ICU 2.6
-   */
-  RuleBasedNumberFormat(const RuleBasedNumberFormat& rhs);
-
-  /**
-   * Assignment operator
-   * @param rhs    the object to be copied from.
-   * @stable ICU 2.6
-   */
-  RuleBasedNumberFormat& operator=(const RuleBasedNumberFormat& rhs);
-
-  /**
-   * Release memory allocated for a RuleBasedNumberFormat when you are finished with it.
-   * @stable ICU 2.6
-   */
-  virtual ~RuleBasedNumberFormat();
-
-  /**
-   * Clone this object polymorphically.  The caller is responsible
-   * for deleting the result when done.
-   * @return  A copy of the object.
-   * @stable ICU 2.6
-   */
-  virtual Format* clone(void) const;
-
-  /**
-   * Return true if the given Format objects are semantically equal.
-   * Objects of different subclasses are considered unequal.
-   * @param other    the object to be compared with.
-   * @return        true if the given Format objects are semantically equal.
-   * @stable ICU 2.6
-   */
-  virtual UBool operator==(const Format& other) const;
-
-//-----------------------------------------------------------------------
-// public API functions
-//-----------------------------------------------------------------------
-
-  /**
-   * return the rules that were provided to the RuleBasedNumberFormat.
-   * @return the result String that was passed in
-   * @stable ICU 2.0
-   */
-  virtual UnicodeString getRules() const;
-
-  /**
-   * Return the number of public rule set names.
-   * @return the number of public rule set names.
-   * @stable ICU 2.0
-   */
-  virtual int32_t getNumberOfRuleSetNames() const;
-
-  /**
-   * Return the name of the index'th public ruleSet.  If index is not valid,
-   * the function returns null.
-   * @param index the index of the ruleset
-   * @return the name of the index'th public ruleSet.
-   * @stable ICU 2.0
-   */
-  virtual UnicodeString getRuleSetName(int32_t index) const;
-
-  /**
-   * Return the number of locales for which we have localized rule set display names.
-   * @return the number of locales for which we have localized rule set display names.
-   * @stable ICU 3.2
-   */
-  virtual int32_t getNumberOfRuleSetDisplayNameLocales(void) const;
-
-  /**
-   * Return the index'th display name locale.
-   * @param index the index of the locale
-   * @param status set to a failure code when this function fails
-   * @return the locale
-   * @see #getNumberOfRuleSetDisplayNameLocales
-   * @stable ICU 3.2
-   */
-  virtual Locale getRuleSetDisplayNameLocale(int32_t index, UErrorCode& status) const;
-
-    /**
-     * Return the rule set display names for the provided locale.  These are in the same order
-     * as those returned by getRuleSetName.  The locale is matched against the locales for
-     * which there is display name data, using normal fallback rules.  If no locale matches, 
-     * the default display names are returned.  (These are the internal rule set names minus
-     * the leading '%'.)
-     * @param index the index of the rule set
-     * @param locale the locale (returned by getRuleSetDisplayNameLocales) for which the localized
-     * display name is desired
-     * @return the display name for the given index, which might be bogus if there is an error
-     * @see #getRuleSetName
-     * @stable ICU 3.2
-     */
-  virtual UnicodeString getRuleSetDisplayName(int32_t index, 
-                          const Locale& locale = Locale::getDefault());
-
-    /**
-     * Return the rule set display name for the provided rule set and locale.  
-     * The locale is matched against the locales for which there is display name data, using
-     * normal fallback rules.  If no locale matches, the default display name is returned.
-     * @return the display name for the rule set
-     * @stable ICU 3.2
-     * @see #getRuleSetDisplayName
-     */
-  virtual UnicodeString getRuleSetDisplayName(const UnicodeString& ruleSetName, 
-                          const Locale& locale = Locale::getDefault());
-
-  /**
-   * Formats the specified 32-bit number using the default ruleset.
-   * @param number The number to format.
-   * @param toAppendTo the string that will hold the (appended) result
-   * @param pos the fieldposition
-   * @return A textual representation of the number.
-   * @stable ICU 2.0
-   */
-  virtual UnicodeString& format(int32_t number,
-                                UnicodeString& toAppendTo,
-                                FieldPosition& pos) const;
-
-  /**
-   * Formats the specified 64-bit number using the default ruleset.
-   * @param number The number to format.
-   * @param toAppendTo the string that will hold the (appended) result
-   * @param pos the fieldposition
-   * @return A textual representation of the number.
-   * @stable ICU 2.1
-   */
-  virtual UnicodeString& format(int64_t number,
-                                UnicodeString& toAppendTo,
-                                FieldPosition& pos) const;
-  /**
-   * Formats the specified number using the default ruleset.
-   * @param number The number to format.
-   * @param toAppendTo the string that will hold the (appended) result
-   * @param pos the fieldposition
-   * @return A textual representation of the number.
-   * @stable ICU 2.0
-   */
-  virtual UnicodeString& format(double number,
-                                UnicodeString& toAppendTo,
-                                FieldPosition& pos) const;
-
-  /**
-   * Formats the specified number using the named ruleset.
-   * @param number The number to format.
-   * @param ruleSetName The name of the rule set to format the number with.
-   * This must be the name of a valid public rule set for this formatter.
-   * @param toAppendTo the string that will hold the (appended) result
-   * @param pos the fieldposition
-   * @param status the status
-   * @return A textual representation of the number.
-   * @stable ICU 2.0
-   */
-  virtual UnicodeString& format(int32_t number,
-                                const UnicodeString& ruleSetName,
-                                UnicodeString& toAppendTo,
-                                FieldPosition& pos,
-                                UErrorCode& status) const;
-  /**
-   * Formats the specified 64-bit number using the named ruleset.
-   * @param number The number to format.
-   * @param ruleSetName The name of the rule set to format the number with.
-   * This must be the name of a valid public rule set for this formatter.
-   * @param toAppendTo the string that will hold the (appended) result
-   * @param pos the fieldposition
-   * @param status the status
-   * @return A textual representation of the number.
-   * @stable ICU 2.1
-   */
-  virtual UnicodeString& format(int64_t number,
-                                const UnicodeString& ruleSetName,
-                                UnicodeString& toAppendTo,
-                                FieldPosition& pos,
-                                UErrorCode& status) const;
-  /**
-   * Formats the specified number using the named ruleset.
-   * @param number The number to format.
-   * @param ruleSetName The name of the rule set to format the number with.
-   * This must be the name of a valid public rule set for this formatter.
-   * @param toAppendTo the string that will hold the (appended) result
-   * @param pos the fieldposition
-   * @param status the status
-   * @return A textual representation of the number.
-   * @stable ICU 2.0
-   */
-  virtual UnicodeString& format(double number,
-                                const UnicodeString& ruleSetName,
-                                UnicodeString& toAppendTo,
-                                FieldPosition& pos,
-                                UErrorCode& status) const;
-
-  /**
-   * Formats the specified number using the default ruleset.
-   * @param obj The number to format.
-   * @param toAppendTo the string that will hold the (appended) result
-   * @param pos the fieldposition
-   * @param status the status
-   * @return A textual representation of the number.
-   * @stable ICU 2.0
-   */
-  virtual UnicodeString& format(const Formattable& obj,
-                                UnicodeString& toAppendTo,
-                                FieldPosition& pos,
-                                UErrorCode& status) const;
-  /**
-   * Redeclared Format method.
-   * @param obj    the object to be formatted.
-   * @param result Output param which will receive the formatted string.
-   * @param status Output param set to success/failure code
-   * @return       A reference to 'result'.
-   * @stable ICU 2.0
-   */
-  UnicodeString& format(const Formattable& obj,
-                        UnicodeString& result,
-                        UErrorCode& status) const;
-
-  /**
-   * Redeclared NumberFormat method.
-   * @param number    the double value to be formatted.
-   * @param output    Output param which will receive the formatted string.
-   * @return          A reference to 'output'.
-   * @stable ICU 2.0
-   */
-   UnicodeString& format(double number,
-                         UnicodeString& output) const;
-
-  /**
-   * Redeclared NumberFormat method.
-   * @param number    the long value to be formatted.
-   * @param output    Output param which will receive the formatted string.
-   * @return          A reference to 'output'.
-   * @stable ICU 2.0
-   */
-   UnicodeString& format(int32_t number,
-                         UnicodeString& output) const;
-
-  /**
-   * Parses the specfied string, beginning at the specified position, according
-   * to this formatter's rules.  This will match the string against all of the
-   * formatter's public rule sets and return the value corresponding to the longest
-   * parseable substring.  This function's behavior is affected by the lenient
-   * parse mode.
-   * @param text The string to parse
-   * @param result the result of the parse, either a double or a long.
-   * @param parsePosition On entry, contains the position of the first character
-   * in "text" to examine.  On exit, has been updated to contain the position
-   * of the first character in "text" that wasn't consumed by the parse.
-   * @see #setLenient
-   * @stable ICU 2.0
-   */
-  virtual void parse(const UnicodeString& text,
-                     Formattable& result,
-                     ParsePosition& parsePosition) const;
-
-
-  /**
-   * Redeclared Format method.
-   * @param text   The string to parse
-   * @param result the result of the parse, either a double or a long.
-   * @param status Output param set to failure code when a problem occurs.
-   * @stable ICU 2.0
-   */
-  virtual inline void parse(const UnicodeString& text,
-                      Formattable& result,
-                      UErrorCode& status) const;
-
-#if !UCONFIG_NO_COLLATION
-
-  /**
-   * Turns lenient parse mode on and off.
-   *
-   * When in lenient parse mode, the formatter uses a Collator for parsing the text.
-   * Only primary differences are treated as significant.  This means that case
-   * differences, accent differences, alternate spellings of the same letter
-   * (e.g., ae and a-umlaut in German), ignorable characters, etc. are ignored in
-   * matching the text.  In many cases, numerals will be accepted in place of words
-   * or phrases as well.
-   *
-   * For example, all of the following will correctly parse as 255 in English in
-   * lenient-parse mode:
-   * <br>"two hundred fifty-five"
-   * <br>"two hundred fifty five"
-   * <br>"TWO HUNDRED FIFTY-FIVE"
-   * <br>"twohundredfiftyfive"
-   * <br>"2 hundred fifty-5"
-   *
-   * The Collator used is determined by the locale that was
-   * passed to this object on construction.  The description passed to this object
-   * on construction may supply additional collation rules that are appended to the
-   * end of the default collator for the locale, enabling additional equivalences
-   * (such as adding more ignorable characters or permitting spelled-out version of
-   * symbols; see the demo program for examples).
-   *
-   * It's important to emphasize that even strict parsing is relatively lenient: it
-   * will accept some text that it won't produce as output.  In English, for example,
-   * it will correctly parse "two hundred zero" and "fifteen hundred".
-   *
-   * @param enabled If true, turns lenient-parse mode on; if false, turns it off.
-   * @see RuleBasedCollator
-   * @stable ICU 2.0
-   */
-  virtual void setLenient(UBool enabled);
-
-  /**
-   * Returns true if lenient-parse mode is turned on.  Lenient parsing is off
-   * by default.
-   * @return true if lenient-parse mode is turned on.
-   * @see #setLenient
-   * @stable ICU 2.0
-   */
-  virtual inline UBool isLenient(void) const;
-
-#endif
-
-  /**
-   * Override the default rule set to use.  If ruleSetName is null, reset
-   * to the initial default rule set.  If the rule set is not a public rule set name,
-   * U_ILLEGAL_ARGUMENT_ERROR is returned in status.
-   * @param ruleSetName the name of the rule set, or null to reset the initial default.
-   * @param status set to failure code when a problem occurs.
-   * @stable ICU 2.6
-   */
-  virtual void setDefaultRuleSet(const UnicodeString& ruleSetName, UErrorCode& status);
-
-  /**
-   * Return the name of the current default rule set.  If the current rule set is
-   * not public, returns a bogus (and empty) UnicodeString.
-   * @return the name of the current default rule set
-   * @stable ICU 3.0
-   */
-  virtual UnicodeString getDefaultRuleSetName() const;
-
-public:
-    /**
-     * ICU "poor man's RTTI", returns a UClassID for this class.
-     *
-     * @stable ICU 2.8
-     */
-    static UClassID U_EXPORT2 getStaticClassID(void);
-
-    /**
-     * ICU "poor man's RTTI", returns a UClassID for the actual class.
-     *
-     * @stable ICU 2.8
-     */
-    virtual UClassID getDynamicClassID(void) const;
-
-private:
-    RuleBasedNumberFormat(); // default constructor not implemented
-
-    // this will ref the localizations if they are not NULL
-    // caller must deref to get adoption 
-    RuleBasedNumberFormat(const UnicodeString& description, LocalizationInfo* localizations, 
-              const Locale& locale, UParseError& perror, UErrorCode& status);
-
-    void init(const UnicodeString& rules, LocalizationInfo* localizations, UParseError& perror, UErrorCode& status);
-    void dispose();
-    void stripWhitespace(UnicodeString& src);
-    void initDefaultRuleSet();
-    void format(double number, NFRuleSet& ruleSet);
-    NFRuleSet* findRuleSet(const UnicodeString& name, UErrorCode& status) const;
-
-    /* friend access */
-    friend class NFSubstitution;
-    friend class NFRule;
-    friend class FractionalPartSubstitution;
-
-    inline NFRuleSet * getDefaultRuleSet() const;
-    Collator * getCollator() const;
-    DecimalFormatSymbols * getDecimalFormatSymbols() const;
-
-private:
-    NFRuleSet **ruleSets;
-    NFRuleSet *defaultRuleSet;
-    Locale locale;
-    Collator* collator;
-    DecimalFormatSymbols* decimalFormatSymbols;
-    UBool lenient;
-    UnicodeString* lenientParseRules;
-    LocalizationInfo* localizations;
-};
-
-// ---------------
-
-inline UnicodeString&
-RuleBasedNumberFormat::format(const Formattable& obj,
-                              UnicodeString& result,
-                              UErrorCode& status) const
-{
-    // Don't use Format:: - use immediate base class only,
-    // in case immediate base modifies behavior later.
-    // dlf - the above comment is bogus, if there were a reason to modify
-    // it, it would be virtual, and there's no reason because it is
-    // a one-line macro in NumberFormat anyway, just like this one.
-    return NumberFormat::format(obj, result, status);
-}
-
-inline UnicodeString&
-RuleBasedNumberFormat::format(double number, UnicodeString& output) const {
-    FieldPosition pos(0);
-    return format(number, output, pos);
-}
-
-inline UnicodeString&
-RuleBasedNumberFormat::format(int32_t number, UnicodeString& output) const {
-    FieldPosition pos(0);
-    return format(number, output, pos);
-}
-
-inline void
-RuleBasedNumberFormat::parse(const UnicodeString& text, Formattable& result, UErrorCode& status) const
-{
-    NumberFormat::parse(text, result, status);
-}
-
-#if !UCONFIG_NO_COLLATION
-
-inline UBool
-RuleBasedNumberFormat::isLenient(void) const {
-    return lenient;
-}
-
-#endif
-
-inline NFRuleSet*
-RuleBasedNumberFormat::getDefaultRuleSet() const {
-    return defaultRuleSet;
-}
-
-U_NAMESPACE_END
-
-/* U_HAVE_RBNF */
-#endif
-
-/* RBNF_H */
-#endif

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/rbtz.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/rbtz.h b/apps/couch_collate/platform/osx/icu/unicode/rbtz.h
deleted file mode 100644
index 78215f3..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/rbtz.h
+++ /dev/null
@@ -1,361 +0,0 @@
-/*
-*******************************************************************************
-* Copyright (C) 2007-2008, International Business Machines Corporation and    *
-* others. All Rights Reserved.                                                *
-*******************************************************************************
-*/
-#ifndef RBTZ_H
-#define RBTZ_H
-
-#include "unicode/utypes.h"
-
-/**
- * \file 
- * \brief C++ API: Rule based customizable time zone
- */
-
-#if !UCONFIG_NO_FORMATTING
-
-#include "unicode/basictz.h"
-#include "unicode/unistr.h"
-
-U_NAMESPACE_BEGIN
-
-// forward declaration
-class UVector;
-struct Transition;
-
-/**
- * a BasicTimeZone subclass implemented in terms of InitialTimeZoneRule and TimeZoneRule instances
- * @see BasicTimeZone
- * @see InitialTimeZoneRule
- * @see TimeZoneRule
- */
-class U_I18N_API RuleBasedTimeZone : public BasicTimeZone {
-public:
-    /**
-     * Constructs a <code>RuleBasedTimeZone</code> object with the ID and the
-     * <code>InitialTimeZoneRule</code>.  The input <code>InitialTimeZoneRule</code>
-     * is adopted by this <code>RuleBasedTimeZone</code>, thus the caller must not
-     * delete it.
-     * @param id                The time zone ID.
-     * @param initialRule       The initial time zone rule.
-     * @stable ICU 4.0
-     */
-    RuleBasedTimeZone(const UnicodeString& id, InitialTimeZoneRule* initialRule);
-
-    /**
-     * Copy constructor.
-     * @param source    The RuleBasedTimeZone object to be copied.
-     * @stable ICU 4.0
-     */
-    RuleBasedTimeZone(const RuleBasedTimeZone& source);
-
-    /**
-     * Destructor.
-     * @stable ICU 4.0
-     */
-    virtual ~RuleBasedTimeZone();
-
-    /**
-     * Assignment operator.
-     * @param right The object to be copied.
-     * @stable ICU 4.0
-     */
-    RuleBasedTimeZone& operator=(const RuleBasedTimeZone& right);
-
-    /**
-     * Return true if the given <code>TimeZone</code> objects are
-     * semantically equal. Objects of different subclasses are considered unequal.
-     * @param that  The object to be compared with.
-     * @return  true if the given <code>TimeZone</code> objects are
-      *semantically equal.
-     * @stable ICU 4.0
-     */
-    virtual UBool operator==(const TimeZone& that) const;
-
-    /**
-     * Return true if the given <code>TimeZone</code> objects are
-     * semantically unequal. Objects of different subclasses are considered unequal.
-     * @param that  The object to be compared with.
-     * @return  true if the given <code>TimeZone</code> objects are
-     * semantically unequal.
-     * @stable ICU 4.0
-     */
-    virtual UBool operator!=(const TimeZone& that) const;
-
-    /**
-     * Adds the <code>TimeZoneRule</code> which represents time transitions.
-     * The <code>TimeZoneRule</code> must have start times, that is, the result
-     * of isTransitionRule() must be true. Otherwise, U_ILLEGAL_ARGUMENT_ERROR
-     * is set to the error code.
-     * The input <code>TimeZoneRule</code> is adopted by this
-     * <code>RuleBasedTimeZone</code> on successful completion of this method,
-     * thus, the caller must not delete it when no error is returned.
-     * After all rules are added, the caller must call complete() method to
-     * make this <code>RuleBasedTimeZone</code> ready to handle common time
-     * zone functions.
-     * @param rule The <code>TimeZoneRule</code>.
-     * @param status Output param to filled in with a success or an error.
-     * @stable ICU 4.0
-     */
-    void addTransitionRule(TimeZoneRule* rule, UErrorCode& status);
-
-    /**
-     * Makes the <code>TimeZoneRule</code> ready to handle actual timezone
-     * calcuation APIs.  This method collects time zone rules specified
-     * by the caller via the constructor and addTransitionRule() and
-     * builds internal structure for making the object ready to support
-     * time zone APIs such as getOffset(), getNextTransition() and others.
-     * @param status Output param to filled in with a success or an error.
-     * @stable ICU 4.0
-     */
-    void complete(UErrorCode& status);
-
-    /**
-     * Clones TimeZone objects polymorphically. Clients are responsible for deleting
-     * the TimeZone object cloned.
-     *
-     * @return   A new copy of this TimeZone object.
-     * @stable ICU 4.0
-     */
-    virtual TimeZone* clone(void) const;
-
-    /**
-     * Returns the TimeZone's adjusted GMT offset (i.e., the number of milliseconds to add
-     * to GMT to get local time in this time zone, taking daylight savings time into
-     * account) as of a particular reference date.  The reference date is used to determine
-     * whether daylight savings time is in effect and needs to be figured into the offset
-     * that is returned (in other words, what is the adjusted GMT offset in this time zone
-     * at this particular date and time?).  For the time zones produced by createTimeZone(),
-     * the reference data is specified according to the Gregorian calendar, and the date
-     * and time fields are local standard time.
-     *
-     * <p>Note: Don't call this method. Instead, call the getOffset(UDate...) overload,
-     * which returns both the raw and the DST offset for a given time. This method
-     * is retained only for backward compatibility.
-     *
-     * @param era        The reference date's era
-     * @param year       The reference date's year
-     * @param month      The reference date's month (0-based; 0 is January)
-     * @param day        The reference date's day-in-month (1-based)
-     * @param dayOfWeek  The reference date's day-of-week (1-based; 1 is Sunday)
-     * @param millis     The reference date's milliseconds in day, local standard time
-     * @param status     Output param to filled in with a success or an error.
-     * @return           The offset in milliseconds to add to GMT to get local time.
-     * @stable ICU 4.0
-     */
-    virtual int32_t getOffset(uint8_t era, int32_t year, int32_t month, int32_t day,
-                              uint8_t dayOfWeek, int32_t millis, UErrorCode& status) const;
-
-    /**
-     * Gets the time zone offset, for current date, modified in case of
-     * daylight savings. This is the offset to add *to* UTC to get local time.
-     *
-     * <p>Note: Don't call this method. Instead, call the getOffset(UDate...) overload,
-     * which returns both the raw and the DST offset for a given time. This method
-     * is retained only for backward compatibility.
-     *
-     * @param era        The reference date's era
-     * @param year       The reference date's year
-     * @param month      The reference date's month (0-based; 0 is January)
-     * @param day        The reference date's day-in-month (1-based)
-     * @param dayOfWeek  The reference date's day-of-week (1-based; 1 is Sunday)
-     * @param millis     The reference date's milliseconds in day, local standard time
-     * @param monthLength The length of the given month in days.
-     * @param status     Output param to filled in with a success or an error.
-     * @return           The offset in milliseconds to add to GMT to get local time.
-     * @stable ICU 4.0
-     */
-    virtual int32_t getOffset(uint8_t era, int32_t year, int32_t month, int32_t day,
-                           uint8_t dayOfWeek, int32_t millis,
-                           int32_t monthLength, UErrorCode& status) const;
-
-    /**
-     * Returns the time zone raw and GMT offset for the given moment
-     * in time.  Upon return, local-millis = GMT-millis + rawOffset +
-     * dstOffset.  All computations are performed in the proleptic
-     * Gregorian calendar.  The default implementation in the TimeZone
-     * class delegates to the 8-argument getOffset().
-     *
-     * @param date moment in time for which to return offsets, in
-     * units of milliseconds from January 1, 1970 0:00 GMT, either GMT
-     * time or local wall time, depending on `local'.
-     * @param local if true, `date' is local wall time; otherwise it
-     * is in GMT time.
-     * @param rawOffset output parameter to receive the raw offset, that
-     * is, the offset not including DST adjustments
-     * @param dstOffset output parameter to receive the DST offset,
-     * that is, the offset to be added to `rawOffset' to obtain the
-     * total offset between local and GMT time. If DST is not in
-     * effect, this value is zero; otherwise it is a positive value,
-     * typically one hour.
-     * @param ec input-output error code
-     * @stable ICU 4.0
-     */
-    virtual void getOffset(UDate date, UBool local, int32_t& rawOffset,
-                           int32_t& dstOffset, UErrorCode& ec) const;
-
-    /**
-     * Sets the TimeZone's raw GMT offset (i.e., the number of milliseconds to add
-     * to GMT to get local time, before taking daylight savings time into account).
-     *
-     * @param offsetMillis  The new raw GMT offset for this time zone.
-     * @stable ICU 4.0
-     */
-    virtual void setRawOffset(int32_t offsetMillis);
-
-    /**
-     * Returns the TimeZone's raw GMT offset (i.e., the number of milliseconds to add
-     * to GMT to get local time, before taking daylight savings time into account).
-     *
-     * @return   The TimeZone's raw GMT offset.
-     * @stable ICU 4.0
-     */
-    virtual int32_t getRawOffset(void) const;
-
-    /**
-     * Queries if this time zone uses daylight savings time.
-     * @return true if this time zone uses daylight savings time,
-     * false, otherwise.
-     * @stable ICU 4.0
-     */
-    virtual UBool useDaylightTime(void) const;
-
-    /**
-     * Queries if the given date is in daylight savings time in
-     * this time zone.
-     * This method is wasteful since it creates a new GregorianCalendar and
-     * deletes it each time it is called. This is a deprecated method
-     * and provided only for Java compatibility.
-     *
-     * @param date the given UDate.
-     * @param status Output param filled in with success/error code.
-     * @return true if the given date is in daylight savings time,
-     * false, otherwise.
-     * @deprecated ICU 2.4. Use Calendar::inDaylightTime() instead.
-     */
-    virtual UBool inDaylightTime(UDate date, UErrorCode& status) const;
-
-    /**
-     * Returns true if this zone has the same rule and offset as another zone.
-     * That is, if this zone differs only in ID, if at all.
-     * @param other the <code>TimeZone</code> object to be compared with
-     * @return true if the given zone is the same as this one,
-     * with the possible exception of the ID
-     * @stable ICU 4.0
-     */
-    virtual UBool hasSameRules(const TimeZone& other) const;
-
-    /**
-     * Gets the first time zone transition after the base time.
-     * @param base      The base time.
-     * @param inclusive Whether the base time is inclusive or not.
-     * @param result    Receives the first transition after the base time.
-     * @return  TRUE if the transition is found.
-     * @stable ICU 4.0
-     */
-    virtual UBool getNextTransition(UDate base, UBool inclusive, TimeZoneTransition& result) /*const*/;
-
-    /**
-     * Gets the most recent time zone transition before the base time.
-     * @param base      The base time.
-     * @param inclusive Whether the base time is inclusive or not.
-     * @param result    Receives the most recent transition before the base time.
-     * @return  TRUE if the transition is found.
-     * @stable ICU 4.0
-     */
-    virtual UBool getPreviousTransition(UDate base, UBool inclusive, TimeZoneTransition& result) /*const*/;
-
-    /**
-     * Returns the number of <code>TimeZoneRule</code>s which represents time transitions,
-     * for this time zone, that is, all <code>TimeZoneRule</code>s for this time zone except
-     * <code>InitialTimeZoneRule</code>.  The return value range is 0 or any positive value.
-     * @param status    Receives error status code.
-     * @return The number of <code>TimeZoneRule</code>s representing time transitions.
-     * @stable ICU 4.0
-     */
-    virtual int32_t countTransitionRules(UErrorCode& status) /*const*/;
-
-    /**
-     * Gets the <code>InitialTimeZoneRule</code> and the set of <code>TimeZoneRule</code>
-     * which represent time transitions for this time zone.  On successful return,
-     * the argument initial points to non-NULL <code>InitialTimeZoneRule</code> and
-     * the array trsrules is filled with 0 or multiple <code>TimeZoneRule</code>
-     * instances up to the size specified by trscount.  The results are referencing the
-     * rule instance held by this time zone instance.  Therefore, after this time zone
-     * is destructed, they are no longer available.
-     * @param initial       Receives the initial timezone rule
-     * @param trsrules      Receives the timezone transition rules
-     * @param trscount      On input, specify the size of the array 'transitions' receiving
-     *                      the timezone transition rules.  On output, actual number of
-     *                      rules filled in the array will be set.
-     * @param status        Receives error status code.
-     * @stable ICU 4.0
-     */
-    virtual void getTimeZoneRules(const InitialTimeZoneRule*& initial,
-        const TimeZoneRule* trsrules[], int32_t& trscount, UErrorCode& status) /*const*/;
-
-    /**
-     * Get time zone offsets from local wall time.
-     * @internal
-     */
-    virtual void getOffsetFromLocal(UDate date, int32_t nonExistingTimeOpt, int32_t duplicatedTimeOpt,
-        int32_t& rawOffset, int32_t& dstOffset, UErrorCode& status) /*const*/;
-
-private:
-    void deleteRules(void);
-    void deleteTransitions(void);
-    UVector* copyRules(UVector* source);
-    TimeZoneRule* findRuleInFinal(UDate date, UBool local,
-        int32_t NonExistingTimeOpt, int32_t DuplicatedTimeOpt) const;
-    UBool findNext(UDate base, UBool inclusive, UDate& time, TimeZoneRule*& from, TimeZoneRule*& to) const;
-    UBool findPrev(UDate base, UBool inclusive, UDate& time, TimeZoneRule*& from, TimeZoneRule*& to) const;
-    int32_t getLocalDelta(int32_t rawBefore, int32_t dstBefore, int32_t rawAfter, int32_t dstAfter,
-        int32_t NonExistingTimeOpt, int32_t DuplicatedTimeOpt) const;
-    UDate getTransitionTime(Transition* transition, UBool local,
-        int32_t NonExistingTimeOpt, int32_t DuplicatedTimeOpt) const;
-    void getOffsetInternal(UDate date, UBool local, int32_t NonExistingTimeOpt, int32_t DuplicatedTimeOpt,
-        int32_t& rawOffset, int32_t& dstOffset, UErrorCode& ec) const;
-
-    InitialTimeZoneRule *fInitialRule;
-    UVector             *fHistoricRules;
-    UVector             *fFinalRules;
-    UVector             *fHistoricTransitions;
-    UBool               fUpToDate;
-
-public:
-    /**
-     * Return the class ID for this class. This is useful only for comparing to
-     * a return value from getDynamicClassID(). For example:
-     * <pre>
-     * .   Base* polymorphic_pointer = createPolymorphicObject();
-     * .   if (polymorphic_pointer->getDynamicClassID() ==
-     * .       erived::getStaticClassID()) ...
-     * </pre>
-     * @return          The class ID for all objects of this class.
-     * @stable ICU 4.0
-     */
-    static UClassID U_EXPORT2 getStaticClassID(void);
-
-    /**
-     * Returns a unique class ID POLYMORPHICALLY. Pure virtual override. This
-     * method is to implement a simple version of RTTI, since not all C++
-     * compilers support genuine RTTI. Polymorphic operator==() and clone()
-     * methods call this method.
-     *
-     * @return          The class ID for this object. All objects of a
-     *                  given class have the same class ID.  Objects of
-     *                  other classes have different class IDs.
-     * @stable ICU 4.0
-     */
-    virtual UClassID getDynamicClassID(void) const;
-};
-
-U_NAMESPACE_END
-
-#endif /* #if !UCONFIG_NO_FORMATTING */
-
-#endif // RBTZ_H
-
-//eof


[19/57] [abbrv] remove couch_collate

Posted by be...@apache.org.
http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/uchriter.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/uchriter.h b/apps/couch_collate/platform/osx/icu/unicode/uchriter.h
deleted file mode 100644
index 6d5a990..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/uchriter.h
+++ /dev/null
@@ -1,381 +0,0 @@
-/*
-**********************************************************************
-*   Copyright (C) 1998-2005, International Business Machines
-*   Corporation and others.  All Rights Reserved.
-**********************************************************************
-*/
-
-#ifndef UCHRITER_H
-#define UCHRITER_H
-
-#include "unicode/utypes.h"
-#include "unicode/chariter.h"
-
-/**
- * \file 
- * \brief C++ API: UChar Character Iterator
- */
- 
-U_NAMESPACE_BEGIN
-
-/**
- * A concrete subclass of CharacterIterator that iterates over the
- * characters (code units or code points) in a UChar array.
- * It's possible not only to create an
- * iterator that iterates over an entire UChar array, but also to
- * create one that iterates over only a subrange of a UChar array
- * (iterators over different subranges of the same UChar array don't
- * compare equal).
- * @see CharacterIterator
- * @see ForwardCharacterIterator
- * @stable ICU 2.0
- */
-class U_COMMON_API UCharCharacterIterator : public CharacterIterator {
-public:
-  /**
-   * Create an iterator over the UChar array referred to by "textPtr".
-   * The iteration range is 0 to <code>length-1</code>.
-   * text is only aliased, not adopted (the
-   * destructor will not delete it).
-   * @param textPtr The UChar array to be iterated over
-   * @param length The length of the UChar array
-   * @stable ICU 2.0
-   */
-  UCharCharacterIterator(const UChar* textPtr, int32_t length);
-
-  /**
-   * Create an iterator over the UChar array referred to by "textPtr".
-   * The iteration range is 0 to <code>length-1</code>.
-   * text is only aliased, not adopted (the
-   * destructor will not delete it).
-   * The starting
-   * position is specified by "position". If "position" is outside the valid
-   * iteration range, the behavior of this object is undefined.
-   * @param textPtr The UChar array to be iteratd over
-   * @param length The length of the UChar array
-   * @param position The starting position of the iteration
-   * @stable ICU 2.0
-   */
-  UCharCharacterIterator(const UChar* textPtr, int32_t length,
-                         int32_t position);
-
-  /**
-   * Create an iterator over the UChar array referred to by "textPtr".
-   * The iteration range is 0 to <code>end-1</code>.
-   * text is only aliased, not adopted (the
-   * destructor will not delete it).
-   * The starting
-   * position is specified by "position". If begin and end do not
-   * form a valid iteration range or "position" is outside the valid
-   * iteration range, the behavior of this object is undefined.
-   * @param textPtr The UChar array to be iterated over
-   * @param length The length of the UChar array
-   * @param textBegin  The begin position of the iteration range
-   * @param textEnd    The end position of the iteration range
-   * @param position    The starting position of the iteration
-   * @stable ICU 2.0
-   */
-  UCharCharacterIterator(const UChar* textPtr, int32_t length,
-                         int32_t textBegin,
-                         int32_t textEnd,
-                         int32_t position);
-
-  /**
-   * Copy constructor.  The new iterator iterates over the same range
-   * of the same string as "that", and its initial position is the
-   * same as "that"'s current position.
-   * @param that The UCharCharacterIterator to be copied
-   * @stable ICU 2.0
-   */
-  UCharCharacterIterator(const UCharCharacterIterator&  that);
-
-  /**
-   * Destructor.
-   * @stable ICU 2.0
-   */
-  virtual ~UCharCharacterIterator();
-
-  /**
-   * Assignment operator.  *this is altered to iterate over the sane
-   * range of the same string as "that", and refers to the same
-   * character within that string as "that" does.
-   * @param that The object to be copied
-   * @return the newly created object
-   * @stable ICU 2.0
-   */
-  UCharCharacterIterator&
-  operator=(const UCharCharacterIterator&    that);
-
-  /**
-   * Returns true if the iterators iterate over the same range of the
-   * same string and are pointing at the same character.
-   * @param that The ForwardCharacterIterator used to be compared for equality
-   * @return true if the iterators iterate over the same range of the
-   * same string and are pointing at the same character.
-   * @stable ICU 2.0
-   */
-  virtual UBool          operator==(const ForwardCharacterIterator& that) const;
-
-  /**
-   * Generates a hash code for this iterator.
-   * @return the hash code.
-   * @stable ICU 2.0
-   */
-  virtual int32_t         hashCode(void) const;
-
-  /**
-   * Returns a new UCharCharacterIterator referring to the same
-   * character in the same range of the same string as this one.  The
-   * caller must delete the new iterator.
-   * @return the CharacterIterator newly created
-   * @stable ICU 2.0
-   */
-  virtual CharacterIterator* clone(void) const;
-
-  /**
-   * Sets the iterator to refer to the first code unit in its
-   * iteration range, and returns that code unit.
-   * This can be used to begin an iteration with next().
-   * @return the first code unit in its iteration range.
-   * @stable ICU 2.0
-   */
-  virtual UChar         first(void);
-
-  /**
-   * Sets the iterator to refer to the first code unit in its
-   * iteration range, returns that code unit, and moves the position
-   * to the second code unit. This is an alternative to setToStart()
-   * for forward iteration with nextPostInc().
-   * @return the first code unit in its iteration range
-   * @stable ICU 2.0
-   */
-  virtual UChar         firstPostInc(void);
-
-  /**
-   * Sets the iterator to refer to the first code point in its
-   * iteration range, and returns that code unit,
-   * This can be used to begin an iteration with next32().
-   * Note that an iteration with next32PostInc(), beginning with,
-   * e.g., setToStart() or firstPostInc(), is more efficient.
-   * @return the first code point in its iteration range
-   * @stable ICU 2.0
-   */
-  virtual UChar32       first32(void);
-
-  /**
-   * Sets the iterator to refer to the first code point in its
-   * iteration range, returns that code point, and moves the position
-   * to the second code point. This is an alternative to setToStart()
-   * for forward iteration with next32PostInc().
-   * @return the first code point in its iteration range.
-   * @stable ICU 2.0
-   */
-  virtual UChar32       first32PostInc(void);
-
-  /**
-   * Sets the iterator to refer to the last code unit in its
-   * iteration range, and returns that code unit.
-   * This can be used to begin an iteration with previous().
-   * @return the last code unit in its iteration range.
-   * @stable ICU 2.0
-   */
-  virtual UChar         last(void);
-
-  /**
-   * Sets the iterator to refer to the last code point in its
-   * iteration range, and returns that code unit.
-   * This can be used to begin an iteration with previous32().
-   * @return the last code point in its iteration range.
-   * @stable ICU 2.0
-   */
-  virtual UChar32       last32(void);
-
-  /**
-   * Sets the iterator to refer to the "position"-th code unit
-   * in the text-storage object the iterator refers to, and
-   * returns that code unit.
-   * @param position the position within the text-storage object
-   * @return the code unit
-   * @stable ICU 2.0
-   */
-  virtual UChar         setIndex(int32_t position);
-
-  /**
-   * Sets the iterator to refer to the beginning of the code point
-   * that contains the "position"-th code unit
-   * in the text-storage object the iterator refers to, and
-   * returns that code point.
-   * The current position is adjusted to the beginning of the code point
-   * (its first code unit).
-   * @param position the position within the text-storage object
-   * @return the code unit
-   * @stable ICU 2.0
-   */
-  virtual UChar32       setIndex32(int32_t position);
-
-  /**
-   * Returns the code unit the iterator currently refers to.
-   * @return the code unit the iterator currently refers to.
-   * @stable ICU 2.0
-   */
-  virtual UChar         current(void) const;
-
-  /**
-   * Returns the code point the iterator currently refers to.
-   * @return the code point the iterator currently refers to.
-   * @stable ICU 2.0
-   */
-  virtual UChar32       current32(void) const;
-
-  /**
-   * Advances to the next code unit in the iteration range (toward
-   * endIndex()), and returns that code unit.  If there are no more
-   * code units to return, returns DONE.
-   * @return the next code unit in the iteration range.
-   * @stable ICU 2.0
-   */
-  virtual UChar         next(void);
-
-  /**
-   * Gets the current code unit for returning and advances to the next code unit
-   * in the iteration range
-   * (toward endIndex()).  If there are
-   * no more code units to return, returns DONE.
-   * @return the current code unit.
-   * @stable ICU 2.0
-   */
-  virtual UChar         nextPostInc(void);
-
-  /**
-   * Advances to the next code point in the iteration range (toward
-   * endIndex()), and returns that code point.  If there are no more
-   * code points to return, returns DONE.
-   * Note that iteration with "pre-increment" semantics is less
-   * efficient than iteration with "post-increment" semantics
-   * that is provided by next32PostInc().
-   * @return the next code point in the iteration range.
-   * @stable ICU 2.0
-   */
-  virtual UChar32       next32(void);
-
-  /**
-   * Gets the current code point for returning and advances to the next code point
-   * in the iteration range
-   * (toward endIndex()).  If there are
-   * no more code points to return, returns DONE.
-   * @return the current point.
-   * @stable ICU 2.0
-   */
-  virtual UChar32       next32PostInc(void);
-
-  /**
-   * Returns FALSE if there are no more code units or code points
-   * at or after the current position in the iteration range.
-   * This is used with nextPostInc() or next32PostInc() in forward
-   * iteration.
-   * @return FALSE if there are no more code units or code points
-   * at or after the current position in the iteration range.
-   * @stable ICU 2.0
-   */
-  virtual UBool        hasNext();
-
-  /**
-   * Advances to the previous code unit in the iteration range (toward
-   * startIndex()), and returns that code unit.  If there are no more
-   * code units to return, returns DONE.
-   * @return the previous code unit in the iteration range.
-   * @stable ICU 2.0
-   */
-  virtual UChar         previous(void);
-
-  /**
-   * Advances to the previous code point in the iteration range (toward
-   * startIndex()), and returns that code point.  If there are no more
-   * code points to return, returns DONE.
-   * @return the previous code point in the iteration range.
-   * @stable ICU 2.0
-   */
-  virtual UChar32       previous32(void);
-
-  /**
-   * Returns FALSE if there are no more code units or code points
-   * before the current position in the iteration range.
-   * This is used with previous() or previous32() in backward
-   * iteration.
-   * @return FALSE if there are no more code units or code points
-   * before the current position in the iteration range.
-   * @stable ICU 2.0
-   */
-  virtual UBool        hasPrevious();
-
-  /**
-   * Moves the current position relative to the start or end of the
-   * iteration range, or relative to the current position itself.
-   * The movement is expressed in numbers of code units forward
-   * or backward by specifying a positive or negative delta.
-   * @param delta the position relative to origin. A positive delta means forward;
-   * a negative delta means backward.
-   * @param origin Origin enumeration {kStart, kCurrent, kEnd}
-   * @return the new position
-   * @stable ICU 2.0
-   */
-  virtual int32_t      move(int32_t delta, EOrigin origin);
-
-  /**
-   * Moves the current position relative to the start or end of the
-   * iteration range, or relative to the current position itself.
-   * The movement is expressed in numbers of code points forward
-   * or backward by specifying a positive or negative delta.
-   * @param delta the position relative to origin. A positive delta means forward;
-   * a negative delta means backward.
-   * @param origin Origin enumeration {kStart, kCurrent, kEnd}
-   * @return the new position
-   * @stable ICU 2.0
-   */
-  virtual int32_t      move32(int32_t delta, EOrigin origin);
-
-  /**
-   * Sets the iterator to iterate over a new range of text
-   * @stable ICU 2.0
-   */
-  void setText(const UChar* newText, int32_t newTextLength);
-
-  /**
-   * Copies the UChar array under iteration into the UnicodeString
-   * referred to by "result".  Even if this iterator iterates across
-   * only a part of this string, the whole string is copied.
-   * @param result Receives a copy of the text under iteration.
-   * @stable ICU 2.0
-   */
-  virtual void            getText(UnicodeString& result);
-
-  /**
-   * Return a class ID for this class (not really public)
-   * @return a class ID for this class
-   * @stable ICU 2.0
-   */
-  static UClassID         U_EXPORT2 getStaticClassID(void);
-
-  /**
-   * Return a class ID for this object (not really public)
-   * @return a class ID for this object.
-   * @stable ICU 2.0
-   */
-  virtual UClassID        getDynamicClassID(void) const;
-
-protected:
-  /**
-   * Protected constructor
-   * @stable ICU 2.0
-   */
-  UCharCharacterIterator();
-  /**
-   * Protected member text
-   * @stable ICU 2.0
-   */
-  const UChar*            text;
-
-};
-
-U_NAMESPACE_END
-#endif

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/uclean.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/uclean.h b/apps/couch_collate/platform/osx/icu/unicode/uclean.h
deleted file mode 100644
index a13924a..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/uclean.h
+++ /dev/null
@@ -1,267 +0,0 @@
-/*
-******************************************************************************
-*                                                                            *
-* Copyright (C) 2001-2005, International Business Machines                   *
-*                Corporation and others. All Rights Reserved.                *
-*                                                                            *
-******************************************************************************
-*   file name:  uclean.h
-*   encoding:   US-ASCII
-*   tab size:   8 (not used)
-*   indentation:4
-*
-*   created on: 2001July05
-*   created by: George Rhoten
-*/
-
-#ifndef __UCLEAN_H__
-#define __UCLEAN_H__
-
-#include "unicode/utypes.h"
-/**
- * \file
- * \brief C API: Initialize and clean up ICU
- */
- 
-/**
- *  Initialize ICU. The description further below applies to ICU 2.6 to ICU 3.4.
- *  Starting with ICU 3.4, u_init() needs not be called any more for
- *  ensuring thread safety, but it can give an indication for whether ICU
- *  can load its data. In ICU 3.4, it will try to load the converter alias table
- *  (cnvalias.icu) and give an error code if that fails.
- *  This may change in the future.
- *  <p>
- *  For ensuring the availability of necessary data, an application should
- *  open the service objects (converters, collators, etc.) that it will use
- *  and check for error codes there.
- *  <p>
- *  Documentation for ICU 2.6 to ICU 3.4:
- *  <p>
- *  This function loads and initializes data items
- *  that are required internally by various ICU functions.  Use of this explicit
- *  initialization is required in multi-threaded applications; in 
- *  single threaded apps, use is optional, but incurs little additional
- *  cost, and is thus recommended.
- *  <p>
- *  In multi-threaded applications, u_init() should be called  in the
- *  main thread before starting additional threads, or, alternatively
- *  it can be called in each individual thread once, before other ICU
- *  functions are called in that thread.  In this second scenario, the
- *  application must guarantee that the first call to u_init() happen
- *  without contention, in a single thread only.
- *  <p>
- *  If <code>u_setMemoryFunctions()</code> or 
- *  <code>u_setMutexFunctions</code> are needed (uncommon), they must be
- *  called _before_ <code>u_init()</code>.
- *  <p>
- *  Extra, repeated, or otherwise unneeded calls to u_init() do no harm,
- *  other than taking a small amount of time.
- *
- * @param status An ICU UErrorCode parameter. It must not be <code>NULL</code>.
- *    An Error will be returned if some required part of ICU data can not
- *    be loaded or initialized.
- *    The function returns immediately if the input error code indicates a
- *    failure, as usual.
- *
- * @stable ICU 2.6
- */  
-U_STABLE void U_EXPORT2 
-u_init(UErrorCode *status);
-
-/**
- * Clean up the system resources, such as allocated memory or open files,
- * used in all ICU libraries. This will free/delete all memory owned by the
- * ICU libraries, and return them to their original load state. All open ICU
- * items (collators, resource bundles, converters, etc.) must be closed before
- * calling this function, otherwise ICU may not free its allocated memory
- * (e.g. close your converters and resource bundles before calling this
- * function). Generally, this function should be called once just before
- * an application exits. For applications that dynamically load and unload
- * the ICU libraries (relatively uncommon), u_cleanup() should be called
- * just before the library unload.
- * <p>
- * u_cleanup() also clears any ICU heap functions, mutex functions or
- * trace functions that may have been set for the process.  
- * This has the effect of restoring ICU to its initial condition, before
- * any of these override functions were installed.  Refer to
- * u_setMemoryFunctions(), u_setMutexFunctions and 
- * utrace_setFunctions().  If ICU is to be reinitialized after after
- * calling u_cleanup(), these runtime override functions will need to
- * be set up again if they are still required.
- * <p>
- * u_cleanup() is not thread safe.  All other threads should stop using ICU
- * before calling this function.
- * <p>
- * Any open ICU items will be left in an undefined state by u_cleanup(),
- * and any subsequent attempt to use such an item will give unpredictable
- * results.
- * <p>
- * After calling u_cleanup(), an application may continue to use ICU by
- * calling u_init().  An application must invoke u_init() first from one single
- * thread before allowing other threads call u_init().  All threads existing
- * at the time of the first thread's call to u_init() must also call
- * u_init() themselves before continuing with other ICU operations.  
- * <p>
- * The use of u_cleanup() just before an application terminates is optional,
- * but it should be called only once for performance reasons. The primary
- * benefit is to eliminate reports of memory or resource leaks originating
- * in ICU code from the results generated by heap analysis tools.
- * <p>
- * <strong>Use this function with great care!</strong>
- * </p>
- *
- * @stable ICU 2.0
- * @system
- */
-U_STABLE void U_EXPORT2 
-u_cleanup(void);
-
-
-
-
-/**
-  * An opaque pointer type that represents an ICU mutex.
-  * For user-implemented mutexes, the value will typically point to a
-  *  struct or object that implements the mutex.
-  * @stable ICU 2.8
-  * @system
-  */
-typedef void *UMTX;
-
-/**
-  *  Function Pointer type for a user supplied mutex initialization function.
-  *  The user-supplied function will be called by ICU whenever ICU needs to create a
-  *  new mutex.  The function implementation should create a mutex, and store a pointer
-  *  to something that uniquely identifies the mutex into the UMTX that is supplied
-  *  as a paramter.
-  *  @param context user supplied value, obtained from from u_setMutexFunctions().
-  *  @param mutex   Receives a pointer that identifies the new mutex.
-  *                 The mutex init function must set the UMTX to a non-null value.   
-  *                 Subsequent calls by ICU to lock, unlock, or destroy a mutex will 
-  *                 identify the mutex by the UMTX value.
-  *  @param status  Error status.  Report errors back to ICU by setting this variable
-  *                 with an error code.
-  *  @stable ICU 2.8
-  *  @system
-  */
-typedef void U_CALLCONV UMtxInitFn (const void *context, UMTX  *mutex, UErrorCode* status);
-
-
-/**
-  *  Function Pointer type for a user supplied mutex functions.
-  *  One of the  user-supplied functions with this signature will be called by ICU
-  *  whenever ICU needs to lock, unlock, or destroy a mutex.
-  *  @param context user supplied value, obtained from from u_setMutexFunctions().
-  *  @param mutex   specify the mutex on which to operate.
-  *  @stable ICU 2.8
-  *  @system
-  */
-typedef void U_CALLCONV UMtxFn   (const void *context, UMTX  *mutex);
-
-
-/**
-  *  Set the functions that ICU will use for mutex operations
-  *  Use of this function is optional; by default (without this function), ICU will
-  *  directly access system functions for mutex operations
-  *  This function can only be used when ICU is in an initial, unused state, before
-  *  u_init() has been called.
-  *  This function may be used even when ICU has been built without multi-threaded
-  *  support  (see ICU_USE_THREADS pre-processor variable, umutex.h)
-  *  @param context This pointer value will be saved, and then (later) passed as
-  *                 a parameter to the user-supplied mutex functions each time they
-  *                 are called. 
-  *  @param init    Pointer to a mutex initialization function.  Must be non-null.
-  *  @param destroy Pointer to the mutex destroy function.  Must be non-null.
-  *  @param lock    pointer to the mutex lock function.  Must be non-null.
-  *  @param unlock  Pointer to the mutex unlock function.  Must be non-null.
-  *  @param status  Receives error values.
-  *  @stable ICU 2.8
-  *  @system
-  */  
-U_STABLE void U_EXPORT2 
-u_setMutexFunctions(const void *context, UMtxInitFn *init, UMtxFn *destroy, UMtxFn *lock, UMtxFn *unlock,
-                    UErrorCode *status);
-
-
-/**
-  *  Pointer type for a user supplied atomic increment or decrement function.
-  *  @param context user supplied value, obtained from from u_setAtomicIncDecFunctions().
-  *  @param p   Pointer to a 32 bit int to be incremented or decremented
-  *  @return    The value of the variable after the inc or dec operation.
-  *  @stable ICU 2.8
-  *  @system
-  */
-typedef int32_t U_CALLCONV UMtxAtomicFn(const void *context, int32_t *p);
-
-/**
- *  Set the functions that ICU will use for atomic increment and decrement of int32_t values.
- *  Use of this function is optional; by default (without this function), ICU will
- *  use its own internal implementation of atomic increment/decrement.
- *  This function can only be used when ICU is in an initial, unused state, before
- *  u_init() has been called.
- *  @param context This pointer value will be saved, and then (later) passed as
- *                 a parameter to the increment and decrement functions each time they
- *                 are called.  This function can only be called 
- *  @param inc     Pointer to a function to do an atomic increment operation.  Must be non-null.
- *  @param dec     Pointer to a function to do an atomic decrement operation.  Must be non-null.
- *  @param status  Receives error values.
- *  @stable ICU 2.8
- *  @system
- */  
-U_STABLE void U_EXPORT2 
-u_setAtomicIncDecFunctions(const void *context, UMtxAtomicFn *inc, UMtxAtomicFn *dec,
-                    UErrorCode *status);
-
-
-
-/**
-  *  Pointer type for a user supplied memory allocation function.
-  *  @param context user supplied value, obtained from from u_setMemoryFunctions().
-  *  @param size    The number of bytes to be allocated
-  *  @return        Pointer to the newly allocated memory, or NULL if the allocation failed.
-  *  @stable ICU 2.8
-  *  @system
-  */
-typedef void *U_CALLCONV UMemAllocFn(const void *context, size_t size);
-/**
-  *  Pointer type for a user supplied memory re-allocation function.
-  *  @param context user supplied value, obtained from from u_setMemoryFunctions().
-  *  @param size    The number of bytes to be allocated
-  *  @return        Pointer to the newly allocated memory, or NULL if the allocation failed.
-  *  @stable ICU 2.8
-  *  @system
-  */
-typedef void *U_CALLCONV UMemReallocFn(const void *context, void *mem, size_t size);
-/**
-  *  Pointer type for a user supplied memory free  function.  Behavior should be
-  *  similar the standard C library free().
-  *  @param context user supplied value, obtained from from u_setMemoryFunctions().
-  *  @param mem     Pointer to the memory block to be resized
-  *  @param size    The new size for the block
-  *  @return        Pointer to the resized memory block, or NULL if the resizing failed.
-  *  @stable ICU 2.8
-  *  @system
-  */
-typedef void  U_CALLCONV UMemFreeFn (const void *context, void *mem);
-
-/**
- *  Set the functions that ICU will use for memory allocation.
- *  Use of this function is optional; by default (without this function), ICU will
- *  use the standard C library malloc() and free() functions.
- *  This function can only be used when ICU is in an initial, unused state, before
- *  u_init() has been called.
- *  @param context This pointer value will be saved, and then (later) passed as
- *                 a parameter to the memory functions each time they
- *                 are called.
- *  @param a       Pointer to a user-supplied malloc function.
- *  @param r       Pointer to a user-supplied realloc function.
- *  @param f       Pointer to a user-supplied free function.
- *  @param status  Receives error values.
- *  @stable ICU 2.8
- *  @system
- */  
-U_STABLE void U_EXPORT2 
-u_setMemoryFunctions(const void *context, UMemAllocFn *a, UMemReallocFn *r, UMemFreeFn *f, 
-                    UErrorCode *status);
-
-#endif


[13/57] [abbrv] remove couch_collate

Posted by be...@apache.org.
http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/umsg.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/umsg.h b/apps/couch_collate/platform/osx/icu/unicode/umsg.h
deleted file mode 100644
index 32ed063..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/umsg.h
+++ /dev/null
@@ -1,647 +0,0 @@
-/*
-*******************************************************************************
-* Copyright (C) 1996-2006, International Business Machines Corporation
-* and others. All Rights Reserved.
-*******************************************************************************
-*
-*   file name:  umsg.h
-*   encoding:   US-ASCII
-*   tab size:   8 (not used)
-*   indentation:4
-*
-*   Change history:
-*
-*   08/5/2001  Ram         Added C wrappers for C++ API.
-*                          
-*
-*/
-
-#ifndef UMSG_H
-#define UMSG_H
-
-#include "unicode/utypes.h"
-
-#if !UCONFIG_NO_FORMATTING
-
-#include "unicode/uloc.h"
-#include "unicode/parseerr.h"
-#include <stdarg.h>
-/**
- * \file
- * \brief C API: MessageFormat
- *
- * <h2>Message Format C API </h2>
- *
- * Provides means to produce concatenated messages in language-neutral way.
- * Use this for all concatenations that show up to end users.
- * <P>
- * Takes a set of objects, formats them, then inserts the formatted
- * strings into the pattern at the appropriate places.
- * <P>
- * Here are some examples of usage:
- * Example 1:
- * <pre>
- * \code
- *     UChar *result, *tzID, *str;
- *     UChar pattern[100];
- *     int32_t resultLengthOut, resultlength;
- *     UCalendar *cal;
- *     UDate d1;
- *     UDateFormat *def1;
- *     UErrorCode status = U_ZERO_ERROR;
- *
- *     str=(UChar*)malloc(sizeof(UChar) * (strlen("disturbance in force") +1));
- *     u_uastrcpy(str, "disturbance in force");
- *     tzID=(UChar*)malloc(sizeof(UChar) * 4);
- *     u_uastrcpy(tzID, "PST");
- *     cal=ucal_open(tzID, u_strlen(tzID), "en_US", UCAL_TRADITIONAL, &status);
- *     ucal_setDateTime(cal, 1999, UCAL_MARCH, 18, 0, 0, 0, &status);
- *     d1=ucal_getMillis(cal, &status);
- *     u_uastrcpy(pattern, "On {0, date, long}, there was a {1} on planet {2,number,integer}");
- *     resultlength=0;
- *     resultLengthOut=u_formatMessage( "en_US", pattern, u_strlen(pattern), NULL, resultlength, &status, d1, str, 7);
- *     if(status==U_BUFFER_OVERFLOW_ERROR){
- *         status=U_ZERO_ERROR;
- *         resultlength=resultLengthOut+1;
- *         result=(UChar*)realloc(result, sizeof(UChar) * resultlength);
- *         u_formatMessage( "en_US", pattern, u_strlen(pattern), result, resultlength, &status, d1, str, 7);
- *     }
- *     printf("%s\n", austrdup(result) );//austrdup( a function used to convert UChar* to char*)
- *     //output>: "On March 18, 1999, there was a disturbance in force on planet 7
- * \endcode
- * </pre>
- * Typically, the message format will come from resources, and the
- * arguments will be dynamically set at runtime.
- * <P>
- * Example 2:
- * <pre>
- * \code
- *     UChar* str;
- *     UErrorCode status = U_ZERO_ERROR;
- *     UChar *result;
- *     UChar pattern[100];
- *     int32_t resultlength, resultLengthOut, i;
- *     double testArgs= { 100.0, 1.0, 0.0};
- *
- *     str=(UChar*)malloc(sizeof(UChar) * 10);
- *     u_uastrcpy(str, "MyDisk");
- *     u_uastrcpy(pattern, "The disk {1} contains {0,choice,0#no files|1#one file|1<{0,number,integer} files}");
- *     for(i=0; i<3; i++){
- *       resultlength=0;
- *       resultLengthOut=u_formatMessage( "en_US", pattern, u_strlen(pattern), NULL, resultlength, &status, testArgs[i], str);
- *       if(status==U_BUFFER_OVERFLOW_ERROR){
- *         status=U_ZERO_ERROR;
- *         resultlength=resultLengthOut+1;
- *         result=(UChar*)malloc(sizeof(UChar) * resultlength);
- *         u_formatMessage( "en_US", pattern, u_strlen(pattern), result, resultlength, &status, testArgs[i], str);
- *       }
- *       printf("%s\n", austrdup(result) );  //austrdup( a function used to convert UChar* to char*)
- *       free(result);
- *     }
- *     // output, with different testArgs:
- *     // output: The disk "MyDisk" contains 100 files.
- *     // output: The disk "MyDisk" contains one file.
- *     // output: The disk "MyDisk" contains no files.
- * \endcode
- *  </pre>
- *
- *  The pattern is of the following form.  Legend:
- *  <pre>
- * \code
- *       {optional item}
- *       (group that may be repeated)*
- * \endcode
- *  </pre>
- *  Do not confuse optional items with items inside quotes braces, such
- *  as this: "{".  Quoted braces are literals.
- *  <pre>
- * \code
- *       messageFormatPattern := string ( "{" messageFormatElement "}" string )*
- *
- *       messageFormatElement := argument { "," elementFormat }
- *
- *       elementFormat := "time" { "," datetimeStyle }
- *                      | "date" { "," datetimeStyle }
- *                      | "number" { "," numberStyle }
- *                      | "choice" "," choiceStyle
- *
- *       datetimeStyle := "short"
- *                      | "medium"
- *                      | "long"
- *                      | "full"
- *                      | dateFormatPattern
- *
- *       numberStyle :=   "currency"
- *                      | "percent"
- *                      | "integer"
- *                      | numberFormatPattern
- *
- *       choiceStyle :=   choiceFormatPattern
- * \endcode
- * </pre>
- * If there is no elementFormat, then the argument must be a string,
- * which is substituted. If there is no dateTimeStyle or numberStyle,
- * then the default format is used (e.g.  NumberFormat.getInstance(),
- * DateFormat.getDefaultTime() or DateFormat.getDefaultDate(). For
- * a ChoiceFormat, the pattern must always be specified, since there
- * is no default.
- * <P>
- * In strings, single quotes can be used to quote the "{" sign if
- * necessary. A real single quote is represented by ''.  Inside a
- * messageFormatElement, quotes are [not] removed. For example,
- * {1,number,$'#',##} will produce a number format with the pound-sign
- * quoted, with a result such as: "$#31,45".
- * <P>
- * If a pattern is used, then unquoted braces in the pattern, if any,
- * must match: that is, "ab {0} de" and "ab '}' de" are ok, but "ab
- * {0'}' de" and "ab } de" are not.
- * <p>
- * <dl><dt><b>Warning:</b><dd>The rules for using quotes within message
- * format patterns unfortunately have shown to be somewhat confusing.
- * In particular, it isn't always obvious to localizers whether single
- * quotes need to be doubled or not. Make sure to inform localizers about
- * the rules, and tell them (for example, by using comments in resource
- * bundle source files) which strings will be processed by MessageFormat.
- * Note that localizers may need to use single quotes in translated
- * strings where the original version doesn't have them.
- * <br>Note also that the simplest way to avoid the problem is to
- * use the real apostrophe (single quote) character U+2019 (') for
- * human-readable text, and to use the ASCII apostrophe (U+0027 ' )
- * only in program syntax, like quoting in MessageFormat.
- * See the annotations for U+0027 Apostrophe in The Unicode Standard.</p>
- * </dl>
- * <P>
- * The argument is a number from 0 to 9, which corresponds to the
- * arguments presented in an array to be formatted.
- * <P>
- * It is ok to have unused arguments in the array.  With missing
- * arguments or arguments that are not of the right class for the
- * specified format, a failing UErrorCode result is set.
- * <P>
-
- * <P>
- * [Note:] As we see above, the string produced by a choice Format in
- * MessageFormat is treated specially; occurances of '{' are used to
- * indicated subformats.
- * <P>
- * [Note:] Formats are numbered by order of variable in the string.
- * This is [not] the same as the argument numbering!
- * <pre>
- * \code
- *    For example: with "abc{2}def{3}ghi{0}...",
- *
- *    format0 affects the first variable {2}
- *    format1 affects the second variable {3}
- *    format2 affects the second variable {0}
- * \endcode
- * </pre>
- * and so on.
- */
-
-/**
- * Format a message for a locale.
- * This function may perform re-ordering of the arguments depending on the
- * locale. For all numeric arguments, double is assumed unless the type is
- * explicitly integer.  All choice format arguments must be of type double.
- * @param locale The locale for which the message will be formatted
- * @param pattern The pattern specifying the message's format
- * @param patternLength The length of pattern
- * @param result A pointer to a buffer to receive the formatted message.
- * @param resultLength The maximum size of result.
- * @param status A pointer to an UErrorCode to receive any errors
- * @param ... A variable-length argument list containing the arguments specified
- * in pattern.
- * @return The total buffer size needed; if greater than resultLength, the
- * output was truncated.
- * @see u_parseMessage
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2 
-u_formatMessage(const char  *locale,
-                 const UChar *pattern,
-                int32_t     patternLength,
-                UChar       *result,
-                int32_t     resultLength,
-                UErrorCode  *status,
-                ...);
-
-/**
- * Format a message for a locale.
- * This function may perform re-ordering of the arguments depending on the
- * locale. For all numeric arguments, double is assumed unless the type is
- * explicitly integer.  All choice format arguments must be of type double.
- * @param locale The locale for which the message will be formatted
- * @param pattern The pattern specifying the message's format
- * @param patternLength The length of pattern
- * @param result A pointer to a buffer to receive the formatted message.
- * @param resultLength The maximum size of result.
- * @param ap A variable-length argument list containing the arguments specified
- * @param status A pointer to an UErrorCode to receive any errors
- * in pattern.
- * @return The total buffer size needed; if greater than resultLength, the
- * output was truncated.
- * @see u_parseMessage
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2 
-u_vformatMessage(   const char  *locale,
-                    const UChar *pattern,
-                    int32_t     patternLength,
-                    UChar       *result,
-                    int32_t     resultLength,
-                    va_list     ap,
-                    UErrorCode  *status);
-
-/**
- * Parse a message.
- * For numeric arguments, this function will always use doubles.  Integer types
- * should not be passed.
- * This function is not able to parse all output from {@link #u_formatMessage }.
- * @param locale The locale for which the message is formatted
- * @param pattern The pattern specifying the message's format
- * @param patternLength The length of pattern
- * @param source The text to parse.
- * @param sourceLength The length of source, or -1 if null-terminated.
- * @param status A pointer to an UErrorCode to receive any errors
- * @param ... A variable-length argument list containing the arguments
- * specified in pattern.
- * @see u_formatMessage
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2 
-u_parseMessage( const char   *locale,
-                const UChar  *pattern,
-                int32_t      patternLength,
-                const UChar  *source,
-                int32_t      sourceLength,
-                UErrorCode   *status,
-                ...);
-
-/**
- * Parse a message.
- * For numeric arguments, this function will always use doubles.  Integer types
- * should not be passed.
- * This function is not able to parse all output from {@link #u_formatMessage }.
- * @param locale The locale for which the message is formatted
- * @param pattern The pattern specifying the message's format
- * @param patternLength The length of pattern
- * @param source The text to parse.
- * @param sourceLength The length of source, or -1 if null-terminated.
- * @param ap A variable-length argument list containing the arguments
- * @param status A pointer to an UErrorCode to receive any errors
- * specified in pattern.
- * @see u_formatMessage
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2 
-u_vparseMessage(const char  *locale,
-                const UChar *pattern,
-                int32_t     patternLength,
-                const UChar *source,
-                int32_t     sourceLength,
-                va_list     ap,
-                UErrorCode  *status);
-
-/**
- * Format a message for a locale.
- * This function may perform re-ordering of the arguments depending on the
- * locale. For all numeric arguments, double is assumed unless the type is
- * explicitly integer.  All choice format arguments must be of type double.
- * @param locale The locale for which the message will be formatted
- * @param pattern The pattern specifying the message's format
- * @param patternLength The length of pattern
- * @param result A pointer to a buffer to receive the formatted message.
- * @param resultLength The maximum size of result.
- * @param status A pointer to an UErrorCode to receive any errors
- * @param ... A variable-length argument list containing the arguments specified
- * in pattern.
- * @param parseError  A pointer to UParseError to receive information about errors
- *                     occurred during parsing.
- * @return The total buffer size needed; if greater than resultLength, the
- * output was truncated.
- * @see u_parseMessage
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2 
-u_formatMessageWithError(   const char    *locale,
-                            const UChar   *pattern,
-                            int32_t       patternLength,
-                            UChar         *result,
-                            int32_t       resultLength,
-                            UParseError   *parseError,
-                            UErrorCode    *status,
-                            ...);
-
-/**
- * Format a message for a locale.
- * This function may perform re-ordering of the arguments depending on the
- * locale. For all numeric arguments, double is assumed unless the type is
- * explicitly integer.  All choice format arguments must be of type double.
- * @param locale The locale for which the message will be formatted
- * @param pattern The pattern specifying the message's format
- * @param patternLength The length of pattern
- * @param result A pointer to a buffer to receive the formatted message.
- * @param resultLength The maximum size of result.
- * @param parseError  A pointer to UParseError to receive information about errors
- *                    occurred during parsing.
- * @param ap A variable-length argument list containing the arguments specified
- * @param status A pointer to an UErrorCode to receive any errors
- * in pattern.
- * @return The total buffer size needed; if greater than resultLength, the
- * output was truncated.
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2 
-u_vformatMessageWithError(  const char   *locale,
-                            const UChar  *pattern,
-                            int32_t      patternLength,
-                            UChar        *result,
-                            int32_t      resultLength,
-                            UParseError* parseError,
-                            va_list      ap,
-                            UErrorCode   *status);
-
-/**
- * Parse a message.
- * For numeric arguments, this function will always use doubles.  Integer types
- * should not be passed.
- * This function is not able to parse all output from {@link #u_formatMessage }.
- * @param locale The locale for which the message is formatted
- * @param pattern The pattern specifying the message's format
- * @param patternLength The length of pattern
- * @param source The text to parse.
- * @param sourceLength The length of source, or -1 if null-terminated.
- * @param parseError  A pointer to UParseError to receive information about errors
- *                     occurred during parsing.
- * @param status A pointer to an UErrorCode to receive any errors
- * @param ... A variable-length argument list containing the arguments
- * specified in pattern.
- * @see u_formatMessage
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2 
-u_parseMessageWithError(const char  *locale,
-                        const UChar *pattern,
-                        int32_t     patternLength,
-                        const UChar *source,
-                        int32_t     sourceLength,
-                        UParseError *parseError,
-                        UErrorCode  *status,
-                        ...);
-
-/**
- * Parse a message.
- * For numeric arguments, this function will always use doubles.  Integer types
- * should not be passed.
- * This function is not able to parse all output from {@link #u_formatMessage }.
- * @param locale The locale for which the message is formatted
- * @param pattern The pattern specifying the message's format
- * @param patternLength The length of pattern
- * @param source The text to parse.
- * @param sourceLength The length of source, or -1 if null-terminated.
- * @param ap A variable-length argument list containing the arguments
- * @param parseError  A pointer to UParseError to receive information about errors
- *                     occurred during parsing.
- * @param status A pointer to an UErrorCode to receive any errors
- * specified in pattern.
- * @see u_formatMessage
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2 
-u_vparseMessageWithError(const char  *locale,
-                         const UChar *pattern,
-                         int32_t     patternLength,
-                         const UChar *source,
-                         int32_t     sourceLength,
-                         va_list     ap,
-                         UParseError *parseError,
-                         UErrorCode* status);
-
-/*----------------------- New experimental API --------------------------- */
-/** 
- * The message format object
- * @stable ICU 2.0
- */
-typedef void* UMessageFormat;
-
-
-/**
- * Open a message formatter with given pattern and for the given locale.
- * @param pattern       A pattern specifying the format to use.
- * @param patternLength Length of the pattern to use
- * @param locale        The locale for which the messages are formatted.
- * @param parseError    A pointer to UParseError struct to receive any errors 
- *                      occured during parsing. Can be NULL.
- * @param status        A pointer to an UErrorCode to receive any errors.
- * @return              A pointer to a UMessageFormat to use for formatting 
- *                      messages, or 0 if an error occurred. 
- * @stable ICU 2.0
- */
-U_STABLE UMessageFormat* U_EXPORT2 
-umsg_open(  const UChar     *pattern,
-            int32_t         patternLength,
-            const  char     *locale,
-            UParseError     *parseError,
-            UErrorCode      *status);
-
-/**
- * Close a UMessageFormat.
- * Once closed, a UMessageFormat may no longer be used.
- * @param format The formatter to close.
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2 
-umsg_close(UMessageFormat* format);
-
-/**
- * Open a copy of a UMessageFormat.
- * This function performs a deep copy.
- * @param fmt The formatter to copy
- * @param status A pointer to an UErrorCode to receive any errors.
- * @return A pointer to a UDateFormat identical to fmt.
- * @stable ICU 2.0
- */
-U_STABLE UMessageFormat U_EXPORT2 
-umsg_clone(const UMessageFormat *fmt,
-           UErrorCode *status);
-
-/**
- * Sets the locale. This locale is used for fetching default number or date
- * format information.
- * @param fmt The formatter to set
- * @param locale The locale the formatter should use.
- * @stable ICU 2.0
- */
-U_STABLE void  U_EXPORT2 
-umsg_setLocale(UMessageFormat *fmt,
-               const char* locale);
-
-/**
- * Gets the locale. This locale is used for fetching default number or date
- * format information.
- * @param fmt The formatter to querry
- * @return the locale.
- * @stable ICU 2.0
- */
-U_STABLE const char*  U_EXPORT2 
-umsg_getLocale(const UMessageFormat *fmt);
-
-/**
- * Sets the pattern.
- * @param fmt           The formatter to use
- * @param pattern       The pattern to be applied.
- * @param patternLength Length of the pattern to use
- * @param parseError    Struct to receive information on position 
- *                      of error if an error is encountered.Can be NULL.
- * @param status        Output param set to success/failure code on
- *                      exit. If the pattern is invalid, this will be
- *                      set to a failure result.
- * @stable ICU 2.0
- */
-U_STABLE void  U_EXPORT2 
-umsg_applyPattern( UMessageFormat *fmt,
-                   const UChar* pattern,
-                   int32_t patternLength,
-                   UParseError* parseError,
-                   UErrorCode* status);
-
-/**
- * Gets the pattern.
- * @param fmt          The formatter to use
- * @param result       A pointer to a buffer to receive the pattern.
- * @param resultLength The maximum size of result.
- * @param status       Output param set to success/failure code on
- *                     exit. If the pattern is invalid, this will be
- *                     set to a failure result.  
- * @return the pattern of the format
- * @stable ICU 2.0
- */
-U_STABLE int32_t  U_EXPORT2 
-umsg_toPattern(const UMessageFormat *fmt,
-               UChar* result, 
-               int32_t resultLength,
-               UErrorCode* status);
-
-/**
- * Format a message for a locale.
- * This function may perform re-ordering of the arguments depending on the
- * locale. For all numeric arguments, double is assumed unless the type is
- * explicitly integer.  All choice format arguments must be of type double.
- * @param fmt           The formatter to use
- * @param result        A pointer to a buffer to receive the formatted message.
- * @param resultLength  The maximum size of result.
- * @param status        A pointer to an UErrorCode to receive any errors
- * @param ...           A variable-length argument list containing the arguments 
- *                      specified in pattern.
- * @return              The total buffer size needed; if greater than resultLength, 
- *                      the output was truncated.
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2 
-umsg_format(    const UMessageFormat *fmt,
-                UChar          *result,
-                int32_t        resultLength,
-                UErrorCode     *status,
-                ...);
-
-/**
- * Format a message for a locale.
- * This function may perform re-ordering of the arguments depending on the
- * locale. For all numeric arguments, double is assumed unless the type is
- * explicitly integer.  All choice format arguments must be of type double.
- * @param fmt          The formatter to use 
- * @param result       A pointer to a buffer to receive the formatted message.
- * @param resultLength The maximum size of result.
- * @param ap           A variable-length argument list containing the arguments 
- * @param status       A pointer to an UErrorCode to receive any errors
- *                     specified in pattern.
- * @return             The total buffer size needed; if greater than resultLength, 
- *                     the output was truncated.
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2 
-umsg_vformat(   const UMessageFormat *fmt,
-                UChar          *result,
-                int32_t        resultLength,
-                va_list        ap,
-                UErrorCode     *status);
-
-/**
- * Parse a message.
- * For numeric arguments, this function will always use doubles.  Integer types
- * should not be passed.
- * This function is not able to parse all output from {@link #umsg_format }.
- * @param fmt           The formatter to use 
- * @param source        The text to parse.
- * @param sourceLength  The length of source, or -1 if null-terminated.
- * @param count         Output param to receive number of elements returned.
- * @param status        A pointer to an UErrorCode to receive any errors
- * @param ...           A variable-length argument list containing the arguments
- *                      specified in pattern.
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2 
-umsg_parse( const UMessageFormat *fmt,
-            const UChar    *source,
-            int32_t        sourceLength,
-            int32_t        *count,
-            UErrorCode     *status,
-            ...);
-
-/**
- * Parse a message.
- * For numeric arguments, this function will always use doubles.  Integer types
- * should not be passed.
- * This function is not able to parse all output from {@link #umsg_format }.
- * @param fmt           The formatter to use 
- * @param source        The text to parse.
- * @param sourceLength  The length of source, or -1 if null-terminated.
- * @param count         Output param to receive number of elements returned.
- * @param ap            A variable-length argument list containing the arguments
- * @param status        A pointer to an UErrorCode to receive any errors
- *                      specified in pattern.
- * @see u_formatMessage
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2 
-umsg_vparse(const UMessageFormat *fmt,
-            const UChar    *source,
-            int32_t        sourceLength,
-            int32_t        *count,
-            va_list        ap,
-            UErrorCode     *status);
-
-
-/**
- * Convert an 'apostrophe-friendly' pattern into a standard
- * pattern.  Standard patterns treat all apostrophes as
- * quotes, which is problematic in some languages, e.g. 
- * French, where apostrophe is commonly used.  This utility
- * assumes that only an unpaired apostrophe immediately before
- * a brace is a true quote.  Other unpaired apostrophes are paired,
- * and the resulting standard pattern string is returned.
- *
- * <p><b>Note</b> it is not guaranteed that the returned pattern
- * is indeed a valid pattern.  The only effect is to convert
- * between patterns having different quoting semantics.
- *
- * @param pattern the 'apostrophe-friendly' patttern to convert
- * @param patternLength the length of pattern, or -1 if unknown and pattern is null-terminated
- * @param dest the buffer for the result, or NULL if preflight only
- * @param destCapacity the length of the buffer, or 0 if preflighting
- * @param ec the error code
- * @return the length of the resulting text, not including trailing null
- *        if buffer has room for the trailing null, it is provided, otherwise
- *        not
- * @stable ICU 3.4
- */
-U_STABLE int32_t U_EXPORT2 
-umsg_autoQuoteApostrophe(const UChar* pattern, 
-                         int32_t patternLength,
-                         UChar* dest,
-                         int32_t destCapacity,
-                         UErrorCode* ec);
-
-#endif /* #if !UCONFIG_NO_FORMATTING */
-
-#endif

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/unifilt.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/unifilt.h b/apps/couch_collate/platform/osx/icu/unicode/unifilt.h
deleted file mode 100644
index 5bf1ba4..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/unifilt.h
+++ /dev/null
@@ -1,127 +0,0 @@
-/*
-**********************************************************************
-* Copyright (C) 1999-2006, International Business Machines Corporation and others.
-* All Rights Reserved.
-**********************************************************************
-*   Date        Name        Description
-*   11/17/99    aliu        Creation.
-**********************************************************************
-*/
-#ifndef UNIFILT_H
-#define UNIFILT_H
-
-#include "unicode/unifunct.h"
-#include "unicode/unimatch.h"
-
-/**
- * \file 
- * \brief C++ API: Unicode Filter
- */
-
-U_NAMESPACE_BEGIN
-
-/**
- * U_ETHER is used to represent character values for positions outside
- * a range.  For example, transliterator uses this to represent
- * characters outside the range contextStart..contextLimit-1.  This
- * allows explicit matching by rules and UnicodeSets of text outside a
- * defined range.
- * @stable ICU 3.0
- */
-#define U_ETHER ((UChar)0xFFFF)
-
-/**
- *
- * <code>UnicodeFilter</code> defines a protocol for selecting a
- * subset of the full range (U+0000 to U+10FFFF) of Unicode characters.
- * Currently, filters are used in conjunction with classes like {@link
- * Transliterator} to only process selected characters through a
- * transformation.
- *
- * <p>Note: UnicodeFilter currently stubs out two pure virtual methods
- * of its base class, UnicodeMatcher.  These methods are toPattern()
- * and matchesIndexValue().  This is done so that filter classes that
- * are not actually used as matchers -- specifically, those in the
- * UnicodeFilterLogic component, and those in tests -- can continue to
- * work without defining these methods.  As long as a filter is not
- * used in an RBT during real transliteration, these methods will not
- * be called.  However, this breaks the UnicodeMatcher base class
- * protocol, and it is not a correct solution.
- *
- * <p>In the future we may revisit the UnicodeMatcher / UnicodeFilter
- * hierarchy and either redesign it, or simply remove the stubs in
- * UnicodeFilter and force subclasses to implement the full
- * UnicodeMatcher protocol.
- *
- * @see UnicodeFilterLogic
- * @stable ICU 2.0
- */
-class U_COMMON_API UnicodeFilter : public UnicodeFunctor, public UnicodeMatcher {
-
-public:
-    /**
-     * Destructor
-     * @stable ICU 2.0
-     */
-    virtual ~UnicodeFilter();
-
-    /**
-     * Returns <tt>true</tt> for characters that are in the selected
-     * subset.  In other words, if a character is <b>to be
-     * filtered</b>, then <tt>contains()</tt> returns
-     * <b><tt>false</tt></b>.
-     * @stable ICU 2.0
-     */
-    virtual UBool contains(UChar32 c) const = 0;
-
-    /**
-     * UnicodeFunctor API.  Cast 'this' to a UnicodeMatcher* pointer
-     * and return the pointer.
-     * @stable ICU 2.4
-     */
-    virtual UnicodeMatcher* toMatcher() const;
-
-    /**
-     * Implement UnicodeMatcher API.
-     * @stable ICU 2.4
-     */
-    virtual UMatchDegree matches(const Replaceable& text,
-                                 int32_t& offset,
-                                 int32_t limit,
-                                 UBool incremental);
-
-    /**
-     * UnicodeFunctor API.  Nothing to do.
-     * @stable ICU 2.4
-     */
-    virtual void setData(const TransliterationRuleData*);
-
-    /**
-     * ICU "poor man's RTTI", returns a UClassID for the actual class.
-     *
-     * @stable ICU 2.2
-     */
-    virtual UClassID getDynamicClassID() const = 0;
-
-    /**
-     * ICU "poor man's RTTI", returns a UClassID for this class.
-     *
-     * @stable ICU 2.2
-     */
-    static UClassID U_EXPORT2 getStaticClassID();
-
-protected:
-
-    /*
-     * Since this class has pure virtual functions,
-     * a constructor can't be used.
-     * @stable ICU 2.0
-     */
-/*    UnicodeFilter();*/
-};
-
-/*inline UnicodeFilter::UnicodeFilter() {}*/
-
-U_NAMESPACE_END
-
-#endif

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/unifunct.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/unifunct.h b/apps/couch_collate/platform/osx/icu/unicode/unifunct.h
deleted file mode 100644
index 3aa7b03..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/unifunct.h
+++ /dev/null
@@ -1,125 +0,0 @@
-/*
-**********************************************************************
-*   Copyright (c) 2002-2005, International Business Machines Corporation
-*   and others.  All Rights Reserved.
-**********************************************************************
-*   Date        Name        Description
-*   01/14/2002  aliu        Creation.
-**********************************************************************
-*/
-#ifndef UNIFUNCT_H
-#define UNIFUNCT_H
-
-#include "unicode/utypes.h"
-#include "unicode/uobject.h"
-
-/**
- * \file 
- * \brief C++ API: Unicode Functor
- */
- 
-U_NAMESPACE_BEGIN
-
-class UnicodeMatcher;
-class UnicodeReplacer;
-class TransliterationRuleData;
-
-/**
- * <code>UnicodeFunctor</code> is an abstract base class for objects
- * that perform match and/or replace operations on Unicode strings.
- * @author Alan Liu
- * @stable ICU 2.4
- */
-class U_COMMON_API UnicodeFunctor : public UObject {
-
-public:
-
-    /**
-     * Destructor
-     * @stable ICU 2.4
-     */
-    virtual ~UnicodeFunctor();
-
-    /**
-     * Return a copy of this object.  All UnicodeFunctor objects
-     * have to support cloning in order to allow classes using
-     * UnicodeFunctor to implement cloning.
-     * @stable ICU 2.4
-     */
-    virtual UnicodeFunctor* clone() const = 0;
-
-    /**
-     * Cast 'this' to a UnicodeMatcher* pointer and return the
-     * pointer, or null if this is not a UnicodeMatcher*.  Subclasses
-     * that mix in UnicodeMatcher as a base class must override this.
-     * This protocol is required because a pointer to a UnicodeFunctor
-     * cannot be cast to a pointer to a UnicodeMatcher, since
-     * UnicodeMatcher is a mixin that does not derive from
-     * UnicodeFunctor.
-     * @stable ICU 2.4
-     */
-    virtual UnicodeMatcher* toMatcher() const;
-
-    /**
-     * Cast 'this' to a UnicodeReplacer* pointer and return the
-     * pointer, or null if this is not a UnicodeReplacer*.  Subclasses
-     * that mix in UnicodeReplacer as a base class must override this.
-     * This protocol is required because a pointer to a UnicodeFunctor
-     * cannot be cast to a pointer to a UnicodeReplacer, since
-     * UnicodeReplacer is a mixin that does not derive from
-     * UnicodeFunctor.
-     * @stable ICU 2.4
-     */
-    virtual UnicodeReplacer* toReplacer() const;
-
-    /**
-     * Return the class ID for this class.  This is useful only for
-     * comparing to a return value from getDynamicClassID().
-     * @return          The class ID for all objects of this class.
-     * @stable ICU 2.0
-     */
-    static UClassID U_EXPORT2 getStaticClassID(void);
-
-    /**
-     * Returns a unique class ID <b>polymorphically</b>.  This method
-     * is to implement a simple version of RTTI, since not all C++
-     * compilers support genuine RTTI.  Polymorphic operator==() and
-     * clone() methods call this method.
-     *
-     * <p>Concrete subclasses of UnicodeFunctor should use the macro
-     *    UOBJECT_DEFINE_RTTI_IMPLEMENTATION from uobject.h to
-     *    provide definitios getStaticClassID and getDynamicClassID.
-     *
-     * @return The class ID for this object. All objects of a given
-     * class have the same class ID.  Objects of other classes have
-     * different class IDs.
-     * @stable ICU 2.4
-     */
-    virtual UClassID getDynamicClassID(void) const = 0;
-
-    /**
-     * Set the data object associated with this functor.  The data
-     * object provides context for functor-to-standin mapping.  This
-     * method is required when assigning a functor to a different data
-     * object.  This function MAY GO AWAY later if the architecture is
-     * changed to pass data object pointers through the API.
-     * @internal ICU 2.1
-     */
-    virtual void setData(const TransliterationRuleData*) = 0;
-
-protected:
-
-    /**
-     * Since this class has pure virtual functions,
-     * a constructor can't be used.
-     * @stable ICU 2.0
-     */
-    /*UnicodeFunctor();*/
-
-};
-
-/*inline UnicodeFunctor::UnicodeFunctor() {}*/
-
-U_NAMESPACE_END
-
-#endif

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/unimatch.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/unimatch.h b/apps/couch_collate/platform/osx/icu/unicode/unimatch.h
deleted file mode 100644
index 0dbb14e..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/unimatch.h
+++ /dev/null
@@ -1,163 +0,0 @@
-/*
-* Copyright (C) 2001-2005, International Business Machines Corporation and others. All Rights Reserved.
-**********************************************************************
-*   Date        Name        Description
-*   07/18/01    aliu        Creation.
-**********************************************************************
-*/
-#ifndef UNIMATCH_H
-#define UNIMATCH_H
-
-#include "unicode/utypes.h"
-
-/**
- * \file 
- * \brief C++ API: Unicode Matcher
- */
-
-
-U_NAMESPACE_BEGIN
-
-class Replaceable;
-class UnicodeString;
-class UnicodeSet;
-
-/**
- * Constants returned by <code>UnicodeMatcher::matches()</code>
- * indicating the degree of match.
- * @stable ICU 2.4
- */
-enum UMatchDegree {
-    /**
-     * Constant returned by <code>matches()</code> indicating a
-     * mismatch between the text and this matcher.  The text contains
-     * a character which does not match, or the text does not contain
-     * all desired characters for a non-incremental match.
-     * @stable ICU 2.4
-     */
-    U_MISMATCH,
-    
-    /**
-     * Constant returned by <code>matches()</code> indicating a
-     * partial match between the text and this matcher.  This value is
-     * only returned for incremental match operations.  All characters
-     * of the text match, but more characters are required for a
-     * complete match.  Alternatively, for variable-length matchers,
-     * all characters of the text match, and if more characters were
-     * supplied at limit, they might also match.
-     * @stable ICU 2.4
-     */
-    U_PARTIAL_MATCH,
-    
-    /**
-     * Constant returned by <code>matches()</code> indicating a
-     * complete match between the text and this matcher.  For an
-     * incremental variable-length match, this value is returned if
-     * the given text matches, and it is known that additional
-     * characters would not alter the extent of the match.
-     * @stable ICU 2.4
-     */
-    U_MATCH
-};
-
-/**
- * <code>UnicodeMatcher</code> defines a protocol for objects that can
- * match a range of characters in a Replaceable string.
- * @stable ICU 2.4
- */
-class U_COMMON_API UnicodeMatcher /* not : public UObject because this is an interface/mixin class */ {
-
-public:
-    /**
-     * Destructor.
-     * @stable ICU 2.4
-     */
-    virtual ~UnicodeMatcher();
-
-    /**
-     * Return a UMatchDegree value indicating the degree of match for
-     * the given text at the given offset.  Zero, one, or more
-     * characters may be matched.
-     *
-     * Matching in the forward direction is indicated by limit >
-     * offset.  Characters from offset forwards to limit-1 will be
-     * considered for matching.
-     * 
-     * Matching in the reverse direction is indicated by limit <
-     * offset.  Characters from offset backwards to limit+1 will be
-     * considered for matching.
-     *
-     * If limit == offset then the only match possible is a zero
-     * character match (which subclasses may implement if desired).
-     *
-     * As a side effect, advance the offset parameter to the limit of
-     * the matched substring.  In the forward direction, this will be
-     * the index of the last matched character plus one.  In the
-     * reverse direction, this will be the index of the last matched
-     * character minus one.
-     *
-     * <p>Note:  This method is not const because some classes may
-     * modify their state as the result of a match.
-     *
-     * @param text the text to be matched
-     * @param offset on input, the index into text at which to begin
-     * matching.  On output, the limit of the matched text.  The
-     * number of matched characters is the output value of offset
-     * minus the input value.  Offset should always point to the
-     * HIGH SURROGATE (leading code unit) of a pair of surrogates,
-     * both on entry and upon return.
-     * @param limit the limit index of text to be matched.  Greater
-     * than offset for a forward direction match, less than offset for
-     * a backward direction match.  The last character to be
-     * considered for matching will be text.charAt(limit-1) in the
-     * forward direction or text.charAt(limit+1) in the backward
-     * direction.
-     * @param incremental if TRUE, then assume further characters may
-     * be inserted at limit and check for partial matching.  Otherwise
-     * assume the text as given is complete.
-     * @return a match degree value indicating a full match, a partial
-     * match, or a mismatch.  If incremental is FALSE then
-     * U_PARTIAL_MATCH should never be returned.
-     * @stable ICU 2.4
-     */
-    virtual UMatchDegree matches(const Replaceable& text,
-                                 int32_t& offset,
-                                 int32_t limit,
-                                 UBool incremental) = 0;
-
-    /**
-     * Returns a string representation of this matcher.  If the result of
-     * calling this function is passed to the appropriate parser, it
-     * will produce another matcher that is equal to this one.
-     * @param result the string to receive the pattern.  Previous
-     * contents will be deleted.
-     * @param escapeUnprintable if TRUE then convert unprintable
-     * character to their hex escape representations, \\uxxxx or
-     * \\Uxxxxxxxx.  Unprintable characters are those other than
-     * U+000A, U+0020..U+007E.
-     * @stable ICU 2.4
-     */
-    virtual UnicodeString& toPattern(UnicodeString& result,
-                                     UBool escapeUnprintable = FALSE) const = 0;
-
-    /**
-     * Returns TRUE if this matcher will match a character c, where c
-     * & 0xFF == v, at offset, in the forward direction (with limit >
-     * offset).  This is used by <tt>RuleBasedTransliterator</tt> for
-     * indexing.
-     * @stable ICU 2.4
-     */
-    virtual UBool matchesIndexValue(uint8_t v) const = 0;
-
-    /**
-     * Union the set of all characters that may be matched by this object
-     * into the given set.
-     * @param toUnionTo the set into which to union the source characters
-     * @stable ICU 2.4
-     */
-    virtual void addMatchSetTo(UnicodeSet& toUnionTo) const = 0;
-};
-
-U_NAMESPACE_END
-
-#endif

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/unirepl.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/unirepl.h b/apps/couch_collate/platform/osx/icu/unicode/unirepl.h
deleted file mode 100644
index 6b7746b..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/unirepl.h
+++ /dev/null
@@ -1,97 +0,0 @@
-/*
-**********************************************************************
-*   Copyright (c) 2002-2005, International Business Machines Corporation
-*   and others.  All Rights Reserved.
-**********************************************************************
-*   Date        Name        Description
-*   01/14/2002  aliu        Creation.
-**********************************************************************
-*/
-#ifndef UNIREPL_H
-#define UNIREPL_H
-
-#include "unicode/utypes.h"
-
-/**
- * \file 
- * \brief C++ API: UnicodeReplacer
- */
-
-U_NAMESPACE_BEGIN
-
-class Replaceable;
-class UnicodeString;
-class UnicodeSet;
-
-/**
- * <code>UnicodeReplacer</code> defines a protocol for objects that
- * replace a range of characters in a Replaceable string with output
- * text.  The replacement is done via the Replaceable API so as to
- * preserve out-of-band data.
- *
- * <p>This is a mixin class.
- * @author Alan Liu
- * @stable ICU 2.4
- */
-class U_I18N_API UnicodeReplacer /* not : public UObject because this is an interface/mixin class */ {
-
- public:
-
-    /**
-     * Destructor.
-     * @stable ICU 2.4
-     */
-    virtual ~UnicodeReplacer();
-
-    /**
-     * Replace characters in 'text' from 'start' to 'limit' with the
-     * output text of this object.  Update the 'cursor' parameter to
-     * give the cursor position and return the length of the
-     * replacement text.
-     *
-     * @param text the text to be matched
-     * @param start inclusive start index of text to be replaced
-     * @param limit exclusive end index of text to be replaced;
-     * must be greater than or equal to start
-     * @param cursor output parameter for the cursor position.
-     * Not all replacer objects will update this, but in a complete
-     * tree of replacer objects, representing the entire output side
-     * of a transliteration rule, at least one must update it.
-     * @return the number of 16-bit code units in the text replacing
-     * the characters at offsets start..(limit-1) in text
-     * @stable ICU 2.4
-     */
-    virtual int32_t replace(Replaceable& text,
-                            int32_t start,
-                            int32_t limit,
-                            int32_t& cursor) = 0;
-
-    /**
-     * Returns a string representation of this replacer.  If the
-     * result of calling this function is passed to the appropriate
-     * parser, typically TransliteratorParser, it will produce another
-     * replacer that is equal to this one.
-     * @param result the string to receive the pattern.  Previous
-     * contents will be deleted.
-     * @param escapeUnprintable if TRUE then convert unprintable
-     * character to their hex escape representations, \\uxxxx or
-     * \\Uxxxxxxxx.  Unprintable characters are defined by
-     * Utility.isUnprintable().
-     * @return a reference to 'result'.
-     * @stable ICU 2.4
-     */
-    virtual UnicodeString& toReplacerPattern(UnicodeString& result,
-                                             UBool escapeUnprintable) const = 0;
-
-    /**
-     * Union the set of all characters that may output by this object
-     * into the given set.
-     * @param toUnionTo the set into which to union the output characters
-     * @stable ICU 2.4
-     */
-    virtual void addReplacementSetTo(UnicodeSet& toUnionTo) const = 0;
-};
-
-U_NAMESPACE_END
-
-#endif


[56/57] [abbrv] couchdb commit: updated refs/heads/1994-merge-rcouch-multi-repo to b19d055

Posted by be...@apache.org.
fix


Project: http://git-wip-us.apache.org/repos/asf/couchdb/repo
Commit: http://git-wip-us.apache.org/repos/asf/couchdb/commit/a3d75ba4
Tree: http://git-wip-us.apache.org/repos/asf/couchdb/tree/a3d75ba4
Diff: http://git-wip-us.apache.org/repos/asf/couchdb/diff/a3d75ba4

Branch: refs/heads/1994-merge-rcouch-multi-repo
Commit: a3d75ba406f4911b15adf4d5f53467f94a2890cb
Parents: cb4817b
Author: Benoit Chesneau <bc...@gmail.com>
Authored: Thu Feb 13 18:09:00 2014 +0100
Committer: Benoit Chesneau <bc...@gmail.com>
Committed: Thu Feb 13 18:09:00 2014 +0100

----------------------------------------------------------------------
 rel/reltool.config.script | 4 ++--
 1 file changed, 2 insertions(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/couchdb/blob/a3d75ba4/rel/reltool.config.script
----------------------------------------------------------------------
diff --git a/rel/reltool.config.script b/rel/reltool.config.script
index c413557..44c47cc 100644
--- a/rel/reltool.config.script
+++ b/rel/reltool.config.script
@@ -43,7 +43,7 @@ CouchJSName = proplists:get_value(couchjs_name, Cfg, "couchjs"),
 
 [
     {sys, [
-            {lib_dirs, ["../deps", "../apps"]},
+            {lib_dirs, ["../deps"]},
             {rel, "couchdb", Vsn,
                 [
                     kernel,
@@ -145,7 +145,7 @@ CouchJSName = proplists:get_value(couchjs_name, Cfg, "couchjs"),
         {copy, "../share/server/main.js", "share/server"},
         {copy, "../share/server/main-coffee.js", "share/server"},
         {copy, "../share/www", "share"},
-        {copy, "../apps/couch/priv/" ++ CouchJSName, "bin/" ++ CouchJSName},
+        {copy, "../deps/couch/priv/" ++ CouchJSName, "bin/" ++ CouchJSName},
 
         %% misc
         {mkdir, "lib/couch-patches"},


[24/57] [abbrv] remove couch_collate

Posted by be...@apache.org.
http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/translit.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/translit.h b/apps/couch_collate/platform/osx/icu/unicode/translit.h
deleted file mode 100644
index bfff344..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/translit.h
+++ /dev/null
@@ -1,1323 +0,0 @@
-/*
-**********************************************************************
-* Copyright (C) 1999-2008, International Business Machines
-* Corporation and others. All Rights Reserved.
-**********************************************************************
-*   Date        Name        Description
-*   11/17/99    aliu        Creation.
-**********************************************************************
-*/
-#ifndef TRANSLIT_H
-#define TRANSLIT_H
-
-#include "unicode/utypes.h"
-
-/**
- * \file 
- * \brief C++ API: Tranforms text from one format to another.
- */
- 
-#if !UCONFIG_NO_TRANSLITERATION
-
-#include "unicode/uobject.h"
-#include "unicode/unistr.h"
-#include "unicode/parseerr.h"
-#include "unicode/utrans.h" // UTransPosition, UTransDirection
-#include "unicode/strenum.h"
-
-U_NAMESPACE_BEGIN
-
-class UnicodeFilter;
-class UnicodeSet;
-class CompoundTransliterator;
-class TransliteratorParser;
-class NormalizationTransliterator;
-class TransliteratorIDParser;
-
-/**
- *
- * <code>Transliterator</code> is an abstract class that
- * transliterates text from one format to another.  The most common
- * kind of transliterator is a script, or alphabet, transliterator.
- * For example, a Russian to Latin transliterator changes Russian text
- * written in Cyrillic characters to phonetically equivalent Latin
- * characters.  It does not <em>translate</em> Russian to English!
- * Transliteration, unlike translation, operates on characters, without
- * reference to the meanings of words and sentences.
- *
- * <p>Although script conversion is its most common use, a
- * transliterator can actually perform a more general class of tasks.
- * In fact, <code>Transliterator</code> defines a very general API
- * which specifies only that a segment of the input text is replaced
- * by new text.  The particulars of this conversion are determined
- * entirely by subclasses of <code>Transliterator</code>.
- *
- * <p><b>Transliterators are stateless</b>
- *
- * <p><code>Transliterator</code> objects are <em>stateless</em>; they
- * retain no information between calls to
- * <code>transliterate()</code>.  (However, this does <em>not</em>
- * mean that threads may share transliterators without synchronizing
- * them.  Transliterators are not immutable, so they must be
- * synchronized when shared between threads.)  This might seem to
- * limit the complexity of the transliteration operation.  In
- * practice, subclasses perform complex transliterations by delaying
- * the replacement of text until it is known that no other
- * replacements are possible.  In other words, although the
- * <code>Transliterator</code> objects are stateless, the source text
- * itself embodies all the needed information, and delayed operation
- * allows arbitrary complexity.
- *
- * <p><b>Batch transliteration</b>
- *
- * <p>The simplest way to perform transliteration is all at once, on a
- * string of existing text.  This is referred to as <em>batch</em>
- * transliteration.  For example, given a string <code>input</code>
- * and a transliterator <code>t</code>, the call
- *
- * \htmlonly<blockquote>\endhtmlonly<code>String result = t.transliterate(input);
- * </code>\htmlonly</blockquote>\endhtmlonly
- *
- * will transliterate it and return the result.  Other methods allow
- * the client to specify a substring to be transliterated and to use
- * {@link Replaceable } objects instead of strings, in order to
- * preserve out-of-band information (such as text styles).
- *
- * <p><b>Keyboard transliteration</b>
- *
- * <p>Somewhat more involved is <em>keyboard</em>, or incremental
- * transliteration.  This is the transliteration of text that is
- * arriving from some source (typically the user's keyboard) one
- * character at a time, or in some other piecemeal fashion.
- *
- * <p>In keyboard transliteration, a <code>Replaceable</code> buffer
- * stores the text.  As text is inserted, as much as possible is
- * transliterated on the fly.  This means a GUI that displays the
- * contents of the buffer may show text being modified as each new
- * character arrives.
- *
- * <p>Consider the simple <code>RuleBasedTransliterator</code>:
- *
- * \htmlonly<blockquote>\endhtmlonly<code>
- * th&gt;{theta}<br>
- * t&gt;{tau}
- * </code>\htmlonly</blockquote>\endhtmlonly
- *
- * When the user types 't', nothing will happen, since the
- * transliterator is waiting to see if the next character is 'h'.  To
- * remedy this, we introduce the notion of a cursor, marked by a '|'
- * in the output string:
- *
- * \htmlonly<blockquote>\endhtmlonly<code>
- * t&gt;|{tau}<br>
- * {tau}h&gt;{theta}
- * </code>\htmlonly</blockquote>\endhtmlonly
- *
- * Now when the user types 't', tau appears, and if the next character
- * is 'h', the tau changes to a theta.  This is accomplished by
- * maintaining a cursor position (independent of the insertion point,
- * and invisible in the GUI) across calls to
- * <code>transliterate()</code>.  Typically, the cursor will
- * be coincident with the insertion point, but in a case like the one
- * above, it will precede the insertion point.
- *
- * <p>Keyboard transliteration methods maintain a set of three indices
- * that are updated with each call to
- * <code>transliterate()</code>, including the cursor, start,
- * and limit.  Since these indices are changed by the method, they are
- * passed in an <code>int[]</code> array. The <code>START</code> index
- * marks the beginning of the substring that the transliterator will
- * look at.  It is advanced as text becomes committed (but it is not
- * the committed index; that's the <code>CURSOR</code>).  The
- * <code>CURSOR</code> index, described above, marks the point at
- * which the transliterator last stopped, either because it reached
- * the end, or because it required more characters to disambiguate
- * between possible inputs.  The <code>CURSOR</code> can also be
- * explicitly set by rules in a <code>RuleBasedTransliterator</code>.
- * Any characters before the <code>CURSOR</code> index are frozen;
- * future keyboard transliteration calls within this input sequence
- * will not change them.  New text is inserted at the
- * <code>LIMIT</code> index, which marks the end of the substring that
- * the transliterator looks at.
- *
- * <p>Because keyboard transliteration assumes that more characters
- * are to arrive, it is conservative in its operation.  It only
- * transliterates when it can do so unambiguously.  Otherwise it waits
- * for more characters to arrive.  When the client code knows that no
- * more characters are forthcoming, perhaps because the user has
- * performed some input termination operation, then it should call
- * <code>finishTransliteration()</code> to complete any
- * pending transliterations.
- *
- * <p><b>Inverses</b>
- *
- * <p>Pairs of transliterators may be inverses of one another.  For
- * example, if transliterator <b>A</b> transliterates characters by
- * incrementing their Unicode value (so "abc" -> "def"), and
- * transliterator <b>B</b> decrements character values, then <b>A</b>
- * is an inverse of <b>B</b> and vice versa.  If we compose <b>A</b>
- * with <b>B</b> in a compound transliterator, the result is the
- * indentity transliterator, that is, a transliterator that does not
- * change its input text.
- *
- * The <code>Transliterator</code> method <code>getInverse()</code>
- * returns a transliterator's inverse, if one exists, or
- * <code>null</code> otherwise.  However, the result of
- * <code>getInverse()</code> usually will <em>not</em> be a true
- * mathematical inverse.  This is because true inverse transliterators
- * are difficult to formulate.  For example, consider two
- * transliterators: <b>AB</b>, which transliterates the character 'A'
- * to 'B', and <b>BA</b>, which transliterates 'B' to 'A'.  It might
- * seem that these are exact inverses, since
- *
- * \htmlonly<blockquote>\endhtmlonly"A" x <b>AB</b> -> "B"<br>
- * "B" x <b>BA</b> -> "A"\htmlonly</blockquote>\endhtmlonly
- *
- * where 'x' represents transliteration.  However,
- *
- * \htmlonly<blockquote>\endhtmlonly"ABCD" x <b>AB</b> -> "BBCD"<br>
- * "BBCD" x <b>BA</b> -> "AACD"\htmlonly</blockquote>\endhtmlonly
- *
- * so <b>AB</b> composed with <b>BA</b> is not the
- * identity. Nonetheless, <b>BA</b> may be usefully considered to be
- * <b>AB</b>'s inverse, and it is on this basis that
- * <b>AB</b><code>.getInverse()</code> could legitimately return
- * <b>BA</b>.
- *
- * <p><b>IDs and display names</b>
- *
- * <p>A transliterator is designated by a short identifier string or
- * <em>ID</em>.  IDs follow the format <em>source-destination</em>,
- * where <em>source</em> describes the entity being replaced, and
- * <em>destination</em> describes the entity replacing
- * <em>source</em>.  The entities may be the names of scripts,
- * particular sequences of characters, or whatever else it is that the
- * transliterator converts to or from.  For example, a transliterator
- * from Russian to Latin might be named "Russian-Latin".  A
- * transliterator from keyboard escape sequences to Latin-1 characters
- * might be named "KeyboardEscape-Latin1".  By convention, system
- * entity names are in English, with the initial letters of words
- * capitalized; user entity names may follow any format so long as
- * they do not contain dashes.
- *
- * <p>In addition to programmatic IDs, transliterator objects have
- * display names for presentation in user interfaces, returned by
- * {@link #getDisplayName }.
- *
- * <p><b>Factory methods and registration</b>
- *
- * <p>In general, client code should use the factory method
- * {@link #createInstance } to obtain an instance of a
- * transliterator given its ID.  Valid IDs may be enumerated using
- * <code>getAvailableIDs()</code>.  Since transliterators are mutable,
- * multiple calls to {@link #createInstance } with the same ID will
- * return distinct objects.
- *
- * <p>In addition to the system transliterators registered at startup,
- * user transliterators may be registered by calling
- * <code>registerInstance()</code> at run time.  A registered instance
- * acts a template; future calls to {@link #createInstance } with the ID
- * of the registered object return clones of that object.  Thus any
- * object passed to <tt>registerInstance()</tt> must implement
- * <tt>clone()</tt> propertly.  To register a transliterator subclass
- * without instantiating it (until it is needed), users may call
- * {@link #registerFactory }.  In this case, the objects are
- * instantiated by invoking the zero-argument public constructor of
- * the class.
- *
- * <p><b>Subclassing</b>
- *
- * Subclasses must implement the abstract method
- * <code>handleTransliterate()</code>.  <p>Subclasses should override
- * the <code>transliterate()</code> method taking a
- * <code>Replaceable</code> and the <code>transliterate()</code>
- * method taking a <code>String</code> and <code>StringBuffer</code>
- * if the performance of these methods can be improved over the
- * performance obtained by the default implementations in this class.
- *
- * @author Alan Liu
- * @stable ICU 2.0
- */
-class U_I18N_API Transliterator : public UObject {
-
-private:
-
-    /**
-     * Programmatic name, e.g., "Latin-Arabic".
-     */
-    UnicodeString ID;
-
-    /**
-     * This transliterator's filter.  Any character for which
-     * <tt>filter.contains()</tt> returns <tt>false</tt> will not be
-     * altered by this transliterator.  If <tt>filter</tt> is
-     * <tt>null</tt> then no filtering is applied.
-     */
-    UnicodeFilter* filter;
-
-    int32_t maximumContextLength;
-
- public:
-
-    /**
-     * A context integer or pointer for a factory function, passed by
-     * value.
-     * @stable ICU 2.4
-     */
-    union Token {
-        /**
-         * This token, interpreted as a 32-bit integer.
-         * @stable ICU 2.4
-         */
-        int32_t integer;
-        /**
-         * This token, interpreted as a native pointer.
-         * @stable ICU 2.4
-         */
-        void*   pointer;
-    };
-
-    /**
-     * Return a token containing an integer.
-     * @return a token containing an integer.
-     * @internal
-     */
-    inline static Token integerToken(int32_t);
-
-    /**
-     * Return a token containing a pointer.
-     * @return a token containing a pointer.
-     * @internal
-     */
-    inline static Token pointerToken(void*);
-
-    /**
-     * A function that creates and returns a Transliterator.  When
-     * invoked, it will be passed the ID string that is being
-     * instantiated, together with the context pointer that was passed
-     * in when the factory function was first registered.  Many
-     * factory functions will ignore both parameters, however,
-     * functions that are registered to more than one ID may use the
-     * ID or the context parameter to parameterize the transliterator
-     * they create.
-     * @param ID      the string identifier for this transliterator
-     * @param context a context pointer that will be stored and
-     *                later passed to the factory function when an ID matching
-     *                the registration ID is being instantiated with this factory.
-     * @stable ICU 2.4
-     */
-    typedef Transliterator* (U_EXPORT2 *Factory)(const UnicodeString& ID, Token context);
-
-protected:
-
-    /**
-     * Default constructor.
-     * @param ID the string identifier for this transliterator
-     * @param adoptedFilter the filter.  Any character for which
-     * <tt>filter.contains()</tt> returns <tt>false</tt> will not be
-     * altered by this transliterator.  If <tt>filter</tt> is
-     * <tt>null</tt> then no filtering is applied.
-     * @stable ICU 2.4
-     */
-    Transliterator(const UnicodeString& ID, UnicodeFilter* adoptedFilter);
-
-    /**
-     * Copy constructor.
-     * @stable ICU 2.4
-     */
-    Transliterator(const Transliterator&);
-
-    /**
-     * Assignment operator.
-     * @stable ICU 2.4
-     */
-    Transliterator& operator=(const Transliterator&);
-
-    /**
-     * Create a transliterator from a basic ID.  This is an ID
-     * containing only the forward direction source, target, and
-     * variant.
-     * @param id a basic ID of the form S-T or S-T/V.
-     * @param canon canonical ID to assign to the object, or
-     * NULL to leave the ID unchanged
-     * @return a newly created Transliterator or null if the ID is
-     * invalid.
-     * @stable ICU 2.4
-     */
-    static Transliterator* createBasicInstance(const UnicodeString& id,
-                                               const UnicodeString* canon);
-
-    friend class TransliteratorParser; // for parseID()
-    friend class TransliteratorIDParser; // for createBasicInstance()
-    friend class TransliteratorAlias; // for setID()
-
-public:
-
-    /**
-     * Destructor.
-     * @stable ICU 2.0
-     */
-    virtual ~Transliterator();
-
-    /**
-     * Implements Cloneable.
-     * All subclasses are encouraged to implement this method if it is
-     * possible and reasonable to do so.  Subclasses that are to be
-     * registered with the system using <tt>registerInstance()</tt>
-     * are required to implement this method.  If a subclass does not
-     * implement clone() properly and is registered with the system
-     * using registerInstance(), then the default clone() implementation
-     * will return null, and calls to createInstance() will fail.
-     *
-     * @return a copy of the object.
-     * @see #registerInstance
-     * @stable ICU 2.0
-     */
-    virtual Transliterator* clone() const;
-
-    /**
-     * Transliterates a segment of a string, with optional filtering.
-     *
-     * @param text the string to be transliterated
-     * @param start the beginning index, inclusive; <code>0 <= start
-     * <= limit</code>.
-     * @param limit the ending index, exclusive; <code>start <= limit
-     * <= text.length()</code>.
-     * @return The new limit index.  The text previously occupying <code>[start,
-     * limit)</code> has been transliterated, possibly to a string of a different
-     * length, at <code>[start, </code><em>new-limit</em><code>)</code>, where
-     * <em>new-limit</em> is the return value. If the input offsets are out of bounds,
-     * the returned value is -1 and the input string remains unchanged.
-     * @stable ICU 2.0
-     */
-    virtual int32_t transliterate(Replaceable& text,
-                                  int32_t start, int32_t limit) const;
-
-    /**
-     * Transliterates an entire string in place. Convenience method.
-     * @param text the string to be transliterated
-     * @stable ICU 2.0
-     */
-    virtual void transliterate(Replaceable& text) const;
-
-    /**
-     * Transliterates the portion of the text buffer that can be
-     * transliterated unambiguosly after new text has been inserted,
-     * typically as a result of a keyboard event.  The new text in
-     * <code>insertion</code> will be inserted into <code>text</code>
-     * at <code>index.limit</code>, advancing
-     * <code>index.limit</code> by <code>insertion.length()</code>.
-     * Then the transliterator will try to transliterate characters of
-     * <code>text</code> between <code>index.cursor</code> and
-     * <code>index.limit</code>.  Characters before
-     * <code>index.cursor</code> will not be changed.
-     *
-     * <p>Upon return, values in <code>index</code> will be updated.
-     * <code>index.start</code> will be advanced to the first
-     * character that future calls to this method will read.
-     * <code>index.cursor</code> and <code>index.limit</code> will
-     * be adjusted to delimit the range of text that future calls to
-     * this method may change.
-     *
-     * <p>Typical usage of this method begins with an initial call
-     * with <code>index.start</code> and <code>index.limit</code>
-     * set to indicate the portion of <code>text</code> to be
-     * transliterated, and <code>index.cursor == index.start</code>.
-     * Thereafter, <code>index</code> can be used without
-     * modification in future calls, provided that all changes to
-     * <code>text</code> are made via this method.
-     *
-     * <p>This method assumes that future calls may be made that will
-     * insert new text into the buffer.  As a result, it only performs
-     * unambiguous transliterations.  After the last call to this
-     * method, there may be untransliterated text that is waiting for
-     * more input to resolve an ambiguity.  In order to perform these
-     * pending transliterations, clients should call {@link
-     * #finishTransliteration } after the last call to this
-     * method has been made.
-     *
-     * @param text the buffer holding transliterated and untransliterated text
-     * @param index an array of three integers.
-     *
-     * <ul><li><code>index.start</code>: the beginning index,
-     * inclusive; <code>0 <= index.start <= index.limit</code>.
-     *
-     * <li><code>index.limit</code>: the ending index, exclusive;
-     * <code>index.start <= index.limit <= text.length()</code>.
-     * <code>insertion</code> is inserted at
-     * <code>index.limit</code>.
-     *
-     * <li><code>index.cursor</code>: the next character to be
-     * considered for transliteration; <code>index.start <=
-     * index.cursor <= index.limit</code>.  Characters before
-     * <code>index.cursor</code> will not be changed by future calls
-     * to this method.</ul>
-     *
-     * @param insertion text to be inserted and possibly
-     * transliterated into the translation buffer at
-     * <code>index.limit</code>.  If <code>null</code> then no text
-     * is inserted.
-     * @param status    Output param to filled in with a success or an error.
-     * @see #handleTransliterate
-     * @exception IllegalArgumentException if <code>index</code>
-     * is invalid
-     * @see UTransPosition
-     * @stable ICU 2.0
-     */
-    virtual void transliterate(Replaceable& text, UTransPosition& index,
-                               const UnicodeString& insertion,
-                               UErrorCode& status) const;
-
-    /**
-     * Transliterates the portion of the text buffer that can be
-     * transliterated unambiguosly after a new character has been
-     * inserted, typically as a result of a keyboard event.  This is a
-     * convenience method; see {@link
-     * #transliterate(Replaceable&, UTransPosition&, const UnicodeString&, UErrorCode&) const}
-     * for details.
-     * @param text the buffer holding transliterated and
-     * untransliterated text
-     * @param index an array of three integers.  See {@link
-     * #transliterate(Replaceable&, UTransPosition&, const UnicodeString&, UErrorCode&) const }.
-     * @param insertion text to be inserted and possibly
-     * transliterated into the translation buffer at
-     * <code>index.limit</code>.
-     * @param status    Output param to filled in with a success or an error.
-     * @see #transliterate(Replaceable&, UTransPosition&, const UnicodeString&, UErrorCode&) const
-     * @stable ICU 2.0
-     */
-    virtual void transliterate(Replaceable& text, UTransPosition& index,
-                               UChar32 insertion,
-                               UErrorCode& status) const;
-
-    /**
-     * Transliterates the portion of the text buffer that can be
-     * transliterated unambiguosly.  This is a convenience method; see
-     * {@link
-     * #transliterate(Replaceable&, UTransPosition&, const UnicodeString&, UErrorCode&) const }
-     * for details.
-     * @param text the buffer holding transliterated and
-     * untransliterated text
-     * @param index an array of three integers.  See {@link
-     * #transliterate(Replaceable&, UTransPosition&, const UnicodeString&, UErrorCode&) const }.
-     * @param status    Output param to filled in with a success or an error.
-     * @see #transliterate(Replaceable, int[], String)
-     * @stable ICU 2.0
-     */
-    virtual void transliterate(Replaceable& text, UTransPosition& index,
-                               UErrorCode& status) const;
-
-    /**
-     * Finishes any pending transliterations that were waiting for
-     * more characters.  Clients should call this method as the last
-     * call after a sequence of one or more calls to
-     * <code>transliterate()</code>.
-     * @param text the buffer holding transliterated and
-     * untransliterated text.
-     * @param index the array of indices previously passed to {@link
-     * #transliterate }
-     * @stable ICU 2.0
-     */
-    virtual void finishTransliteration(Replaceable& text,
-                                       UTransPosition& index) const;
-
-private:
-
-    /**
-     * This internal method does incremental transliteration.  If the
-     * 'insertion' is non-null then we append it to 'text' before
-     * proceeding.  This method calls through to the pure virtual
-     * framework method handleTransliterate() to do the actual
-     * work.
-     * @param text the buffer holding transliterated and
-     * untransliterated text
-     * @param index an array of three integers.  See {@link
-     * #transliterate(Replaceable, int[], String)}.
-     * @param insertion text to be inserted and possibly
-     * transliterated into the translation buffer at
-     * <code>index.limit</code>.
-     * @param status    Output param to filled in with a success or an error.
-     */
-    void _transliterate(Replaceable& text,
-                        UTransPosition& index,
-                        const UnicodeString* insertion,
-                        UErrorCode &status) const;
-
-protected:
-
-    /**
-     * Abstract method that concrete subclasses define to implement
-     * their transliteration algorithm.  This method handles both
-     * incremental and non-incremental transliteration.  Let
-     * <code>originalStart</code> refer to the value of
-     * <code>pos.start</code> upon entry.
-     *
-     * <ul>
-     *  <li>If <code>incremental</code> is false, then this method
-     *  should transliterate all characters between
-     *  <code>pos.start</code> and <code>pos.limit</code>. Upon return
-     *  <code>pos.start</code> must == <code> pos.limit</code>.</li>
-     *
-     *  <li>If <code>incremental</code> is true, then this method
-     *  should transliterate all characters between
-     *  <code>pos.start</code> and <code>pos.limit</code> that can be
-     *  unambiguously transliterated, regardless of future insertions
-     *  of text at <code>pos.limit</code>.  Upon return,
-     *  <code>pos.start</code> should be in the range
-     *  [<code>originalStart</code>, <code>pos.limit</code>).
-     *  <code>pos.start</code> should be positioned such that
-     *  characters [<code>originalStart</code>, <code>
-     *  pos.start</code>) will not be changed in the future by this
-     *  transliterator and characters [<code>pos.start</code>,
-     *  <code>pos.limit</code>) are unchanged.</li>
-     * </ul>
-     *
-     * <p>Implementations of this method should also obey the
-     * following invariants:</p>
-     *
-     * <ul>
-     *  <li> <code>pos.limit</code> and <code>pos.contextLimit</code>
-     *  should be updated to reflect changes in length of the text
-     *  between <code>pos.start</code> and <code>pos.limit</code>. The
-     *  difference <code> pos.contextLimit - pos.limit</code> should
-     *  not change.</li>
-     *
-     *  <li><code>pos.contextStart</code> should not change.</li>
-     *
-     *  <li>Upon return, neither <code>pos.start</code> nor
-     *  <code>pos.limit</code> should be less than
-     *  <code>originalStart</code>.</li>
-     *
-     *  <li>Text before <code>originalStart</code> and text after
-     *  <code>pos.limit</code> should not change.</li>
-     *
-     *  <li>Text before <code>pos.contextStart</code> and text after
-     *  <code> pos.contextLimit</code> should be ignored.</li>
-     * </ul>
-     *
-     * <p>Subclasses may safely assume that all characters in
-     * [<code>pos.start</code>, <code>pos.limit</code>) are filtered.
-     * In other words, the filter has already been applied by the time
-     * this method is called.  See
-     * <code>filteredTransliterate()</code>.
-     *
-     * <p>This method is <b>not</b> for public consumption.  Calling
-     * this method directly will transliterate
-     * [<code>pos.start</code>, <code>pos.limit</code>) without
-     * applying the filter. End user code should call <code>
-     * transliterate()</code> instead of this method. Subclass code
-     * and wrapping transliterators should call
-     * <code>filteredTransliterate()</code> instead of this method.<p>
-     *
-     * @param text the buffer holding transliterated and
-     * untransliterated text
-     *
-     * @param pos the indices indicating the start, limit, context
-     * start, and context limit of the text.
-     *
-     * @param incremental if true, assume more text may be inserted at
-     * <code>pos.limit</code> and act accordingly.  Otherwise,
-     * transliterate all text between <code>pos.start</code> and
-     * <code>pos.limit</code> and move <code>pos.start</code> up to
-     * <code>pos.limit</code>.
-     *
-     * @see #transliterate
-     * @stable ICU 2.4
-     */
-    virtual void handleTransliterate(Replaceable& text,
-                                     UTransPosition& pos,
-                                     UBool incremental) const = 0;
-
-public:
-    /**
-     * Transliterate a substring of text, as specified by index, taking filters
-     * into account.  This method is for subclasses that need to delegate to
-     * another transliterator, such as CompoundTransliterator.
-     * @param text the text to be transliterated
-     * @param index the position indices
-     * @param incremental if TRUE, then assume more characters may be inserted
-     * at index.limit, and postpone processing to accomodate future incoming
-     * characters
-     * @stable ICU 2.4
-     */
-    virtual void filteredTransliterate(Replaceable& text,
-                                       UTransPosition& index,
-                                       UBool incremental) const;
-
-private:
-
-    /**
-     * Top-level transliteration method, handling filtering, incremental and
-     * non-incremental transliteration, and rollback.  All transliteration
-     * public API methods eventually call this method with a rollback argument
-     * of TRUE.  Other entities may call this method but rollback should be
-     * FALSE.
-     *
-     * <p>If this transliterator has a filter, break up the input text into runs
-     * of unfiltered characters.  Pass each run to
-     * <subclass>.handleTransliterate().
-     *
-     * <p>In incremental mode, if rollback is TRUE, perform a special
-     * incremental procedure in which several passes are made over the input
-     * text, adding one character at a time, and committing successful
-     * transliterations as they occur.  Unsuccessful transliterations are rolled
-     * back and retried with additional characters to give correct results.
-     *
-     * @param text the text to be transliterated
-     * @param index the position indices
-     * @param incremental if TRUE, then assume more characters may be inserted
-     * at index.limit, and postpone processing to accomodate future incoming
-     * characters
-     * @param rollback if TRUE and if incremental is TRUE, then perform special
-     * incremental processing, as described above, and undo partial
-     * transliterations where necessary.  If incremental is FALSE then this
-     * parameter is ignored.
-     */
-    virtual void filteredTransliterate(Replaceable& text,
-                                       UTransPosition& index,
-                                       UBool incremental,
-                                       UBool rollback) const;
-
-public:
-
-    /**
-     * Returns the length of the longest context required by this transliterator.
-     * This is <em>preceding</em> context.  The default implementation supplied
-     * by <code>Transliterator</code> returns zero; subclasses
-     * that use preceding context should override this method to return the
-     * correct value.  For example, if a transliterator translates "ddd" (where
-     * d is any digit) to "555" when preceded by "(ddd)", then the preceding
-     * context length is 5, the length of "(ddd)".
-     *
-     * @return The maximum number of preceding context characters this
-     * transliterator needs to examine
-     * @stable ICU 2.0
-     */
-    int32_t getMaximumContextLength(void) const;
-
-protected:
-
-    /**
-     * Method for subclasses to use to set the maximum context length.
-     * @param maxContextLength the new value to be set.
-     * @see #getMaximumContextLength
-     * @stable ICU 2.4
-     */
-    void setMaximumContextLength(int32_t maxContextLength);
-
-public:
-
-    /**
-     * Returns a programmatic identifier for this transliterator.
-     * If this identifier is passed to <code>createInstance()</code>, it
-     * will return this object, if it has been registered.
-     * @return a programmatic identifier for this transliterator.
-     * @see #registerInstance
-     * @see #registerFactory
-     * @see #getAvailableIDs
-     * @stable ICU 2.0
-     */
-    virtual const UnicodeString& getID(void) const;
-
-    /**
-     * Returns a name for this transliterator that is appropriate for
-     * display to the user in the default locale.  See {@link
-     * #getDisplayName } for details.
-     * @param ID     the string identifier for this transliterator
-     * @param result Output param to receive the display name
-     * @return       A reference to 'result'.
-     * @stable ICU 2.0
-     */
-    static UnicodeString& U_EXPORT2 getDisplayName(const UnicodeString& ID,
-                                         UnicodeString& result);
-
-    /**
-     * Returns a name for this transliterator that is appropriate for
-     * display to the user in the given locale.  This name is taken
-     * from the locale resource data in the standard manner of the
-     * <code>java.text</code> package.
-     *
-     * <p>If no localized names exist in the system resource bundles,
-     * a name is synthesized using a localized
-     * <code>MessageFormat</code> pattern from the resource data.  The
-     * arguments to this pattern are an integer followed by one or two
-     * strings.  The integer is the number of strings, either 1 or 2.
-     * The strings are formed by splitting the ID for this
-     * transliterator at the first '-'.  If there is no '-', then the
-     * entire ID forms the only string.
-     * @param ID       the string identifier for this transliterator
-     * @param inLocale the Locale in which the display name should be
-     *                 localized.
-     * @param result   Output param to receive the display name
-     * @return         A reference to 'result'.
-     * @stable ICU 2.0
-     */
-    static UnicodeString& U_EXPORT2 getDisplayName(const UnicodeString& ID,
-                                         const Locale& inLocale,
-                                         UnicodeString& result);
-
-    /**
-     * Returns the filter used by this transliterator, or <tt>NULL</tt>
-     * if this transliterator uses no filter.
-     * @return the filter used by this transliterator, or <tt>NULL</tt>
-     *         if this transliterator uses no filter.
-     * @stable ICU 2.0
-     */
-    const UnicodeFilter* getFilter(void) const;
-
-    /**
-     * Returns the filter used by this transliterator, or <tt>NULL</tt> if this
-     * transliterator uses no filter.  The caller must eventually delete the
-     * result.  After this call, this transliterator's filter is set to
-     * <tt>NULL</tt>.
-     * @return the filter used by this transliterator, or <tt>NULL</tt> if this
-     *         transliterator uses no filter.
-     * @stable ICU 2.4
-     */
-    UnicodeFilter* orphanFilter(void);
-
-    /**
-     * Changes the filter used by this transliterator.  If the filter
-     * is set to <tt>null</tt> then no filtering will occur.
-     *
-     * <p>Callers must take care if a transliterator is in use by
-     * multiple threads.  The filter should not be changed by one
-     * thread while another thread may be transliterating.
-     * @param adoptedFilter the new filter to be adopted.
-     * @stable ICU 2.0
-     */
-    void adoptFilter(UnicodeFilter* adoptedFilter);
-
-    /**
-     * Returns this transliterator's inverse.  See the class
-     * documentation for details.  This implementation simply inverts
-     * the two entities in the ID and attempts to retrieve the
-     * resulting transliterator.  That is, if <code>getID()</code>
-     * returns "A-B", then this method will return the result of
-     * <code>createInstance("B-A")</code>, or <code>null</code> if that
-     * call fails.
-     *
-     * <p>Subclasses with knowledge of their inverse may wish to
-     * override this method.
-     *
-     * @param status Output param to filled in with a success or an error.
-     * @return a transliterator that is an inverse, not necessarily
-     * exact, of this transliterator, or <code>null</code> if no such
-     * transliterator is registered.
-     * @see #registerInstance
-     * @stable ICU 2.0
-     */
-    Transliterator* createInverse(UErrorCode& status) const;
-
-    /**
-     * Returns a <code>Transliterator</code> object given its ID.
-     * The ID must be either a system transliterator ID or a ID registered
-     * using <code>registerInstance()</code>.
-     *
-     * @param ID a valid ID, as enumerated by <code>getAvailableIDs()</code>
-     * @param dir        either FORWARD or REVERSE.
-     * @param parseError Struct to recieve information on position
-     *                   of error if an error is encountered
-     * @param status     Output param to filled in with a success or an error.
-     * @return A <code>Transliterator</code> object with the given ID
-     * @see #registerInstance
-     * @see #getAvailableIDs
-     * @see #getID
-     * @stable ICU 2.0
-     */
-    static Transliterator* U_EXPORT2 createInstance(const UnicodeString& ID,
-                                          UTransDirection dir,
-                                          UParseError& parseError,
-                                          UErrorCode& status);
-
-    /**
-     * Returns a <code>Transliterator</code> object given its ID.
-     * The ID must be either a system transliterator ID or a ID registered
-     * using <code>registerInstance()</code>.
-     * @param ID a valid ID, as enumerated by <code>getAvailableIDs()</code>
-     * @param dir        either FORWARD or REVERSE.
-     * @param status     Output param to filled in with a success or an error.
-     * @return A <code>Transliterator</code> object with the given ID
-     * @stable ICU 2.0
-     */
-    static Transliterator* U_EXPORT2 createInstance(const UnicodeString& ID,
-                                          UTransDirection dir,
-                                          UErrorCode& status);
-
-    /**
-     * Returns a <code>Transliterator</code> object constructed from
-     * the given rule string.  This will be a RuleBasedTransliterator,
-     * if the rule string contains only rules, or a
-     * CompoundTransliterator, if it contains ID blocks, or a
-     * NullTransliterator, if it contains ID blocks which parse as
-     * empty for the given direction.
-     * @param ID            the id for the transliterator.
-     * @param rules         rules, separated by ';'
-     * @param dir           either FORWARD or REVERSE.
-     * @param parseError    Struct to recieve information on position
-     *                      of error if an error is encountered
-     * @param status        Output param set to success/failure code.
-     * @stable ICU 2.0
-     */
-    static Transliterator* U_EXPORT2 createFromRules(const UnicodeString& ID,
-                                           const UnicodeString& rules,
-                                           UTransDirection dir,
-                                           UParseError& parseError,
-                                           UErrorCode& status);
-
-    /**
-     * Create a rule string that can be passed to createFromRules()
-     * to recreate this transliterator.
-     * @param result the string to receive the rules.  Previous
-     * contents will be deleted.
-     * @param escapeUnprintable if TRUE then convert unprintable
-     * character to their hex escape representations, \\uxxxx or
-     * \\Uxxxxxxxx.  Unprintable characters are those other than
-     * U+000A, U+0020..U+007E.
-     * @stable ICU 2.0
-     */
-    virtual UnicodeString& toRules(UnicodeString& result,
-                                   UBool escapeUnprintable) const;
-
-    /**
-     * Return the number of elements that make up this transliterator.
-     * For example, if the transliterator "NFD;Jamo-Latin;Latin-Greek"
-     * were created, the return value of this method would be 3.
-     *
-     * <p>If this transliterator is not composed of other
-     * transliterators, then this method returns 1.
-     * @return the number of transliterators that compose this
-     * transliterator, or 1 if this transliterator is not composed of
-     * multiple transliterators
-     * @stable ICU 3.0
-     */
-    int32_t countElements() const;
-
-    /**
-     * Return an element that makes up this transliterator.  For
-     * example, if the transliterator "NFD;Jamo-Latin;Latin-Greek"
-     * were created, the return value of this method would be one
-     * of the three transliterator objects that make up that
-     * transliterator: [NFD, Jamo-Latin, Latin-Greek].
-     *
-     * <p>If this transliterator is not composed of other
-     * transliterators, then this method will return a reference to
-     * this transliterator when given the index 0.
-     * @param index a value from 0..countElements()-1 indicating the
-     * transliterator to return
-     * @param ec input-output error code
-     * @return one of the transliterators that makes up this
-     * transliterator, if this transliterator is made up of multiple
-     * transliterators, otherwise a reference to this object if given
-     * an index of 0
-     * @stable ICU 3.0
-     */
-    const Transliterator& getElement(int32_t index, UErrorCode& ec) const;
-
-    /**
-     * Returns the set of all characters that may be modified in the
-     * input text by this Transliterator.  This incorporates this
-     * object's current filter; if the filter is changed, the return
-     * value of this function will change.  The default implementation
-     * returns an empty set.  Some subclasses may override {@link
-     * #handleGetSourceSet } to return a more precise result.  The
-     * return result is approximate in any case and is intended for
-     * use by tests, tools, or utilities.
-     * @param result receives result set; previous contents lost
-     * @return a reference to result
-     * @see #getTargetSet
-     * @see #handleGetSourceSet
-     * @stable ICU 2.4
-     */
-    UnicodeSet& getSourceSet(UnicodeSet& result) const;
-
-    /**
-     * Framework method that returns the set of all characters that
-     * may be modified in the input text by this Transliterator,
-     * ignoring the effect of this object's filter.  The base class
-     * implementation returns the empty set.  Subclasses that wish to
-     * implement this should override this method.
-     * @return the set of characters that this transliterator may
-     * modify.  The set may be modified, so subclasses should return a
-     * newly-created object.
-     * @param result receives result set; previous contents lost
-     * @see #getSourceSet
-     * @see #getTargetSet
-     * @stable ICU 2.4
-     */
-    virtual void handleGetSourceSet(UnicodeSet& result) const;
-
-    /**
-     * Returns the set of all characters that may be generated as
-     * replacement text by this transliterator.  The default
-     * implementation returns the empty set.  Some subclasses may
-     * override this method to return a more precise result.  The
-     * return result is approximate in any case and is intended for
-     * use by tests, tools, or utilities requiring such
-     * meta-information.
-     * @param result receives result set; previous contents lost
-     * @return a reference to result
-     * @see #getTargetSet
-     * @stable ICU 2.4
-     */
-    virtual UnicodeSet& getTargetSet(UnicodeSet& result) const;
-
-public:
-
-    /**
-     * Registers a factory function that creates transliterators of
-     * a given ID.
-     * @param id the ID being registered
-     * @param factory a function pointer that will be copied and
-     * called later when the given ID is passed to createInstance()
-     * @param context a context pointer that will be stored and
-     * later passed to the factory function when an ID matching
-     * the registration ID is being instantiated with this factory.
-     * @stable ICU 2.0
-     */
-    static void U_EXPORT2 registerFactory(const UnicodeString& id,
-                                Factory factory,
-                                Token context);
-
-    /**
-     * Registers an instance <tt>obj</tt> of a subclass of
-     * <code>Transliterator</code> with the system.  When
-     * <tt>createInstance()</tt> is called with an ID string that is
-     * equal to <tt>obj->getID()</tt>, then <tt>obj->clone()</tt> is
-     * returned.
-     *
-     * After this call the Transliterator class owns the adoptedObj
-     * and will delete it.
-     *
-     * @param adoptedObj an instance of subclass of
-     * <code>Transliterator</code> that defines <tt>clone()</tt>
-     * @see #createInstance
-     * @see #registerFactory
-     * @see #unregister
-     * @stable ICU 2.0
-     */
-    static void U_EXPORT2 registerInstance(Transliterator* adoptedObj);
-
-    /**
-     * Registers an ID string as an alias of another ID string.
-     * That is, after calling this function, <tt>createInstance(aliasID)</tt>
-     * will return the same thing as <tt>createInstance(realID)</tt>.
-     * This is generally used to create shorter, more mnemonic aliases
-     * for long compound IDs.
-     *
-     * @param aliasID The new ID being registered.
-     * @param realID The ID that the new ID is to be an alias for.
-     * This can be a compound ID and can include filters and should
-     * refer to transliterators that have already been registered with
-     * the framework, although this isn't checked.
-     * @stable ICU 3.6
-     */
-     static void U_EXPORT2 registerAlias(const UnicodeString& aliasID,
-                                         const UnicodeString& realID);
-
-protected:
-
-    /**
-     * @internal
-     * @param id the ID being registered
-     * @param factory a function pointer that will be copied and
-     * called later when the given ID is passed to createInstance()
-     * @param context a context pointer that will be stored and
-     * later passed to the factory function when an ID matching
-     * the registration ID is being instantiated with this factory.
-     */
-    static void _registerFactory(const UnicodeString& id,
-                                 Factory factory,
-                                 Token context);
-
-    /**
-     * @internal
-     */
-    static void _registerInstance(Transliterator* adoptedObj);
-
-    /**
-     * @internal
-     */
-    static void _registerAlias(const UnicodeString& aliasID, const UnicodeString& realID);
-
-    /**
-     * Register two targets as being inverses of one another.  For
-     * example, calling registerSpecialInverse("NFC", "NFD", true) causes
-     * Transliterator to form the following inverse relationships:
-     *
-     * <pre>NFC => NFD
-     * Any-NFC => Any-NFD
-     * NFD => NFC
-     * Any-NFD => Any-NFC</pre>
-     *
-     * (Without the special inverse registration, the inverse of NFC
-     * would be NFC-Any.)  Note that NFD is shorthand for Any-NFD, but
-     * that the presence or absence of "Any-" is preserved.
-     *
-     * <p>The relationship is symmetrical; registering (a, b) is
-     * equivalent to registering (b, a).
-     *
-     * <p>The relevant IDs must still be registered separately as
-     * factories or classes.
-     *
-     * <p>Only the targets are specified.  Special inverses always
-     * have the form Any-Target1 <=> Any-Target2.  The target should
-     * have canonical casing (the casing desired to be produced when
-     * an inverse is formed) and should contain no whitespace or other
-     * extraneous characters.
-     *
-     * @param target the target against which to register the inverse
-     * @param inverseTarget the inverse of target, that is
-     * Any-target.getInverse() => Any-inverseTarget
-     * @param bidirectional if true, register the reverse relation
-     * as well, that is, Any-inverseTarget.getInverse() => Any-target
-     * @internal
-     */
-    static void _registerSpecialInverse(const UnicodeString& target,
-                                        const UnicodeString& inverseTarget,
-                                        UBool bidirectional);
-
-public:
-
-    /**
-     * Unregisters a transliterator or class.  This may be either
-     * a system transliterator or a user transliterator or class.
-     * Any attempt to construct an unregistered transliterator based
-     * on its ID will fail.
-     *
-     * @param ID the ID of the transliterator or class
-     * @return the <code>Object</code> that was registered with
-     * <code>ID</code>, or <code>null</code> if none was
-     * @see #registerInstance
-     * @see #registerFactory
-     * @stable ICU 2.0
-     */
-    static void U_EXPORT2 unregister(const UnicodeString& ID);
-
-public:
-
-    /**
-     * Return a StringEnumeration over the IDs available at the time of the
-     * call, including user-registered IDs.
-     * @param ec input-output error code
-     * @return a newly-created StringEnumeration over the transliterators
-     * available at the time of the call. The caller should delete this object
-     * when done using it.
-     * @stable ICU 3.0
-     */
-    static StringEnumeration* U_EXPORT2 getAvailableIDs(UErrorCode& ec);
-
-    /**
-     * Return the number of registered source specifiers.
-     * @return the number of registered source specifiers.
-     * @stable ICU 2.0
-     */
-    static int32_t U_EXPORT2 countAvailableSources(void);
-
-    /**
-     * Return a registered source specifier.
-     * @param index which specifier to return, from 0 to n-1, where
-     * n = countAvailableSources()
-     * @param result fill-in paramter to receive the source specifier.
-     * If index is out of range, result will be empty.
-     * @return reference to result
-     * @stable ICU 2.0
-     */
-    static UnicodeString& U_EXPORT2 getAvailableSource(int32_t index,
-                                             UnicodeString& result);
-
-    /**
-     * Return the number of registered target specifiers for a given
-     * source specifier.
-     * @param source the given source specifier.
-     * @return the number of registered target specifiers for a given
-     *         source specifier.
-     * @stable ICU 2.0
-     */
-    static int32_t U_EXPORT2 countAvailableTargets(const UnicodeString& source);
-
-    /**
-     * Return a registered target specifier for a given source.
-     * @param index which specifier to return, from 0 to n-1, where
-     * n = countAvailableTargets(source)
-     * @param source the source specifier
-     * @param result fill-in paramter to receive the target specifier.
-     * If source is invalid or if index is out of range, result will
-     * be empty.
-     * @return reference to result
-     * @stable ICU 2.0
-     */
-    static UnicodeString& U_EXPORT2 getAvailableTarget(int32_t index,
-                                             const UnicodeString& source,
-                                             UnicodeString& result);
-
-    /**
-     * Return the number of registered variant specifiers for a given
-     * source-target pair.
-     * @param source    the source specifiers.
-     * @param target    the target specifiers.
-     * @stable ICU 2.0
-     */
-    static int32_t U_EXPORT2 countAvailableVariants(const UnicodeString& source,
-                                          const UnicodeString& target);
-
-    /**
-     * Return a registered variant specifier for a given source-target
-     * pair.
-     * @param index which specifier to return, from 0 to n-1, where
-     * n = countAvailableVariants(source, target)
-     * @param source the source specifier
-     * @param target the target specifier
-     * @param result fill-in paramter to receive the variant
-     * specifier.  If source is invalid or if target is invalid or if
-     * index is out of range, result will be empty.
-     * @return reference to result
-     * @stable ICU 2.0
-     */
-    static UnicodeString& U_EXPORT2 getAvailableVariant(int32_t index,
-                                              const UnicodeString& source,
-                                              const UnicodeString& target,
-                                              UnicodeString& result);
-
-protected:
-
-    /**
-     * Non-mutexed internal method
-     * @internal
-     */
-    static int32_t _countAvailableSources(void);
-
-    /**
-     * Non-mutexed internal method
-     * @internal
-     */
-    static UnicodeString& _getAvailableSource(int32_t index,
-                                              UnicodeString& result);
-
-    /**
-     * Non-mutexed internal method
-     * @internal
-     */
-    static int32_t _countAvailableTargets(const UnicodeString& source);
-
-    /**
-     * Non-mutexed internal method
-     * @internal
-     */
-    static UnicodeString& _getAvailableTarget(int32_t index,
-                                              const UnicodeString& source,
-                                              UnicodeString& result);
-
-    /**
-     * Non-mutexed internal method
-     * @internal
-     */
-    static int32_t _countAvailableVariants(const UnicodeString& source,
-                                           const UnicodeString& target);
-
-    /**
-     * Non-mutexed internal method
-     * @internal
-     */
-    static UnicodeString& _getAvailableVariant(int32_t index,
-                                               const UnicodeString& source,
-                                               const UnicodeString& target,
-                                               UnicodeString& result);
-
-protected:
-
-    /**
-     * Set the ID of this transliterators.  Subclasses shouldn't do
-     * this, unless the underlying script behavior has changed.
-     * @param id the new id t to be set.
-     * @stable ICU 2.4
-     */
-    void setID(const UnicodeString& id);
-
-public:
-
-    /**
-     * Return the class ID for this class.  This is useful only for
-     * comparing to a return value from getDynamicClassID().
-     * Note that Transliterator is an abstract base class, and therefor
-     * no fully constructed object will  have a dynamic
-     * UCLassID that equals the UClassID returned from
-     * TRansliterator::getStaticClassID().
-     * @return       The class ID for class Transliterator.
-     * @stable ICU 2.0
-     */
-    static UClassID U_EXPORT2 getStaticClassID(void);
-
-    /**
-     * Returns a unique class ID <b>polymorphically</b>.  This method
-     * is to implement a simple version of RTTI, since not all C++
-     * compilers support genuine RTTI.  Polymorphic operator==() and
-     * clone() methods call this method.
-     *
-     * <p>Concrete subclasses of Transliterator must use the
-     *    UOBJECT_DEFINE_RTTI_IMPLEMENTATION macro from
-     *    uobject.h to provide the RTTI functions.
-     *
-     * @return The class ID for this object. All objects of a given
-     * class have the same class ID.  Objects of other classes have
-     * different class IDs.
-     * @stable ICU 2.0
-     */
-    virtual UClassID getDynamicClassID(void) const = 0;
-
-private:
-    static UBool initializeRegistry(UErrorCode &status);
-
-public:
-    /**
-     * Return the number of IDs currently registered with the system.
-     * To retrieve the actual IDs, call getAvailableID(i) with
-     * i from 0 to countAvailableIDs() - 1.
-     * @return the number of IDs currently registered with the system.
-     * @obsolete ICU 3.4 use getAvailableIDs() instead
-     */
-    static int32_t U_EXPORT2 countAvailableIDs(void);
-
-    /**
-     * Return the index-th available ID.  index must be between 0
-     * and countAvailableIDs() - 1, inclusive.  If index is out of
-     * range, the result of getAvailableID(0) is returned.
-     * @param index the given ID index.
-     * @return      the index-th available ID.  index must be between 0
-     *              and countAvailableIDs() - 1, inclusive.  If index is out of
-     *              range, the result of getAvailableID(0) is returned.
-     * @obsolete ICU 3.4 use getAvailableIDs() instead; this function
-     * is not thread safe, since it returns a reference to storage that
-     * may become invalid if another thread calls unregister
-     */
-    static const UnicodeString& U_EXPORT2 getAvailableID(int32_t index);
-};
-
-inline int32_t Transliterator::getMaximumContextLength(void) const {
-    return maximumContextLength;
-}
-
-inline void Transliterator::setID(const UnicodeString& id) {
-    ID = id;
-    // NUL-terminate the ID string, which is a non-aliased copy.
-    ID.append((UChar)0);
-    ID.truncate(ID.length()-1);
-}
-
-inline Transliterator::Token Transliterator::integerToken(int32_t i) {
-    Token t;
-    t.integer = i;
-    return t;
-}
-
-inline Transliterator::Token Transliterator::pointerToken(void* p) {
-    Token t;
-    t.pointer = p;
-    return t;
-}
-
-U_NAMESPACE_END
-
-#endif /* #if !UCONFIG_NO_TRANSLITERATION */
-
-#endif


[12/57] [abbrv] remove couch_collate

Posted by be...@apache.org.
http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/uniset.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/uniset.h b/apps/couch_collate/platform/osx/icu/unicode/uniset.h
deleted file mode 100644
index 7839661..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/uniset.h
+++ /dev/null
@@ -1,1566 +0,0 @@
-/*
-***************************************************************************
-* Copyright (C) 1999-2008, International Business Machines Corporation
-* and others. All Rights Reserved.
-***************************************************************************
-*   Date        Name        Description
-*   10/20/99    alan        Creation.
-***************************************************************************
-*/
-
-#ifndef UNICODESET_H
-#define UNICODESET_H
-
-#include "unicode/unifilt.h"
-#include "unicode/unistr.h"
-#include "unicode/uset.h"
-
-/**
- * \file
- * \brief C++ API: Unicode Set
- */
-
-U_NAMESPACE_BEGIN
-
-class BMPSet;
-class ParsePosition;
-class SymbolTable;
-class UnicodeSetStringSpan;
-class UVector;
-class RuleCharacterIterator;
-
-/**
- * A mutable set of Unicode characters and multicharacter strings.  Objects of this class
- * represent <em>character classes</em> used in regular expressions.
- * A character specifies a subset of Unicode code points.  Legal
- * code points are U+0000 to U+10FFFF, inclusive.
- *
- * <p>The UnicodeSet class is not designed to be subclassed.
- *
- * <p><code>UnicodeSet</code> supports two APIs. The first is the
- * <em>operand</em> API that allows the caller to modify the value of
- * a <code>UnicodeSet</code> object. It conforms to Java 2's
- * <code>java.util.Set</code> interface, although
- * <code>UnicodeSet</code> does not actually implement that
- * interface. All methods of <code>Set</code> are supported, with the
- * modification that they take a character range or single character
- * instead of an <code>Object</code>, and they take a
- * <code>UnicodeSet</code> instead of a <code>Collection</code>.  The
- * operand API may be thought of in terms of boolean logic: a boolean
- * OR is implemented by <code>add</code>, a boolean AND is implemented
- * by <code>retain</code>, a boolean XOR is implemented by
- * <code>complement</code> taking an argument, and a boolean NOT is
- * implemented by <code>complement</code> with no argument.  In terms
- * of traditional set theory function names, <code>add</code> is a
- * union, <code>retain</code> is an intersection, <code>remove</code>
- * is an asymmetric difference, and <code>complement</code> with no
- * argument is a set complement with respect to the superset range
- * <code>MIN_VALUE-MAX_VALUE</code>
- *
- * <p>The second API is the
- * <code>applyPattern()</code>/<code>toPattern()</code> API from the
- * <code>java.text.Format</code>-derived classes.  Unlike the
- * methods that add characters, add categories, and control the logic
- * of the set, the method <code>applyPattern()</code> sets all
- * attributes of a <code>UnicodeSet</code> at once, based on a
- * string pattern.
- *
- * <p><b>Pattern syntax</b></p>
- *
- * Patterns are accepted by the constructors and the
- * <code>applyPattern()</code> methods and returned by the
- * <code>toPattern()</code> method.  These patterns follow a syntax
- * similar to that employed by version 8 regular expression character
- * classes.  Here are some simple examples:
- *
- * \htmlonly<blockquote>\endhtmlonly
- *   <table>
- *     <tr align="top">
- *       <td nowrap valign="top" align="left"><code>[]</code></td>
- *       <td valign="top">No characters</td>
- *     </tr><tr align="top">
- *       <td nowrap valign="top" align="left"><code>[a]</code></td>
- *       <td valign="top">The character 'a'</td>
- *     </tr><tr align="top">
- *       <td nowrap valign="top" align="left"><code>[ae]</code></td>
- *       <td valign="top">The characters 'a' and 'e'</td>
- *     </tr>
- *     <tr>
- *       <td nowrap valign="top" align="left"><code>[a-e]</code></td>
- *       <td valign="top">The characters 'a' through 'e' inclusive, in Unicode code
- *       point order</td>
- *     </tr>
- *     <tr>
- *       <td nowrap valign="top" align="left"><code>[\\u4E01]</code></td>
- *       <td valign="top">The character U+4E01</td>
- *     </tr>
- *     <tr>
- *       <td nowrap valign="top" align="left"><code>[a{ab}{ac}]</code></td>
- *       <td valign="top">The character 'a' and the multicharacter strings &quot;ab&quot; and
- *       &quot;ac&quot;</td>
- *     </tr>
- *     <tr>
- *       <td nowrap valign="top" align="left"><code>[\\p{Lu}]</code></td>
- *       <td valign="top">All characters in the general category Uppercase Letter</td>
- *     </tr>
- *   </table>
- * \htmlonly</blockquote>\endhtmlonly
- *
- * Any character may be preceded by a backslash in order to remove any special
- * meaning.  White space characters, as defined by UCharacter.isWhitespace(), are
- * ignored, unless they are escaped.
- *
- * <p>Property patterns specify a set of characters having a certain
- * property as defined by the Unicode standard.  Both the POSIX-like
- * "[:Lu:]" and the Perl-like syntax "\\p{Lu}" are recognized.  For a
- * complete list of supported property patterns, see the User's Guide
- * for UnicodeSet at
- * <a href="http://icu-project.org/userguide/unicodeSet.html">
- * http://icu-project.org/userguide/unicodeSet.html</a>.
- * Actual determination of property data is defined by the underlying
- * Unicode database as implemented by UCharacter.
- *
- * <p>Patterns specify individual characters, ranges of characters, and
- * Unicode property sets.  When elements are concatenated, they
- * specify their union.  To complement a set, place a '^' immediately
- * after the opening '['.  Property patterns are inverted by modifying
- * their delimiters; "[:^foo]" and "\\P{foo}".  In any other location,
- * '^' has no special meaning.
- *
- * <p>Ranges are indicated by placing two a '-' between two
- * characters, as in "a-z".  This specifies the range of all
- * characters from the left to the right, in Unicode order.  If the
- * left character is greater than or equal to the
- * right character it is a syntax error.  If a '-' occurs as the first
- * character after the opening '[' or '[^', or if it occurs as the
- * last character before the closing ']', then it is taken as a
- * literal.  Thus "[a\-b]", "[-ab]", and "[ab-]" all indicate the same
- * set of three characters, 'a', 'b', and '-'.
- *
- * <p>Sets may be intersected using the '&' operator or the asymmetric
- * set difference may be taken using the '-' operator, for example,
- * "[[:L:]&[\\u0000-\\u0FFF]]" indicates the set of all Unicode letters
- * with values less than 4096.  Operators ('&' and '|') have equal
- * precedence and bind left-to-right.  Thus
- * "[[:L:]-[a-z]-[\\u0100-\\u01FF]]" is equivalent to
- * "[[[:L:]-[a-z]]-[\\u0100-\\u01FF]]".  This only really matters for
- * difference; intersection is commutative.
- *
- * <table>
- * <tr valign=top><td nowrap><code>[a]</code><td>The set containing 'a'
- * <tr valign=top><td nowrap><code>[a-z]</code><td>The set containing 'a'
- * through 'z' and all letters in between, in Unicode order
- * <tr valign=top><td nowrap><code>[^a-z]</code><td>The set containing
- * all characters but 'a' through 'z',
- * that is, U+0000 through 'a'-1 and 'z'+1 through U+10FFFF
- * <tr valign=top><td nowrap><code>[[<em>pat1</em>][<em>pat2</em>]]</code>
- * <td>The union of sets specified by <em>pat1</em> and <em>pat2</em>
- * <tr valign=top><td nowrap><code>[[<em>pat1</em>]&[<em>pat2</em>]]</code>
- * <td>The intersection of sets specified by <em>pat1</em> and <em>pat2</em>
- * <tr valign=top><td nowrap><code>[[<em>pat1</em>]-[<em>pat2</em>]]</code>
- * <td>The asymmetric difference of sets specified by <em>pat1</em> and
- * <em>pat2</em>
- * <tr valign=top><td nowrap><code>[:Lu:] or \\p{Lu}</code>
- * <td>The set of characters having the specified
- * Unicode property; in
- * this case, Unicode uppercase letters
- * <tr valign=top><td nowrap><code>[:^Lu:] or \\P{Lu}</code>
- * <td>The set of characters <em>not</em> having the given
- * Unicode property
- * </table>
- *
- * <p><b>Warning</b>: you cannot add an empty string ("") to a UnicodeSet.</p>
- *
- * <p><b>Formal syntax</b></p>
- *
- * \htmlonly<blockquote>\endhtmlonly
- *   <table>
- *     <tr align="top">
- *       <td nowrap valign="top" align="right"><code>pattern :=&nbsp; </code></td>
- *       <td valign="top"><code>('[' '^'? item* ']') |
- *       property</code></td>
- *     </tr>
- *     <tr align="top">
- *       <td nowrap valign="top" align="right"><code>item :=&nbsp; </code></td>
- *       <td valign="top"><code>char | (char '-' char) | pattern-expr<br>
- *       </code></td>
- *     </tr>
- *     <tr align="top">
- *       <td nowrap valign="top" align="right"><code>pattern-expr :=&nbsp; </code></td>
- *       <td valign="top"><code>pattern | pattern-expr pattern |
- *       pattern-expr op pattern<br>
- *       </code></td>
- *     </tr>
- *     <tr align="top">
- *       <td nowrap valign="top" align="right"><code>op :=&nbsp; </code></td>
- *       <td valign="top"><code>'&amp;' | '-'<br>
- *       </code></td>
- *     </tr>
- *     <tr align="top">
- *       <td nowrap valign="top" align="right"><code>special :=&nbsp; </code></td>
- *       <td valign="top"><code>'[' | ']' | '-'<br>
- *       </code></td>
- *     </tr>
- *     <tr align="top">
- *       <td nowrap valign="top" align="right"><code>char :=&nbsp; </code></td>
- *       <td valign="top"><em>any character that is not</em><code> special<br>
- *       | ('\' </code><em>any character</em><code>)<br>
- *       | ('\\u' hex hex hex hex)<br>
- *       </code></td>
- *     </tr>
- *     <tr align="top">
- *       <td nowrap valign="top" align="right"><code>hex :=&nbsp; </code></td>
- *       <td valign="top"><em>any character for which
- *       </em><code>Character.digit(c, 16)</code><em>
- *       returns a non-negative result</em></td>
- *     </tr>
- *     <tr>
- *       <td nowrap valign="top" align="right"><code>property :=&nbsp; </code></td>
- *       <td valign="top"><em>a Unicode property set pattern</em></td>
- *     </tr>
- *   </table>
- *   <br>
- *   <table border="1">
- *     <tr>
- *       <td>Legend: <table>
- *         <tr>
- *           <td nowrap valign="top"><code>a := b</code></td>
- *           <td width="20" valign="top">&nbsp; </td>
- *           <td valign="top"><code>a</code> may be replaced by <code>b</code> </td>
- *         </tr>
- *         <tr>
- *           <td nowrap valign="top"><code>a?</code></td>
- *           <td valign="top"></td>
- *           <td valign="top">zero or one instance of <code>a</code><br>
- *           </td>
- *         </tr>
- *         <tr>
- *           <td nowrap valign="top"><code>a*</code></td>
- *           <td valign="top"></td>
- *           <td valign="top">one or more instances of <code>a</code><br>
- *           </td>
- *         </tr>
- *         <tr>
- *           <td nowrap valign="top"><code>a | b</code></td>
- *           <td valign="top"></td>
- *           <td valign="top">either <code>a</code> or <code>b</code><br>
- *           </td>
- *         </tr>
- *         <tr>
- *           <td nowrap valign="top"><code>'a'</code></td>
- *           <td valign="top"></td>
- *           <td valign="top">the literal string between the quotes </td>
- *         </tr>
- *       </table>
- *       </td>
- *     </tr>
- *   </table>
- * \htmlonly</blockquote>\endhtmlonly
- * 
- * <p>Note:
- *  - Most UnicodeSet methods do not take a UErrorCode parameter because
- *   there are usually very few opportunities for failure other than a shortage
- *   of memory, error codes in low-level C++ string methods would be inconvenient,
- *   and the error code as the last parameter (ICU convention) would prevent
- *   the use of default parameter values.
- *   Instead, such methods set the UnicodeSet into a "bogus" state
- *   (see isBogus()) if an error occurs.
- *
- * @author Alan Liu
- * @stable ICU 2.0
- */
-class U_COMMON_API UnicodeSet : public UnicodeFilter {
-
-    int32_t len; // length of list used; 0 <= len <= capacity
-    int32_t capacity; // capacity of list
-    UChar32* list; // MUST be terminated with HIGH
-    BMPSet *bmpSet; // The set is frozen iff either bmpSet or stringSpan is not NULL.
-    UChar32* buffer; // internal buffer, may be NULL
-    int32_t bufferCapacity; // capacity of buffer
-    int32_t patLen;
-
-    /**
-     * The pattern representation of this set.  This may not be the
-     * most economical pattern.  It is the pattern supplied to
-     * applyPattern(), with variables substituted and whitespace
-     * removed.  For sets constructed without applyPattern(), or
-     * modified using the non-pattern API, this string will be empty,
-     * indicating that toPattern() must generate a pattern
-     * representation from the inversion list.
-     */
-    UChar *pat;
-    UVector* strings; // maintained in sorted order
-    UnicodeSetStringSpan *stringSpan;
-
-private:
-    enum { // constants
-        kIsBogus = 1       // This set is bogus (i.e. not valid)
-    };
-    uint8_t fFlags;         // Bit flag (see constants above)
-public:
-    /**
-     * Determine if this object contains a valid set.
-     * A bogus set has no value. It is different from an empty set.
-     * It can be used to indicate that no set value is available.
-     *
-     * @return TRUE if the set is valid, FALSE otherwise
-     * @see setToBogus()
-     * @draft ICU 4.0
-     */
-    inline UBool isBogus(void) const;
-    
-    /**
-     * Make this UnicodeSet object invalid.
-     * The string will test TRUE with isBogus().
-     *
-     * A bogus set has no value. It is different from an empty set.
-     * It can be used to indicate that no set value is available.
-     *
-     * This utility function is used throughout the UnicodeSet
-     * implementation to indicate that a UnicodeSet operation failed,
-     * and may be used in other functions,
-     * especially but not exclusively when such functions do not
-     * take a UErrorCode for simplicity.
-     *
-     * @see isBogus()
-     * @draft ICU 4.0
-     */
-    void setToBogus();
-
-public:
-
-    enum {
-        /**
-         * Minimum value that can be stored in a UnicodeSet.
-         * @stable ICU 2.4
-         */
-        MIN_VALUE = 0,
-
-        /**
-         * Maximum value that can be stored in a UnicodeSet.
-         * @stable ICU 2.4
-         */
-        MAX_VALUE = 0x10ffff
-    };
-
-    //----------------------------------------------------------------
-    // Constructors &c
-    //----------------------------------------------------------------
-
-public:
-
-    /**
-     * Constructs an empty set.
-     * @stable ICU 2.0
-     */
-    UnicodeSet();
-
-    /**
-     * Constructs a set containing the given range. If <code>end >
-     * start</code> then an empty set is created.
-     *
-     * @param start first character, inclusive, of range
-     * @param end last character, inclusive, of range
-     * @stable ICU 2.4
-     */
-    UnicodeSet(UChar32 start, UChar32 end);
-
-    /**
-     * Constructs a set from the given pattern.  See the class
-     * description for the syntax of the pattern language.
-     * @param pattern a string specifying what characters are in the set
-     * @param status returns <code>U_ILLEGAL_ARGUMENT_ERROR</code> if the pattern
-     * contains a syntax error.
-     * @stable ICU 2.0
-     */
-    UnicodeSet(const UnicodeString& pattern,
-               UErrorCode& status);
-
-    /**
-     * Constructs a set from the given pattern.  See the class
-     * description for the syntax of the pattern language.
-     * @param pattern a string specifying what characters are in the set
-     * @param options bitmask for options to apply to the pattern.
-     * Valid options are USET_IGNORE_SPACE and USET_CASE_INSENSITIVE.
-     * @param symbols a symbol table mapping variable names to values
-     * and stand-in characters to UnicodeSets; may be NULL
-     * @param status returns <code>U_ILLEGAL_ARGUMENT_ERROR</code> if the pattern
-     * contains a syntax error.
-     * @internal
-     */
-    UnicodeSet(const UnicodeString& pattern,
-               uint32_t options,
-               const SymbolTable* symbols,
-               UErrorCode& status);
-
-    /**
-     * Constructs a set from the given pattern.  See the class description
-     * for the syntax of the pattern language.
-     * @param pattern a string specifying what characters are in the set
-     * @param pos on input, the position in pattern at which to start parsing.
-     * On output, the position after the last character parsed.
-     * @param options bitmask for options to apply to the pattern.
-     * Valid options are USET_IGNORE_SPACE and USET_CASE_INSENSITIVE.
-     * @param symbols a symbol table mapping variable names to values
-     * and stand-in characters to UnicodeSets; may be NULL
-     * @param status input-output error code
-     * @stable ICU 2.8
-     */
-    UnicodeSet(const UnicodeString& pattern, ParsePosition& pos,
-               uint32_t options,
-               const SymbolTable* symbols,
-               UErrorCode& status);
-
-    /**
-     * Constructs a set that is identical to the given UnicodeSet.
-     * @stable ICU 2.0
-     */
-    UnicodeSet(const UnicodeSet& o);
-
-    /**
-     * Destructs the set.
-     * @stable ICU 2.0
-     */
-    virtual ~UnicodeSet();
-
-    /**
-     * Assigns this object to be a copy of another.
-     * A frozen set will not be modified.
-     * @stable ICU 2.0
-     */
-    UnicodeSet& operator=(const UnicodeSet& o);
-
-    /**
-     * Compares the specified object with this set for equality.  Returns
-     * <tt>true</tt> if the two sets
-     * have the same size, and every member of the specified set is
-     * contained in this set (or equivalently, every member of this set is
-     * contained in the specified set).
-     *
-     * @param o set to be compared for equality with this set.
-     * @return <tt>true</tt> if the specified set is equal to this set.
-     * @stable ICU 2.0
-     */
-    virtual UBool operator==(const UnicodeSet& o) const;
-
-    /**
-     * Compares the specified object with this set for equality.  Returns
-     * <tt>true</tt> if the specified set is not equal to this set.
-     * @stable ICU 2.0
-     */
-    UBool operator!=(const UnicodeSet& o) const;
-
-    /**
-     * Returns a copy of this object.  All UnicodeFunctor objects have
-     * to support cloning in order to allow classes using
-     * UnicodeFunctors, such as Transliterator, to implement cloning.
-     * If this set is frozen, then the clone will be frozen as well.
-     * Use cloneAsThawed() for a mutable clone of a frozen set.
-     * @see cloneAsThawed
-     * @stable ICU 2.0
-     */
-    virtual UnicodeFunctor* clone() const;
-
-    /**
-     * Returns the hash code value for this set.
-     *
-     * @return the hash code value for this set.
-     * @see Object#hashCode()
-     * @stable ICU 2.0
-     */
-    virtual int32_t hashCode(void) const;
-
-    //----------------------------------------------------------------
-    // Freezable API
-    //----------------------------------------------------------------
-
-    /**
-     * Determines whether the set has been frozen (made immutable) or not.
-     * See the ICU4J Freezable interface for details.
-     * @return TRUE/FALSE for whether the set has been frozen
-     * @see freeze
-     * @see cloneAsThawed
-     * @stable ICU 4.0
-     */
-    inline UBool isFrozen() const;
-
-    /**
-     * Freeze the set (make it immutable).
-     * Once frozen, it cannot be unfrozen and is therefore thread-safe
-     * until it is deleted.
-     * See the ICU4J Freezable interface for details.
-     * Freezing the set may also make some operations faster, for example
-     * contains() and span().
-     * A frozen set will not be modified. (It remains frozen.)
-     * @return this set.
-     * @see isFrozen
-     * @see cloneAsThawed
-     * @stable ICU 4.0
-     */
-    UnicodeFunctor *freeze();
-
-    /**
-     * Clone the set and make the clone mutable.
-     * See the ICU4J Freezable interface for details.
-     * @return the mutable clone
-     * @see freeze
-     * @see isFrozen
-     * @stable ICU 4.0
-     */
-    UnicodeFunctor *cloneAsThawed() const;
-
-    //----------------------------------------------------------------
-    // Public API
-    //----------------------------------------------------------------
-
-    /**
-     * Make this object represent the range <code>start - end</code>.
-     * If <code>end > start</code> then this object is set to an
-     * an empty range.
-     * A frozen set will not be modified.
-     *
-     * @param start first character in the set, inclusive
-     * @param end last character in the set, inclusive
-     * @stable ICU 2.4
-     */
-    UnicodeSet& set(UChar32 start, UChar32 end);
-
-    /**
-     * Return true if the given position, in the given pattern, appears
-     * to be the start of a UnicodeSet pattern.
-     * @stable ICU 2.4
-     */
-    static UBool resemblesPattern(const UnicodeString& pattern,
-                                  int32_t pos);
-
-    /**
-     * Modifies this set to represent the set specified by the given
-     * pattern, optionally ignoring white space.  See the class
-     * description for the syntax of the pattern language.
-     * A frozen set will not be modified.
-     * @param pattern a string specifying what characters are in the set
-     * @param status returns <code>U_ILLEGAL_ARGUMENT_ERROR</code> if the pattern
-     * contains a syntax error.
-     * <em> Empties the set passed before applying the pattern.</em>
-     * @return a reference to this
-     * @stable ICU 2.0
-     */
-    UnicodeSet& applyPattern(const UnicodeString& pattern,
-                             UErrorCode& status);
-
-    /**
-     * Modifies this set to represent the set specified by the given
-     * pattern, optionally ignoring white space.  See the class
-     * description for the syntax of the pattern language.
-     * A frozen set will not be modified.
-     * @param pattern a string specifying what characters are in the set
-     * @param options bitmask for options to apply to the pattern.
-     * Valid options are USET_IGNORE_SPACE and USET_CASE_INSENSITIVE.
-     * @param symbols a symbol table mapping variable names to
-     * values and stand-ins to UnicodeSets; may be NULL
-     * @param status returns <code>U_ILLEGAL_ARGUMENT_ERROR</code> if the pattern
-     * contains a syntax error.
-     *<em> Empties the set passed before applying the pattern.</em>
-     * @return a reference to this
-     * @internal
-     */
-    UnicodeSet& applyPattern(const UnicodeString& pattern,
-                             uint32_t options,
-                             const SymbolTable* symbols,
-                             UErrorCode& status);
-
-    /**
-     * Parses the given pattern, starting at the given position.  The
-     * character at pattern.charAt(pos.getIndex()) must be '[', or the
-     * parse fails.  Parsing continues until the corresponding closing
-     * ']'.  If a syntax error is encountered between the opening and
-     * closing brace, the parse fails.  Upon return from a successful
-     * parse, the ParsePosition is updated to point to the character
-     * following the closing ']', and a StringBuffer containing a
-     * pairs list for the parsed pattern is returned.  This method calls
-     * itself recursively to parse embedded subpatterns.
-     *<em> Empties the set passed before applying the pattern.</em>
-     * A frozen set will not be modified.
-     *
-     * @param pattern the string containing the pattern to be parsed.
-     * The portion of the string from pos.getIndex(), which must be a
-     * '[', to the corresponding closing ']', is parsed.
-     * @param pos upon entry, the position at which to being parsing.
-     * The character at pattern.charAt(pos.getIndex()) must be a '['.
-     * Upon return from a successful parse, pos.getIndex() is either
-     * the character after the closing ']' of the parsed pattern, or
-     * pattern.length() if the closing ']' is the last character of
-     * the pattern string.
-     * @param options bitmask for options to apply to the pattern.
-     * Valid options are USET_IGNORE_SPACE and USET_CASE_INSENSITIVE.
-     * @param symbols a symbol table mapping variable names to
-     * values and stand-ins to UnicodeSets; may be NULL
-     * @param status returns <code>U_ILLEGAL_ARGUMENT_ERROR</code> if the pattern
-     * contains a syntax error.
-     * @return a reference to this
-     * @stable ICU 2.8
-     */
-    UnicodeSet& applyPattern(const UnicodeString& pattern,
-                             ParsePosition& pos,
-                             uint32_t options,
-                             const SymbolTable* symbols,
-                             UErrorCode& status);
-
-    /**
-     * Returns a string representation of this set.  If the result of
-     * calling this function is passed to a UnicodeSet constructor, it
-     * will produce another set that is equal to this one.
-     * A frozen set will not be modified.
-     * @param result the string to receive the rules.  Previous
-     * contents will be deleted.
-     * @param escapeUnprintable if TRUE then convert unprintable
-     * character to their hex escape representations, \\uxxxx or
-     * \\Uxxxxxxxx.  Unprintable characters are those other than
-     * U+000A, U+0020..U+007E.
-     * @stable ICU 2.0
-     */
-    virtual UnicodeString& toPattern(UnicodeString& result,
-                             UBool escapeUnprintable = FALSE) const;
-
-    /**
-     * Modifies this set to contain those code points which have the given value
-     * for the given binary or enumerated property, as returned by
-     * u_getIntPropertyValue.  Prior contents of this set are lost.
-     * A frozen set will not be modified.
-     *
-     * @param prop a property in the range UCHAR_BIN_START..UCHAR_BIN_LIMIT-1
-     * or UCHAR_INT_START..UCHAR_INT_LIMIT-1
-     * or UCHAR_MASK_START..UCHAR_MASK_LIMIT-1.
-     *
-     * @param value a value in the range u_getIntPropertyMinValue(prop)..
-     * u_getIntPropertyMaxValue(prop), with one exception.  If prop is
-     * UCHAR_GENERAL_CATEGORY_MASK, then value should not be a UCharCategory, but
-     * rather a mask value produced by U_GET_GC_MASK().  This allows grouped
-     * categories such as [:L:] to be represented.
-     *
-     * @param ec error code input/output parameter
-     *
-     * @return a reference to this set
-     *
-     * @stable ICU 2.4
-     */
-    UnicodeSet& applyIntPropertyValue(UProperty prop,
-                                      int32_t value,
-                                      UErrorCode& ec);
-
-    /**
-     * Modifies this set to contain those code points which have the
-     * given value for the given property.  Prior contents of this
-     * set are lost.
-     * A frozen set will not be modified.
-     *
-     * @param prop a property alias, either short or long.  The name is matched
-     * loosely.  See PropertyAliases.txt for names and a description of loose
-     * matching.  If the value string is empty, then this string is interpreted
-     * as either a General_Category value alias, a Script value alias, a binary
-     * property alias, or a special ID.  Special IDs are matched loosely and
-     * correspond to the following sets:
-     *
-     * "ANY" = [\\u0000-\\U0010FFFF],
-     * "ASCII" = [\\u0000-\\u007F],
-     * "Assigned" = [:^Cn:].
-     *
-     * @param value a value alias, either short or long.  The name is matched
-     * loosely.  See PropertyValueAliases.txt for names and a description of
-     * loose matching.  In addition to aliases listed, numeric values and
-     * canonical combining classes may be expressed numerically, e.g., ("nv",
-     * "0.5") or ("ccc", "220").  The value string may also be empty.
-     *
-     * @param ec error code input/output parameter
-     *
-     * @return a reference to this set
-     *
-     * @stable ICU 2.4
-     */
-    UnicodeSet& applyPropertyAlias(const UnicodeString& prop,
-                                   const UnicodeString& value,
-                                   UErrorCode& ec);
-
-    /**
-     * Returns the number of elements in this set (its cardinality).
-     * Note than the elements of a set may include both individual
-     * codepoints and strings.
-     *
-     * @return the number of elements in this set (its cardinality).
-     * @stable ICU 2.0
-     */
-    virtual int32_t size(void) const;
-
-    /**
-     * Returns <tt>true</tt> if this set contains no elements.
-     *
-     * @return <tt>true</tt> if this set contains no elements.
-     * @stable ICU 2.0
-     */
-    virtual UBool isEmpty(void) const;
-
-    /**
-     * Returns true if this set contains the given character.
-     * This function works faster with a frozen set.
-     * @param c character to be checked for containment
-     * @return true if the test condition is met
-     * @stable ICU 2.0
-     */
-    virtual UBool contains(UChar32 c) const;
-
-    /**
-     * Returns true if this set contains every character
-     * of the given range.
-     * @param start first character, inclusive, of the range
-     * @param end last character, inclusive, of the range
-     * @return true if the test condition is met
-     * @stable ICU 2.0
-     */
-    virtual UBool contains(UChar32 start, UChar32 end) const;
-
-    /**
-     * Returns <tt>true</tt> if this set contains the given
-     * multicharacter string.
-     * @param s string to be checked for containment
-     * @return <tt>true</tt> if this set contains the specified string
-     * @stable ICU 2.4
-     */
-    UBool contains(const UnicodeString& s) const;
-
-    /**
-     * Returns true if this set contains all the characters and strings
-     * of the given set.
-     * @param c set to be checked for containment
-     * @return true if the test condition is met
-     * @stable ICU 2.4
-     */
-    virtual UBool containsAll(const UnicodeSet& c) const;
-
-    /**
-     * Returns true if this set contains all the characters
-     * of the given string.
-     * @param s string containing characters to be checked for containment
-     * @return true if the test condition is met
-     * @stable ICU 2.4
-     */
-    UBool containsAll(const UnicodeString& s) const;
-
-    /**
-     * Returns true if this set contains none of the characters
-     * of the given range.
-     * @param start first character, inclusive, of the range
-     * @param end last character, inclusive, of the range
-     * @return true if the test condition is met
-     * @stable ICU 2.4
-     */
-    UBool containsNone(UChar32 start, UChar32 end) const;
-
-    /**
-     * Returns true if this set contains none of the characters and strings
-     * of the given set.
-     * @param c set to be checked for containment
-     * @return true if the test condition is met
-     * @stable ICU 2.4
-     */
-    UBool containsNone(const UnicodeSet& c) const;
-
-    /**
-     * Returns true if this set contains none of the characters
-     * of the given string.
-     * @param s string containing characters to be checked for containment
-     * @return true if the test condition is met
-     * @stable ICU 2.4
-     */
-    UBool containsNone(const UnicodeString& s) const;
-
-    /**
-     * Returns true if this set contains one or more of the characters
-     * in the given range.
-     * @param start first character, inclusive, of the range
-     * @param end last character, inclusive, of the range
-     * @return true if the condition is met
-     * @stable ICU 2.4
-     */
-    inline UBool containsSome(UChar32 start, UChar32 end) const;
-
-    /**
-     * Returns true if this set contains one or more of the characters
-     * and strings of the given set.
-     * @param s The set to be checked for containment
-     * @return true if the condition is met
-     * @stable ICU 2.4
-     */
-    inline UBool containsSome(const UnicodeSet& s) const;
-
-    /**
-     * Returns true if this set contains one or more of the characters
-     * of the given string.
-     * @param s string containing characters to be checked for containment
-     * @return true if the condition is met
-     * @stable ICU 2.4
-     */
-    inline UBool containsSome(const UnicodeString& s) const;
-
-    /**
-     * Returns the length of the initial substring of the input string which
-     * consists only of characters and strings that are contained in this set
-     * (USET_SPAN_CONTAINED, USET_SPAN_SIMPLE),
-     * or only of characters and strings that are not contained
-     * in this set (USET_SPAN_NOT_CONTAINED).
-     * See USetSpanCondition for details.
-     * Similar to the strspn() C library function.
-     * Unpaired surrogates are treated according to contains() of their surrogate code points.
-     * This function works faster with a frozen set and with a non-negative string length argument.
-     * @param s start of the string
-     * @param length of the string; can be -1 for NUL-terminated
-     * @param spanCondition specifies the containment condition
-     * @return the length of the initial substring according to the spanCondition;
-     *         0 if the start of the string does not fit the spanCondition
-     * @stable ICU 4.0
-     * @see USetSpanCondition
-     */
-    int32_t span(const UChar *s, int32_t length, USetSpanCondition spanCondition) const;
-
-    /**
-     * Returns the start of the trailing substring of the input string which
-     * consists only of characters and strings that are contained in this set
-     * (USET_SPAN_CONTAINED, USET_SPAN_SIMPLE),
-     * or only of characters and strings that are not contained
-     * in this set (USET_SPAN_NOT_CONTAINED).
-     * See USetSpanCondition for details.
-     * Unpaired surrogates are treated according to contains() of their surrogate code points.
-     * This function works faster with a frozen set and with a non-negative string length argument.
-     * @param s start of the string
-     * @param length of the string; can be -1 for NUL-terminated
-     * @param spanCondition specifies the containment condition
-     * @return the start of the trailing substring according to the spanCondition;
-     *         the string length if the end of the string does not fit the spanCondition
-     * @stable ICU 4.0
-     * @see USetSpanCondition
-     */
-    int32_t spanBack(const UChar *s, int32_t length, USetSpanCondition spanCondition) const;
-
-    /**
-     * Returns the length of the initial substring of the input string which
-     * consists only of characters and strings that are contained in this set
-     * (USET_SPAN_CONTAINED, USET_SPAN_SIMPLE),
-     * or only of characters and strings that are not contained
-     * in this set (USET_SPAN_NOT_CONTAINED).
-     * See USetSpanCondition for details.
-     * Similar to the strspn() C library function.
-     * Malformed byte sequences are treated according to contains(0xfffd).
-     * This function works faster with a frozen set and with a non-negative string length argument.
-     * @param s start of the string (UTF-8)
-     * @param length of the string; can be -1 for NUL-terminated
-     * @param spanCondition specifies the containment condition
-     * @return the length of the initial substring according to the spanCondition;
-     *         0 if the start of the string does not fit the spanCondition
-     * @stable ICU 4.0
-     * @see USetSpanCondition
-     */
-    int32_t spanUTF8(const char *s, int32_t length, USetSpanCondition spanCondition) const;
-
-    /**
-     * Returns the start of the trailing substring of the input string which
-     * consists only of characters and strings that are contained in this set
-     * (USET_SPAN_CONTAINED, USET_SPAN_SIMPLE),
-     * or only of characters and strings that are not contained
-     * in this set (USET_SPAN_NOT_CONTAINED).
-     * See USetSpanCondition for details.
-     * Malformed byte sequences are treated according to contains(0xfffd).
-     * This function works faster with a frozen set and with a non-negative string length argument.
-     * @param s start of the string (UTF-8)
-     * @param length of the string; can be -1 for NUL-terminated
-     * @param spanCondition specifies the containment condition
-     * @return the start of the trailing substring according to the spanCondition;
-     *         the string length if the end of the string does not fit the spanCondition
-     * @stable ICU 4.0
-     * @see USetSpanCondition
-     */
-    int32_t spanBackUTF8(const char *s, int32_t length, USetSpanCondition spanCondition) const;
-
-    /**
-     * Implement UnicodeMatcher::matches()
-     * @stable ICU 2.4
-     */
-    virtual UMatchDegree matches(const Replaceable& text,
-                         int32_t& offset,
-                         int32_t limit,
-                         UBool incremental);
-
-private:
-    /**
-     * Returns the longest match for s in text at the given position.
-     * If limit > start then match forward from start+1 to limit
-     * matching all characters except s.charAt(0).  If limit < start,
-     * go backward starting from start-1 matching all characters
-     * except s.charAt(s.length()-1).  This method assumes that the
-     * first character, text.charAt(start), matches s, so it does not
-     * check it.
-     * @param text the text to match
-     * @param start the first character to match.  In the forward
-     * direction, text.charAt(start) is matched against s.charAt(0).
-     * In the reverse direction, it is matched against
-     * s.charAt(s.length()-1).
-     * @param limit the limit offset for matching, either last+1 in
-     * the forward direction, or last-1 in the reverse direction,
-     * where last is the index of the last character to match.
-     * @return If part of s matches up to the limit, return |limit -
-     * start|.  If all of s matches before reaching the limit, return
-     * s.length().  If there is a mismatch between s and text, return
-     * 0
-     */
-    static int32_t matchRest(const Replaceable& text,
-                             int32_t start, int32_t limit,
-                             const UnicodeString& s);
-
-    /**
-     * Returns the smallest value i such that c < list[i].  Caller
-     * must ensure that c is a legal value or this method will enter
-     * an infinite loop.  This method performs a binary search.
-     * @param c a character in the range MIN_VALUE..MAX_VALUE
-     * inclusive
-     * @return the smallest integer i in the range 0..len-1,
-     * inclusive, such that c < list[i]
-     */
-    int32_t findCodePoint(UChar32 c) const;
-
-public:
-
-    /**
-     * Implementation of UnicodeMatcher API.  Union the set of all
-     * characters that may be matched by this object into the given
-     * set.
-     * @param toUnionTo the set into which to union the source characters
-     * @stable ICU 2.4
-     */
-    virtual void addMatchSetTo(UnicodeSet& toUnionTo) const;
-
-    /**
-     * Returns the index of the given character within this set, where
-     * the set is ordered by ascending code point.  If the character
-     * is not in this set, return -1.  The inverse of this method is
-     * <code>charAt()</code>.
-     * @return an index from 0..size()-1, or -1
-     * @stable ICU 2.4
-     */
-    int32_t indexOf(UChar32 c) const;
-
-    /**
-     * Returns the character at the given index within this set, where
-     * the set is ordered by ascending code point.  If the index is
-     * out of range, return (UChar32)-1.  The inverse of this method is
-     * <code>indexOf()</code>.
-     * @param index an index from 0..size()-1
-     * @return the character at the given index, or (UChar32)-1.
-     * @stable ICU 2.4
-     */
-    UChar32 charAt(int32_t index) const;
-
-    /**
-     * Adds the specified range to this set if it is not already
-     * present.  If this set already contains the specified range,
-     * the call leaves this set unchanged.  If <code>end > start</code>
-     * then an empty range is added, leaving the set unchanged.
-     * This is equivalent to a boolean logic OR, or a set UNION.
-     * A frozen set will not be modified.
-     *
-     * @param start first character, inclusive, of range to be added
-     * to this set.
-     * @param end last character, inclusive, of range to be added
-     * to this set.
-     * @stable ICU 2.0
-     */
-    virtual UnicodeSet& add(UChar32 start, UChar32 end);
-
-    /**
-     * Adds the specified character to this set if it is not already
-     * present.  If this set already contains the specified character,
-     * the call leaves this set unchanged.
-     * A frozen set will not be modified.
-     * @stable ICU 2.0
-     */
-    UnicodeSet& add(UChar32 c);
-
-    /**
-     * Adds the specified multicharacter to this set if it is not already
-     * present.  If this set already contains the multicharacter,
-     * the call leaves this set unchanged.
-     * Thus "ch" => {"ch"}
-     * <br><b>Warning: you cannot add an empty string ("") to a UnicodeSet.</b>
-     * A frozen set will not be modified.
-     * @param s the source string
-     * @return this object, for chaining
-     * @stable ICU 2.4
-     */
-    UnicodeSet& add(const UnicodeString& s);
-
- private:
-    /**
-     * @return a code point IF the string consists of a single one.
-     * otherwise returns -1.
-     * @param string to test
-     */
-    static int32_t getSingleCP(const UnicodeString& s);
-
-    void _add(const UnicodeString& s);
-
- public:
-    /**
-     * Adds each of the characters in this string to the set. Thus "ch" => {"c", "h"}
-     * If this set already any particular character, it has no effect on that character.
-     * A frozen set will not be modified.
-     * @param s the source string
-     * @return this object, for chaining
-     * @stable ICU 2.4
-     */
-    UnicodeSet& addAll(const UnicodeString& s);
-
-    /**
-     * Retains EACH of the characters in this string. Note: "ch" == {"c", "h"}
-     * If this set already any particular character, it has no effect on that character.
-     * A frozen set will not be modified.
-     * @param s the source string
-     * @return this object, for chaining
-     * @stable ICU 2.4
-     */
-    UnicodeSet& retainAll(const UnicodeString& s);
-
-    /**
-     * Complement EACH of the characters in this string. Note: "ch" == {"c", "h"}
-     * If this set already any particular character, it has no effect on that character.
-     * A frozen set will not be modified.
-     * @param s the source string
-     * @return this object, for chaining
-     * @stable ICU 2.4
-     */
-    UnicodeSet& complementAll(const UnicodeString& s);
-
-    /**
-     * Remove EACH of the characters in this string. Note: "ch" == {"c", "h"}
-     * If this set already any particular character, it has no effect on that character.
-     * A frozen set will not be modified.
-     * @param s the source string
-     * @return this object, for chaining
-     * @stable ICU 2.4
-     */
-    UnicodeSet& removeAll(const UnicodeString& s);
-
-    /**
-     * Makes a set from a multicharacter string. Thus "ch" => {"ch"}
-     * <br><b>Warning: you cannot add an empty string ("") to a UnicodeSet.</b>
-     * @param s the source string
-     * @return a newly created set containing the given string.
-     * The caller owns the return object and is responsible for deleting it.
-     * @stable ICU 2.4
-     */
-    static UnicodeSet* U_EXPORT2 createFrom(const UnicodeString& s);
-
-
-    /**
-     * Makes a set from each of the characters in the string. Thus "ch" => {"c", "h"}
-     * @param s the source string
-     * @return a newly created set containing the given characters
-     * The caller owns the return object and is responsible for deleting it.
-     * @stable ICU 2.4
-     */
-    static UnicodeSet* U_EXPORT2 createFromAll(const UnicodeString& s);
-
-    /**
-     * Retain only the elements in this set that are contained in the
-     * specified range.  If <code>end > start</code> then an empty range is
-     * retained, leaving the set empty.  This is equivalent to
-     * a boolean logic AND, or a set INTERSECTION.
-     * A frozen set will not be modified.
-     *
-     * @param start first character, inclusive, of range to be retained
-     * to this set.
-     * @param end last character, inclusive, of range to be retained
-     * to this set.
-     * @stable ICU 2.0
-     */
-    virtual UnicodeSet& retain(UChar32 start, UChar32 end);
-
-
-    /**
-     * Retain the specified character from this set if it is present.
-     * A frozen set will not be modified.
-     * @stable ICU 2.0
-     */
-    UnicodeSet& retain(UChar32 c);
-
-    /**
-     * Removes the specified range from this set if it is present.
-     * The set will not contain the specified range once the call
-     * returns.  If <code>end > start</code> then an empty range is
-     * removed, leaving the set unchanged.
-     * A frozen set will not be modified.
-     *
-     * @param start first character, inclusive, of range to be removed
-     * from this set.
-     * @param end last character, inclusive, of range to be removed
-     * from this set.
-     * @stable ICU 2.0
-     */
-    virtual UnicodeSet& remove(UChar32 start, UChar32 end);
-
-    /**
-     * Removes the specified character from this set if it is present.
-     * The set will not contain the specified range once the call
-     * returns.
-     * A frozen set will not be modified.
-     * @stable ICU 2.0
-     */
-    UnicodeSet& remove(UChar32 c);
-
-    /**
-     * Removes the specified string from this set if it is present.
-     * The set will not contain the specified character once the call
-     * returns.
-     * A frozen set will not be modified.
-     * @param s the source string
-     * @return this object, for chaining
-     * @stable ICU 2.4
-     */
-    UnicodeSet& remove(const UnicodeString& s);
-
-    /**
-     * Inverts this set.  This operation modifies this set so that
-     * its value is its complement.  This is equivalent to
-     * <code>complement(MIN_VALUE, MAX_VALUE)</code>.
-     * A frozen set will not be modified.
-     * @stable ICU 2.0
-     */
-    virtual UnicodeSet& complement(void);
-
-    /**
-     * Complements the specified range in this set.  Any character in
-     * the range will be removed if it is in this set, or will be
-     * added if it is not in this set.  If <code>end > start</code>
-     * then an empty range is complemented, leaving the set unchanged.
-     * This is equivalent to a boolean logic XOR.
-     * A frozen set will not be modified.
-     *
-     * @param start first character, inclusive, of range to be removed
-     * from this set.
-     * @param end last character, inclusive, of range to be removed
-     * from this set.
-     * @stable ICU 2.0
-     */
-    virtual UnicodeSet& complement(UChar32 start, UChar32 end);
-
-    /**
-     * Complements the specified character in this set.  The character
-     * will be removed if it is in this set, or will be added if it is
-     * not in this set.
-     * A frozen set will not be modified.
-     * @stable ICU 2.0
-     */
-    UnicodeSet& complement(UChar32 c);
-
-    /**
-     * Complement the specified string in this set.
-     * The set will not contain the specified string once the call
-     * returns.
-     * <br><b>Warning: you cannot add an empty string ("") to a UnicodeSet.</b>
-     * A frozen set will not be modified.
-     * @param s the string to complement
-     * @return this object, for chaining
-     * @stable ICU 2.4
-     */
-    UnicodeSet& complement(const UnicodeString& s);
-
-    /**
-     * Adds all of the elements in the specified set to this set if
-     * they're not already present.  This operation effectively
-     * modifies this set so that its value is the <i>union</i> of the two
-     * sets.  The behavior of this operation is unspecified if the specified
-     * collection is modified while the operation is in progress.
-     * A frozen set will not be modified.
-     *
-     * @param c set whose elements are to be added to this set.
-     * @see #add(UChar32, UChar32)
-     * @stable ICU 2.0
-     */
-    virtual UnicodeSet& addAll(const UnicodeSet& c);
-
-    /**
-     * Retains only the elements in this set that are contained in the
-     * specified set.  In other words, removes from this set all of
-     * its elements that are not contained in the specified set.  This
-     * operation effectively modifies this set so that its value is
-     * the <i>intersection</i> of the two sets.
-     * A frozen set will not be modified.
-     *
-     * @param c set that defines which elements this set will retain.
-     * @stable ICU 2.0
-     */
-    virtual UnicodeSet& retainAll(const UnicodeSet& c);
-
-    /**
-     * Removes from this set all of its elements that are contained in the
-     * specified set.  This operation effectively modifies this
-     * set so that its value is the <i>asymmetric set difference</i> of
-     * the two sets.
-     * A frozen set will not be modified.
-     *
-     * @param c set that defines which elements will be removed from
-     *          this set.
-     * @stable ICU 2.0
-     */
-    virtual UnicodeSet& removeAll(const UnicodeSet& c);
-
-    /**
-     * Complements in this set all elements contained in the specified
-     * set.  Any character in the other set will be removed if it is
-     * in this set, or will be added if it is not in this set.
-     * A frozen set will not be modified.
-     *
-     * @param c set that defines which elements will be xor'ed from
-     *          this set.
-     * @stable ICU 2.4
-     */
-    virtual UnicodeSet& complementAll(const UnicodeSet& c);
-
-    /**
-     * Removes all of the elements from this set.  This set will be
-     * empty after this call returns.
-     * A frozen set will not be modified.
-     * @stable ICU 2.0
-     */
-    virtual UnicodeSet& clear(void);
-
-    /**
-     * Close this set over the given attribute.  For the attribute
-     * USET_CASE, the result is to modify this set so that:
-     *
-     * 1. For each character or string 'a' in this set, all strings or
-     * characters 'b' such that foldCase(a) == foldCase(b) are added
-     * to this set.
-     *
-     * 2. For each string 'e' in the resulting set, if e !=
-     * foldCase(e), 'e' will be removed.
-     *
-     * Example: [aq\\u00DF{Bc}{bC}{Fi}] => [aAqQ\\u00DF\\uFB01{ss}{bc}{fi}]
-     *
-     * (Here foldCase(x) refers to the operation u_strFoldCase, and a
-     * == b denotes that the contents are the same, not pointer
-     * comparison.)
-     *
-     * A frozen set will not be modified.
-     *
-     * @param attribute bitmask for attributes to close over.
-     * Currently only the USET_CASE bit is supported.  Any undefined bits
-     * are ignored.
-     * @return a reference to this set.
-     * @internal
-     */
-    UnicodeSet& closeOver(int32_t attribute);
-
-    /**
-     * Remove all strings from this set.
-     *
-     * @return a reference to this set.
-     * @internal
-     */
-    virtual UnicodeSet &removeAllStrings();
-
-    /**
-     * Iteration method that returns the number of ranges contained in
-     * this set.
-     * @see #getRangeStart
-     * @see #getRangeEnd
-     * @stable ICU 2.4
-     */
-    virtual int32_t getRangeCount(void) const;
-
-    /**
-     * Iteration method that returns the first character in the
-     * specified range of this set.
-     * @see #getRangeCount
-     * @see #getRangeEnd
-     * @stable ICU 2.4
-     */
-    virtual UChar32 getRangeStart(int32_t index) const;
-
-    /**
-     * Iteration method that returns the last character in the
-     * specified range of this set.
-     * @see #getRangeStart
-     * @see #getRangeEnd
-     * @stable ICU 2.4
-     */
-    virtual UChar32 getRangeEnd(int32_t index) const;
-
-    /**
-     * Serializes this set into an array of 16-bit integers.  Serialization
-     * (currently) only records the characters in the set; multicharacter
-     * strings are ignored.
-     *
-     * The array has following format (each line is one 16-bit
-     * integer):
-     *
-     *  length     = (n+2*m) | (m!=0?0x8000:0)
-     *  bmpLength  = n; present if m!=0
-     *  bmp[0]
-     *  bmp[1]
-     *  ...
-     *  bmp[n-1]
-     *  supp-high[0]
-     *  supp-low[0]
-     *  supp-high[1]
-     *  supp-low[1]
-     *  ...
-     *  supp-high[m-1]
-     *  supp-low[m-1]
-     *
-     * The array starts with a header.  After the header are n bmp
-     * code points, then m supplementary code points.  Either n or m
-     * or both may be zero.  n+2*m is always <= 0x7FFF.
-     *
-     * If there are no supplementary characters (if m==0) then the
-     * header is one 16-bit integer, 'length', with value n.
-     *
-     * If there are supplementary characters (if m!=0) then the header
-     * is two 16-bit integers.  The first, 'length', has value
-     * (n+2*m)|0x8000.  The second, 'bmpLength', has value n.
-     *
-     * After the header the code points are stored in ascending order.
-     * Supplementary code points are stored as most significant 16
-     * bits followed by least significant 16 bits.
-     *
-     * @param dest pointer to buffer of destCapacity 16-bit integers.
-     * May be NULL only if destCapacity is zero.
-     * @param destCapacity size of dest, or zero.  Must not be negative.
-     * @param ec error code.  Will be set to U_INDEX_OUTOFBOUNDS_ERROR
-     * if n+2*m > 0x7FFF.  Will be set to U_BUFFER_OVERFLOW_ERROR if
-     * n+2*m+(m!=0?2:1) > destCapacity.
-     * @return the total length of the serialized format, including
-     * the header, that is, n+2*m+(m!=0?2:1), or 0 on error other
-     * than U_BUFFER_OVERFLOW_ERROR.
-     * @stable ICU 2.4
-     */
-    int32_t serialize(uint16_t *dest, int32_t destCapacity, UErrorCode& ec) const;
-
-    /**
-     * Reallocate this objects internal structures to take up the least
-     * possible space, without changing this object's value.
-     * A frozen set will not be modified.
-     * @stable ICU 2.4
-     */
-    virtual UnicodeSet& compact();
-
-    /**
-     * Return the class ID for this class.  This is useful only for
-     * comparing to a return value from getDynamicClassID().  For example:
-     * <pre>
-     * .      Base* polymorphic_pointer = createPolymorphicObject();
-     * .      if (polymorphic_pointer->getDynamicClassID() ==
-     * .          Derived::getStaticClassID()) ...
-     * </pre>
-     * @return          The class ID for all objects of this class.
-     * @stable ICU 2.0
-     */
-    static UClassID U_EXPORT2 getStaticClassID(void);
-
-    /**
-     * Implement UnicodeFunctor API.
-     *
-     * @return The class ID for this object. All objects of a given
-     * class have the same class ID.  Objects of other classes have
-     * different class IDs.
-     * @stable ICU 2.4
-     */
-    virtual UClassID getDynamicClassID(void) const;
-
-private:
-
-    // Private API for the USet API
-
-    friend class USetAccess;
-
-    int32_t getStringCount() const;
-
-    const UnicodeString* getString(int32_t index) const;
-
-    //----------------------------------------------------------------
-    // RuleBasedTransliterator support
-    //----------------------------------------------------------------
-
-private:
-
-    /**
-     * Returns <tt>true</tt> if this set contains any character whose low byte
-     * is the given value.  This is used by <tt>RuleBasedTransliterator</tt> for
-     * indexing.
-     */
-    virtual UBool matchesIndexValue(uint8_t v) const;
-
-private:
-
-    //----------------------------------------------------------------
-    // Implementation: Clone as thawed (see ICU4J Freezable)
-    //----------------------------------------------------------------
-
-    UnicodeSet(const UnicodeSet& o, UBool /* asThawed */);
-
-    //----------------------------------------------------------------
-    // Implementation: Pattern parsing
-    //----------------------------------------------------------------
-
-    void applyPattern(RuleCharacterIterator& chars,
-                      const SymbolTable* symbols,
-                      UnicodeString& rebuiltPat,
-                      uint32_t options,
-                      UErrorCode& ec);
-
-    //----------------------------------------------------------------
-    // Implementation: Utility methods
-    //----------------------------------------------------------------
-
-    void ensureCapacity(int32_t newLen, UErrorCode& ec);
-
-    void ensureBufferCapacity(int32_t newLen, UErrorCode& ec);
-
-    void swapBuffers(void);
-
-    UBool allocateStrings(UErrorCode &status);
-
-    UnicodeString& _toPattern(UnicodeString& result,
-                              UBool escapeUnprintable) const;
-
-    UnicodeString& _generatePattern(UnicodeString& result,
-                                    UBool escapeUnprintable) const;
-
-    static void _appendToPat(UnicodeString& buf, const UnicodeString& s, UBool escapeUnprintable);
-
-    static void _appendToPat(UnicodeString& buf, UChar32 c, UBool escapeUnprintable);
-
-    //----------------------------------------------------------------
-    // Implementation: Fundamental operators
-    //----------------------------------------------------------------
-
-    void exclusiveOr(const UChar32* other, int32_t otherLen, int8_t polarity);
-
-    void add(const UChar32* other, int32_t otherLen, int8_t polarity);
-
-    void retain(const UChar32* other, int32_t otherLen, int8_t polarity);
-
-    /**
-     * Return true if the given position, in the given pattern, appears
-     * to be the start of a property set pattern [:foo:], \\p{foo}, or
-     * \\P{foo}, or \\N{name}.
-     */
-    static UBool resemblesPropertyPattern(const UnicodeString& pattern,
-                                          int32_t pos);
-
-    static UBool resemblesPropertyPattern(RuleCharacterIterator& chars,
-                                          int32_t iterOpts);
-
-    /**
-     * Parse the given property pattern at the given parse position
-     * and set this UnicodeSet to the result.
-     *
-     * The original design document is out of date, but still useful.
-     * Ignore the property and value names:
-     * http://source.icu-project.org/repos/icu/icuhtml/trunk/design/unicodeset_properties.html
-     *
-     * Recognized syntax:
-     *
-     * [:foo:] [:^foo:] - white space not allowed within "[:" or ":]"
-     * \\p{foo} \\P{foo}  - white space not allowed within "\\p" or "\\P"
-     * \\N{name}         - white space not allowed within "\\N"
-     *
-     * Other than the above restrictions, white space is ignored.  Case
-     * is ignored except in "\\p" and "\\P" and "\\N".  In 'name' leading
-     * and trailing space is deleted, and internal runs of whitespace
-     * are collapsed to a single space.
-     *
-     * We support binary properties, enumerated properties, and the
-     * following non-enumerated properties:
-     *
-     *  Numeric_Value
-     *  Name
-     *  Unicode_1_Name
-     *
-     * @param pattern the pattern string
-     * @param ppos on entry, the position at which to begin parsing.
-     * This should be one of the locations marked '^':
-     *
-     *   [:blah:]     \\p{blah}     \\P{blah}     \\N{name}
-     *   ^       %    ^       %    ^       %    ^       %
-     *
-     * On return, the position after the last character parsed, that is,
-     * the locations marked '%'.  If the parse fails, ppos is returned
-     * unchanged.
-     * @return a reference to this.
-     */
-    UnicodeSet& applyPropertyPattern(const UnicodeString& pattern,
-                                     ParsePosition& ppos,
-                                     UErrorCode &ec);
-
-    void applyPropertyPattern(RuleCharacterIterator& chars,
-                              UnicodeString& rebuiltPat,
-                              UErrorCode& ec);
-
-    static const UnicodeSet* getInclusions(int32_t src, UErrorCode &status);
-
-    /**
-     * A filter that returns TRUE if the given code point should be
-     * included in the UnicodeSet being constructed.
-     */
-    typedef UBool (*Filter)(UChar32 codePoint, void* context);
-
-    /**
-     * Given a filter, set this UnicodeSet to the code points
-     * contained by that filter.  The filter MUST be
-     * property-conformant.  That is, if it returns value v for one
-     * code point, then it must return v for all affiliated code
-     * points, as defined by the inclusions list.  See
-     * getInclusions().
-     * src is a UPropertySource value.
-     */
-    void applyFilter(Filter filter,
-                     void* context,
-                     int32_t src,
-                     UErrorCode &status);
-
-    /**
-     * Set the new pattern to cache.
-     */
-    void setPattern(const UnicodeString& newPat);
-    /**
-     * Release existing cached pattern.
-     */
-    void releasePattern();
-
-    friend class UnicodeSetIterator;
-};
-
-inline UBool UnicodeSet::operator!=(const UnicodeSet& o) const {
-    return !operator==(o);
-}
-
-inline UBool UnicodeSet::isFrozen() const {
-    return (UBool)(bmpSet!=NULL || stringSpan!=NULL);
-}
-
-inline UBool UnicodeSet::containsSome(UChar32 start, UChar32 end) const {
-    return !containsNone(start, end);
-}
-
-inline UBool UnicodeSet::containsSome(const UnicodeSet& s) const {
-    return !containsNone(s);
-}
-
-inline UBool UnicodeSet::containsSome(const UnicodeString& s) const {
-    return !containsNone(s);
-}
-
-inline UBool UnicodeSet::isBogus() const {
-    return (UBool)(fFlags & kIsBogus);
-}
-
-U_NAMESPACE_END
-
-#endif


[41/57] [abbrv] remove couch_collate

Posted by be...@apache.org.
http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/calendar.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/calendar.h b/apps/couch_collate/platform/osx/icu/unicode/calendar.h
deleted file mode 100644
index 709b27e..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/calendar.h
+++ /dev/null
@@ -1,2170 +0,0 @@
-/*
-********************************************************************************
-*   Copyright (C) 1997-2008, International Business Machines
-*   Corporation and others.  All Rights Reserved.
-********************************************************************************
-*
-* File CALENDAR.H
-*
-* Modification History:
-*
-*   Date        Name        Description
-*   04/22/97    aliu        Expanded and corrected comments and other header
-*                           contents.
-*   05/01/97    aliu        Made equals(), before(), after() arguments const.
-*   05/20/97    aliu        Replaced fAreFieldsSet with fAreFieldsInSync and
-*                           fAreAllFieldsSet.
-*   07/27/98    stephen     Sync up with JDK 1.2
-*   11/15/99    weiv        added YEAR_WOY and DOW_LOCAL
-*                           to EDateFields
-*    8/19/2002  srl         Removed Javaisms
-*   11/07/2003  srl         Update, clean up documentation.
-********************************************************************************
-*/
-
-#ifndef CALENDAR_H
-#define CALENDAR_H
-
-#include "unicode/utypes.h"
-
-/**
- * \file 
- * \brief C++ API: Calendar object
- */
-#if !UCONFIG_NO_FORMATTING
-
-#include "unicode/uobject.h"
-#include "unicode/locid.h"
-#include "unicode/timezone.h"
-#include "unicode/ucal.h"
-#include "unicode/umisc.h"
-
-U_NAMESPACE_BEGIN
-
-class ICUServiceFactory;
-
-/**
- * @internal
- */
-typedef int32_t UFieldResolutionTable[12][8];
-
-/**
- * <code>Calendar</code> is an abstract base class for converting between
- * a <code>UDate</code> object and a set of integer fields such as
- * <code>YEAR</code>, <code>MONTH</code>, <code>DAY</code>, <code>HOUR</code>,
- * and so on. (A <code>UDate</code> object represents a specific instant in
- * time with millisecond precision. See UDate
- * for information about the <code>UDate</code> class.)
- *
- * <p>
- * Subclasses of <code>Calendar</code> interpret a <code>UDate</code>
- * according to the rules of a specific calendar system.
- * The most commonly used subclass of <code>Calendar</code> is
- * <code>GregorianCalendar</code>. Other subclasses could represent
- * the various types of lunar calendars in use in many parts of the world.
- *
- * <p>
- * <b>NOTE</b>: (ICU 2.6) The subclass interface should be considered unstable
- * - it WILL change.
- *
- * <p>
- * Like other locale-sensitive classes, <code>Calendar</code> provides a
- * static method, <code>createInstance</code>, for getting a generally useful
- * object of this type. <code>Calendar</code>'s <code>createInstance</code> method
- * returns the appropriate <code>Calendar</code> subclass whose
- * time fields have been initialized with the current date and time:
- * \htmlonly<blockquote>\endhtmlonly
- * <pre>
- * Calendar *rightNow = Calendar::createInstance(errCode);
- * </pre>
- * \htmlonly</blockquote>\endhtmlonly
- *
- * <p>
- * A <code>Calendar</code> object can produce all the time field values
- * needed to implement the date-time formatting for a particular language
- * and calendar style (for example, Japanese-Gregorian, Japanese-Traditional).
- *
- * <p>
- * When computing a <code>UDate</code> from time fields, two special circumstances
- * may arise: there may be insufficient information to compute the
- * <code>UDate</code> (such as only year and month but no day in the month),
- * or there may be inconsistent information (such as "Tuesday, July 15, 1996"
- * -- July 15, 1996 is actually a Monday).
- *
- * <p>
- * <strong>Insufficient information.</strong> The calendar will use default
- * information to specify the missing fields. This may vary by calendar; for
- * the Gregorian calendar, the default for a field is the same as that of the
- * start of the epoch: i.e., YEAR = 1970, MONTH = JANUARY, DATE = 1, etc.
- *
- * <p>
- * <strong>Inconsistent information.</strong> If fields conflict, the calendar
- * will give preference to fields set more recently. For example, when
- * determining the day, the calendar will look for one of the following
- * combinations of fields.  The most recent combination, as determined by the
- * most recently set single field, will be used.
- *
- * \htmlonly<blockquote>\endhtmlonly
- * <pre>
- * MONTH + DAY_OF_MONTH
- * MONTH + WEEK_OF_MONTH + DAY_OF_WEEK
- * MONTH + DAY_OF_WEEK_IN_MONTH + DAY_OF_WEEK
- * DAY_OF_YEAR
- * DAY_OF_WEEK + WEEK_OF_YEAR
- * </pre>
- * \htmlonly</blockquote>\endhtmlonly
- *
- * For the time of day:
- *
- * \htmlonly<blockquote>\endhtmlonly
- * <pre>
- * HOUR_OF_DAY
- * AM_PM + HOUR
- * </pre>
- * \htmlonly</blockquote>\endhtmlonly
- *
- * <p>
- * <strong>Note:</strong> for some non-Gregorian calendars, different
- * fields may be necessary for complete disambiguation. For example, a full
- * specification of the historial Arabic astronomical calendar requires year,
- * month, day-of-month <em>and</em> day-of-week in some cases.
- *
- * <p>
- * <strong>Note:</strong> There are certain possible ambiguities in
- * interpretation of certain singular times, which are resolved in the
- * following ways:
- * <ol>
- *     <li> 24:00:00 "belongs" to the following day. That is,
- *          23:59 on Dec 31, 1969 &lt; 24:00 on Jan 1, 1970 &lt; 24:01:00 on Jan 1, 1970
- *
- *     <li> Although historically not precise, midnight also belongs to "am",
- *          and noon belongs to "pm", so on the same day,
- *          12:00 am (midnight) &lt; 12:01 am, and 12:00 pm (noon) &lt; 12:01 pm
- * </ol>
- *
- * <p>
- * The date or time format strings are not part of the definition of a
- * calendar, as those must be modifiable or overridable by the user at
- * runtime. Use {@link DateFormat}
- * to format dates.
- *
- * <p>
- * <code>Calendar</code> provides an API for field "rolling", where fields
- * can be incremented or decremented, but wrap around. For example, rolling the
- * month up in the date <code>December 12, <b>1996</b></code> results in
- * <code>January 12, <b>1996</b></code>.
- *
- * <p>
- * <code>Calendar</code> also provides a date arithmetic function for
- * adding the specified (signed) amount of time to a particular time field.
- * For example, subtracting 5 days from the date <code>September 12, 1996</code>
- * results in <code>September 7, 1996</code>.
- *
- * @stable ICU 2.0
- */
-class U_I18N_API Calendar : public UObject {
-public:
-
-    /**
-     * Field IDs for date and time. Used to specify date/time fields. ERA is calendar
-     * specific. Example ranges given are for illustration only; see specific Calendar
-     * subclasses for actual ranges.
-     * @deprecated ICU 2.6. Use C enum UCalendarDateFields defined in ucal.h
-     */
-    enum EDateFields {
-#ifndef U_HIDE_DEPRECATED_API
-        ERA,                  // Example: 0..1
-        YEAR,                 // Example: 1..big number
-        MONTH,                // Example: 0..11
-        WEEK_OF_YEAR,         // Example: 1..53
-        WEEK_OF_MONTH,        // Example: 1..4
-        DATE,                 // Example: 1..31
-        DAY_OF_YEAR,          // Example: 1..365
-        DAY_OF_WEEK,          // Example: 1..7
-        DAY_OF_WEEK_IN_MONTH, // Example: 1..4, may be specified as -1
-        AM_PM,                // Example: 0..1
-        HOUR,                 // Example: 0..11
-        HOUR_OF_DAY,          // Example: 0..23
-        MINUTE,               // Example: 0..59
-        SECOND,               // Example: 0..59
-        MILLISECOND,          // Example: 0..999
-        ZONE_OFFSET,          // Example: -12*U_MILLIS_PER_HOUR..12*U_MILLIS_PER_HOUR
-        DST_OFFSET,           // Example: 0 or U_MILLIS_PER_HOUR
-        YEAR_WOY,             // 'Y' Example: 1..big number - Year of Week of Year
-        DOW_LOCAL,            // 'e' Example: 1..7 - Day of Week / Localized
-		
-		EXTENDED_YEAR,
-		JULIAN_DAY,
-		MILLISECONDS_IN_DAY,
-		IS_LEAP_MONTH,
-
-        FIELD_COUNT = UCAL_FIELD_COUNT // See ucal.h for other fields.
-#endif /* U_HIDE_DEPRECATED_API */
-    };
-
-    /**
-     * Useful constant for days of week. Note: Calendar day-of-week is 1-based. Clients
-     * who create locale resources for the field of first-day-of-week should be aware of
-     * this. For instance, in US locale, first-day-of-week is set to 1, i.e., SUNDAY.
-     * @deprecated ICU 2.6. Use C enum UCalendarDaysOfWeek defined in ucal.h
-     */
-    enum EDaysOfWeek {
-#ifndef U_HIDE_DEPRECATED_API
-        SUNDAY = 1,
-        MONDAY,
-        TUESDAY,
-        WEDNESDAY,
-        THURSDAY,
-        FRIDAY,
-        SATURDAY
-#endif /* U_HIDE_DEPRECATED_API */
-    };
-
-    /**
-     * Useful constants for month. Note: Calendar month is 0-based.
-     * @deprecated ICU 2.6. Use C enum UCalendarMonths defined in ucal.h
-     */
-    enum EMonths {
-#ifndef U_HIDE_DEPRECATED_API
-        JANUARY,
-        FEBRUARY,
-        MARCH,
-        APRIL,
-        MAY,
-        JUNE,
-        JULY,
-        AUGUST,
-        SEPTEMBER,
-        OCTOBER,
-        NOVEMBER,
-        DECEMBER,
-        UNDECIMBER
-#endif /* U_HIDE_DEPRECATED_API */
-    };
-
-    /**
-     * Useful constants for hour in 12-hour clock. Used in GregorianCalendar.
-     * @deprecated ICU 2.6. Use C enum UCalendarAMPMs defined in ucal.h
-     */
-    enum EAmpm {
-#ifndef U_HIDE_DEPRECATED_API
-        AM,
-        PM
-#endif /* U_HIDE_DEPRECATED_API */
-    };
-
-    /**
-     * destructor
-     * @stable ICU 2.0
-     */
-    virtual ~Calendar();
-
-    /**
-     * Create and return a polymorphic copy of this calendar.
-     *
-     * @return    a polymorphic copy of this calendar.
-     * @stable ICU 2.0
-     */
-    virtual Calendar* clone(void) const = 0;
-
-    /**
-     * Creates a Calendar using the default timezone and locale. Clients are responsible
-     * for deleting the object returned.
-     *
-     * @param success  Indicates the success/failure of Calendar creation. Filled in
-     *                 with U_ZERO_ERROR if created successfully, set to a failure result
-     *                 otherwise. U_MISSING_RESOURCE_ERROR will be returned if the resource data
-     *                 requests a calendar type which has not been installed.
-     * @return         A Calendar if created successfully. NULL otherwise.
-     * @stable ICU 2.0
-     */
-    static Calendar* U_EXPORT2 createInstance(UErrorCode& success);
-
-    /**
-     * Creates a Calendar using the given timezone and the default locale.
-     * The Calendar takes ownership of zoneToAdopt; the
-     * client must not delete it.
-     *
-     * @param zoneToAdopt  The given timezone to be adopted.
-     * @param success      Indicates the success/failure of Calendar creation. Filled in
-     *                     with U_ZERO_ERROR if created successfully, set to a failure result
-     *                     otherwise.
-     * @return             A Calendar if created successfully. NULL otherwise.
-     * @stable ICU 2.0
-     */
-    static Calendar* U_EXPORT2 createInstance(TimeZone* zoneToAdopt, UErrorCode& success);
-
-    /**
-     * Creates a Calendar using the given timezone and the default locale.  The TimeZone
-     * is _not_ adopted; the client is still responsible for deleting it.
-     *
-     * @param zone  The timezone.
-     * @param success      Indicates the success/failure of Calendar creation. Filled in
-     *                     with U_ZERO_ERROR if created successfully, set to a failure result
-     *                     otherwise.
-     * @return             A Calendar if created successfully. NULL otherwise.
-     * @stable ICU 2.0
-     */
-    static Calendar* U_EXPORT2 createInstance(const TimeZone& zone, UErrorCode& success);
-
-    /**
-     * Creates a Calendar using the default timezone and the given locale.
-     *
-     * @param aLocale  The given locale.
-     * @param success  Indicates the success/failure of Calendar creation. Filled in
-     *                 with U_ZERO_ERROR if created successfully, set to a failure result
-     *                 otherwise.
-     * @return         A Calendar if created successfully. NULL otherwise.
-     * @stable ICU 2.0
-     */
-    static Calendar* U_EXPORT2 createInstance(const Locale& aLocale, UErrorCode& success);
-
-    /**
-     * Creates a Calendar using the given timezone and given locale.
-     * The Calendar takes ownership of zoneToAdopt; the
-     * client must not delete it.
-     *
-     * @param zoneToAdopt  The given timezone to be adopted.
-     * @param aLocale      The given locale.
-     * @param success      Indicates the success/failure of Calendar creation. Filled in
-     *                     with U_ZERO_ERROR if created successfully, set to a failure result
-     *                     otherwise.
-     * @return             A Calendar if created successfully. NULL otherwise.
-     * @stable ICU 2.0
-     */
-    static Calendar* U_EXPORT2 createInstance(TimeZone* zoneToAdopt, const Locale& aLocale, UErrorCode& success);
-
-    /**
-     * Gets a Calendar using the given timezone and given locale.  The TimeZone
-     * is _not_ adopted; the client is still responsible for deleting it.
-     *
-     * @param zoneToAdopt  The given timezone to be adopted.
-     * @param aLocale      The given locale.
-     * @param success      Indicates the success/failure of Calendar creation. Filled in
-     *                     with U_ZERO_ERROR if created successfully, set to a failure result
-     *                     otherwise.
-     * @return             A Calendar if created successfully. NULL otherwise.
-     * @stable ICU 2.0
-     */
-    static Calendar* U_EXPORT2 createInstance(const TimeZone& zoneToAdopt, const Locale& aLocale, UErrorCode& success);
-
-    /**
-     * Returns a list of the locales for which Calendars are installed.
-     *
-     * @param count  Number of locales returned.
-     * @return       An array of Locale objects representing the set of locales for which
-     *               Calendars are installed.  The system retains ownership of this list;
-     *               the caller must NOT delete it. Does not include user-registered Calendars.
-     * @stable ICU 2.0
-     */
-    static const Locale* U_EXPORT2 getAvailableLocales(int32_t& count);
-
-    /**
-     * Returns the current UTC (GMT) time measured in milliseconds since 0:00:00 on 1/1/70
-     * (derived from the system time).
-     *
-     * @return   The current UTC time in milliseconds.
-     * @stable ICU 2.0
-     */
-    static UDate U_EXPORT2 getNow(void);
-
-    /**
-     * Gets this Calendar's time as milliseconds. May involve recalculation of time due
-     * to previous calls to set time field values. The time specified is non-local UTC
-     * (GMT) time. Although this method is const, this object may actually be changed
-     * (semantically const).
-     *
-     * @param status  Output param set to success/failure code on exit. If any value
-     *                previously set in the time field is invalid or restricted by
-     *                leniency, this will be set to an error status.
-     * @return        The current time in UTC (GMT) time, or zero if the operation
-     *                failed.
-     * @stable ICU 2.0
-     */
-    inline UDate getTime(UErrorCode& status) const { return getTimeInMillis(status); }
-
-    /**
-     * Sets this Calendar's current time with the given UDate. The time specified should
-     * be in non-local UTC (GMT) time.
-     *
-     * @param date  The given UDate in UTC (GMT) time.
-     * @param status  Output param set to success/failure code on exit. If any value
-     *                set in the time field is invalid or restricted by
-     *                leniency, this will be set to an error status.
-     * @stable ICU 2.0
-     */
-    inline void setTime(UDate date, UErrorCode& status) { setTimeInMillis(date, status); }
-
-    /**
-     * Compares the equality of two Calendar objects. Objects of different subclasses
-     * are considered unequal. This comparison is very exacting; two Calendar objects
-     * must be in exactly the same state to be considered equal. To compare based on the
-     * represented time, use equals() instead.
-     *
-     * @param that  The Calendar object to be compared with.
-     * @return      True if the given Calendar is the same as this Calendar; false
-     *              otherwise.
-     * @stable ICU 2.0
-     */
-    virtual UBool operator==(const Calendar& that) const;
-
-    /**
-     * Compares the inequality of two Calendar objects.
-     *
-     * @param that  The Calendar object to be compared with.
-     * @return      True if the given Calendar is not the same as this Calendar; false
-     *              otherwise.
-     * @stable ICU 2.0
-     */
-    UBool operator!=(const Calendar& that) const {return !operator==(that);}
-
-    /**
-     * Returns TRUE if the given Calendar object is equivalent to this
-     * one.  An equivalent Calendar will behave exactly as this one
-     * does, but it may be set to a different time.  By contrast, for
-     * the operator==() method to return TRUE, the other Calendar must
-     * be set to the same time.
-     *
-     * @param other the Calendar to be compared with this Calendar
-     * @stable ICU 2.4
-     */
-    virtual UBool isEquivalentTo(const Calendar& other) const;
-
-    /**
-     * Compares the Calendar time, whereas Calendar::operator== compares the equality of
-     * Calendar objects.
-     *
-     * @param when    The Calendar to be compared with this Calendar. Although this is a
-     *                const parameter, the object may be modified physically
-     *                (semantically const).
-     * @param status  Output param set to success/failure code on exit. If any value
-     *                previously set in the time field is invalid or restricted by
-     *                leniency, this will be set to an error status.
-     * @return        True if the current time of this Calendar is equal to the time of
-     *                Calendar when; false otherwise.
-     * @stable ICU 2.0
-     */
-    UBool equals(const Calendar& when, UErrorCode& status) const;
-
-    /**
-     * Returns true if this Calendar's current time is before "when"'s current time.
-     *
-     * @param when    The Calendar to be compared with this Calendar. Although this is a
-     *                const parameter, the object may be modified physically
-     *                (semantically const).
-     * @param status  Output param set to success/failure code on exit. If any value
-     *                previously set in the time field is invalid or restricted by
-     *                leniency, this will be set to an error status.
-     * @return        True if the current time of this Calendar is before the time of
-     *                Calendar when; false otherwise.
-     * @stable ICU 2.0
-     */
-    UBool before(const Calendar& when, UErrorCode& status) const;
-
-    /**
-     * Returns true if this Calendar's current time is after "when"'s current time.
-     *
-     * @param when    The Calendar to be compared with this Calendar. Although this is a
-     *                const parameter, the object may be modified physically
-     *                (semantically const).
-     * @param status  Output param set to success/failure code on exit. If any value
-     *                previously set in the time field is invalid or restricted by
-     *                leniency, this will be set to an error status.
-     * @return        True if the current time of this Calendar is after the time of
-     *                Calendar when; false otherwise.
-     * @stable ICU 2.0
-     */
-    UBool after(const Calendar& when, UErrorCode& status) const;
-
-    /**
-     * UDate Arithmetic function. Adds the specified (signed) amount of time to the given
-     * time field, based on the calendar's rules. For example, to subtract 5 days from
-     * the current time of the calendar, call add(Calendar::DATE, -5). When adding on
-     * the month or Calendar::MONTH field, other fields like date might conflict and
-     * need to be changed. For instance, adding 1 month on the date 01/31/96 will result
-     * in 02/29/96.
-     *
-     * @param field   Specifies which date field to modify.
-     * @param amount  The amount of time to be added to the field, in the natural unit
-     *                for that field (e.g., days for the day fields, hours for the hour
-     *                field.)
-     * @param status  Output param set to success/failure code on exit. If any value
-     *                previously set in the time field is invalid or restricted by
-     *                leniency, this will be set to an error status.
-     * @deprecated ICU 2.6. use add(UCalendarDateFields field, int32_t amount, UErrorCode& status) instead.
-     */
-    virtual void add(EDateFields field, int32_t amount, UErrorCode& status);
-
-    /**
-     * UDate Arithmetic function. Adds the specified (signed) amount of time to the given
-     * time field, based on the calendar's rules. For example, to subtract 5 days from
-     * the current time of the calendar, call add(Calendar::DATE, -5). When adding on
-     * the month or Calendar::MONTH field, other fields like date might conflict and
-     * need to be changed. For instance, adding 1 month on the date 01/31/96 will result
-     * in 02/29/96.
-     *
-     * @param field   Specifies which date field to modify.
-     * @param amount  The amount of time to be added to the field, in the natural unit
-     *                for that field (e.g., days for the day fields, hours for the hour
-     *                field.)
-     * @param status  Output param set to success/failure code on exit. If any value
-     *                previously set in the time field is invalid or restricted by
-     *                leniency, this will be set to an error status.
-     * @stable ICU 2.6.
-     */
-    virtual void add(UCalendarDateFields field, int32_t amount, UErrorCode& status);
-
-    /**
-     * Time Field Rolling function. Rolls (up/down) a single unit of time on the given
-     * time field. For example, to roll the current date up by one day, call
-     * roll(Calendar::DATE, true). When rolling on the year or Calendar::YEAR field, it
-     * will roll the year value in the range between getMinimum(Calendar::YEAR) and the
-     * value returned by getMaximum(Calendar::YEAR). When rolling on the month or
-     * Calendar::MONTH field, other fields like date might conflict and, need to be
-     * changed. For instance, rolling the month up on the date 01/31/96 will result in
-     * 02/29/96. Rolling up always means rolling forward in time; e.g., rolling the year
-     * up on "100 BC" will result in "99 BC", for Gregorian calendar. When rolling on the
-     * hour-in-day or Calendar::HOUR_OF_DAY field, it will roll the hour value in the range
-     * between 0 and 23, which is zero-based.
-     * <P>
-     * NOTE: Do not use this method -- use roll(EDateFields, int, UErrorCode&) instead.
-     *
-     * @param field   The time field.
-     * @param up      Indicates if the value of the specified time field is to be rolled
-     *                up or rolled down. Use true if rolling up, false otherwise.
-     * @param status  Output param set to success/failure code on exit. If any value
-     *                previously set in the time field is invalid or restricted by
-     *                leniency, this will be set to an error status.
-     * @deprecated ICU 2.6. Use roll(UCalendarDateFields field, UBool up, UErrorCode& status) instead.
-     */
-    inline void roll(EDateFields field, UBool up, UErrorCode& status);
-
-    /**
-     * Time Field Rolling function. Rolls (up/down) a single unit of time on the given
-     * time field. For example, to roll the current date up by one day, call
-     * roll(Calendar::DATE, true). When rolling on the year or Calendar::YEAR field, it
-     * will roll the year value in the range between getMinimum(Calendar::YEAR) and the
-     * value returned by getMaximum(Calendar::YEAR). When rolling on the month or
-     * Calendar::MONTH field, other fields like date might conflict and, need to be
-     * changed. For instance, rolling the month up on the date 01/31/96 will result in
-     * 02/29/96. Rolling up always means rolling forward in time; e.g., rolling the year
-     * up on "100 BC" will result in "99 BC", for Gregorian calendar. When rolling on the
-     * hour-in-day or Calendar::HOUR_OF_DAY field, it will roll the hour value in the range
-     * between 0 and 23, which is zero-based.
-     * <P>
-     * NOTE: Do not use this method -- use roll(UCalendarDateFields, int, UErrorCode&) instead.
-     *
-     * @param field   The time field.
-     * @param up      Indicates if the value of the specified time field is to be rolled
-     *                up or rolled down. Use true if rolling up, false otherwise.
-     * @param status  Output param set to success/failure code on exit. If any value
-     *                previously set in the time field is invalid or restricted by
-     *                leniency, this will be set to an error status.
-     * @stable ICU 2.6.
-     */
-    inline void roll(UCalendarDateFields field, UBool up, UErrorCode& status);
-
-    /**
-     * Time Field Rolling function. Rolls by the given amount on the given
-     * time field. For example, to roll the current date up by one day, call
-     * roll(Calendar::DATE, +1, status). When rolling on the month or
-     * Calendar::MONTH field, other fields like date might conflict and, need to be
-     * changed. For instance, rolling the month up on the date 01/31/96 will result in
-     * 02/29/96.  Rolling by a positive value always means rolling forward in time;
-     * e.g., rolling the year by +1 on "100 BC" will result in "99 BC", for Gregorian
-     * calendar. When rolling on the hour-in-day or Calendar::HOUR_OF_DAY field, it will
-     * roll the hour value in the range between 0 and 23, which is zero-based.
-     * <P>
-     * The only difference between roll() and add() is that roll() does not change
-     * the value of more significant fields when it reaches the minimum or maximum
-     * of its range, whereas add() does.
-     *
-     * @param field   The time field.
-     * @param amount  Indicates amount to roll.
-     * @param status  Output param set to success/failure code on exit. If any value
-     *                previously set in the time field is invalid, this will be set to
-     *                an error status.
-     * @deprecated ICU 2.6. Use roll(UCalendarDateFields field, int32_t amount, UErrorCode& status) instead.
-     */
-    virtual void roll(EDateFields field, int32_t amount, UErrorCode& status);
-
-    /**
-     * Time Field Rolling function. Rolls by the given amount on the given
-     * time field. For example, to roll the current date up by one day, call
-     * roll(Calendar::DATE, +1, status). When rolling on the month or
-     * Calendar::MONTH field, other fields like date might conflict and, need to be
-     * changed. For instance, rolling the month up on the date 01/31/96 will result in
-     * 02/29/96.  Rolling by a positive value always means rolling forward in time;
-     * e.g., rolling the year by +1 on "100 BC" will result in "99 BC", for Gregorian
-     * calendar. When rolling on the hour-in-day or Calendar::HOUR_OF_DAY field, it will
-     * roll the hour value in the range between 0 and 23, which is zero-based.
-     * <P>
-     * The only difference between roll() and add() is that roll() does not change
-     * the value of more significant fields when it reaches the minimum or maximum
-     * of its range, whereas add() does.
-     *
-     * @param field   The time field.
-     * @param amount  Indicates amount to roll.
-     * @param status  Output param set to success/failure code on exit. If any value
-     *                previously set in the time field is invalid, this will be set to
-     *                an error status.
-     * @stable ICU 2.6.
-     */
-    virtual void roll(UCalendarDateFields field, int32_t amount, UErrorCode& status);
-
-    /**
-     * Return the difference between the given time and the time this
-     * calendar object is set to.  If this calendar is set
-     * <em>before</em> the given time, the returned value will be
-     * positive.  If this calendar is set <em>after</em> the given
-     * time, the returned value will be negative.  The
-     * <code>field</code> parameter specifies the units of the return
-     * value.  For example, if <code>fieldDifference(when,
-     * Calendar::MONTH)</code> returns 3, then this calendar is set to
-     * 3 months before <code>when</code>, and possibly some addition
-     * time less than one month.
-     *
-     * <p>As a side effect of this call, this calendar is advanced
-     * toward <code>when</code> by the given amount.  That is, calling
-     * this method has the side effect of calling <code>add(field,
-     * n)</code>, where <code>n</code> is the return value.
-     *
-     * <p>Usage: To use this method, call it first with the largest
-     * field of interest, then with progressively smaller fields.  For
-     * example:
-     *
-     * <pre>
-     * int y = cal->fieldDifference(when, Calendar::YEAR, err);
-     * int m = cal->fieldDifference(when, Calendar::MONTH, err);
-     * int d = cal->fieldDifference(when, Calendar::DATE, err);</pre>
-     *
-     * computes the difference between <code>cal</code> and
-     * <code>when</code> in years, months, and days.
-     *
-     * <p>Note: <code>fieldDifference()</code> is
-     * <em>asymmetrical</em>.  That is, in the following code:
-     *
-     * <pre>
-     * cal->setTime(date1, err);
-     * int m1 = cal->fieldDifference(date2, Calendar::MONTH, err);
-     * int d1 = cal->fieldDifference(date2, Calendar::DATE, err);
-     * cal->setTime(date2, err);
-     * int m2 = cal->fieldDifference(date1, Calendar::MONTH, err);
-     * int d2 = cal->fieldDifference(date1, Calendar::DATE, err);</pre>
-     *
-     * one might expect that <code>m1 == -m2 && d1 == -d2</code>.
-     * However, this is not generally the case, because of
-     * irregularities in the underlying calendar system (e.g., the
-     * Gregorian calendar has a varying number of days per month).
-     *
-     * @param when the date to compare this calendar's time to
-     * @param field the field in which to compute the result
-     * @param status  Output param set to success/failure code on exit. If any value
-     *                previously set in the time field is invalid, this will be set to
-     *                an error status.
-     * @return the difference, either positive or negative, between
-     * this calendar's time and <code>when</code>, in terms of
-     * <code>field</code>.
-     * @deprecated ICU 2.6. Use fieldDifference(UDate when, UCalendarDateFields field, UErrorCode& status).
-     */
-    virtual int32_t fieldDifference(UDate when, EDateFields field, UErrorCode& status);
-
-    /**
-     * Return the difference between the given time and the time this
-     * calendar object is set to.  If this calendar is set
-     * <em>before</em> the given time, the returned value will be
-     * positive.  If this calendar is set <em>after</em> the given
-     * time, the returned value will be negative.  The
-     * <code>field</code> parameter specifies the units of the return
-     * value.  For example, if <code>fieldDifference(when,
-     * Calendar::MONTH)</code> returns 3, then this calendar is set to
-     * 3 months before <code>when</code>, and possibly some addition
-     * time less than one month.
-     *
-     * <p>As a side effect of this call, this calendar is advanced
-     * toward <code>when</code> by the given amount.  That is, calling
-     * this method has the side effect of calling <code>add(field,
-     * n)</code>, where <code>n</code> is the return value.
-     *
-     * <p>Usage: To use this method, call it first with the largest
-     * field of interest, then with progressively smaller fields.  For
-     * example:
-     *
-     * <pre>
-     * int y = cal->fieldDifference(when, Calendar::YEAR, err);
-     * int m = cal->fieldDifference(when, Calendar::MONTH, err);
-     * int d = cal->fieldDifference(when, Calendar::DATE, err);</pre>
-     *
-     * computes the difference between <code>cal</code> and
-     * <code>when</code> in years, months, and days.
-     *
-     * <p>Note: <code>fieldDifference()</code> is
-     * <em>asymmetrical</em>.  That is, in the following code:
-     *
-     * <pre>
-     * cal->setTime(date1, err);
-     * int m1 = cal->fieldDifference(date2, Calendar::MONTH, err);
-     * int d1 = cal->fieldDifference(date2, Calendar::DATE, err);
-     * cal->setTime(date2, err);
-     * int m2 = cal->fieldDifference(date1, Calendar::MONTH, err);
-     * int d2 = cal->fieldDifference(date1, Calendar::DATE, err);</pre>
-     *
-     * one might expect that <code>m1 == -m2 && d1 == -d2</code>.
-     * However, this is not generally the case, because of
-     * irregularities in the underlying calendar system (e.g., the
-     * Gregorian calendar has a varying number of days per month).
-     *
-     * @param when the date to compare this calendar's time to
-     * @param field the field in which to compute the result
-     * @param status  Output param set to success/failure code on exit. If any value
-     *                previously set in the time field is invalid, this will be set to
-     *                an error status.
-     * @return the difference, either positive or negative, between
-     * this calendar's time and <code>when</code>, in terms of
-     * <code>field</code>.
-     * @stable ICU 2.6.
-     */
-    virtual int32_t fieldDifference(UDate when, UCalendarDateFields field, UErrorCode& status);
-
-    /**
-     * Sets the calendar's time zone to be the one passed in. The Calendar takes ownership
-     * of the TimeZone; the caller is no longer responsible for deleting it.  If the
-     * given time zone is NULL, this function has no effect.
-     *
-     * @param value  The given time zone.
-     * @stable ICU 2.0
-     */
-    void adoptTimeZone(TimeZone* value);
-
-    /**
-     * Sets the calendar's time zone to be the same as the one passed in. The TimeZone
-     * passed in is _not_ adopted; the client is still responsible for deleting it.
-     *
-     * @param zone  The given time zone.
-     * @stable ICU 2.0
-     */
-    void setTimeZone(const TimeZone& zone);
-
-    /**
-     * Returns a reference to the time zone owned by this calendar. The returned reference
-     * is only valid until clients make another call to adoptTimeZone or setTimeZone,
-     * or this Calendar is destroyed.
-     *
-     * @return   The time zone object associated with this calendar.
-     * @stable ICU 2.0
-     */
-    const TimeZone& getTimeZone(void) const;
-
-    /**
-     * Returns the time zone owned by this calendar. The caller owns the returned object
-     * and must delete it when done.  After this call, the new time zone associated
-     * with this Calendar is the default TimeZone as returned by TimeZone::createDefault().
-     *
-     * @return   The time zone object which was associated with this calendar.
-     * @stable ICU 2.0
-     */
-    TimeZone* orphanTimeZone(void);
-
-    /**
-     * Queries if the current date for this Calendar is in Daylight Savings Time.
-     *
-     * @param status Fill-in parameter which receives the status of this operation.
-     * @return   True if the current date for this Calendar is in Daylight Savings Time,
-     *           false, otherwise.
-     * @stable ICU 2.0
-     */
-    virtual UBool inDaylightTime(UErrorCode& status) const = 0;
-
-    /**
-     * Specifies whether or not date/time interpretation is to be lenient. With lenient
-     * interpretation, a date such as "February 942, 1996" will be treated as being
-     * equivalent to the 941st day after February 1, 1996. With strict interpretation,
-     * such dates will cause an error when computing time from the time field values
-     * representing the dates.
-     *
-     * @param lenient  True specifies date/time interpretation to be lenient.
-     *
-     * @see            DateFormat#setLenient
-     * @stable ICU 2.0
-     */
-    void setLenient(UBool lenient);
-
-    /**
-     * Tells whether date/time interpretation is to be lenient.
-     *
-     * @return   True tells that date/time interpretation is to be lenient.
-     * @stable ICU 2.0
-     */
-    UBool isLenient(void) const;
-
-    /**
-     * Sets what the first day of the week is; e.g., Sunday in US, Monday in France.
-     *
-     * @param value  The given first day of the week.
-     * @deprecated ICU 2.6. Use setFirstDayOfWeek(UCalendarDaysOfWeek value) instead.
-     */
-    void setFirstDayOfWeek(EDaysOfWeek value);
-
-    /**
-     * Sets what the first day of the week is; e.g., Sunday in US, Monday in France.
-     *
-     * @param value  The given first day of the week.
-     * @stable ICU 2.6.
-     */
-    void setFirstDayOfWeek(UCalendarDaysOfWeek value);
-
-    /**
-     * Gets what the first day of the week is; e.g., Sunday in US, Monday in France.
-     *
-     * @return   The first day of the week.
-     * @deprecated ICU 2.6 use the overload with error code
-     */
-    EDaysOfWeek getFirstDayOfWeek(void) const;
-
-    /**
-     * Gets what the first day of the week is; e.g., Sunday in US, Monday in France.
-     *
-     * @param status error code
-     * @return   The first day of the week.
-     * @stable ICU 2.6
-     */
-    UCalendarDaysOfWeek getFirstDayOfWeek(UErrorCode &status) const;
-
-    /**
-     * Sets what the minimal days required in the first week of the year are; For
-     * example, if the first week is defined as one that contains the first day of the
-     * first month of a year, call the method with value 1. If it must be a full week,
-     * use value 7.
-     *
-     * @param value  The given minimal days required in the first week of the year.
-     * @stable ICU 2.0
-     */
-    void setMinimalDaysInFirstWeek(uint8_t value);
-
-    /**
-     * Gets what the minimal days required in the first week of the year are; e.g., if
-     * the first week is defined as one that contains the first day of the first month
-     * of a year, getMinimalDaysInFirstWeek returns 1. If the minimal days required must
-     * be a full week, getMinimalDaysInFirstWeek returns 7.
-     *
-     * @return   The minimal days required in the first week of the year.
-     * @stable ICU 2.0
-     */
-    uint8_t getMinimalDaysInFirstWeek(void) const;
-
-    /**
-     * Gets the minimum value for the given time field. e.g., for Gregorian
-     * DAY_OF_MONTH, 1.
-     *
-     * @param field  The given time field.
-     * @return       The minimum value for the given time field.
-     * @deprecated ICU 2.6. Use getMinimum(UCalendarDateFields field) instead.
-     */
-    virtual int32_t getMinimum(EDateFields field) const;
-
-    /**
-     * Gets the minimum value for the given time field. e.g., for Gregorian
-     * DAY_OF_MONTH, 1.
-     *
-     * @param field  The given time field.
-     * @return       The minimum value for the given time field.
-     * @stable ICU 2.6.
-     */
-    virtual int32_t getMinimum(UCalendarDateFields field) const;
-
-    /**
-     * Gets the maximum value for the given time field. e.g. for Gregorian DAY_OF_MONTH,
-     * 31.
-     *
-     * @param field  The given time field.
-     * @return       The maximum value for the given time field.
-     * @deprecated ICU 2.6. Use getMaximum(UCalendarDateFields field) instead.
-     */
-    virtual int32_t getMaximum(EDateFields field) const;
-
-    /**
-     * Gets the maximum value for the given time field. e.g. for Gregorian DAY_OF_MONTH,
-     * 31.
-     *
-     * @param field  The given time field.
-     * @return       The maximum value for the given time field.
-     * @stable ICU 2.6.
-     */
-    virtual int32_t getMaximum(UCalendarDateFields field) const;
-
-    /**
-     * Gets the highest minimum value for the given field if varies. Otherwise same as
-     * getMinimum(). For Gregorian, no difference.
-     *
-     * @param field  The given time field.
-     * @return       The highest minimum value for the given time field.
-     * @deprecated ICU 2.6. Use getGreatestMinimum(UCalendarDateFields field) instead.
-     */
-    virtual int32_t getGreatestMinimum(EDateFields field) const;
-
-    /**
-     * Gets the highest minimum value for the given field if varies. Otherwise same as
-     * getMinimum(). For Gregorian, no difference.
-     *
-     * @param field  The given time field.
-     * @return       The highest minimum value for the given time field.
-     * @stable ICU 2.6.
-     */
-    virtual int32_t getGreatestMinimum(UCalendarDateFields field) const;
-
-    /**
-     * Gets the lowest maximum value for the given field if varies. Otherwise same as
-     * getMaximum(). e.g., for Gregorian DAY_OF_MONTH, 28.
-     *
-     * @param field  The given time field.
-     * @return       The lowest maximum value for the given time field.
-     * @deprecated ICU 2.6. Use getLeastMaximum(UCalendarDateFields field) instead.
-     */
-    virtual int32_t getLeastMaximum(EDateFields field) const;
-
-    /**
-     * Gets the lowest maximum value for the given field if varies. Otherwise same as
-     * getMaximum(). e.g., for Gregorian DAY_OF_MONTH, 28.
-     *
-     * @param field  The given time field.
-     * @return       The lowest maximum value for the given time field.
-     * @stable ICU 2.6.
-     */
-    virtual int32_t getLeastMaximum(UCalendarDateFields field) const;
-
-    /**
-     * Return the minimum value that this field could have, given the current date.
-     * For the Gregorian calendar, this is the same as getMinimum() and getGreatestMinimum().
-     *
-     * The version of this function on Calendar uses an iterative algorithm to determine the
-     * actual minimum value for the field.  There is almost always a more efficient way to
-     * accomplish this (in most cases, you can simply return getMinimum()).  GregorianCalendar
-     * overrides this function with a more efficient implementation.
-     *
-     * @param field    the field to determine the minimum of
-     * @param status   Fill-in parameter which receives the status of this operation.
-     * @return         the minimum of the given field for the current date of this Calendar
-     * @deprecated ICU 2.6. Use getActualMinimum(UCalendarDateFields field, UErrorCode& status) instead.
-     */
-    int32_t getActualMinimum(EDateFields field, UErrorCode& status) const;
-
-    /**
-     * Return the minimum value that this field could have, given the current date.
-     * For the Gregorian calendar, this is the same as getMinimum() and getGreatestMinimum().
-     *
-     * The version of this function on Calendar uses an iterative algorithm to determine the
-     * actual minimum value for the field.  There is almost always a more efficient way to
-     * accomplish this (in most cases, you can simply return getMinimum()).  GregorianCalendar
-     * overrides this function with a more efficient implementation.
-     *
-     * @param field    the field to determine the minimum of
-     * @param status   Fill-in parameter which receives the status of this operation.
-     * @return         the minimum of the given field for the current date of this Calendar
-     * @stable ICU 2.6.
-     */
-    virtual int32_t getActualMinimum(UCalendarDateFields field, UErrorCode& status) const;
-
-    /**
-     * Return the maximum value that this field could have, given the current date.
-     * For example, with the date "Feb 3, 1997" and the DAY_OF_MONTH field, the actual
-     * maximum would be 28; for "Feb 3, 1996" it s 29.  Similarly for a Hebrew calendar,
-     * for some years the actual maximum for MONTH is 12, and for others 13.
-     *
-     * The version of this function on Calendar uses an iterative algorithm to determine the
-     * actual maximum value for the field.  There is almost always a more efficient way to
-     * accomplish this (in most cases, you can simply return getMaximum()).  GregorianCalendar
-     * overrides this function with a more efficient implementation.
-     *
-     * @param field    the field to determine the maximum of
-     * @param status   Fill-in parameter which receives the status of this operation.
-     * @return         the maximum of the given field for the current date of this Calendar
-     * @deprecated ICU 2.6. Use getActualMaximum(UCalendarDateFields field, UErrorCode& status) instead.
-     */
-    int32_t getActualMaximum(EDateFields field, UErrorCode& status) const;
-
-    /**
-     * Return the maximum value that this field could have, given the current date.
-     * For example, with the date "Feb 3, 1997" and the DAY_OF_MONTH field, the actual
-     * maximum would be 28; for "Feb 3, 1996" it s 29.  Similarly for a Hebrew calendar,
-     * for some years the actual maximum for MONTH is 12, and for others 13.
-     *
-     * The version of this function on Calendar uses an iterative algorithm to determine the
-     * actual maximum value for the field.  There is almost always a more efficient way to
-     * accomplish this (in most cases, you can simply return getMaximum()).  GregorianCalendar
-     * overrides this function with a more efficient implementation.
-     *
-     * @param field    the field to determine the maximum of
-     * @param status   Fill-in parameter which receives the status of this operation.
-     * @return         the maximum of the given field for the current date of this Calendar
-     * @stable ICU 2.6.
-     */
-    virtual int32_t getActualMaximum(UCalendarDateFields field, UErrorCode& status) const;
-
-    /**
-     * Gets the value for a given time field. Recalculate the current time field values
-     * if the time value has been changed by a call to setTime(). Return zero for unset
-     * fields if any fields have been explicitly set by a call to set(). To force a
-     * recomputation of all fields regardless of the previous state, call complete().
-     * This method is semantically const, but may alter the object in memory.
-     *
-     * @param field  The given time field.
-     * @param status Fill-in parameter which receives the status of the operation.
-     * @return       The value for the given time field, or zero if the field is unset,
-     *               and set() has been called for any other field.
-     * @deprecated ICU 2.6. Use get(UCalendarDateFields field, UErrorCode& status) instead.
-     */
-    int32_t get(EDateFields field, UErrorCode& status) const;
-
-    /**
-     * Gets the value for a given time field. Recalculate the current time field values
-     * if the time value has been changed by a call to setTime(). Return zero for unset
-     * fields if any fields have been explicitly set by a call to set(). To force a
-     * recomputation of all fields regardless of the previous state, call complete().
-     * This method is semantically const, but may alter the object in memory.
-     *
-     * @param field  The given time field.
-     * @param status Fill-in parameter which receives the status of the operation.
-     * @return       The value for the given time field, or zero if the field is unset,
-     *               and set() has been called for any other field.
-     * @stable ICU 2.6.
-     */
-    int32_t get(UCalendarDateFields field, UErrorCode& status) const;
-
-    /**
-     * Determines if the given time field has a value set. This can affect in the
-     * resolving of time in Calendar. Unset fields have a value of zero, by definition.
-     *
-     * @param field  The given time field.
-     * @return   True if the given time field has a value set; false otherwise.
-     * @deprecated ICU 2.6. Use isSet(UCalendarDateFields field) instead.
-     */
-    UBool isSet(EDateFields field) const;
-
-    /**
-     * Determines if the given time field has a value set. This can affect in the
-     * resolving of time in Calendar. Unset fields have a value of zero, by definition.
-     *
-     * @param field  The given time field.
-     * @return   True if the given time field has a value set; false otherwise.
-     * @stable ICU 2.6.
-     */
-    UBool isSet(UCalendarDateFields field) const;
-
-    /**
-     * Sets the given time field with the given value.
-     *
-     * @param field  The given time field.
-     * @param value  The value to be set for the given time field.
-     * @deprecated ICU 2.6. Use set(UCalendarDateFields field, int32_t value) instead.
-     */
-    void set(EDateFields field, int32_t value);
-
-    /**
-     * Sets the given time field with the given value.
-     *
-     * @param field  The given time field.
-     * @param value  The value to be set for the given time field.
-     * @stable ICU 2.6.
-     */
-    void set(UCalendarDateFields field, int32_t value);
-
-    /**
-     * Sets the values for the fields YEAR, MONTH, and DATE. Other field values are
-     * retained; call clear() first if this is not desired.
-     *
-     * @param year   The value used to set the YEAR time field.
-     * @param month  The value used to set the MONTH time field. Month value is 0-based.
-     *               e.g., 0 for January.
-     * @param date   The value used to set the DATE time field.
-     * @stable ICU 2.0
-     */
-    void set(int32_t year, int32_t month, int32_t date);
-
-    /**
-     * Sets the values for the fields YEAR, MONTH, DATE, HOUR_OF_DAY, and MINUTE. Other
-     * field values are retained; call clear() first if this is not desired.
-     *
-     * @param year    The value used to set the YEAR time field.
-     * @param month   The value used to set the MONTH time field. Month value is
-     *                0-based. E.g., 0 for January.
-     * @param date    The value used to set the DATE time field.
-     * @param hour    The value used to set the HOUR_OF_DAY time field.
-     * @param minute  The value used to set the MINUTE time field.
-     * @stable ICU 2.0
-     */
-    void set(int32_t year, int32_t month, int32_t date, int32_t hour, int32_t minute);
-
-    /**
-     * Sets the values for the fields YEAR, MONTH, DATE, HOUR_OF_DAY, MINUTE, and SECOND.
-     * Other field values are retained; call clear() first if this is not desired.
-     *
-     * @param year    The value used to set the YEAR time field.
-     * @param month   The value used to set the MONTH time field. Month value is
-     *                0-based. E.g., 0 for January.
-     * @param date    The value used to set the DATE time field.
-     * @param hour    The value used to set the HOUR_OF_DAY time field.
-     * @param minute  The value used to set the MINUTE time field.
-     * @param second  The value used to set the SECOND time field.
-     * @stable ICU 2.0
-     */
-    void set(int32_t year, int32_t month, int32_t date, int32_t hour, int32_t minute, int32_t second);
-
-    /**
-     * Clears the values of all the time fields, making them both unset and assigning
-     * them a value of zero. The field values will be determined during the next
-     * resolving of time into time fields.
-     * @stable ICU 2.0
-     */
-    void clear(void);
-
-    /**
-     * Clears the value in the given time field, both making it unset and assigning it a
-     * value of zero. This field value will be determined during the next resolving of
-     * time into time fields.
-     *
-     * @param field  The time field to be cleared.
-     * @deprecated ICU 2.6. Use clear(UCalendarDateFields field) instead.
-     */
-    void clear(EDateFields field);
-
-    /**
-     * Clears the value in the given time field, both making it unset and assigning it a
-     * value of zero. This field value will be determined during the next resolving of
-     * time into time fields.
-     *
-     * @param field  The time field to be cleared.
-     * @stable ICU 2.6.
-     */
-    void clear(UCalendarDateFields field);
-
-    /**
-     * Returns a unique class ID POLYMORPHICALLY. Pure virtual method. This method is to
-     * implement a simple version of RTTI, since not all C++ compilers support genuine
-     * RTTI. Polymorphic operator==() and clone() methods call this method.
-     * <P>
-     * Concrete subclasses of Calendar must implement getDynamicClassID() and also a
-     * static method and data member:
-     *
-     *      static UClassID getStaticClassID() { return (UClassID)&amp;fgClassID; }
-     *      static char fgClassID;
-     *
-     * @return   The class ID for this object. All objects of a given class have the
-     *           same class ID. Objects of other classes have different class IDs.
-     * @stable ICU 2.0
-     */
-    virtual UClassID getDynamicClassID(void) const = 0;
-
-    /**
-     * Returns the resource key string used for this calendar type.
-     * For example, prepending "Eras_" to this string could return "Eras_japanese"
-     * or "Eras_gregorian".
-     *
-     * @returns static string, for example, "gregorian" or "japanese"
-     * @internal
-     */
-    virtual const char * getType() const = 0;
-
-protected:
-
-     /**
-      * Constructs a Calendar with the default time zone as returned by
-      * TimeZone::createInstance(), and the default locale.
-      *
-      * @param success  Indicates the status of Calendar object construction. Returns
-      *                 U_ZERO_ERROR if constructed successfully.
-     * @stable ICU 2.0
-      */
-    Calendar(UErrorCode& success);
-
-    /**
-     * Copy constructor
-     *
-     * @param source    Calendar object to be copied from
-     * @stable ICU 2.0
-     */
-    Calendar(const Calendar& source);
-
-    /**
-     * Default assignment operator
-     *
-     * @param right    Calendar object to be copied
-     * @stable ICU 2.0
-     */
-    Calendar& operator=(const Calendar& right);
-
-    /**
-     * Constructs a Calendar with the given time zone and locale. Clients are no longer
-     * responsible for deleting the given time zone object after it's adopted.
-     *
-     * @param zone     The given time zone.
-     * @param aLocale  The given locale.
-     * @param success  Indicates the status of Calendar object construction. Returns
-     *                 U_ZERO_ERROR if constructed successfully.
-     * @stable ICU 2.0
-     */
-    Calendar(TimeZone* zone, const Locale& aLocale, UErrorCode& success);
-
-    /**
-     * Constructs a Calendar with the given time zone and locale.
-     *
-     * @param zone     The given time zone.
-     * @param aLocale  The given locale.
-     * @param success  Indicates the status of Calendar object construction. Returns
-     *                 U_ZERO_ERROR if constructed successfully.
-     * @stable ICU 2.0
-     */
-    Calendar(const TimeZone& zone, const Locale& aLocale, UErrorCode& success);
-
-    /**
-     * Converts Calendar's time field values to GMT as milliseconds.
-     *
-     * @param status  Output param set to success/failure code on exit. If any value
-     *                previously set in the time field is invalid or restricted by
-     *                leniency, this will be set to an error status.
-     * @stable ICU 2.0
-     */
-    virtual void computeTime(UErrorCode& status);
-
-    /**
-     * Converts GMT as milliseconds to time field values. This allows you to sync up the
-     * time field values with a new time that is set for the calendar.  This method
-     * does NOT recompute the time first; to recompute the time, then the fields, use
-     * the method complete().
-     *
-     * @param status  Output param set to success/failure code on exit. If any value
-     *                previously set in the time field is invalid or restricted by
-     *                leniency, this will be set to an error status.
-     * @stable ICU 2.0
-     */
-    virtual void computeFields(UErrorCode& status);
-
-    /**
-     * Gets this Calendar's current time as a long.
-     *
-     * @param status  Output param set to success/failure code on exit. If any value
-     *                previously set in the time field is invalid or restricted by
-     *                leniency, this will be set to an error status.
-     * @return the current time as UTC milliseconds from the epoch.
-     * @stable ICU 2.0
-     */
-    double getTimeInMillis(UErrorCode& status) const;
-
-    /**
-     * Sets this Calendar's current time from the given long value.
-     * @param millis  the new time in UTC milliseconds from the epoch.
-     * @param status  Output param set to success/failure code on exit. If any value
-     *                previously set in the time field is invalid or restricted by
-     *                leniency, this will be set to an error status.
-     * @stable ICU 2.0
-     */
-    void setTimeInMillis( double millis, UErrorCode& status );
-
-    /**
-     * Recomputes the current time from currently set fields, and then fills in any
-     * unset fields in the time field list.
-     *
-     * @param status  Output param set to success/failure code on exit. If any value
-     *                previously set in the time field is invalid or restricted by
-     *                leniency, this will be set to an error status.
-     * @stable ICU 2.0
-     */
-    void complete(UErrorCode& status);
-
-    /**
-     * Gets the value for a given time field. Subclasses can use this function to get
-     * field values without forcing recomputation of time.
-     *
-     * @param field  The given time field.
-     * @return       The value for the given time field.
-     * @deprecated ICU 2.6. Use internalGet(UCalendarDateFields field) instead.
-     */
-    inline int32_t internalGet(EDateFields field) const {return fFields[field];}
-
-    /**
-     * Gets the value for a given time field. Subclasses can use this function to get
-     * field values without forcing recomputation of time. If the field's stamp is UNSET,
-     * the defaultValue is used.
-     *
-     * @param field  The given time field.
-     * @param defaultValue a default value used if the field is unset.
-     * @return       The value for the given time field.
-     * @internal
-     */
-    inline int32_t internalGet(UCalendarDateFields field, int32_t defaultValue) const {return fStamp[field]>kUnset ? fFields[field] : defaultValue;}
-
-    /**
-     * Gets the value for a given time field. Subclasses can use this function to get
-     * field values without forcing recomputation of time.
-     *
-     * @param field  The given time field.
-     * @return       The value for the given time field.
-     * @internal
-     */
-    inline int32_t internalGet(UCalendarDateFields field) const {return fFields[field];}
-
-    /**
-     * Sets the value for a given time field.  This is a fast internal method for
-     * subclasses.  It does not affect the areFieldsInSync, isTimeSet, or areAllFieldsSet
-     * flags.
-     *
-     * @param field    The given time field.
-     * @param value    The value for the given time field.
-     * @deprecated ICU 2.6. Use internalSet(UCalendarDateFields field, int32_t value) instead.
-     */
-    void internalSet(EDateFields field, int32_t value);
-
-    /**
-     * Sets the value for a given time field.  This is a fast internal method for
-     * subclasses.  It does not affect the areFieldsInSync, isTimeSet, or areAllFieldsSet
-     * flags.
-     *
-     * @param field    The given time field.
-     * @param value    The value for the given time field.
-     * @stable ICU 2.6.
-     */
-    inline void internalSet(UCalendarDateFields field, int32_t value);
-
-    /**
-     * Prepare this calendar for computing the actual minimum or maximum.
-     * This method modifies this calendar's fields; it is called on a
-     * temporary calendar.
-     * @internal
-     */
-    virtual void prepareGetActual(UCalendarDateFields field, UBool isMinimum, UErrorCode &status);
-
-    /**
-     * Limit enums. Not in sync with UCalendarLimitType (refers to internal fields).
-     * @internal
-     */
-    enum ELimitType {
-      UCAL_LIMIT_MINIMUM = 0,
-      UCAL_LIMIT_GREATEST_MINIMUM,
-      UCAL_LIMIT_LEAST_MAXIMUM,
-      UCAL_LIMIT_MAXIMUM,
-      UCAL_LIMIT_COUNT
-    };
-
-    /**
-     * Subclass API for defining limits of different types.
-     * Subclasses must implement this method to return limits for the
-     * following fields:
-     *
-     * <pre>UCAL_ERA
-     * UCAL_YEAR
-     * UCAL_MONTH
-     * UCAL_WEEK_OF_YEAR
-     * UCAL_WEEK_OF_MONTH
-     * UCAL_DATE (DAY_OF_MONTH on Java)
-     * UCAL_DAY_OF_YEAR
-     * UCAL_DAY_OF_WEEK_IN_MONTH
-     * UCAL_YEAR_WOY
-     * UCAL_EXTENDED_YEAR</pre>
-     *
-     * @param field one of the above field numbers
-     * @param limitType one of <code>MINIMUM</code>, <code>GREATEST_MINIMUM</code>,
-     * <code>LEAST_MAXIMUM</code>, or <code>MAXIMUM</code>
-     * @internal
-     */
-    virtual int32_t handleGetLimit(UCalendarDateFields field, ELimitType limitType) const = 0;
-
-    /**
-     * Return a limit for a field.
-     * @param field the field, from <code>0..UCAL_MAX_FIELD</code>
-     * @param limitType the type specifier for the limit
-     * @see #ELimitType
-     * @internal
-     */
-    virtual int32_t getLimit(UCalendarDateFields field, ELimitType limitType) const;
-
-
-    /**
-     * Return the Julian day number of day before the first day of the
-     * given month in the given extended year.  Subclasses should override
-     * this method to implement their calendar system.
-     * @param eyear the extended year
-     * @param month the zero-based month, or 0 if useMonth is false
-     * @param useMonth if false, compute the day before the first day of
-     * the given year, otherwise, compute the day before the first day of
-     * the given month
-     * @return the Julian day number of the day before the first
-     * day of the given month and year
-     * @internal
-     */
-    virtual int32_t handleComputeMonthStart(int32_t eyear, int32_t month,
-                                                   UBool useMonth) const  = 0;
-
-    /**
-     * Return the number of days in the given month of the given extended
-     * year of this calendar system.  Subclasses should override this
-     * method if they can provide a more correct or more efficient
-     * implementation than the default implementation in Calendar.
-     * @internal
-     */
-    virtual int32_t handleGetMonthLength(int32_t extendedYear, int32_t month) const ;
-
-    /**
-     * Return the number of days in the given extended year of this
-     * calendar system.  Subclasses should override this method if they can
-     * provide a more correct or more efficient implementation than the
-     * default implementation in Calendar.
-     * @stable ICU 2.0
-     */
-    virtual int32_t handleGetYearLength(int32_t eyear) const;
-
-
-    /**
-     * Return the extended year defined by the current fields.  This will
-     * use the UCAL_EXTENDED_YEAR field or the UCAL_YEAR and supra-year fields (such
-     * as UCAL_ERA) specific to the calendar system, depending on which set of
-     * fields is newer.
-     * @return the extended year
-     * @internal
-     */
-    virtual int32_t handleGetExtendedYear() = 0;
-
-    /**
-     * Subclasses may override this.  This method calls
-     * handleGetMonthLength() to obtain the calendar-specific month
-     * length.
-     * @param bestField which field to use to calculate the date
-     * @return julian day specified by calendar fields.
-     * @internal
-     */
-    virtual int32_t handleComputeJulianDay(UCalendarDateFields bestField);
-
-    /**
-     * Subclasses must override this to convert from week fields
-     * (YEAR_WOY and WEEK_OF_YEAR) to an extended year in the case
-     * where YEAR, EXTENDED_YEAR are not set.
-     * The Calendar implementation assumes yearWoy is in extended gregorian form
-     * @internal
-     * @return the extended year, UCAL_EXTENDED_YEAR
-     */
-    virtual int32_t handleGetExtendedYearFromWeekFields(int32_t yearWoy, int32_t woy);
-
-    /**
-     * Compute the Julian day from fields.  Will determine whether to use
-     * the JULIAN_DAY field directly, or other fields.
-     * @return the julian day
-     * @internal
-     */
-    int32_t computeJulianDay();
-
-    /**
-     * Compute the milliseconds in the day from the fields.  This is a
-     * value from 0 to 23:59:59.999 inclusive, unless fields are out of
-     * range, in which case it can be an arbitrary value.  This value
-     * reflects local zone wall time.
-     * @internal
-     */
-    int32_t computeMillisInDay();
-
-    /**
-     * This method can assume EXTENDED_YEAR has been set.
-     * @param millis milliseconds of the date fields
-     * @param millisInDay milliseconds of the time fields; may be out
-     * or range.
-     * @param ec Output param set to failure code on function return
-     *          when this function fails.
-     * @internal
-     */
-    int32_t computeZoneOffset(double millis, int32_t millisInDay, UErrorCode &ec);
-
-
-    /**
-     * Determine the best stamp in a range.
-     * @param start first enum to look at
-     * @param end last enum to look at
-     * @param bestSoFar stamp prior to function call
-     * @return the stamp value of the best stamp
-     * @internal
-     */
-    int32_t newestStamp(UCalendarDateFields start, UCalendarDateFields end, int32_t bestSoFar) const;
-
-    /**
-     * Values for field resolution tables
-     * @see #resolveFields
-     * @internal
-     */
-    enum {
-      /** Marker for end of resolve set (row or group). */
-      kResolveSTOP = -1,
-      /** Value to be bitwised "ORed" against resolve table field values for remapping.  Example: (UCAL_DATE | kResolveRemap) in 1st column will cause 'UCAL_DATE' to be returned, but will not examine the value of UCAL_DATE.  */
-      kResolveRemap = 32
-    };
-
-    /**
-     * Precedence table for Dates
-     * @see #resolveFields
-     * @internal
-     */
-    static const UFieldResolutionTable kDatePrecedence[];
-
-    /**
-     * Precedence table for Year
-     * @see #resolveFields
-     * @internal
-     */
-    static const UFieldResolutionTable kYearPrecedence[];
-
-    /**
-     * Precedence table for Day of Week
-     * @see #resolveFields
-     * @internal
-     */
-    static const UFieldResolutionTable kDOWPrecedence[];
-
-    /**
-     * Given a precedence table, return the newest field combination in
-     * the table, or UCAL_FIELD_COUNT if none is found.
-     *
-     * <p>The precedence table is a 3-dimensional array of integers.  It
-     * may be thought of as an array of groups.  Each group is an array of
-     * lines.  Each line is an array of field numbers.  Within a line, if
-     * all fields are set, then the time stamp of the line is taken to be
-     * the stamp of the most recently set field.  If any field of a line is
-     * unset, then the line fails to match.  Within a group, the line with
-     * the newest time stamp is selected.  The first field of the line is
-     * returned to indicate which line matched.
-     *
-     * <p>In some cases, it may be desirable to map a line to field that
-     * whose stamp is NOT examined.  For example, if the best field is
-     * DAY_OF_WEEK then the DAY_OF_WEEK_IN_MONTH algorithm may be used.  In
-     * order to do this, insert the value <code>kResolveRemap | F</code> at
-     * the start of the line, where <code>F</code> is the desired return
-     * field value.  This field will NOT be examined; it only determines
-     * the return value if the other fields in the line are the newest.
-     *
-     * <p>If all lines of a group contain at least one unset field, then no
-     * line will match, and the group as a whole will fail to match.  In
-     * that case, the next group will be processed.  If all groups fail to
-     * match, then UCAL_FIELD_COUNT is returned.
-     * @internal
-     */
-    UCalendarDateFields resolveFields(const UFieldResolutionTable *precedenceTable);
-
-
-    /**
-     * @internal
-     */
-    virtual const UFieldResolutionTable* getFieldResolutionTable() const;
-
-    /**
-     * Return the field that is newer, either defaultField, or
-     * alternateField.  If neither is newer or neither is set, return defaultField.
-     * @internal
-     */
-    UCalendarDateFields newerField(UCalendarDateFields defaultField, UCalendarDateFields alternateField) const;
-
-
-private:
-    /**
-     * Helper function for calculating limits by trial and error
-     * @param field The field being investigated
-     * @param startValue starting (least max) value of field
-     * @param endValue ending (greatest max) value of field
-     * @param status return type
-     * @internal
-     */
-    int32_t getActualHelper(UCalendarDateFields field, int32_t startValue, int32_t endValue, UErrorCode &status) const;
-
-
-protected:
-    /**
-     * The flag which indicates if the current time is set in the calendar.
-     * @stable ICU 2.0
-     */
-    UBool      fIsTimeSet;
-
-    /**
-     * True if the fields are in sync with the currently set time of this Calendar.
-     * If false, then the next attempt to get the value of a field will
-     * force a recomputation of all fields from the current value of the time
-     * field.
-     * <P>
-     * This should really be named areFieldsInSync, but the old name is retained
-     * for backward compatibility.
-     * @stable ICU 2.0
-     */
-    UBool      fAreFieldsSet;
-
-    /**
-     * True if all of the fields have been set.  This is initially false, and set to
-     * true by computeFields().
-     * @stable ICU 2.0
-     */
-    UBool      fAreAllFieldsSet;
-
-    /**
-     * True if all fields have been virtually set, but have not yet been
-     * computed.  This occurs only in setTimeInMillis().  A calendar set
-     * to this state will compute all fields from the time if it becomes
-     * necessary, but otherwise will delay such computation.
-     * @stable ICU 3.0
-     */
-    UBool fAreFieldsVirtuallySet;
-
-    /**
-     * Get the current time without recomputing.
-     *
-     * @return     the current time without recomputing.
-     * @stable ICU 2.0
-     */
-    UDate        internalGetTime(void) const     { return fTime; }
-
-    /**
-     * Set the current time without affecting flags or fields.
-     *
-     * @param time    The time to be set
-     * @return        the current time without recomputing.
-     * @stable ICU 2.0
-     */
-    void        internalSetTime(UDate time)     { fTime = time; }
-
-    /**
-     * The time fields containing values into which the millis is computed.
-     * @stable ICU 2.0
-     */
-    int32_t     fFields[UCAL_FIELD_COUNT];
-
-    /**
-     * The flags which tell if a specified time field for the calendar is set.
-     * @deprecated ICU 2.8 use (fStamp[n]!=kUnset)
-     */
-    UBool      fIsSet[UCAL_FIELD_COUNT];
-
-    /** Special values of stamp[]
-     * @stable ICU 2.0
-     */
-    enum {
-        kUnset                 = 0,
-        kInternallySet,
-        kMinimumUserStamp
-    };
-
-    /**
-     * Pseudo-time-stamps which specify when each field was set. There
-     * are two special values, UNSET and INTERNALLY_SET. Values from
-     * MINIMUM_USER_SET to Integer.MAX_VALUE are legal user set values.
-     * @stable ICU 2.0
-     */
-    int32_t        fStamp[UCAL_FIELD_COUNT];
-
-    /**
-     * Subclasses may override this method to compute several fields
-     * specific to each calendar system.  These are:
-     *
-     * <ul><li>ERA
-     * <li>YEAR
-     * <li>MONTH
-     * <li>DAY_OF_MONTH
-     * <li>DAY_OF_YEAR
-     * <li>EXTENDED_YEAR</ul>
-     *
-     * Subclasses can refer to the DAY_OF_WEEK and DOW_LOCAL fields, which
-     * will be set when this method is called.  Subclasses can also call
-     * the getGregorianXxx() methods to obtain Gregorian calendar
-     * equivalents for the given Julian day.
-     *
-     * <p>In addition, subclasses should compute any subclass-specific
-     * fields, that is, fields from BASE_FIELD_COUNT to
-     * getFieldCount() - 1.
-     *
-     * <p>The default implementation in <code>Calendar</code> implements
-     * a pure proleptic Gregorian calendar.
-     * @internal
-     */
-    virtual void handleComputeFields(int32_t julianDay, UErrorCode &status);
-
-    /**
-     * Return the extended year on the Gregorian calendar as computed by
-     * <code>computeGregorianFields()</code>.
-     * @internal
-     */
-    int32_t getGregorianYear() const {
-        return fGregorianYear;
-    }
-
-    /**
-     * Return the month (0-based) on the Gregorian calendar as computed by
-     * <code>computeGregorianFields()</code>.
-     * @internal
-     */
-    int32_t getGregorianMonth() const {
-        return fGregorianMonth;
-    }
-
-    /**
-     * Return the day of year (1-based) on the Gregorian calendar as
-     * computed by <code>computeGregorianFields()</code>.
-     * @internal
-     */
-    int32_t getGregorianDayOfYear() const {
-        return fGregorianDayOfYear;
-    }
-
-    /**
-     * Return the day of month (1-based) on the Gregorian calendar as
-     * computed by <code>computeGregorianFields()</code>.
-     * @internal
-     */
-    int32_t getGregorianDayOfMonth() const {
-      return fGregorianDayOfMonth;
-    }
-
-    /**
-     * Called by computeJulianDay.  Returns the default month (0-based) for the year,
-     * taking year and era into account.  Defaults to 0 for Gregorian, which doesn't care.
-     * @internal
-     * @internal
-     */
-    virtual int32_t getDefaultMonthInYear() ;
-
-
-    /**
-     * Called by computeJulianDay.  Returns the default day (1-based) for the month,
-     * taking currently-set year and era into account.  Defaults to 1 for Gregorian.
-     * @internal
-     */
-    virtual int32_t getDefaultDayInMonth(int32_t /*month*/);
-
-    //-------------------------------------------------------------------------
-    // Protected utility methods for use by subclasses.  These are very handy
-    // for implementing add, roll, and computeFields.
-    //-------------------------------------------------------------------------
-
-    /**
-     * Adjust the specified field so that it is within
-     * the allowable range for the date to which this calendar is set.
-     * For example, in a Gregorian calendar pinning the {@link #UCalendarDateFields DAY_OF_MONTH}
-     * field for a calendar set to April 31 would cause it to be set
-     * to April 30.
-     * <p>
-     * <b>Subclassing:</b>
-     * <br>
-     * This utility method is intended for use by subclasses that need to implement
-     * their own overrides of {@link #roll roll} and {@link #add add}.
-     * <p>
-     * <b>Note:</b>
-     * <code>pinField</code> is implemented in terms of
-     * {@link #getActualMinimum getActualMinimum}
-     * and {@link #getActualMaximum getActualMaximum}.  If either of those methods uses
-     * a slow, iterative algorithm for a particular field, it would be
-     * unwise to attempt to call <code>pinField</code> for that field.  If you
-     * really do need to do so, you should override this method to do
-     * something more efficient for that field.
-     * <p>
-     * @param field The calendar field whose value should be pinned.
-     * @param status Output param set to failure code on function return
-     *          when this function fails.
-     *
-     * @see #getActualMinimum
-     * @see #getActualMaximum
-     * @stable ICU 2.0
-     */
-    virtual void pinField(UCalendarDateFields field, UErrorCode& status);
-
-    /**
-     * Return the week number of a day, within a period. This may be the week number in
-     * a year or the week number in a month. Usually this will be a value >= 1, but if
-     * some initial days of the period are excluded from week 1, because
-     * {@link #getMinimalDaysInFirstWeek getMinimalDaysInFirstWeek} is > 1, then
-     * the week number will be zero for those
-     * initial days. This method requires the day number and day of week for some
-     * known date in the period in order to determine the day of week
-     * on the desired day.
-     * <p>
-     * <b>Subclassing:</b>
-     * <br>
-     * This method is intended for use by subclasses in implementing their
-     * {@link #computeTime computeTime} and/or {@link #computeFields computeFields} methods.
-     * It is often useful in {@link #getActualMinimum getActualMinimum} and
-     * {@link #getActualMaximum getActualMaximum} as well.
-     * <p>
-     * This variant is handy for computing the week number of some other
-     * day of a period (often the first or last day of the period) when its day
-     * of the week is not known but the day number and day of week for some other
-     * day in the period (e.g. the current date) <em>is</em> known.
-     * <p>
-     * @param desiredDay    The {@link #UCalendarDateFields DAY_OF_YEAR} or
-     *              {@link #UCalendarDateFields DAY_OF_MONTH} whose week number is desired.
-     *              Should be 1 for the first day of the period.
-     *
-     * @param dayOfPeriod   The {@link #UCalendarDateFields DAY_OF_YEAR}
-     *              or {@link #UCalendarDateFields DAY_OF_MONTH} for a day in the period whose
-     *              {@link #UCalendarDateFields DAY_OF_WEEK} is specified by the
-     *              <code>knownDayOfWeek</code> parameter.
-     *              Should be 1 for first day of period.
-     *
-     * @param dayOfWeek  The {@link #UCalendarDateFields DAY_OF_WEEK} for the day
-     *              corresponding to the <code>knownDayOfPeriod</code> parameter.
-     *              1-based with 1=Sunday.
-     *
-     * @return      The week number (one-based), or zero if the day falls before
-     *              the first week because
-     *              {@link #getMinimalDaysInFirstWeek getMinimalDaysInFirstWeek}
-     *              is more than one.
-     *
-     * @stable ICU 2.8
-     */
-    int32_t weekNumber(int32_t desiredDay, int32_t dayOfPeriod, int32_t dayOfWeek);
-
-
-    /**
-     * Return the week number of a day, within a period. This may be the week number in
-     * a year, or the week number in a month. Usually this will be a value >= 1, but if
-     * some initial days of the period are excluded from week 1, because
-     * {@link #getMinimalDaysInFirstWeek getMinimalDaysInFirstWeek} is > 1,
-     * then the week number will be zero for those
-     * initial days. This method requires the day of week for the given date in order to
-     * determine the result.
-     * <p>
-     * <b>Subclassing:</b>
-     * <br>
-     * This method is intended for use by subclasses in implementing their
-     * {@link #computeTime computeTime} and/or {@link #computeFields computeFields} methods.
-     * It is often useful in {@link #getActualMinimum getActualMinimum} and
-     * {@link #getActualMaximum getActualMaximum} as well.
-     * <p>
-     * @param dayOfPeriod   The {@link #UCalendarDateFields DAY_OF_YEAR} or
-     *                      {@link #UCalendarDateFields DAY_OF_MONTH} whose week number is desired.
-     *                      Should be 1 for the first day of the period.
-     *
-     * @param dayOfWeek     The {@link #UCalendarDateFields DAY_OF_WEEK} for the day
-     *                      corresponding to the <code>dayOfPeriod</code> parameter.
-     *                      1-based with 1=Sunday.
-     *
-     * @return      The week number (one-based), or zero if the day falls before
-     *              the first week because
-     *              {@link #getMinimalDaysInFirstWeek getMinimalDaysInFirstWeek}
-     *              is more than one.
-     * @internal
-     */
-    inline int32_t weekNumber(int32_t dayOfPeriod, int32_t dayOfWeek);
-
-    /**
-     * returns the local DOW, valid range 0..6
-     * @internal
-     */
-    int32_t getLocalDOW();
-
-private:
-
-    /**
-     * The next available value for fStamp[]
-     */
-    int32_t fNextStamp;// = MINIMUM_USER_STAMP;
-
-    /**
-     * The current time set for the calendar.
-     */
-    UDate        fTime;
-
-    /**
-     * @see   #setLenient
-     */
-    UBool      fLenient;
-
-    /**
-     * Time zone affects the time calculation done by Calendar. Calendar subclasses use
-     * the time zone data to produce the local time.
-     */
-    TimeZone*   fZone;
-
-    /**
-     * Both firstDayOfWeek and minimalDaysInFirstWeek are locale-dependent. They are
-     * used to figure out the week count for a specific date for a given locale. These
-     * must be set when a Calendar is constructed. For example, in US locale,
-     * firstDayOfWeek is SUNDAY; minimalDaysInFirstWeek is 1. They are used to figure
-     * out the week count for a specific date for a given locale. These must be set when
-     * a Calendar is constructed.
-     */
-    UCalendarDaysOfWeek fFirstDayOfWeek;
-    uint8_t     fMinimalDaysInFirstWeek;
-
-    /**
-     * Sets firstDayOfWeek and minimalDaysInFirstWeek. Called at Calendar construction
-     * time.
-     *
-     * @param desiredLocale  The given locale.
-     * @param type           The calendar type identifier, e.g: gregorian, buddhist, etc.
-     * @param success        Indicates the status of setting the week count data from
-     *                       the resource for the given locale. Returns U_ZERO_ERROR if
-     *                       constructed successfully.
-     */
-    void        setWeekCountData(const Locale& desiredLocale, const char *type, UErrorCode& success);
-
-    /**
-     * Recompute the time and update the status fields isTimeSet
-     * and areFieldsSet.  Callers should check isTimeSet and only
-     * call this method if isTimeSet is false.
-     *
-     * @param status  Output param set to success/failure code on exit. If any value
-     *                previously set in the time field is invalid or restricted by
-     *                leniency, this will be set to an error status.
-     */
-    void updateTime(UErrorCode& status);
-
-    /**
-     * The Gregorian year, as computed by computeGregorianFields() and
-     * returned by getGregorianYear().
-     * @see #computeGregorianFields
-     */
-    int32_t fGregorianYear;
-
-    /**
-     * The Gregorian month, as computed by computeGregorianFields() and
-     * returned by getGregorianMonth().
-     * @see #computeGregorianFields
-     */
-    int32_t fGregorianMonth;
-
-    /**
-     * The Gregorian day of the year, as computed by
-     * computeGregorianFields() and returned by getGregorianDayOfYear().
-     * @see #computeGregorianFields
-     */
-    int32_t fGregorianDayOfYear;
-
-    /**
-     * The Gregorian day of the month, as computed by
-     * computeGregorianFields() and returned by getGregorianDayOfMonth().
-     * @see #computeGregorianFields
-     */
-    int32_t fGregorianDayOfMonth;
-
-    /* calculations */
-
-    /**
-     * Compute the Gregorian calendar year, month, and day of month from
-     * the given Julian day.  These values are not stored in fields, but in
-     * member variables gregorianXxx.  Also compute the DAY_OF_WEEK and
-     * DOW_LOCAL fields.
-     */
-    void computeGregorianAndDOWFields(int32_t julianDay, UErrorCode &ec);
-
-	protected:
-
-    /**
-     * Compute the Gregorian calendar year, month, and day of month from the
-     * Julian day.  These values are not stored in fields, but in member
-     * variables gregorianXxx.  They are used for time zone computations and by
-     * subclasses that are Gregorian derivatives.  Subclasses may call this
-     * method to perform a Gregorian calendar millis->fields computation.
-     * To perform a Gregorian calendar fields->millis computation, call
-     * computeGregorianMonthStart().
-     * @see #computeGregorianMonthStart
-     */
-    void computeGregorianFields(int32_t julianDay, UErrorCode &ec);
-
-	private:
-
-    /**
-     * Compute the fields WEEK_OF_YEAR, YEAR_WOY, WEEK_OF_MONTH,
-     * DAY_OF_WEEK_IN_MONTH, and DOW_LOCAL from EXTENDED_YEAR, YEAR,
-     * DAY_OF_WEEK, and DAY_OF_YEAR.  The latter fields are computed by the
-     * subclass based on the calendar system.
-     *
-     * <p>The YEAR_WOY field is computed simplistically.  It is equal to YEAR
-     * most of the time, but at the year boundary it may be adjusted to YEAR-1
-     * or YEAR+1 to reflect the overlap of a week into an adjacent year.  In
-     * this case, a simple increment or decrement is performed on YEAR, even
-     * though this may yield an invalid YEAR value.  For instance, if the YEAR
-     * is part of a calendar system with an N-year cycle field CYCLE, then
-     * incrementing the YEAR may involve incrementing CYCLE and setting YEAR
-     * back to 0 or 1.  This is not handled by this code, and in fact cannot be
-     * simply handled without having subclasses define an entire parallel set of
-     * fields for fields larger than or equal to a year.  This additional
-     * complexity is not warranted, since the intention of the YEAR_WOY field is
-     * to support ISO 8601 notation, so it will typically be used with a
-     * proleptic Gregorian calendar, which has no field larger than a year.
-     */
-    void computeWeekFields(UErrorCode &ec);
-
-
-    /**
-     * Ensure that each field is within its valid range by calling {@link
-     * #validateField(int, int&)} on each field that has been set.  This method
-     * should only be called if this calendar is not lenient.
-     * @see #isLenient
-     * @see #validateField(int, int&)
-     * @internal
-     */
-    void validateFields(UErrorCode &status);
-
-    /**
-     * Validate a single field of this calendar.  Subclasses should
-     * override this method to validate any calendar-specific fields.
-     * Generic fields can be handled by
-     * <code>Calendar.validateField()</code>.
-     * @see #validateField(int, int, int, int&)
-     * @internal
-     */
-    virtual void validateField(UCalendarDateFields field, UErrorCode &status);
-
-    /**
-     * Validate a single field of this calendar given its minimum and
-     * maximum allowed value.  If the field is out of range,
-     * <code>U_ILLEGAL_ARGUMENT_ERROR</code> will be set.  Subclasses may
-     * use this method in their implementation of {@link
-     * #validateField(int, int&)}.
-     * @internal
-     */
-    void validateField(UCalendarDateFields field, int32_t min, int32_t max, UErrorCode& status);
-
- protected:
-    /**
-     * Convert a quasi Julian date to the day of the week. The Julian date used here is
-     * not a true Julian date, since it is measured from midnight, not noon. Return
-     * value is one-based.
-     *
-     * @param julian  The given Julian date number.
-     * @return   Day number from 1..7 (SUN..SAT).
-     * @internal
-     */
-    static uint8_t julianDayToDayOfWeek(double julian);
-
- private:
-    char validLocale[ULOC_FULLNAME_CAPACITY];
-    char actualLocale[ULOC_FULLNAME_CAPACITY];
-
- public:
-#if !UCONFIG_NO_SERVICE
-    /**
-     * INTERNAL FOR 2.6 --  Registration.
-     */
-
-    /**
-     * Return a StringEnumeration over the locales available at the time of the call,
-     * including registered locales.
-     * @return a StringEnumeration over the locales available at the time of the call
-     * @internal
-     */
-    static StringEnumeration* getAvailableLocales(void);
-
-    /**
-     * Register a new Calendar factory.  The factory will be adopted.
-     * INTERNAL in 2.6
-     * @param toAdopt the factory instance to be adopted
-     * @param status the in/out status code, no special meanings are assigned
-     * @return a registry key that can be used to unregister this factory
-     * @internal
-     */
-    static URegistryKey registerFactory(ICUServiceFactory* toAdopt, UErrorCode& status);
-
-    /**
-     * Unregister a previously-registered CalendarFactory using the key returned from the
-     * register call.  Key becomes invalid after a successful call and should not be used again.
-     * The CalendarFactory corresponding to the key will be deleted.
-     * INTERNAL in 2.6
-     * @param key the registry key returned by a previous call to registerFactory
-     * @param status the in/out status code, no special meanings are assigned
-     * @return TRUE if the factory for the key was successfully unregistered
-     * @internal
-     */
-    static UBool unregister(URegistryKey key, UErrorCode& status);
-
-    /**
-     * Multiple Calendar Implementation
-     * @internal
-     */
-    friend class CalendarFactory;
-
-    /**
-     *

<TRUNCATED>

[43/57] [abbrv] couchdb commit: updated refs/heads/1994-merge-rcouch-multi-repo to b19d055

Posted by be...@apache.org.
remove couch_dbupdates


Project: http://git-wip-us.apache.org/repos/asf/couchdb/repo
Commit: http://git-wip-us.apache.org/repos/asf/couchdb/commit/ae6eae31
Tree: http://git-wip-us.apache.org/repos/asf/couchdb/tree/ae6eae31
Diff: http://git-wip-us.apache.org/repos/asf/couchdb/diff/ae6eae31

Branch: refs/heads/1994-merge-rcouch-multi-repo
Commit: ae6eae31a1f08b7116c3b47257fd34a01287427f
Parents: 81332b7
Author: Benoit Chesneau <bc...@gmail.com>
Authored: Thu Feb 13 16:37:35 2014 +0100
Committer: Benoit Chesneau <bc...@gmail.com>
Committed: Thu Feb 13 16:37:35 2014 +0100

----------------------------------------------------------------------
 .../couch_dbupdates/src/couch_dbupdates.app.src | 11 ----
 apps/couch_dbupdates/src/couch_dbupdates.erl    | 46 -------------
 .../src/couch_dbupdates_httpd.erl               | 69 --------------------
 3 files changed, 126 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/couchdb/blob/ae6eae31/apps/couch_dbupdates/src/couch_dbupdates.app.src
----------------------------------------------------------------------
diff --git a/apps/couch_dbupdates/src/couch_dbupdates.app.src b/apps/couch_dbupdates/src/couch_dbupdates.app.src
deleted file mode 100644
index 54a543e..0000000
--- a/apps/couch_dbupdates/src/couch_dbupdates.app.src
+++ /dev/null
@@ -1,11 +0,0 @@
-{application, couch_dbupdates,
- [
-  {description, ""},
-  {vsn, "1.0.0"},
-  {registered, []},
-  {applications, [
-                  kernel,
-                  stdlib
-                 ]},
-  {env, []}
- ]}.

http://git-wip-us.apache.org/repos/asf/couchdb/blob/ae6eae31/apps/couch_dbupdates/src/couch_dbupdates.erl
----------------------------------------------------------------------
diff --git a/apps/couch_dbupdates/src/couch_dbupdates.erl b/apps/couch_dbupdates/src/couch_dbupdates.erl
deleted file mode 100644
index e37362f..0000000
--- a/apps/couch_dbupdates/src/couch_dbupdates.erl
+++ /dev/null
@@ -1,46 +0,0 @@
--module(couch_dbupdates).
-
--export([handle_dbupdates/3]).
-
-
-handle_dbupdates(Fun, Acc, Options) ->
-    NotifierPid = db_update_notifier(),
-    try
-        loop(Fun, Acc, Options)
-    after
-        couch_db_update_notifier:stop(NotifierPid)
-    end.
-
-
-loop(Fun, Acc, Options) ->
-    [{timeout, Timeout}, {heartbeat, Heartbeat}] = Options,
-    receive
-        {db_updated, Event} ->
-            case Fun(Event, Acc) of
-                {ok, Acc1} ->
-                    loop(Fun, Acc1, Options);
-                stop ->
-                    Fun(stop, Acc)
-
-            end
-    after Timeout ->
-        case Heartbeat of
-            true ->
-                case Fun(heartbeat, Acc) of
-                {ok, Acc1} ->
-                    loop(Fun, Acc1, Options);
-                stop ->
-                    Fun(stop, Acc)
-
-                end;
-            _ ->
-                Fun(stop, Acc)
-        end
-    end.
-
-db_update_notifier() ->
-    Self = self(),
-    {ok, Notifier} = couch_db_update_notifier:start_link(fun(Event) ->
-        Self ! {db_updated, Event}
-    end),
-    Notifier.

http://git-wip-us.apache.org/repos/asf/couchdb/blob/ae6eae31/apps/couch_dbupdates/src/couch_dbupdates_httpd.erl
----------------------------------------------------------------------
diff --git a/apps/couch_dbupdates/src/couch_dbupdates_httpd.erl b/apps/couch_dbupdates/src/couch_dbupdates_httpd.erl
deleted file mode 100644
index 09f1104..0000000
--- a/apps/couch_dbupdates/src/couch_dbupdates_httpd.erl
+++ /dev/null
@@ -1,69 +0,0 @@
--module(couch_dbupdates_httpd).
-
--export([handle_req/1]).
-
--include_lib("couch/include/couch_db.hrl").
-
--record(state, {resp, feed}).
-
-handle_req(#httpd{method='GET'}=Req) ->
-    ok = couch_httpd:verify_is_server_admin(Req),
-    Qs = couch_httpd:qs(Req),
-    Feed = proplists:get_value("feed", Qs, "longpoll"),
-
-    Timeout = list_to_integer(
-                proplists:get_value("timeout", Qs, "60000")
-    ),
-
-    Heartbeat0 = proplists:get_value("heartbeat", Qs),
-    Heartbeat = case {Feed, Heartbeat0} of
-        {"longpoll", _} -> false;
-        {_, "false"} -> false;
-        _ -> true
-    end,
-
-    Options = [{timeout, Timeout}, {heartbeat, Heartbeat}],
-
-    {ok, Resp} = case Feed of
-        "eventsource" ->
-            Headers = [
-                {"Content-Type", "text/event-stream"},
-                {"Cache-Control", "no-cache"}
-            ],
-            couch_httpd:start_json_response(Req, 200, Headers);
-        _ ->
-            couch_httpd:start_json_response(Req, 200)
-    end,
-
-    State = #state{resp=Resp, feed=Feed},
-    couch_dbupdates:handle_dbupdates(fun handle_update/2,
-                                     State, Options);
-
-handle_req(Req) ->
-    couch_httpd:send_method_not_allowed(Req, "GET").
-
-handle_update(stop, #state{resp=Resp}) ->
-    couch_httpd:end_json_response(Resp);
-handle_update(heartbeat, #state{resp=Resp}=State) ->
-    {ok, Resp1} = couch_httpd:send_chunk(Resp, "\n"),
-    {ok, State#state{resp=Resp1}};
-handle_update(Event, #state{resp=Resp, feed="eventsource"}=State) ->
-    EventObj = event_obj(Event),
-    {ok, Resp1} = couch_httpd:send_chunk(Resp, ["data: ",
-                                                ?JSON_ENCODE(EventObj),
-                                                "\n\n"]),
-    {ok, State#state{resp=Resp1}};
-handle_update(Event, #state{resp=Resp, feed="continuous"}=State) ->
-    EventObj = event_obj(Event),
-    {ok, Resp1} = couch_httpd:send_chunk(Resp, [?JSON_ENCODE(EventObj) |
-                            "\n"]),
-    {ok, State#state{resp=Resp1}};
-handle_update(Event, #state{resp=Resp, feed="longpoll"}) ->
-    {Props} = event_obj(Event),
-    JsonObj = {[{<<"ok">>, true} | Props]},
-    couch_httpd:send_chunk(Resp, ?JSON_ENCODE(JsonObj)),
-    stop.
-
-event_obj({Type, DbName}) ->
-    {[{<<"type">>, couch_util:to_binary(Type)},
-      {<<"db_name">>, couch_util:to_binary(DbName)}]}.


[31/57] [abbrv] remove couch_collate

Posted by be...@apache.org.
http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/ppalmos.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/ppalmos.h b/apps/couch_collate/platform/osx/icu/unicode/ppalmos.h
deleted file mode 100644
index c15b2ce..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/ppalmos.h
+++ /dev/null
@@ -1,273 +0,0 @@
-/*
-******************************************************************************
-*
-*   Copyright (C) 1997-2006, International Business Machines
-*   Corporation and others.  All Rights Reserved.
-*
-******************************************************************************
-*
-*  FILE NAME : ppalmos.h
-*
-*   Date        Name        Description
-*   05/10/04    Ken Krugler Creation (copied from pwin32.h & modified).
-******************************************************************************
-*/
-
-#ifndef U_PPALMOS_H
-#define U_PPALMOS_H
-
- /**
-  * \file
-  * \brief Configuration constants for the Palm OS platform
-  */
-  
-/* Define the platform we're on. */
-#ifndef U_PALMOS
-#define U_PALMOS
-#endif
-
-/* _MSC_VER is used to detect the Microsoft compiler. */
-#if defined(_MSC_VER)
-#define U_INT64_IS_LONG_LONG 0
-#else
-#define U_INT64_IS_LONG_LONG 1
-#endif
-
-/* Define whether inttypes.h is available */
-#ifndef U_HAVE_INTTYPES_H
-#define U_HAVE_INTTYPES_H 1
-#endif
-
-/*
- * Define what support for C++ streams is available.
- *     If U_IOSTREAM_SOURCE is set to 199711, then <iostream> is available
- * (1997711 is the date the ISO/IEC C++ FDIS was published), and then
- * one should qualify streams using the std namespace in ICU header
- * files.
- *     If U_IOSTREAM_SOURCE is set to 198506, then <iostream.h> is
- * available instead (198506 is the date when Stroustrup published
- * "An Extensible I/O Facility for C++" at the summer USENIX conference).
- *     If U_IOSTREAM_SOURCE is 0, then C++ streams are not available and
- * support for them will be silently suppressed in ICU.
- *
- */
-
-#ifndef U_IOSTREAM_SOURCE
-#define U_IOSTREAM_SOURCE 199711
-#endif
-
-/* Determines whether specific types are available */
-#ifndef U_HAVE_INT8_T
-#define U_HAVE_INT8_T U_HAVE_INTTYPES_H
-#endif
-
-#ifndef U_HAVE_UINT8_T
-#define U_HAVE_UINT8_T U_HAVE_INTTYPES_H
-#endif
-
-#ifndef U_HAVE_INT16_T
-#define U_HAVE_INT16_T U_HAVE_INTTYPES_H
-#endif
-
-#ifndef U_HAVE_UINT16_T
-#define U_HAVE_UINT16_T U_HAVE_INTTYPES_H
-#endif
-
-#ifndef U_HAVE_INT32_T
-#define U_HAVE_INT32_T U_HAVE_INTTYPES_H
-#endif
-
-#ifndef U_HAVE_UINT32_T
-#define U_HAVE_UINT32_T U_HAVE_INTTYPES_H
-#endif
-
-#ifndef U_HAVE_INT64_T
-#define U_HAVE_INT64_T U_HAVE_INTTYPES_H
-#endif
-
-#ifndef U_HAVE_UINT64_T
-#define U_HAVE_UINT64_T U_HAVE_INTTYPES_H
-#endif
-
-
-/*===========================================================================*/
-/* Generic data types                                                        */
-/*===========================================================================*/
-
-/* If your platform does not have the <inttypes.h> header, you may
-   need to edit the typedefs below. */
-#if U_HAVE_INTTYPES_H
-#include <inttypes.h>
-#else /* U_HAVE_INTTYPES_H */
-
-#if ! U_HAVE_INT8_T
-typedef signed char int8_t;
-#endif
-
-#if ! U_HAVE_UINT8_T
-typedef unsigned char uint8_t;
-#endif
-
-#if ! U_HAVE_INT16_T
-typedef signed short int16_t;
-#endif
-
-#if ! U_HAVE_UINT16_T
-typedef unsigned short uint16_t;
-#endif
-
-#if ! U_HAVE_INT32_T
-typedef signed int int32_t;
-#endif
-
-#if ! U_HAVE_UINT32_T
-typedef unsigned int uint32_t;
-#endif
-
-#if ! U_HAVE_INT64_T
-#if U_INT64_IS_LONG_LONG
-    typedef signed long long int64_t;
-#else
-    typedef signed __int64 int64_t;
-#endif
-#endif
-
-#if ! U_HAVE_UINT64_T
-#if U_INT64_IS_LONG_LONG
-    typedef unsigned long long uint64_t;
-#else
-    typedef unsigned __int64 uint64_t;
-#endif
-#endif
-#endif
-
-/*===========================================================================*/
-/* Compiler and environment features                                         */
-/*===========================================================================*/
-
-/* Define whether namespace is supported */
-#ifndef U_HAVE_NAMESPACE
-#define U_HAVE_NAMESPACE 1
-#endif
-
-/* Determines the endianness of the platform */
-#define U_IS_BIG_ENDIAN 0
-
-/* 1 or 0 to enable or disable threads.  If undefined, default is: enable threads. */
-#define ICU_USE_THREADS 1
-
-#ifndef U_DEBUG
-#ifdef _DEBUG
-#define U_DEBUG 1
-#else
-#define U_DEBUG 0
-#endif
-#endif
-
-#ifndef U_RELEASE
-#ifdef NDEBUG
-#define U_RELEASE 1
-#else
-#define U_RELEASE 0
-#endif
-#endif
-
-/* Determine whether to disable renaming or not. This overrides the
-   setting in umachine.h which is for all platforms. */
-#ifndef U_DISABLE_RENAMING
-#define U_DISABLE_RENAMING 0
-#endif
-
-/* Determine whether to override new and delete. */
-#ifndef U_OVERRIDE_CXX_ALLOCATION
-#define U_OVERRIDE_CXX_ALLOCATION 1
-#endif
-/* Determine whether to override placement new and delete for STL. */
-#ifndef U_HAVE_PLACEMENT_NEW
-#define U_HAVE_PLACEMENT_NEW 0
-#endif
-/* Determine whether to override new and delete for MFC. */
-#if !defined(U_HAVE_DEBUG_LOCATION_NEW) && defined(_MSC_VER)
-#define U_HAVE_DEBUG_LOCATION_NEW 0
-#endif
-
-/* Determine whether to enable tracing. */
-#ifndef U_ENABLE_TRACING
-#define U_ENABLE_TRACING 1
-#endif
-
-/* Do we allow ICU users to use the draft APIs by default? */
-#ifndef U_DEFAULT_SHOW_DRAFT
-#define U_DEFAULT_SHOW_DRAFT 1
-#endif
-
-/* Define the library suffix in a C syntax. */
-#define U_HAVE_LIB_SUFFIX 0
-#define U_LIB_SUFFIX_C_NAME 
-#define U_LIB_SUFFIX_C_NAME_STRING ""
-
-/*===========================================================================*/
-/* Information about wchar support                                           */
-/*===========================================================================*/
-
-#define U_HAVE_WCHAR_H 1
-#define U_SIZEOF_WCHAR_T 2
-
-#define U_HAVE_WCSCPY    0
-
-/*===========================================================================*/
-/* Information about POSIX support                                           */
-/*===========================================================================*/
-
-
-/* TODO: Fix Palm OS's determination of a timezone */
-#if 0
-#define U_TZSET         _tzset
-#endif
-#if 0
-#define U_TIMEZONE      _timezone
-#endif
-#if 0
-#define U_TZNAME        _tzname
-#endif
-
-#define U_HAVE_MMAP 0
-#define U_HAVE_POPEN 0
-
-/*===========================================================================*/
-/* Symbol import-export control                                              */
-/*===========================================================================*/
-
-#define U_EXPORT
-#define U_EXPORT2
-#define U_IMPORT
-
-/*===========================================================================*/
-/* Code alignment and C function inlining                                    */
-/*===========================================================================*/
-
-#ifndef U_INLINE
-#   ifdef __cplusplus
-#       define U_INLINE inline
-#   else
-#       define U_INLINE __inline
-#   endif
-#endif
-
-#if defined(_MSC_VER) && defined(_M_IX86)
-#define U_ALIGN_CODE(val)    __asm      align val
-#else
-#define U_ALIGN_CODE(val)
-#endif
-
-
-/*===========================================================================*/
-/* Programs used by ICU code                                                 */
-/*===========================================================================*/
-
-#ifndef U_MAKE
-#define U_MAKE  "nmake"
-#define U_MAKE_IS_NMAKE 1
-#endif
-
-#endif

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/putil.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/putil.h b/apps/couch_collate/platform/osx/icu/unicode/putil.h
deleted file mode 100644
index 3304877..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/putil.h
+++ /dev/null
@@ -1,184 +0,0 @@
-/*
-******************************************************************************
-*
-*   Copyright (C) 1997-2008, International Business Machines
-*   Corporation and others.  All Rights Reserved.
-*
-******************************************************************************
-*
-*  FILE NAME : putil.h
-*
-*   Date        Name        Description
-*   05/14/98    nos         Creation (content moved here from utypes.h).
-*   06/17/99    erm         Added IEEE_754
-*   07/22/98    stephen     Added IEEEremainder, max, min, trunc
-*   08/13/98    stephen     Added isNegativeInfinity, isPositiveInfinity
-*   08/24/98    stephen     Added longBitsFromDouble
-*   03/02/99    stephen     Removed openFile().  Added AS400 support.
-*   04/15/99    stephen     Converted to C
-*   11/15/99    helena      Integrated S/390 changes for IEEE support.
-*   01/11/00    helena      Added u_getVersion.
-******************************************************************************
-*/
-
-#ifndef PUTIL_H
-#define PUTIL_H
-
-#include "unicode/utypes.h"
- /**
-  * \file
-  * \brief C API: Platform Utilities
-  */
-  
-/* Define this to 1 if your platform supports IEEE 754 floating point,
-   to 0 if it does not. */
-#ifndef IEEE_754
-#   define IEEE_754 1
-#endif
-
-/*==========================================================================*/
-/* Platform utilities                                                       */
-/*==========================================================================*/
-
-/**
- * Platform utilities isolates the platform dependencies of the
- * libarary.  For each platform which this code is ported to, these
- * functions may have to be re-implemented.
- */
-
-/**
- * Return the ICU data directory. 
- * The data directory is where common format ICU data files (.dat files)
- *   are loaded from.  Note that normal use of the built-in ICU
- *   facilities does not require loading of an external data file;
- *   unless you are adding custom data to ICU, the data directory
- *   does not need to be set.
- *
- * The data directory is determined as follows:
- *    If u_setDataDirectory() has been called, that is it, otherwise
- *    if the ICU_DATA environment variable is set, use that, otherwise
- *    If a data directory was specifed at ICU build time
- *      <code>( #define ICU_DATA_DIR "path" )</code>, use that,
- *    otherwise no data directory is available.
- *
- * @return the data directory, or an empty string ("") if no data directory has
- *         been specified.
- *   
- * @stable ICU 2.0
- */
-U_STABLE const char* U_EXPORT2 u_getDataDirectory(void);
-
-/** 
- * Set the ICU data directory. 
- * The data directory is where common format ICU data files (.dat files)
- *   are loaded from.  Note that normal use of the built-in ICU
- *   facilities does not require loading of an external data file;
- *   unless you are adding custom data to ICU, the data directory
- *   does not need to be set.
- *
- * This function should be called at most once in a process, before the
- * first ICU operation (e.g., u_init()) that will require the loading of an
- * ICU data file.
- * This function is not thread-safe. Use it before calling ICU APIs from
- * multiple threads.
- *
- * @param directory The directory to be set.
- *
- * @see u_init
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2 u_setDataDirectory(const char *directory);
-
-/**
- * Please use ucnv_getDefaultName() instead.
- * Return the default codepage for this platform and locale.
- * This function can call setlocale() on Unix platforms. Please read the
- * platform documentation on setlocale() before calling this function.
- * @return the default codepage for this platform 
- * @internal
- */
-U_INTERNAL const char*  U_EXPORT2 uprv_getDefaultCodepage(void);
-
-/**
- * Please use uloc_getDefault() instead.
- * Return the default locale ID string by querying ths system, or
- *     zero if one cannot be found. 
- * This function can call setlocale() on Unix platforms. Please read the
- * platform documentation on setlocale() before calling this function.
- * @return the default locale ID string
- * @internal
- */
-U_INTERNAL const char*  U_EXPORT2 uprv_getDefaultLocaleID(void);
-
-/**
- * Filesystem file and path separator characters.
- * Example: '/' and ':' on Unix, '\\' and ';' on Windows.
- * @stable ICU 2.0
- */
-#ifdef XP_MAC
-#   define U_FILE_SEP_CHAR ':'
-#   define U_FILE_ALT_SEP_CHAR ':'
-#   define U_PATH_SEP_CHAR ';'
-#   define U_FILE_SEP_STRING ":"
-#   define U_FILE_ALT_SEP_STRING ":"
-#   define U_PATH_SEP_STRING ";"
-#elif defined(U_WINDOWS)
-#   define U_FILE_SEP_CHAR '\\'
-#   define U_FILE_ALT_SEP_CHAR '/'
-#   define U_PATH_SEP_CHAR ';'
-#   define U_FILE_SEP_STRING "\\"
-#   define U_FILE_ALT_SEP_STRING "/"
-#   define U_PATH_SEP_STRING ";"
-#else
-#   define U_FILE_SEP_CHAR '/'
-#   define U_FILE_ALT_SEP_CHAR '/'
-#   define U_PATH_SEP_CHAR ':'
-#   define U_FILE_SEP_STRING "/"
-#   define U_FILE_ALT_SEP_STRING "/"
-#   define U_PATH_SEP_STRING ":"
-#endif
-
-/**
- * Convert char characters to UChar characters.
- * This utility function is useful only for "invariant characters"
- * that are encoded in the platform default encoding.
- * They are a small, constant subset of the encoding and include
- * just the latin letters, digits, and some punctuation.
- * For details, see U_CHARSET_FAMILY.
- *
- * @param cs Input string, points to <code>length</code>
- *           character bytes from a subset of the platform encoding.
- * @param us Output string, points to memory for <code>length</code>
- *           Unicode characters.
- * @param length The number of characters to convert; this may
- *               include the terminating <code>NUL</code>.
- *
- * @see U_CHARSET_FAMILY
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2
-u_charsToUChars(const char *cs, UChar *us, int32_t length);
-
-/**
- * Convert UChar characters to char characters.
- * This utility function is useful only for "invariant characters"
- * that can be encoded in the platform default encoding.
- * They are a small, constant subset of the encoding and include
- * just the latin letters, digits, and some punctuation.
- * For details, see U_CHARSET_FAMILY.
- *
- * @param us Input string, points to <code>length</code>
- *           Unicode characters that can be encoded with the
- *           codepage-invariant subset of the platform encoding.
- * @param cs Output string, points to memory for <code>length</code>
- *           character bytes.
- * @param length The number of characters to convert; this may
- *               include the terminating <code>NUL</code>.
- *
- * @see U_CHARSET_FAMILY
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2
-u_UCharsToChars(const UChar *us, char *cs, int32_t length);
-
-#endif

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/pwin32.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/pwin32.h b/apps/couch_collate/platform/osx/icu/unicode/pwin32.h
deleted file mode 100644
index 9aad353..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/pwin32.h
+++ /dev/null
@@ -1,311 +0,0 @@
-/*
- ******************************************************************************
- *
- *   Copyright (C) 1997-2007, International Business Machines
- *   Corporation and others.  All Rights Reserved.
- *
- ******************************************************************************
- *
- *  FILE NAME : platform.h
- *
- *   Date        Name        Description
- *   05/13/98    nos         Creation (content moved here from ptypes.h).
- *   03/02/99    stephen     Added AS400 support.
- *   03/30/99    stephen     Added Linux support.
- *   04/13/99    stephen     Reworked for autoconf.
- ******************************************************************************
- */
-
- /**
-  * \file
-  * \brief Configuration constants for the Windows platform
-  */
-  
-/* Define the platform we're on. */
-#ifndef U_WINDOWS
-#define U_WINDOWS
-#endif
-
-#if defined(__BORLANDC__)
-#define U_HAVE_PLACEMENT_NEW 0
-#define U_HAVE_INTTYPES_H 1
-#define __STDC_CONSTANT_MACROS
-#endif
-
-/* _MSC_VER is used to detect the Microsoft compiler. */
-#if defined(_MSC_VER)
-#define U_INT64_IS_LONG_LONG 0
-#else
-#define U_INT64_IS_LONG_LONG 1
-#endif
-
-/* Define whether inttypes.h is available */
-#ifndef U_HAVE_INTTYPES_H
-#define U_HAVE_INTTYPES_H 0
-#endif
-
-/*
- * Define what support for C++ streams is available.
- *     If U_IOSTREAM_SOURCE is set to 199711, then <iostream> is available
- * (1997711 is the date the ISO/IEC C++ FDIS was published), and then
- * one should qualify streams using the std namespace in ICU header
- * files.
- *     If U_IOSTREAM_SOURCE is set to 198506, then <iostream.h> is
- * available instead (198506 is the date when Stroustrup published
- * "An Extensible I/O Facility for C++" at the summer USENIX conference).
- *     If U_IOSTREAM_SOURCE is 0, then C++ streams are not available and
- * support for them will be silently suppressed in ICU.
- *
- */
-
-#ifndef U_IOSTREAM_SOURCE
-#define U_IOSTREAM_SOURCE 199711
-#endif
-
-/* Determines whether specific types are available */
-#ifndef U_HAVE_INT8_T
-#define U_HAVE_INT8_T U_HAVE_INTTYPES_H
-#endif
-
-#ifndef U_HAVE_UINT8_T
-#define U_HAVE_UINT8_T U_HAVE_INTTYPES_H
-#endif
-
-#ifndef U_HAVE_INT16_T
-#define U_HAVE_INT16_T U_HAVE_INTTYPES_H
-#endif
-
-#ifndef U_HAVE_UINT16_T
-#define U_HAVE_UINT16_T U_HAVE_INTTYPES_H
-#endif
-
-#ifndef U_HAVE_INT32_T
-#define U_HAVE_INT32_T U_HAVE_INTTYPES_H
-#endif
-
-#ifndef U_HAVE_UINT32_T
-#define U_HAVE_UINT32_T U_HAVE_INTTYPES_H
-#endif
-
-#ifndef U_HAVE_INT64_T
-#define U_HAVE_INT64_T U_HAVE_INTTYPES_H
-#endif
-
-#ifndef U_HAVE_UINT64_T
-#define U_HAVE_UINT64_T U_HAVE_INTTYPES_H
-#endif
-
-/* Define 64 bit limits */
-#if !U_INT64_IS_LONG_LONG
-# ifndef INT64_C
-#  define INT64_C(x) ((int64_t)x)
-# endif
-# ifndef UINT64_C
-#  define UINT64_C(x) ((uint64_t)x)
-# endif
-/* else use the umachine.h definition */
-#endif
-
-/*===========================================================================*/
-/* Generic data types                                                        */
-/*===========================================================================*/
-
-/* If your platform does not have the <inttypes.h> header, you may
-   need to edit the typedefs below. */
-#if U_HAVE_INTTYPES_H
-#include <inttypes.h>
-#else /* U_HAVE_INTTYPES_H */
-
-#if ! U_HAVE_INT8_T
-typedef signed char int8_t;
-#endif
-
-#if ! U_HAVE_UINT8_T
-typedef unsigned char uint8_t;
-#endif
-
-#if ! U_HAVE_INT16_T
-typedef signed short int16_t;
-#endif
-
-#if ! U_HAVE_UINT16_T
-typedef unsigned short uint16_t;
-#endif
-
-#if ! U_HAVE_INT32_T
-typedef signed int int32_t;
-#endif
-
-#if ! U_HAVE_UINT32_T
-typedef unsigned int uint32_t;
-#endif
-
-#if ! U_HAVE_INT64_T
-#if U_INT64_IS_LONG_LONG
-    typedef signed long long int64_t;
-#else
-    typedef signed __int64 int64_t;
-#endif
-#endif
-
-#if ! U_HAVE_UINT64_T
-#if U_INT64_IS_LONG_LONG
-    typedef unsigned long long uint64_t;
-#else
-    typedef unsigned __int64 uint64_t;
-#endif
-#endif
-#endif
-
-/*===========================================================================*/
-/* Compiler and environment features                                         */
-/*===========================================================================*/
-
-/* Define whether namespace is supported */
-#ifndef U_HAVE_NAMESPACE
-#define U_HAVE_NAMESPACE 1
-#endif
-
-/* Determines the endianness of the platform */
-#define U_IS_BIG_ENDIAN 0
-
-/* 1 or 0 to enable or disable threads.  If undefined, default is: enable threads. */
-#define ICU_USE_THREADS 1
-
-/* On strong memory model CPUs (e.g. x86 CPUs), we use a safe & quick double check mutex lock. */
-/*
-Microsoft can define _M_IX86, _M_AMD64 (before Visual Studio 8) or _M_X64 (starting in Visual Studio 8). 
-Intel can define _M_IX86 or _M_X64
-*/
-#if defined(_M_IX86) || defined(_M_AMD64) || defined(_M_X64) || (defined(__GNUC__) && (defined(__i386__) || defined(__x86_64__)))
-#define UMTX_STRONG_MEMORY_MODEL 1
-#endif
-
-#ifndef U_DEBUG
-#ifdef _DEBUG
-#define U_DEBUG 1
-#else
-#define U_DEBUG 0
-#endif
-#endif
-
-#ifndef U_RELEASE
-#ifdef NDEBUG
-#define U_RELEASE 1
-#else
-#define U_RELEASE 0
-#endif
-#endif
-
-/* Determine whether to disable renaming or not. This overrides the
-   setting in umachine.h which is for all platforms. */
-#ifndef U_DISABLE_RENAMING
-#define U_DISABLE_RENAMING 0
-#endif
-
-/* Determine whether to override new and delete. */
-#ifndef U_OVERRIDE_CXX_ALLOCATION
-#define U_OVERRIDE_CXX_ALLOCATION 1
-#endif
-/* Determine whether to override placement new and delete for STL. */
-#ifndef U_HAVE_PLACEMENT_NEW
-#define U_HAVE_PLACEMENT_NEW 1
-#endif
-/* Determine whether to override new and delete for MFC. */
-#if !defined(U_HAVE_DEBUG_LOCATION_NEW) && defined(_MSC_VER)
-#define U_HAVE_DEBUG_LOCATION_NEW 1
-#endif
-
-/* Determine whether to enable tracing. */
-#ifndef U_ENABLE_TRACING
-#define U_ENABLE_TRACING 0
-#endif
-
-/* Do we allow ICU users to use the draft APIs by default? */
-#ifndef U_DEFAULT_SHOW_DRAFT
-#define U_DEFAULT_SHOW_DRAFT 1
-#endif
-
-/* Define the library suffix in a C syntax. */
-#define U_HAVE_LIB_SUFFIX 0
-#define U_LIB_SUFFIX_C_NAME 
-#define U_LIB_SUFFIX_C_NAME_STRING ""
-
-/*===========================================================================*/
-/* Information about wchar support                                           */
-/*===========================================================================*/
-
-#define U_HAVE_WCHAR_H 1
-#define U_SIZEOF_WCHAR_T 2
-
-#define U_HAVE_WCSCPY 1
-
-/**
- * \def U_DECLARE_UTF16
- * Do not use this macro. Use the UNICODE_STRING or U_STRING_DECL macros
- * instead.
- * @internal
- */
-#if 1
-#define U_DECLARE_UTF16(string) L ## string
-#endif
-
-/*===========================================================================*/
-/* Information about POSIX support                                           */
-/*===========================================================================*/
-
-#if 1
-#define U_TZSET         _tzset
-#endif
-#if 1
-#define U_TIMEZONE      _timezone
-#endif
-#if 1
-#define U_TZNAME        _tzname
-#endif
-#if 1
-#define U_DAYLIGHT      _daylight
-#endif
-
-#define U_HAVE_MMAP 0
-#define U_HAVE_POPEN 0
-
-/*===========================================================================*/
-/* Symbol import-export control                                              */
-/*===========================================================================*/
-
-#ifdef U_STATIC_IMPLEMENTATION
-#define U_EXPORT
-#else
-#define U_EXPORT __declspec(dllexport)
-#endif
-#define U_EXPORT2 __cdecl
-#define U_IMPORT __declspec(dllimport)
-
-/*===========================================================================*/
-/* Code alignment and C function inlining                                    */
-/*===========================================================================*/
-
-#ifndef U_INLINE
-#   ifdef __cplusplus
-#       define U_INLINE inline
-#   else
-#       define U_INLINE __inline
-#   endif
-#endif
-
-#if defined(_MSC_VER) && defined(_M_IX86) && !defined(_MANAGED)
-#define U_ALIGN_CODE(val)    __asm      align val
-#else
-#define U_ALIGN_CODE(val)
-#endif
-
-
-/*===========================================================================*/
-/* Programs used by ICU code                                                 */
-/*===========================================================================*/
-
-#ifndef U_MAKE
-#define U_MAKE  "nmake"
-#define U_MAKE_IS_NMAKE 1
-#endif

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/rbbi.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/rbbi.h b/apps/couch_collate/platform/osx/icu/unicode/rbbi.h
deleted file mode 100644
index 90ec6e6..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/rbbi.h
+++ /dev/null
@@ -1,722 +0,0 @@
-/*
-***************************************************************************
-*   Copyright (C) 1999-2008 International Business Machines Corporation   *
-*   and others. All rights reserved.                                      *
-***************************************************************************
-
-**********************************************************************
-*   Date        Name        Description
-*   10/22/99    alan        Creation.
-*   11/11/99    rgillam     Complete port from Java.
-**********************************************************************
-*/
-
-#ifndef RBBI_H
-#define RBBI_H
-
-#include "unicode/utypes.h"
-
-/**
- * \file
- * \brief C++ API: Rule Based Break Iterator
- */
-
-#if !UCONFIG_NO_BREAK_ITERATION
-
-#include "unicode/brkiter.h"
-#include "unicode/udata.h"
-#include "unicode/parseerr.h"
-#include "unicode/schriter.h"
-#include "unicode/uchriter.h"
-
-
-struct UTrie;
-
-U_NAMESPACE_BEGIN
-
-/** @internal */
-struct RBBIDataHeader;
-class  RuleBasedBreakIteratorTables;
-class  BreakIterator;
-class  RBBIDataWrapper;
-class  UStack;
-class  LanguageBreakEngine;
-class  UnhandledEngine;
-struct RBBIStateTable;
-
-
-
-
-/**
- *
- * A subclass of BreakIterator whose behavior is specified using a list of rules.
- * <p>Instances of this class are most commonly created by the factory methods of
- *  BreakIterator::createWordInstance(), BreakIterator::createLineInstance(), etc.,
- *  and then used via the abstract API in class BreakIterator</p>
- *
- * <p>See the ICU User Guide for information on Break Iterator Rules.</p>
- *
- * <p>This class is not intended to be subclassed.  (Class DictionaryBasedBreakIterator
- *    is a subclass, but that relationship is effectively internal to the ICU
- *    implementation.  The subclassing interface to RulesBasedBreakIterator is
- *    not part of the ICU API, and may not remain stable.</p>
- *
- */
-class U_COMMON_API RuleBasedBreakIterator : public BreakIterator {
-
-protected:
-    /**
-     * The UText through which this BreakIterator accesses the text
-     * @internal
-     */
-    UText  *fText;
-
-    /**
-     *   A character iterator that refers to the same text as the UText, above.
-     *   Only included for compatibility with old API, which was based on CharacterIterators.
-     *   Value may be adopted from outside, or one of fSCharIter or fDCharIter, below.
-     */
-    CharacterIterator  *fCharIter;
-
-    /**
-     *   When the input text is provided by a UnicodeString, this will point to
-     *    a characterIterator that wraps that data.  Needed only for the
-     *    implementation of getText(), a backwards compatibility issue.
-     */
-    StringCharacterIterator *fSCharIter;
-
-    /**
-     *  When the input text is provided by a UText, this
-     *    dummy CharacterIterator over an empty string will
-     *    be returned from getText()
-     */
-    UCharCharacterIterator *fDCharIter;
-
-    /**
-     * The rule data for this BreakIterator instance
-     * @internal
-     */
-    RBBIDataWrapper    *fData;
-
-    /** Index of the Rule {tag} values for the most recent match.
-     *  @internal
-    */
-    int32_t             fLastRuleStatusIndex;
-
-    /**
-     * Rule tag value valid flag.
-     * Some iterator operations don't intrinsically set the correct tag value.
-     * This flag lets us lazily compute the value if we are ever asked for it.
-     * @internal
-     */
-    UBool               fLastStatusIndexValid;
-
-    /**
-     * Counter for the number of characters encountered with the "dictionary"
-     *   flag set.
-     * @internal
-     */
-    uint32_t            fDictionaryCharCount;
-
-    /**
-     * When a range of characters is divided up using the dictionary, the break
-     * positions that are discovered are stored here, preventing us from having
-     * to use either the dictionary or the state table again until the iterator
-     * leaves this range of text. Has the most impact for line breaking.
-     * @internal
-     */
-    int32_t*            fCachedBreakPositions;
-
-    /**
-     * The number of elements in fCachedBreakPositions
-     * @internal
-     */
-    int32_t             fNumCachedBreakPositions;
-
-    /**
-     * if fCachedBreakPositions is not null, this indicates which item in the
-     * cache the current iteration position refers to
-     * @internal
-     */
-    int32_t             fPositionInCache;
-    
-    /**
-     *
-     * If present, UStack of LanguageBreakEngine objects that might handle
-     * dictionary characters. Searched from top to bottom to find an object to
-     * handle a given character.
-     * @internal
-     */
-    UStack              *fLanguageBreakEngines;
-    
-    /**
-     *
-     * If present, the special LanguageBreakEngine used for handling
-     * characters that are in the dictionary set, but not handled by any
-     * LangugageBreakEngine.
-     * @internal
-     */
-    UnhandledEngine     *fUnhandledBreakEngine;
-    
-    /**
-     *
-     * The type of the break iterator, or -1 if it has not been set.
-     * @internal
-     */
-    int32_t             fBreakType;
-    
-protected:
-    //=======================================================================
-    // constructors
-    //=======================================================================
-
-    /**
-     * Constant to be used in the constructor
-     * RuleBasedBreakIterator(RBBIDataHeader*, EDontAdopt, UErrorCode &);
-     * which does not adopt the memory indicated by the RBBIDataHeader*
-     * parameter.
-     *
-     * @internal
-     */
-    enum EDontAdopt {
-        kDontAdopt
-    };
-
-    /**
-     * Constructor from a flattened set of RBBI data in malloced memory.
-     *             RulesBasedBreakIterators built from a custom set of rules
-     *             are created via this constructor; the rules are compiled
-     *             into memory, then the break iterator is constructed here.
-     *
-     *             The break iterator adopts the memory, and will
-     *             free it when done.
-     * @internal
-     */
-    RuleBasedBreakIterator(RBBIDataHeader* data, UErrorCode &status);
-
-    /**
-     * Constructor from a flattened set of RBBI data in memory which need not
-     *             be malloced (e.g. it may be a memory-mapped file, etc.).
-     *
-     *             This version does not adopt the memory, and does not
-     *             free it when done.
-     * @internal
-     */
-    RuleBasedBreakIterator(const RBBIDataHeader* data, enum EDontAdopt dontAdopt, UErrorCode &status);
-
-
-    friend class RBBIRuleBuilder;
-    /** @internal */
-    friend class BreakIterator;
-
-
-
-public:
-
-    /** Default constructor.  Creates an empty shell of an iterator, with no
-     *  rules or text to iterate over.   Object can subsequently be assigned to.
-     *  @stable ICU 2.2
-     */
-    RuleBasedBreakIterator();
-
-    /**
-     * Copy constructor.  Will produce a break iterator with the same behavior,
-     * and which iterates over the same text, as the one passed in.
-     * @param that The RuleBasedBreakIterator passed to be copied
-     * @stable ICU 2.0
-     */
-    RuleBasedBreakIterator(const RuleBasedBreakIterator& that);
-
-    /**
-     * Construct a RuleBasedBreakIterator from a set of rules supplied as a string.
-     * @param rules The break rules to be used.
-     * @param parseError  In the event of a syntax error in the rules, provides the location
-     *                    within the rules of the problem.
-     * @param status Information on any errors encountered.
-     * @stable ICU 2.2
-     */
-    RuleBasedBreakIterator( const UnicodeString    &rules,
-                             UParseError           &parseError,
-                             UErrorCode            &status);
-
-
-    /**
-     * This constructor uses the udata interface to create a BreakIterator
-     * whose internal tables live in a memory-mapped file.  "image" is an
-     * ICU UDataMemory handle for the pre-compiled break iterator tables.
-     * @param image handle to the memory image for the break iterator data.
-     *        Ownership of the UDataMemory handle passes to the Break Iterator,
-     *        which will be responsible for closing it when it is no longer needed.
-     * @param status Information on any errors encountered.
-     * @see udata_open
-     * @see #getBinaryRules
-     * @stable ICU 2.8
-     */
-    RuleBasedBreakIterator(UDataMemory* image, UErrorCode &status);
-
-    /**
-     * Destructor
-     *  @stable ICU 2.0
-     */
-    virtual ~RuleBasedBreakIterator();
-
-    /**
-     * Assignment operator.  Sets this iterator to have the same behavior,
-     * and iterate over the same text, as the one passed in.
-     * @param that The RuleBasedBreakItertor passed in
-     * @return the newly created RuleBasedBreakIterator
-     *  @stable ICU 2.0
-     */
-    RuleBasedBreakIterator& operator=(const RuleBasedBreakIterator& that);
-
-    /**
-     * Equality operator.  Returns TRUE if both BreakIterators are of the
-     * same class, have the same behavior, and iterate over the same text.
-     * @param that The BreakIterator to be compared for equality
-     * @return TRUE if both BreakIterators are of the
-     * same class, have the same behavior, and iterate over the same text.
-     *  @stable ICU 2.0
-     */
-    virtual UBool operator==(const BreakIterator& that) const;
-
-    /**
-     * Not-equal operator.  If operator== returns TRUE, this returns FALSE,
-     * and vice versa.
-     * @param that The BreakIterator to be compared for inequality
-     * @return TRUE if both BreakIterators are not same.
-     *  @stable ICU 2.0
-     */
-    UBool operator!=(const BreakIterator& that) const;
-
-    /**
-     * Returns a newly-constructed RuleBasedBreakIterator with the same
-     * behavior, and iterating over the same text, as this one.
-     * Differs from the copy constructor in that it is polymorphic, and
-     * will correctly clone (copy) a derived class.
-     * clone() is thread safe.  Multiple threads may simultaeneously
-     * clone the same source break iterator.
-     * @return a newly-constructed RuleBasedBreakIterator
-     * @stable ICU 2.0
-     */
-    virtual BreakIterator* clone() const;
-
-    /**
-     * Compute a hash code for this BreakIterator
-     * @return A hash code
-     *  @stable ICU 2.0
-     */
-    virtual int32_t hashCode(void) const;
-
-    /**
-     * Returns the description used to create this iterator
-     * @return the description used to create this iterator
-     *  @stable ICU 2.0
-     */
-    virtual const UnicodeString& getRules(void) const;
-
-    //=======================================================================
-    // BreakIterator overrides
-    //=======================================================================
-
-    /**
-     * <p>
-     * Return a CharacterIterator over the text being analyzed.
-     * The returned character iterator is owned by the break iterator, and must
-     * not be deleted by the caller.  Repeated calls to this function may
-     * return the same CharacterIterator.
-     * </p>
-     * <p>
-     * The returned character iterator must not be used concurrently with
-     * the break iterator.  If concurrent operation is needed, clone the
-     * returned character iterator first and operate on the clone.
-     * </p>
-     * <p>
-     * When the break iterator is operating on text supplied via a UText,
-     * this function will fail.  Lacking any way to signal failures, it
-     * returns an CharacterIterator containing no text.
-     * The function getUText() provides similar functionality,
-     * is reliable, and is more efficient.
-     * </p>
-     *
-     * TODO:  deprecate this function?
-     *
-     * @return An iterator over the text being analyzed.
-     * @stable ICU 2.0
-     */
-    virtual  CharacterIterator& getText(void) const;
-
-
-    /**
-      *  Get a UText for the text being analyzed.
-      *  The returned UText is a shallow clone of the UText used internally
-      *  by the break iterator implementation.  It can safely be used to
-      *  access the text without impacting any break iterator operations,
-      *  but the underlying text itself must not be altered.
-      *
-      * @param fillIn A UText to be filled in.  If NULL, a new UText will be
-      *           allocated to hold the result.
-      * @param status receives any error codes.
-      * @return   The current UText for this break iterator.  If an input
-      *           UText was provided, it will always be returned.
-      * @stable ICU 3.4
-      */
-     virtual UText *getUText(UText *fillIn, UErrorCode &status) const;
-
-    /**
-     * Set the iterator to analyze a new piece of text.  This function resets
-     * the current iteration position to the beginning of the text.
-     * @param newText An iterator over the text to analyze.  The BreakIterator
-     * takes ownership of the character iterator.  The caller MUST NOT delete it!
-     *  @stable ICU 2.0
-     */
-    virtual void adoptText(CharacterIterator* newText);
-
-    /**
-     * Set the iterator to analyze a new piece of text.  This function resets
-     * the current iteration position to the beginning of the text.
-     * @param newText The text to analyze.
-     *  @stable ICU 2.0
-     */
-    virtual void setText(const UnicodeString& newText);
-
-    /**
-     * Reset the break iterator to operate over the text represented by
-     * the UText.  The iterator position is reset to the start.
-     *
-     * This function makes a shallow clone of the supplied UText.  This means
-     * that the caller is free to immediately close or otherwise reuse the
-     * Utext that was passed as a parameter, but that the underlying text itself
-     * must not be altered while being referenced by the break iterator.
-     *
-     * @param text    The UText used to change the text.
-     * @param status  Receives any error codes.
-     * @stable ICU 3.4
-     */
-    virtual void  setText(UText *text, UErrorCode &status);
-
-    /**
-     * Sets the current iteration position to the beginning of the text.
-     * @return The offset of the beginning of the text.
-     *  @stable ICU 2.0
-     */
-    virtual int32_t first(void);
-
-    /**
-     * Sets the current iteration position to the end of the text.
-     * @return The text's past-the-end offset.
-     *  @stable ICU 2.0
-     */
-    virtual int32_t last(void);
-
-    /**
-     * Advances the iterator either forward or backward the specified number of steps.
-     * Negative values move backward, and positive values move forward.  This is
-     * equivalent to repeatedly calling next() or previous().
-     * @param n The number of steps to move.  The sign indicates the direction
-     * (negative is backwards, and positive is forwards).
-     * @return The character offset of the boundary position n boundaries away from
-     * the current one.
-     *  @stable ICU 2.0
-     */
-    virtual int32_t next(int32_t n);
-
-    /**
-     * Advances the iterator to the next boundary position.
-     * @return The position of the first boundary after this one.
-     *  @stable ICU 2.0
-     */
-    virtual int32_t next(void);
-
-    /**
-     * Moves the iterator backwards, to the last boundary preceding this one.
-     * @return The position of the last boundary position preceding this one.
-     *  @stable ICU 2.0
-     */
-    virtual int32_t previous(void);
-
-    /**
-     * Sets the iterator to refer to the first boundary position following
-     * the specified position.
-     * @param offset The position from which to begin searching for a break position.
-     * @return The position of the first break after the current position.
-     *  @stable ICU 2.0
-     */
-    virtual int32_t following(int32_t offset);
-
-    /**
-     * Sets the iterator to refer to the last boundary position before the
-     * specified position.
-     * @param offset The position to begin searching for a break from.
-     * @return The position of the last boundary before the starting position.
-     *  @stable ICU 2.0
-     */
-    virtual int32_t preceding(int32_t offset);
-
-    /**
-     * Returns true if the specfied position is a boundary position.  As a side
-     * effect, leaves the iterator pointing to the first boundary position at
-     * or after "offset".
-     * @param offset the offset to check.
-     * @return True if "offset" is a boundary position.
-     *  @stable ICU 2.0
-     */
-    virtual UBool isBoundary(int32_t offset);
-
-    /**
-     * Returns the current iteration position.
-     * @return The current iteration position.
-     * @stable ICU 2.0
-     */
-    virtual int32_t current(void) const;
-
-
-    /**
-     * Return the status tag from the break rule that determined the most recently
-     * returned break position.  For break rules that do not specify a
-     * status, a default value of 0 is returned.  If more than one break rule
-     * would cause a boundary to be located at some position in the text,
-     * the numerically largest of the applicable status values is returned.
-     * <p>
-     * Of the standard types of ICU break iterators, only word break and
-     * line break provide status values.  The values are defined in
-     * the header file ubrk.h.  For Word breaks, the status allows distinguishing between words
-     * that contain alphabetic letters, "words" that appear to be numbers,
-     * punctuation and spaces, words containing ideographic characters, and
-     * more.  For Line Break, the status distinguishes between hard (mandatory) breaks
-     * and soft (potential) break positions.
-     * <p>
-     * <code>getRuleStatus()</code> can be called after obtaining a boundary
-     * position from <code>next()</code>, <code>previous()</code>, or
-     * any other break iterator functions that returns a boundary position.
-     * <p>
-     * When creating custom break rules, one is free to define whatever
-     * status values may be convenient for the application.
-     * <p>
-     * Note: this function is not thread safe.  It should not have been
-     *       declared const, and the const remains only for compatibility
-     *       reasons.  (The function is logically const, but not bit-wise const).
-     * <p>
-     * @return the status from the break rule that determined the most recently
-     * returned break position.
-     *
-     * @see UWordBreak
-     * @stable ICU 2.2
-     */
-    virtual int32_t getRuleStatus() const;
-
-   /**
-    * Get the status (tag) values from the break rule(s) that determined the most
-    * recently returned break position.
-    * <p>
-    * The returned status value(s) are stored into an array provided by the caller.
-    * The values are stored in sorted (ascending) order.
-    * If the capacity of the output array is insufficient to hold the data,
-    *  the output will be truncated to the available length, and a
-    *  U_BUFFER_OVERFLOW_ERROR will be signaled.
-    *
-    * @param fillInVec an array to be filled in with the status values.
-    * @param capacity  the length of the supplied vector.  A length of zero causes
-    *                  the function to return the number of status values, in the
-    *                  normal way, without attemtping to store any values.
-    * @param status    receives error codes.
-    * @return          The number of rule status values from rules that determined
-    *                  the most recent boundary returned by the break iterator.
-    *                  In the event of a U_BUFFER_OVERFLOW_ERROR, the return value
-    *                  is the total number of status values that were available,
-    *                  not the reduced number that were actually returned.
-    * @see getRuleStatus
-    * @stable ICU 3.0
-    */
-    virtual int32_t getRuleStatusVec(int32_t *fillInVec, int32_t capacity, UErrorCode &status);
-
-    /**
-     * Returns a unique class ID POLYMORPHICALLY.  Pure virtual override.
-     * This method is to implement a simple version of RTTI, since not all
-     * C++ compilers support genuine RTTI.  Polymorphic operator==() and
-     * clone() methods call this method.
-     *
-     * @return          The class ID for this object. All objects of a
-     *                  given class have the same class ID.  Objects of
-     *                  other classes have different class IDs.
-     * @stable ICU 2.0
-     */
-    virtual UClassID getDynamicClassID(void) const;
-
-    /**
-     * Returns the class ID for this class.  This is useful only for
-     * comparing to a return value from getDynamicClassID().  For example:
-     *
-     *      Base* polymorphic_pointer = createPolymorphicObject();
-     *      if (polymorphic_pointer->getDynamicClassID() ==
-     *          Derived::getStaticClassID()) ...
-     *
-     * @return          The class ID for all objects of this class.
-     * @stable ICU 2.0
-     */
-    static UClassID U_EXPORT2 getStaticClassID(void);
-
-    /*
-     * Create a clone (copy) of this break iterator in memory provided
-     *  by the caller.  The idea is to increase performance by avoiding
-     *  a storage allocation.  Use of this functoin is NOT RECOMMENDED.
-     *  Performance gains are minimal, and correct buffer management is
-     *  tricky.  Use clone() instead.
-     *
-     * @param stackBuffer  The pointer to the memory into which the cloned object
-     *                     should be placed.  If NULL,  allocate heap memory
-     *                     for the cloned object.
-     * @param BufferSize   The size of the buffer.  If zero, return the required
-     *                     buffer size, but do not clone the object.  If the
-     *                     size was too small (but not zero), allocate heap
-     *                     storage for the cloned object.
-     *
-     * @param status       Error status.  U_SAFECLONE_ALLOCATED_WARNING will be
-     *                     returned if the the provided buffer was too small, and
-     *                     the clone was therefore put on the heap.
-     *
-     * @return  Pointer to the clone object.  This may differ from the stackBuffer
-     *          address if the byte alignment of the stack buffer was not suitable
-     *          or if the stackBuffer was too small to hold the clone.
-     * @stable ICU 2.0
-     */
-    virtual BreakIterator *  createBufferClone(void *stackBuffer,
-                                               int32_t &BufferSize,
-                                               UErrorCode &status);
-
-
-    /**
-     * Return the binary form of compiled break rules,
-     * which can then be used to create a new break iterator at some
-     * time in the future.  Creating a break iterator from pre-compiled rules
-     * is much faster than building one from the source form of the
-     * break rules.
-     *
-     * The binary data can only be used with the same version of ICU
-     *  and on the same platform type (processor endian-ness)
-     *
-     * @param length Returns the length of the binary data.  (Out paramter.)
-     *
-     * @return   A pointer to the binary (compiled) rule data.  The storage
-     *           belongs to the RulesBasedBreakIterator object, not the
-     *           caller, and must not be modified or deleted.
-     * @internal
-     */
-    virtual const uint8_t *getBinaryRules(uint32_t &length);
-
-
-protected:
-    //=======================================================================
-    // implementation
-    //=======================================================================
-    /**
-     * Dumps caches and performs other actions associated with a complete change
-     * in text or iteration position.
-     * @internal
-     */
-    virtual void reset(void);
-
-#if 0
-    /**
-      * Return true if the category lookup for this char
-      * indicates that it is in the set of dictionary lookup chars.
-      * This function is intended for use by dictionary based break iterators.
-      * @return true if the category lookup for this char
-      * indicates that it is in the set of dictionary lookup chars.
-      * @internal
-      */
-    virtual UBool isDictionaryChar(UChar32);
-
-    /**
-      * Get the type of the break iterator.
-      * @internal
-      */
-    virtual int32_t getBreakType() const;
-#endif
-
-    /**
-      * Set the type of the break iterator.
-      * @internal
-      */
-    virtual void setBreakType(int32_t type);
-
-    /**
-      * Common initialization function, used by constructors and bufferClone.
-      *   (Also used by DictionaryBasedBreakIterator::createBufferClone().)
-      * @internal
-      */
-    void init();
-
-private:
-
-    /**
-     * This method backs the iterator back up to a "safe position" in the text.
-     * This is a position that we know, without any context, must be a break position.
-     * The various calling methods then iterate forward from this safe position to
-     * the appropriate position to return.  (For more information, see the description
-     * of buildBackwardsStateTable() in RuleBasedBreakIterator.Builder.)
-     * @param statetable state table used of moving backwards
-     * @internal
-     */
-    int32_t handlePrevious(const RBBIStateTable *statetable);
-
-    /**
-     * This method is the actual implementation of the next() method.  All iteration
-     * vectors through here.  This method initializes the state machine to state 1
-     * and advances through the text character by character until we reach the end
-     * of the text or the state machine transitions to state 0.  We update our return
-     * value every time the state machine passes through a possible end state.
-     * @param statetable state table used of moving forwards
-     * @internal
-     */
-    int32_t handleNext(const RBBIStateTable *statetable);
-
-protected:
-
-    /**
-     * This is the function that actually implements dictionary-based
-     * breaking.  Covering at least the range from startPos to endPos,
-     * it checks for dictionary characters, and if it finds them determines
-     * the appropriate object to deal with them. It may cache found breaks in
-     * fCachedBreakPositions as it goes. It may well also look at text outside
-     * the range startPos to endPos.
-     * If going forward, endPos is the normal Unicode break result, and
-     * if goind in reverse, startPos is the normal Unicode break result
-     * @param startPos  The start position of a range of text
-     * @param endPos    The end position of a range of text
-     * @param reverse   The call is for the reverse direction
-     * @internal
-     */
-    int32_t checkDictionary(int32_t startPos, int32_t endPos, UBool reverse);
-
-private:
-
-    /**
-     * This function returns the appropriate LanguageBreakEngine for a
-     * given character c.
-     * @param c         A character in the dictionary set
-     * @internal
-     */
-    const LanguageBreakEngine *getLanguageBreakEngine(UChar32 c);
-
-    /**
-     *  @internal
-     */
-    void makeRuleStatusValid();
-
-};
-
-//------------------------------------------------------------------------------
-//
-//   Inline Functions Definitions ...
-//
-//------------------------------------------------------------------------------
-
-inline UBool RuleBasedBreakIterator::operator!=(const BreakIterator& that) const {
-    return !operator==(that);
-}
-
-U_NAMESPACE_END
-
-#endif /* #if !UCONFIG_NO_BREAK_ITERATION */
-
-#endif


[29/57] [abbrv] remove couch_collate

Posted by be...@apache.org.
http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/regex.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/regex.h b/apps/couch_collate/platform/osx/icu/unicode/regex.h
deleted file mode 100644
index 64b58bb..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/regex.h
+++ /dev/null
@@ -1,1232 +0,0 @@
-/*
-**********************************************************************
-*   Copyright (C) 2002-2008, International Business Machines
-*   Corporation and others.  All Rights Reserved.
-**********************************************************************
-*   file name:  regex.h
-*   encoding:   US-ASCII
-*   indentation:4
-*
-*   created on: 2002oct22
-*   created by: Andy Heninger
-*
-*   ICU Regular Expressions, API for C++
-*/
-
-#ifndef REGEX_H
-#define REGEX_H
-
-//#define REGEX_DEBUG
-
-/**
- * \file
- * \brief  C++ API:  Regular Expressions
- *
- * <h2>Regular Expression API</h2>
- *
- * <p>The ICU API for processing regular expressions consists of two classes,
- *  <code>RegexPattern</code> and <code>RegexMatcher</code>.
- *  <code>RegexPattern</code> objects represent a pre-processed, or compiled
- *  regular expression.  They are created from a regular expression pattern string,
- *  and can be used to create <code>RegexMatcher</code> objects for the pattern.</p>
- *
- * <p>Class <code>RegexMatcher</code> bundles together a regular expression
- *  pattern and a target string to which the search pattern will be applied.
- *  <code>RegexMatcher</code> includes API for doing plain find or search
- *  operations, for search and replace operations, and for obtaining detailed
- *  information about bounds of a match. </p>
- *
- * <p>Note that by constructing <code>RegexMatcher</code> objects directly from regular
- * expression pattern strings application code can be simplified and the explicit
- * need for <code>RegexPattern</code> objects can usually be eliminated.
- * </p>
- */
-
-#include "unicode/utypes.h"
-
-#if !UCONFIG_NO_REGULAR_EXPRESSIONS
-
-#include "unicode/uobject.h"
-#include "unicode/unistr.h"
-#include "unicode/parseerr.h"
-
-#include "unicode/uregex.h"
-
-U_NAMESPACE_BEGIN
-
-
-// Forward Declarations...
-
-class RegexMatcher;
-class RegexPattern;
-class UVector;
-class UVector32;
-class UnicodeSet;
-struct REStackFrame;
-struct Regex8BitSet;
-class  RuleBasedBreakIterator;
-class  RegexCImpl;
-
-
-
-
-/**
- *   RBBIPatternDump   Debug function, displays the compiled form of a pattern.
- *   @internal
- */
-#ifdef REGEX_DEBUG
-U_INTERNAL void U_EXPORT2
-    RegexPatternDump(const RegexPattern *pat);
-#else
-    #define RegexPatternDump(pat)
-#endif
-
-
-
-/**
-  * Class <code>RegexPattern</code> represents a compiled regular expression.  It includes
-  * factory methods for creating a RegexPattern object from the source (string) form
-  * of a regular expression, methods for creating RegexMatchers that allow the pattern
-  * to be applied to input text, and a few convenience methods for simple common
-  * uses of regular expressions.
-  *
-  * <p>Class RegexPattern is not intended to be subclassed.</p>
-  *
-  * @stable ICU 2.4
-  */
-class U_I18N_API RegexPattern: public UObject {
-public:
-
-    /**
-     * default constructor.  Create a RegexPattern object that refers to no actual
-     *   pattern.  Not normally needed; RegexPattern objects are usually
-     *   created using the factory method <code>compile()</code>.
-     *
-     * @stable ICU 2.4
-     */
-    RegexPattern();
-
-    /**
-     * Copy Constructor.  Create a new RegexPattern object that is equivalent
-     *                    to the source object.
-     * @param source the pattern object to be copied.
-     * @stable ICU 2.4
-     */
-    RegexPattern(const RegexPattern &source);
-
-    /**
-     * Destructor.  Note that a RegexPattern object must persist so long as any
-     *  RegexMatcher objects that were created from the RegexPattern are active.
-     * @stable ICU 2.4
-     */
-    virtual ~RegexPattern();
-
-    /**
-     * Comparison operator.  Two RegexPattern objects are considered equal if they
-     * were constructed from identical source patterns using the same match flag
-     * settings.
-     * @param that a RegexPattern object to compare with "this".
-     * @return TRUE if the objects are equivalent.
-     * @stable ICU 2.4
-     */
-    UBool           operator==(const RegexPattern& that) const;
-
-    /**
-     * Comparison operator.  Two RegexPattern objects are considered equal if they
-     * were constructed from identical source patterns using the same match flag
-     * settings.
-     * @param that a RegexPattern object to compare with "this".
-     * @return TRUE if the objects are different.
-     * @stable ICU 2.4
-     */
-    inline UBool    operator!=(const RegexPattern& that) const {return ! operator ==(that);};
-
-    /**
-     * Assignment operator.  After assignment, this RegexPattern will behave identically
-     *     to the source object.
-     * @stable ICU 2.4
-     */
-    RegexPattern  &operator =(const RegexPattern &source);
-
-    /**
-     * Create an exact copy of this RegexPattern object.  Since RegexPattern is not
-     * intended to be subclasses, <code>clone()</code> and the copy construction are
-     * equivalent operations.
-     * @return the copy of this RegexPattern
-     * @stable ICU 2.4
-     */
-    virtual RegexPattern  *clone() const;
-
-
-   /**
-    * Compiles the regular expression in string form into a RegexPattern
-    * object.  These compile methods, rather than the constructors, are the usual
-    * way that RegexPattern objects are created.
-    *
-    * <p>Note that RegexPattern objects must not be deleted while RegexMatcher
-    * objects created from the pattern are active.  RegexMatchers keep a pointer
-    * back to their pattern, so premature deletion of the pattern is a
-    * catastrophic error.</p>
-    *
-    * <p>All pattern match mode flags are set to their default values.</p>
-    *
-    * <p>Note that it is often more convenient to construct a RegexMatcher directly
-    *    from a pattern string rather than separately compiling the pattern and
-    *    then creating a RegexMatcher object from the pattern.</p>
-    *
-    * @param regex The regular expression to be compiled.
-    * @param pe    Receives the position (line and column nubers) of any error
-    *              within the regular expression.)
-    * @param status A reference to a UErrorCode to receive any errors.
-    * @return      A regexPattern object for the compiled pattern.
-    *
-    * @stable ICU 2.4
-    */
-    static RegexPattern * U_EXPORT2 compile( const UnicodeString &regex,
-        UParseError          &pe,
-        UErrorCode           &status);
-
-   /**
-    * Compiles the regular expression in string form into a RegexPattern
-    * object using the specified match mode flags.  These compile methods,
-    * rather than the constructors, are the usual way that RegexPattern objects
-    * are created.
-    *
-    * <p>Note that RegexPattern objects must not be deleted while RegexMatcher
-    * objects created from the pattern are active.  RegexMatchers keep a pointer
-    * back to their pattern, so premature deletion of the pattern is a
-    * catastrophic error.</p>
-    *
-    * <p>Note that it is often more convenient to construct a RegexMatcher directly
-    *    from a pattern string instead of than separately compiling the pattern and
-    *    then creating a RegexMatcher object from the pattern.</p>
-    *
-    * @param regex The regular expression to be compiled.
-    * @param flags The match mode flags to be used.
-    * @param pe    Receives the position (line and column nubers) of any error
-    *              within the regular expression.)
-    * @param status   A reference to a UErrorCode to receive any errors.
-    * @return      A regexPattern object for the compiled pattern.
-    *
-    * @stable ICU 2.4
-    */
-    static RegexPattern * U_EXPORT2 compile( const UnicodeString &regex,
-        uint32_t             flags,
-        UParseError          &pe,
-        UErrorCode           &status);
-
-
-   /**
-    * Compiles the regular expression in string form into a RegexPattern
-    * object using the specified match mode flags.  These compile methods,
-    * rather than the constructors, are the usual way that RegexPattern objects
-    * are created.
-    *
-    * <p>Note that RegexPattern objects must not be deleted while RegexMatcher
-    * objects created from the pattern are active.  RegexMatchers keep a pointer
-    * back to their pattern, so premature deletion of the pattern is a
-    * catastrophic error.</p>
-    *
-    * <p>Note that it is often more convenient to construct a RegexMatcher directly
-    *    from a pattern string instead of than separately compiling the pattern and
-    *    then creating a RegexMatcher object from the pattern.</p>
-    *
-    * @param regex The regular expression to be compiled.
-    * @param flags The match mode flags to be used.
-    * @param status   A reference to a UErrorCode to receive any errors.
-    * @return      A regexPattern object for the compiled pattern.
-    *
-    * @stable ICU 2.6
-    */
-    static RegexPattern * U_EXPORT2 compile( const UnicodeString &regex,
-        uint32_t             flags,
-        UErrorCode           &status);
-
-
-   /**
-    * Get the match mode flags that were used when compiling this pattern.
-    * @return  the match mode flags
-    * @stable ICU 2.4
-    */
-    virtual uint32_t flags() const;
-
-   /**
-    * Creates a RegexMatcher that will match the given input against this pattern.  The
-    * RegexMatcher can then be used to perform match, find or replace operations
-    * on the input.  Note that a RegexPattern object must not be deleted while
-    * RegexMatchers created from it still exist and might possibly be used again.
-    * <p>
-    * The matcher will retain a reference to the supplied input string, and all regexp
-    * pattern matching operations happen directly on this original string.  It is
-    * critical that the string not be altered or deleted before use by the regular
-    * expression operations is complete.
-    *
-    * @param input    The input string to which the regular expression will be applied.
-    * @param status   A reference to a UErrorCode to receive any errors.
-    * @return         A RegexMatcher object for this pattern and input.
-    *
-    * @stable ICU 2.4
-    */
-    virtual RegexMatcher *matcher(const UnicodeString &input,
-        UErrorCode          &status) const;
-
-private:
-    /**
-     * Cause a compilation error if an application accidently attempts to
-     *   create a matcher with a (UChar *) string as input rather than
-     *   a UnicodeString.  Avoids a dangling reference to a temporary string.
-     * <p>
-     * To efficiently work with UChar *strings, wrap the data in a UnicodeString
-     * using one of the aliasing constructors, such as
-     * <code>UnicodeString(UBool isTerminated, const UChar *text, int32_t textLength);</code>
-     *
-     * @internal
-     */
-    RegexMatcher *matcher(const UChar *input,
-        UErrorCode          &status) const;
-public:
-
-
-   /**
-    * Creates a RegexMatcher that will match against this pattern.  The
-    * RegexMatcher can be used to perform match, find or replace operations.
-    * Note that a RegexPattern object must not be deleted while
-    * RegexMatchers created from it still exist and might possibly be used again.
-    *
-    * @param status   A reference to a UErrorCode to receive any errors.
-    * @return      A RegexMatcher object for this pattern and input.
-    *
-    * @stable ICU 2.6
-    */
-    virtual RegexMatcher *matcher(UErrorCode  &status) const;
-
-
-   /**
-    * Test whether a string matches a regular expression.  This convenience function
-    * both compiles the reguluar expression and applies it in a single operation.
-    * Note that if the same pattern needs to be applied repeatedly, this method will be
-    * less efficient than creating and reusing a RegexMatcher object.
-    *
-    * @param regex The regular expression
-    * @param input The string data to be matched
-    * @param pe Receives the position of any syntax errors within the regular expression
-    * @param status A reference to a UErrorCode to receive any errors.
-    * @return True if the regular expression exactly matches the full input string.
-    *
-    * @stable ICU 2.4
-    */
-    static UBool U_EXPORT2 matches(const UnicodeString   &regex,
-        const UnicodeString   &input,
-        UParseError     &pe,
-        UErrorCode      &status);
-
-
-   /**
-    *    Returns the regular expression from which this pattern was compiled.
-    *    @stable ICU 2.4
-    */
-    virtual UnicodeString pattern() const;
-
-
-    /**
-     * Split a string into fields.  Somewhat like split() from Perl.
-     * The pattern matches identify delimiters that separate the input
-     *  into fields.  The input data between the matches becomes the
-     *  fields themselves.
-     * <p>
-     *  For the best performance on split() operations,
-     *  <code>RegexMatcher::split</code> is perferable to this function
-     *
-     * @param input   The string to be split into fields.  The field delimiters
-     *                match the pattern (in the "this" object)
-     * @param dest    An array of UnicodeStrings to receive the results of the split.
-     *                This is an array of actual UnicodeString objects, not an
-     *                array of pointers to strings.  Local (stack based) arrays can
-     *                work well here.
-     * @param destCapacity  The number of elements in the destination array.
-     *                If the number of fields found is less than destCapacity, the
-     *                extra strings in the destination array are not altered.
-     *                If the number of destination strings is less than the number
-     *                of fields, the trailing part of the input string, including any
-     *                field delimiters, is placed in the last destination string.
-     * @param status  A reference to a UErrorCode to receive any errors.
-     * @return        The number of fields into which the input string was split.
-     * @stable ICU 2.4
-     */
-    virtual int32_t  split(const UnicodeString &input,
-        UnicodeString    dest[],
-        int32_t          destCapacity,
-        UErrorCode       &status) const;
-
-
-    /**
-     * ICU "poor man's RTTI", returns a UClassID for the actual class.
-     *
-     * @stable ICU 2.4
-     */
-    virtual UClassID getDynamicClassID() const;
-
-    /**
-     * ICU "poor man's RTTI", returns a UClassID for this class.
-     *
-     * @stable ICU 2.4
-     */
-    static UClassID U_EXPORT2 getStaticClassID();
-
-private:
-    //
-    //  Implementation Data
-    //
-    UnicodeString   fPattern;      // The original pattern string.
-    uint32_t        fFlags;        // The flags used when compiling the pattern.
-                                   //
-    UVector32       *fCompiledPat; // The compiled pattern p-code.
-    UnicodeString   fLiteralText;  // Any literal string data from the pattern,
-                                   //   after un-escaping, for use during the match.
-
-    UVector         *fSets;        // Any UnicodeSets referenced from the pattern.
-    Regex8BitSet    *fSets8;       //      (and fast sets for latin-1 range.)
-
-
-    UErrorCode      fDeferredStatus; // status if some prior error has left this
-                                   //  RegexPattern in an unusable state.
-
-    int32_t         fMinMatchLen;  // Minimum Match Length.  All matches will have length
-                                   //   >= this value.  For some patterns, this calculated
-                                   //   value may be less than the true shortest
-                                   //   possible match.
-
-    int32_t         fFrameSize;    // Size of a state stack frame in the
-                                   //   execution engine.
-
-    int32_t         fDataSize;     // The size of the data needed by the pattern that
-                                   //   does not go on the state stack, but has just
-                                   //   a single copy per matcher.
-
-    UVector32       *fGroupMap;    // Map from capture group number to position of
-                                   //   the group's variables in the matcher stack frame.
-
-    int32_t         fMaxCaptureDigits;
-
-    UnicodeSet     **fStaticSets;  // Ptr to static (shared) sets for predefined
-                                   //   regex character classes, e.g. Word.
-
-    Regex8BitSet   *fStaticSets8;  // Ptr to the static (shared) latin-1 only
-                                   //  sets for predefined regex classes.
-
-    int32_t         fStartType;    // Info on how a match must start.
-    int32_t         fInitialStringIdx;     //
-    int32_t         fInitialStringLen;
-    UnicodeSet     *fInitialChars;
-    UChar32         fInitialChar;
-    Regex8BitSet   *fInitialChars8;
-
-    friend class RegexCompile;
-    friend class RegexMatcher;
-    friend class RegexCImpl;
-
-    //
-    //  Implementation Methods
-    //
-    void        init();            // Common initialization, for use by constructors.
-    void        zap();             // Common cleanup
-#ifdef REGEX_DEBUG
-    void        dumpOp(int32_t index) const;
-    friend     void U_EXPORT2 RegexPatternDump(const RegexPattern *);
-#endif
-
-};
-
-
-
-/**
- *  class RegexMatcher bundles together a reular expression pattern and
- *  input text to which the expression can be applied.  It includes methods
- *  for testing for matches, and for find and replace operations.
- *
- * <p>Class RegexMatcher is not intended to be subclassed.</p>
- *
- * @stable ICU 2.4
- */
-class U_I18N_API RegexMatcher: public UObject {
-public:
-
-    /**
-      * Construct a RegexMatcher for a regular expression.
-      * This is a convenience method that avoids the need to explicitly create
-      * a RegexPattern object.  Note that if several RegexMatchers need to be
-      * created for the same expression, it will be more efficient to
-      * separately create and cache a RegexPattern object, and use
-      * its matcher() method to create the RegexMatcher objects.
-      *
-      *  @param regexp The Regular Expression to be compiled.
-      *  @param flags  Regular expression options, such as case insensitive matching.
-      *                @see UREGEX_CASE_INSENSITIVE
-      *  @param status Any errors are reported by setting this UErrorCode variable.
-      *  @stable ICU 2.6
-      */
-    RegexMatcher(const UnicodeString &regexp, uint32_t flags, UErrorCode &status);
-
-    /**
-      * Construct a RegexMatcher for a regular expression.
-      * This is a convenience method that avoids the need to explicitly create
-      * a RegexPattern object.  Note that if several RegexMatchers need to be
-      * created for the same expression, it will be more efficient to
-      * separately create and cache a RegexPattern object, and use
-      * its matcher() method to create the RegexMatcher objects.
-      * <p>
-      * The matcher will retain a reference to the supplied input string, and all regexp
-      * pattern matching operations happen directly on the original string.  It is
-      * critical that the string not be altered or deleted before use by the regular
-      * expression operations is complete.
-      *
-      *  @param regexp The Regular Expression to be compiled.
-      *  @param input  The string to match.  The matcher retains a reference to the
-      *                caller's string; mo copy is made.
-      *  @param flags  Regular expression options, such as case insensitive matching.
-      *                @see UREGEX_CASE_INSENSITIVE
-      *  @param status Any errors are reported by setting this UErrorCode variable.
-      *  @stable ICU 2.6
-      */
-    RegexMatcher(const UnicodeString &regexp, const UnicodeString &input,
-        uint32_t flags, UErrorCode &status);
-
-private:
-    /**
-     * Cause a compilation error if an application accidently attempts to
-     *   create a matcher with a (UChar *) string as input rather than
-     *   a UnicodeString.    Avoids a dangling reference to a temporary string.
-     * <p>
-     * To efficiently work with UChar *strings, wrap the data in a UnicodeString
-     * using one of the aliasing constructors, such as
-     * <code>UnicodeString(UBool isTerminated, const UChar *text, int32_t textLength);</code>
-     *
-     * @internal
-     */
-    RegexMatcher(const UnicodeString &regexp, const UChar *input,
-        uint32_t flags, UErrorCode &status);
-public:
-
-
-   /**
-    *   Destructor.
-    *
-    *  @stable ICU 2.4
-    */
-    virtual ~RegexMatcher();
-
-
-   /**
-    *   Attempts to match the entire input region against the pattern.
-    *    @param   status     A reference to a UErrorCode to receive any errors.
-    *    @return TRUE if there is a match
-    *    @stable ICU 2.4
-    */
-    virtual UBool matches(UErrorCode &status);
-
-   /**
-    *   Resets the matcher, then attempts to match the input beginning 
-    *   at the specified startIndex, and extending to the end of the input.
-    *   The input region is reset to include the entire input string.
-    *   A successful match must extend to the end of the input.
-    *    @param   startIndex The input string index at which to begin matching.
-    *    @param   status     A reference to a UErrorCode to receive any errors.
-    *    @return TRUE if there is a match
-    *    @stable ICU 2.8
-    */
-    virtual UBool matches(int32_t startIndex, UErrorCode &status);
-
-
-
-
-   /**
-    *   Attempts to match the input string, starting from the beginning of the region,
-    *   against the pattern.  Like the matches() method, this function 
-    *   always starts at the beginning of the input region;
-    *   unlike that function, it does not require that the entire region be matched.
-    *
-    *   <p>If the match succeeds then more information can be obtained via the <code>start()</code>,
-    *     <code>end()</code>, and <code>group()</code> functions.</p>
-    *
-    *    @param   status     A reference to a UErrorCode to receive any errors.
-    *    @return  TRUE if there is a match at the start of the input string.
-    *    @stable ICU 2.4
-    */
-    virtual UBool lookingAt(UErrorCode &status);
-
-
-  /**
-    *   Attempts to match the input string, starting from the specified index, against the pattern.
-    *   The match may be of any length, and is not required to extend to the end
-    *   of the input string.  Contrast with match().
-    *
-    *   <p>If the match succeeds then more information can be obtained via the <code>start()</code>,
-    *     <code>end()</code>, and <code>group()</code> functions.</p>
-    *
-    *    @param   startIndex The input string index at which to begin matching.
-    *    @param   status     A reference to a UErrorCode to receive any errors.
-    *    @return  TRUE if there is a match.
-    *    @stable ICU 2.8
-    */
-    virtual UBool lookingAt(int32_t startIndex, UErrorCode &status);
-
-   /**
-    *  Find the next pattern match in the input string.
-    *  The find begins searching the input at the location following the end of
-    *  the previous match, or at the start of the string if there is no previous match.
-    *  If a match is found, <code>start(), end()</code> and <code>group()</code>
-    *  will provide more information regarding the match.
-    *  <p>Note that if the input string is changed by the application,
-    *     use find(startPos, status) instead of find(), because the saved starting
-    *     position may not be valid with the altered input string.</p>
-    *  @return  TRUE if a match is found.
-    *  @stable ICU 2.4
-    */
-    virtual UBool find();
-
-
-   /**
-    *   Resets this RegexMatcher and then attempts to find the next substring of the
-    *   input string that matches the pattern, starting at the specified index.
-    *
-    *   @param   start     the position in the input string to begin the search
-    *   @param   status    A reference to a UErrorCode to receive any errors.
-    *   @return  TRUE if a match is found.
-    *   @stable ICU 2.4
-    */
-    virtual UBool find(int32_t start, UErrorCode &status);
-
-
-   /**
-    *   Returns a string containing the text matched by the previous match.
-    *   If the pattern can match an empty string, an empty string may be returned.
-    *   @param   status      A reference to a UErrorCode to receive any errors.
-    *                        Possible errors are  U_REGEX_INVALID_STATE if no match
-    *                        has been attempted or the last match failed.
-    *   @return  a string containing the matched input text.
-    *   @stable ICU 2.4
-    */
-    virtual UnicodeString group(UErrorCode &status) const;
-
-
-   /**
-    *    Returns a string containing the text captured by the given group
-    *    during the previous match operation.  Group(0) is the entire match.
-    *
-    *    @param groupNum the capture group number
-    *    @param   status     A reference to a UErrorCode to receive any errors.
-    *                        Possible errors are  U_REGEX_INVALID_STATE if no match
-    *                        has been attempted or the last match failed and
-    *                        U_INDEX_OUTOFBOUNDS_ERROR for a bad capture group number.
-    *    @return the captured text
-    *    @stable ICU 2.4
-    */
-    virtual UnicodeString group(int32_t groupNum, UErrorCode &status) const;
-
-
-   /**
-    *   Returns the number of capturing groups in this matcher's pattern.
-    *   @return the number of capture groups
-    *   @stable ICU 2.4
-    */
-    virtual int32_t groupCount() const;
-
-
-   /**
-    *   Returns the index in the input string of the start of the text matched
-    *   during the previous match operation.
-    *    @param   status      a reference to a UErrorCode to receive any errors.
-    *    @return              The position in the input string of the start of the last match.
-    *    @stable ICU 2.4
-    */
-    virtual int32_t start(UErrorCode &status) const;
-
-
-   /**
-    *   Returns the index in the input string of the start of the text matched by the
-    *    specified capture group during the previous match operation.  Return -1 if
-    *    the capture group exists in the pattern, but was not part of the last match.
-    *
-    *    @param  group       the capture group number
-    *    @param  status      A reference to a UErrorCode to receive any errors.  Possible
-    *                        errors are  U_REGEX_INVALID_STATE if no match has been
-    *                        attempted or the last match failed, and
-    *                        U_INDEX_OUTOFBOUNDS_ERROR for a bad capture group number
-    *    @return the start position of substring matched by the specified group.
-    *    @stable ICU 2.4
-    */
-    virtual int32_t start(int32_t group, UErrorCode &status) const;
-
-
-   /**
-    *    Returns the index in the input string of the first character following the
-    *    text matched during the previous match operation.
-    *   @param   status      A reference to a UErrorCode to receive any errors.  Possible
-    *                        errors are  U_REGEX_INVALID_STATE if no match has been
-    *                        attempted or the last match failed.
-    *    @return the index of the last character matched, plus one.
-    *   @stable ICU 2.4
-    */
-    virtual int32_t end(UErrorCode &status) const;
-
-
-   /**
-    *    Returns the index in the input string of the character following the
-    *    text matched by the specified capture group during the previous match operation.
-    *    @param group  the capture group number
-    *    @param   status      A reference to a UErrorCode to receive any errors.  Possible
-    *                        errors are  U_REGEX_INVALID_STATE if no match has been
-    *                        attempted or the last match failed and
-    *                        U_INDEX_OUTOFBOUNDS_ERROR for a bad capture group number
-    *    @return  the index of the first character following the text
-    *              captured by the specifed group during the previous match operation.
-    *              Return -1 if the capture group exists in the pattern but was not part of the match.
-    *    @stable ICU 2.4
-    */
-    virtual int32_t end(int32_t group, UErrorCode &status) const;
-
-
-   /**
-    *   Resets this matcher.  The effect is to remove any memory of previous matches,
-    *       and to cause subsequent find() operations to begin at the beginning of
-    *       the input string.
-    *
-    *   @return this RegexMatcher.
-    *   @stable ICU 2.4
-    */
-    virtual RegexMatcher &reset();
-
-
-   /**
-    *   Resets this matcher, and set the current input position.
-    *   The effect is to remove any memory of previous matches,
-    *       and to cause subsequent find() operations to begin at
-    *       the specified position in the input string.
-    * <p>
-    *   The matcher's region is reset to its default, which is the entire
-    *   input string.
-    * <p>
-    *   An alternative to this function is to set a match region
-    *   beginning at the desired index.
-    *
-    *   @return this RegexMatcher.
-    *   @stable ICU 2.8
-    */
-    virtual RegexMatcher &reset(int32_t index, UErrorCode &status);
-
-
-   /**
-    *   Resets this matcher with a new input string.  This allows instances of RegexMatcher
-    *     to be reused, which is more efficient than creating a new RegexMatcher for
-    *     each input string to be processed.
-    *   @param input The new string on which subsequent pattern matches will operate.
-    *                The matcher retains a reference to the callers string, and operates
-    *                directly on that.  Ownership of the string remains with the caller.
-    *                Because no copy of the string is made, it is essential that the
-    *                caller not delete the string until after regexp operations on it
-    *                are done.
-    *   @return this RegexMatcher.
-    *   @stable ICU 2.4
-    */
-    virtual RegexMatcher &reset(const UnicodeString &input);
-
-private:
-    /**
-     * Cause a compilation error if an application accidently attempts to
-     *   reset a matcher with a (UChar *) string as input rather than
-     *   a UnicodeString.    Avoids a dangling reference to a temporary string.
-     * <p>
-     * To efficiently work with UChar *strings, wrap the data in a UnicodeString
-     * using one of the aliasing constructors, such as
-     * <code>UnicodeString(UBool isTerminated, const UChar *text, int32_t textLength);</code>
-     *
-     * @internal
-     */
-    RegexMatcher &reset(const UChar *input);
-public:
-
-   /**
-    *   Returns the input string being matched.  The returned string is not a copy,
-    *   but the live input string.  It should not be altered or deleted.
-    *   @return the input string
-    *   @stable ICU 2.4
-    */
-    virtual const UnicodeString &input() const;
-    
-    
-
-   /** Sets the limits of this matcher's region.
-     * The region is the part of the input string that will be searched to find a match.
-     * Invoking this method resets the matcher, and then sets the region to start
-     * at the index specified by the start parameter and end at the index specified
-     * by the end parameter.
-     *
-     * Depending on the transparency and anchoring being used (see useTransparentBounds
-     * and useAnchoringBounds), certain constructs such as anchors may behave differently
-     * at or around the boundaries of the region
-     *
-     * The function will fail if start is greater than limit, or if either index
-     *  is less than zero or greater than the length of the string being matched.
-     *
-     * @param start  The index to begin searches at.
-     * @param limit  The index to end searches at (exclusive).
-     * @param status A reference to a UErrorCode to receive any errors.
-     * @draft ICU 4.0
-     */
-     virtual RegexMatcher &region(int32_t start, int32_t limit, UErrorCode &status);
-
-
-   /**
-     * Reports the start index of this matcher's region. The searches this matcher
-     * conducts are limited to finding matches within regionStart (inclusive) and
-     * regionEnd (exclusive).
-     *
-     * @return The starting index of this matcher's region.
-     * @draft ICU 4.0
-     */
-     virtual int32_t regionStart() const;
-
-
-    /**
-      * Reports the end (limit) index (exclusive) of this matcher's region. The searches
-      * this matcher conducts are limited to finding matches within regionStart
-      * (inclusive) and regionEnd (exclusive).
-      *
-      * @return The ending point of this matcher's region.
-      * @draft ICU 4.0
-      */
-      virtual int32_t regionEnd() const;
-
-    /**
-      * Queries the transparency of region bounds for this matcher.
-      * See useTransparentBounds for a description of transparent and opaque bounds.
-      * By default, a matcher uses opaque region boundaries.
-      *
-      * @return TRUE if this matcher is using opaque bounds, false if it is not.
-      * @draft ICU 4.0
-      */
-      virtual UBool hasTransparentBounds() const;
-
-    /**
-      * Sets the transparency of region bounds for this matcher.
-      * Invoking this function with an argument of true will set this matcher to use transparent bounds.
-      * If the boolean argument is false, then opaque bounds will be used.
-      *
-      * Using transparent bounds, the boundaries of this matcher's region are transparent
-      * to lookahead, lookbehind, and boundary matching constructs. Those constructs can
-      * see text beyond the boundaries of the region while checking for a match.
-      *
-      * With opaque bounds, no text outside of the matcher's region is visible to lookahead,
-      * lookbehind, and boundary matching constructs.
-      *
-      * By default, a matcher uses opaque bounds.
-      *
-      * @param   b TRUE for transparent bounds; FALSE for opaque bounds
-      * @return  This Matcher;
-      * @draft   ICU 4.0
-      **/
-      virtual RegexMatcher &useTransparentBounds(UBool b);
-
-     
-    /**
-      * Return true if this matcher is using anchoring bounds.
-      * By default, matchers use anchoring region boounds.
-      *
-      * @return TRUE if this matcher is using anchoring bounds.
-      * @draft  ICU 4.0
-      */    
-      virtual UBool hasAnchoringBounds() const;
-
-    /**
-      * Set whether this matcher is using Anchoring Bounds for its region.
-      * With anchoring bounds, pattern anchors such as ^ and $ will match at the start
-      * and end of the region.  Without Anchoring Bounds, anchors will only match at
-      * the positions they would in the complete text.
-      *
-      * Anchoring Bounds are the default for regions.
-      *
-      * @param b TRUE if to enable anchoring bounds; FALSE to disable them.
-      * @return  This Matcher
-      * @draft   ICU 4.0
-      */
-      virtual RegexMatcher &useAnchoringBounds(UBool b);
-
-    /**
-      * Return TRUE if the most recent matching operation touched the
-      *  end of the text being processed.  In this case, additional input text could
-      *  change the results of that match.
-      *
-      *  hitEnd() is defined for both successful and unsuccessful matches.
-      *  In either case hitEnd() will return TRUE if if the end of the text was
-      *  reached at any point during the matching process.
-      *
-      *  @return  TRUE if the most recent match hit the end of input
-      *  @draft   ICU 4.0
-      */
-      virtual UBool hitEnd() const;
-
-    /**
-      * Return TRUE the most recent match succeeded and additional input could cause
-      * it to fail. If this method returns false and a match was found, then more input
-      * might change the match but the match won't be lost. If a match was not found,
-      * then requireEnd has no meaning.
-      *
-      * @return TRUE if more input could cause the most recent match to no longer match.
-      * @draft  ICU 4.0
-      */
-      virtual UBool requireEnd() const;
-
-
-
-
-
-   /**
-    *    Returns the pattern that is interpreted by this matcher.
-    *    @return  the RegexPattern for this RegexMatcher
-    *    @stable ICU 2.4
-    */
-    virtual const RegexPattern &pattern() const;
-
-
-   /**
-    *    Replaces every substring of the input that matches the pattern
-    *    with the given replacement string.  This is a convenience function that
-    *    provides a complete find-and-replace-all operation.
-    *
-    *    This method first resets this matcher. It then scans the input string
-    *    looking for matches of the pattern. Input that is not part of any
-    *    match is left unchanged; each match is replaced in the result by the
-    *    replacement string. The replacement string may contain references to
-    *    capture groups.
-    *
-    *    @param   replacement a string containing the replacement text.
-    *    @param   status      a reference to a UErrorCode to receive any errors.
-    *    @return              a string containing the results of the find and replace.
-    *    @stable ICU 2.4
-    */
-    virtual UnicodeString replaceAll(const UnicodeString &replacement, UErrorCode &status);
-
-
-   /**
-    * Replaces the first substring of the input that matches
-    * the pattern with the replacement string.   This is a convenience
-    * function that provides a complete find-and-replace operation.
-    *
-    * <p>This function first resets this RegexMatcher. It then scans the input string
-    * looking for a match of the pattern. Input that is not part
-    * of the match is appended directly to the result string; the match is replaced
-    * in the result by the replacement string. The replacement string may contain
-    * references to captured groups.</p>
-    *
-    * <p>The state of the matcher (the position at which a subsequent find()
-    *    would begin) after completing a replaceFirst() is not specified.  The
-    *    RegexMatcher should be reset before doing additional find() operations.</p>
-    *
-    *    @param   replacement a string containing the replacement text.
-    *    @param   status      a reference to a UErrorCode to receive any errors.
-    *    @return              a string containing the results of the find and replace.
-    *    @stable ICU 2.4
-    */
-    virtual UnicodeString replaceFirst(const UnicodeString &replacement, UErrorCode &status);
-
-   /**
-    *   Implements a replace operation intended to be used as part of an
-    *   incremental find-and-replace.
-    *
-    *   <p>The input string, starting from the end of the previous replacement and ending at
-    *   the start of the current match, is appended to the destination string.  Then the
-    *   replacement string is appended to the output string,
-    *   including handling any substitutions of captured text.</p>
-    *
-    *   <p>For simple, prepackaged, non-incremental find-and-replace
-    *   operations, see replaceFirst() or replaceAll().</p>
-    *
-    *   @param   dest        A UnicodeString to which the results of the find-and-replace are appended.
-    *   @param   replacement A UnicodeString that provides the text to be substituted for
-    *                        the input text that matched the regexp pattern.  The replacement
-    *                        text may contain references to captured text from the
-    *                        input.
-    *   @param   status      A reference to a UErrorCode to receive any errors.  Possible
-    *                        errors are  U_REGEX_INVALID_STATE if no match has been
-    *                        attempted or the last match failed, and U_INDEX_OUTOFBOUNDS_ERROR
-    *                        if the replacement text specifies a capture group that
-    *                        does not exist in the pattern.
-    *
-    *   @return  this  RegexMatcher
-    *   @stable ICU 2.4
-    *
-    */
-    virtual RegexMatcher &appendReplacement(UnicodeString &dest,
-        const UnicodeString &replacement, UErrorCode &status);
-
-
-   /**
-    * As the final step in a find-and-replace operation, append the remainder
-    * of the input string, starting at the position following the last appendReplacement(),
-    * to the destination string. <code>appendTail()</code> is intended to be invoked after one
-    * or more invocations of the <code>RegexMatcher::appendReplacement()</code>.
-    *
-    *  @param dest A UnicodeString to which the results of the find-and-replace are appended.
-    *  @return  the destination string.
-    *  @stable ICU 2.4
-    */
-    virtual UnicodeString &appendTail(UnicodeString &dest);
-
-
-
-    /**
-     * Split a string into fields.  Somewhat like split() from Perl.
-     * The pattern matches identify delimiters that separate the input
-     *  into fields.  The input data between the matches becomes the
-     *  fields themselves.
-     * <p>
-     *
-     * @param input   The string to be split into fields.  The field delimiters
-     *                match the pattern (in the "this" object).  This matcher
-     *                will be reset to this input string.
-     * @param dest    An array of UnicodeStrings to receive the results of the split.
-     *                This is an array of actual UnicodeString objects, not an
-     *                array of pointers to strings.  Local (stack based) arrays can
-     *                work well here.
-     * @param destCapacity  The number of elements in the destination array.
-     *                If the number of fields found is less than destCapacity, the
-     *                extra strings in the destination array are not altered.
-     *                If the number of destination strings is less than the number
-     *                of fields, the trailing part of the input string, including any
-     *                field delimiters, is placed in the last destination string.
-     * @param status  A reference to a UErrorCode to receive any errors.
-     * @return        The number of fields into which the input string was split.
-     * @stable ICU 2.6
-     */
-    virtual int32_t  split(const UnicodeString &input,
-        UnicodeString    dest[],
-        int32_t          destCapacity,
-        UErrorCode       &status);
-
-  /**
-    *   Set a processing time limit for match operations with this Matcher.
-    *  
-    *   Some patterns, when matching certain strings, can run in exponential time.
-    *   For practical purposes, the match operation may appear to be in an
-    *   infinite loop.
-    *   When a limit is set a match operation will fail with an error if the
-    *   limit is exceeded.
-    *   <p>
-    *   The units of the limit are steps of the match engine.
-    *   Correspondence with actual processor time will depend on the speed
-    *   of the processor and the details of the specific pattern, but will
-    *   typically be on the order of milliseconds.
-    *   <p>
-    *   By default, the matching time is not limited.
-    *   <p>
-    *
-    *   @param   limit       The limit value, or 0 for no limit.
-    *   @param   status      A reference to a UErrorCode to receive any errors.
-    *   @draft ICU 4.0
-    */
-    virtual void setTimeLimit(int32_t limit, UErrorCode &status);
-
-  /**
-    * Get the time limit, if any, for match operations made with this Matcher.
-    *
-    *   @return the maximum allowed time for a match, in units of processing steps.
-    *   @draft ICU 4.0
-    */
-    virtual int32_t getTimeLimit() const;
-
-  /**
-    *  Set the amount of heap storage avaliable for use by the match backtracking stack.
-    *  The matcher is also reset, discarding any results from previous matches.
-    *  <p>
-    *  ICU uses a backtracking regular expression engine, with the backtrack stack
-    *  maintained on the heap.  This function sets the limit to the amount of memory
-    *  that can be used  for this purpose.  A backtracking stack overflow will
-    *  result in an error from the match operation that caused it.
-    *  <p>
-    *  A limit is desirable because a malicious or poorly designed pattern can use
-    *  excessive memory, potentially crashing the process.  A limit is enabled
-    *  by default.
-    *  <p>
-    *  @param limit  The maximum size, in bytes, of the matching backtrack stack.
-    *                A value of zero means no limit.
-    *                The limit must be greater or equal to zero.
-    *
-    *  @param status   A reference to a UErrorCode to receive any errors.
-    *
-    *  @draft ICU 4.0
-    */
-    virtual void setStackLimit(int32_t  limit, UErrorCode &status);
-    
-  /**
-    *  Get the size of the heap storage available for use by the back tracking stack.
-    *
-    *  @return  the maximum backtracking stack size, in bytes, or zero if the
-    *           stack size is unlimited.
-    *  @draft ICU 4.0
-    */
-    virtual int32_t  getStackLimit() const;
-
-
-  /**
-    * Set a callback function for use with this Matcher.
-    * During matching operations the function will be called periodically,
-    * giving the application the opportunity to terminate a long-running
-    * match.
-    *
-    *    @param   callback    A pointer to the user-supplied callback function.
-    *    @param   context     User context pointer.  The value supplied at the
-    *                         time the callback function is set will be saved
-    *                         and passed to the callback each time that it is called.
-    *    @param   status      A reference to a UErrorCode to receive any errors.
-    *  @draft ICU 4.0
-    */
-    virtual void setMatchCallback(URegexMatchCallback     *callback,
-                                  const void              *context,
-                                  UErrorCode              &status);
-
-
-
-  /**
-    *  Get the callback function for this URegularExpression.
-    *
-    *    @param   callback    Out paramater, receives a pointer to the user-supplied 
-    *                         callback function.
-    *    @param   context     Out parameter, receives the user context pointer that
-    *                         was set when uregex_setMatchCallback() was called.
-    *    @param   status      A reference to a UErrorCode to receive any errors.
-    *    @draft ICU 4.0
-    */
-    virtual void getMatchCallback(URegexMatchCallback     *&callback,
-                                  const void              *&context,
-                                  UErrorCode              &status);
-
-
-   /**
-     *   setTrace   Debug function, enable/disable tracing of the matching engine.
-     *              For internal ICU development use only.  DO NO USE!!!!
-     *   @internal
-     */
-    void setTrace(UBool state);
-
-
-    /**
-    * ICU "poor man's RTTI", returns a UClassID for this class.
-    *
-    * @stable ICU 2.2
-    */
-    static UClassID U_EXPORT2 getStaticClassID();
-
-    /**
-     * ICU "poor man's RTTI", returns a UClassID for the actual class.
-     *
-     * @stable ICU 2.2
-     */
-    virtual UClassID getDynamicClassID() const;
-
-private:
-    // Constructors and other object boilerplate are private.
-    // Instances of RegexMatcher can not be assigned, copied, cloned, etc.
-    RegexMatcher();                  // default constructor not implemented
-    RegexMatcher(const RegexPattern *pat);
-    RegexMatcher(const RegexMatcher &other);
-    RegexMatcher &operator =(const RegexMatcher &rhs);
-    void init(UErrorCode &status);                      // Common initialization
-    void init2(const UnicodeString &s, UErrorCode &e);  // Common initialization, part 2.
-
-    friend class RegexPattern;
-    friend class RegexCImpl;
-public:
-    /** @internal  */
-    void resetPreserveRegion();  // Reset matcher state, but preserve any region.
-private:
-
-    //
-    //  MatchAt   This is the internal interface to the match engine itself.
-    //            Match status comes back in matcher member variables.
-    //
-    void                 MatchAt(int32_t startIdx, UBool toEnd, UErrorCode &status);
-    inline void          backTrack(int32_t &inputIdx, int32_t &patIdx);
-    UBool                isWordBoundary(int32_t pos);         // perform Perl-like  \b test
-    UBool                isUWordBoundary(int32_t pos);        // perform RBBI based \b test
-    REStackFrame        *resetStack();
-    inline REStackFrame *StateSave(REStackFrame *fp, int32_t savePatIdx, UErrorCode &status);
-    void                 IncrementTime(UErrorCode &status);
-
-
-    const RegexPattern  *fPattern;
-    RegexPattern        *fPatternOwned;    // Non-NULL if this matcher owns the pattern, and
-                                           //   should delete it when through.
-
-    const UnicodeString *fInput;           // The text being matched. Is never NULL.
-    int32_t              fFrameSize;       // The size of a frame in the backtrack stack.
-    
-    int32_t              fRegionStart;     // Start of the input region, default = 0.
-    int32_t              fRegionLimit;     // End of input region, default to input.length.
-    
-    int32_t              fAnchorStart;     // Region bounds for anchoring operations (^ or $).
-    int32_t              fAnchorLimit;     //   See useAnchoringBounds
-    
-    int32_t              fLookStart;       // Region bounds for look-ahead/behind and
-    int32_t              fLookLimit;       //   and other boundary tests.  See
-                                           //   useTransparentBounds
-
-    int32_t              fActiveStart;     // Currently active bounds for matching.
-    int32_t              fActiveLimit;     //   Usually is the same as region, but
-                                           //   is changed to fLookStart/Limit when
-                                           //   entering look around regions.
-
-    UBool                fTransparentBounds;  // True if using transparent bounds.
-    UBool                fAnchoringBounds; // True if using anchoring bounds.
-
-    UBool                fMatch;           // True if the last attempted match was successful.
-    int32_t              fMatchStart;      // Position of the start of the most recent match
-    int32_t              fMatchEnd;        // First position after the end of the most recent match
-                                           //   Zero if no previous match, even when a region
-                                           //   is active.
-    int32_t              fLastMatchEnd;    // First position after the end of the previous match,
-                                           //   or -1 if there was no previous match.
-    int32_t              fAppendPosition;  // First position after the end of the previous
-                                           //   appendReplacement().  As described by the
-                                           //   JavaDoc for Java Matcher, where it is called 
-                                           //   "append position"
-    UBool                fHitEnd;          // True if the last match touched the end of input.
-    UBool                fRequireEnd;      // True if the last match required end-of-input
-                                           //    (matched $ or Z)
-
-    UVector32           *fStack;
-    REStackFrame        *fFrame;           // After finding a match, the last active stack frame,
-                                           //   which will contain the capture group results.
-                                           //   NOT valid while match engine is running.
-
-    int32_t             *fData;            // Data area for use by the compiled pattern.
-    int32_t             fSmallData[8];     //   Use this for data if it's enough.
-
-    int32_t             fTimeLimit;        // Max time (in arbitrary steps) to let the
-                                           //   match engine run.  Zero for unlimited.
-    
-    int32_t             fTime;             // Match time, accumulates while matching.
-    int32_t             fTickCounter;      // Low bits counter for time.  Counts down StateSaves.
-                                           //   Kept separately from fTime to keep as much
-                                           //   code as possible out of the inline
-                                           //   StateSave function.
-
-    int32_t             fStackLimit;       // Maximum memory size to use for the backtrack
-                                           //   stack, in bytes.  Zero for unlimited.
-
-    URegexMatchCallback *fCallbackFn;       // Pointer to match progress callback funct.
-                                           //   NULL if there is no callback.
-    const void         *fCallbackContext;  // User Context ptr for callback function.
-
-    UBool               fTraceDebug;       // Set true for debug tracing of match engine.
-
-    UErrorCode          fDeferredStatus;   // Save error state that cannot be immediately
-                                           //   reported, or that permanently disables this matcher.
-
-    RuleBasedBreakIterator  *fWordBreakItr;
-
-
-};
-
-U_NAMESPACE_END
-#endif  // UCONFIG_NO_REGULAR_EXPRESSIONS
-#endif

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/rep.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/rep.h b/apps/couch_collate/platform/osx/icu/unicode/rep.h
deleted file mode 100644
index 3fab6fa..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/rep.h
+++ /dev/null
@@ -1,259 +0,0 @@
-/*
-**************************************************************************
-* Copyright (C) 1999-2005, International Business Machines Corporation and
-* others. All Rights Reserved.
-**************************************************************************
-*   Date        Name        Description
-*   11/17/99    aliu        Creation.  Ported from java.  Modified to
-*                           match current UnicodeString API.  Forced
-*                           to use name "handleReplaceBetween" because
-*                           of existing methods in UnicodeString.
-**************************************************************************
-*/
-
-#ifndef REP_H
-#define REP_H
-
-#include "unicode/uobject.h"
-
-/**
- * \file 
- * \brief C++ API: Replaceable String
- */
- 
-U_NAMESPACE_BEGIN
-
-class UnicodeString;
-
-/**
- * <code>Replaceable</code> is an abstract base class representing a
- * string of characters that supports the replacement of a range of
- * itself with a new string of characters.  It is used by APIs that
- * change a piece of text while retaining metadata.  Metadata is data
- * other than the Unicode characters returned by char32At().  One
- * example of metadata is style attributes; another is an edit
- * history, marking each character with an author and revision number.
- *
- * <p>An implicit aspect of the <code>Replaceable</code> API is that
- * during a replace operation, new characters take on the metadata of
- * the old characters.  For example, if the string "the <b>bold</b>
- * font" has range (4, 8) replaced with "strong", then it becomes "the
- * <b>strong</b> font".
- *
- * <p><code>Replaceable</code> specifies ranges using a start
- * offset and a limit offset.  The range of characters thus specified
- * includes the characters at offset start..limit-1.  That is, the
- * start offset is inclusive, and the limit offset is exclusive.
- *
- * <p><code>Replaceable</code> also includes API to access characters
- * in the string: <code>length()</code>, <code>charAt()</code>,
- * <code>char32At()</code>, and <code>extractBetween()</code>.
- *
- * <p>For a subclass to support metadata, typical behavior of
- * <code>replace()</code> is the following:
- * <ul>
- *   <li>Set the metadata of the new text to the metadata of the first
- *   character replaced</li>
- *   <li>If no characters are replaced, use the metadata of the
- *   previous character</li>
- *   <li>If there is no previous character (i.e. start == 0), use the
- *   following character</li>
- *   <li>If there is no following character (i.e. the replaceable was
- *   empty), use default metadata.<br>
- *   <li>If the code point U+FFFF is seen, it should be interpreted as
- *   a special marker having no metadata<li>
- *   </li>
- * </ul>
- * If this is not the behavior, the subclass should document any differences.
- * @author Alan Liu
- * @stable ICU 2.0
- */
-class U_COMMON_API Replaceable : public UObject {
-
-public:
-    /**
-     * Destructor.
-     * @stable ICU 2.0
-     */
-    virtual ~Replaceable();
-
-    /**
-     * Returns the number of 16-bit code units in the text.
-     * @return number of 16-bit code units in text
-     * @stable ICU 1.8
-     */ 
-    inline int32_t length() const;
-
-    /**
-     * Returns the 16-bit code unit at the given offset into the text.
-     * @param offset an integer between 0 and <code>length()</code>-1
-     * inclusive
-     * @return 16-bit code unit of text at given offset
-     * @stable ICU 1.8
-     */
-    inline UChar charAt(int32_t offset) const;
-
-    /**
-     * Returns the 32-bit code point at the given 16-bit offset into
-     * the text.  This assumes the text is stored as 16-bit code units
-     * with surrogate pairs intermixed.  If the offset of a leading or
-     * trailing code unit of a surrogate pair is given, return the
-     * code point of the surrogate pair.
-     *
-     * @param offset an integer between 0 and <code>length()</code>-1
-     * inclusive
-     * @return 32-bit code point of text at given offset
-     * @stable ICU 1.8
-     */
-    inline UChar32 char32At(int32_t offset) const;
-
-    /**
-     * Copies characters in the range [<tt>start</tt>, <tt>limit</tt>) 
-     * into the UnicodeString <tt>target</tt>.
-     * @param start offset of first character which will be copied
-     * @param limit offset immediately following the last character to
-     * be copied
-     * @param target UnicodeString into which to copy characters.
-     * @return A reference to <TT>target</TT>
-     * @stable ICU 2.1
-     */
-    virtual void extractBetween(int32_t start,
-                                int32_t limit,
-                                UnicodeString& target) const = 0;
-
-    /**
-     * Replaces a substring of this object with the given text.  If the
-     * characters being replaced have metadata, the new characters
-     * that replace them should be given the same metadata.
-     *
-     * <p>Subclasses must ensure that if the text between start and
-     * limit is equal to the replacement text, that replace has no
-     * effect. That is, any metadata
-     * should be unaffected. In addition, subclasses are encouraged to
-     * check for initial and trailing identical characters, and make a
-     * smaller replacement if possible. This will preserve as much
-     * metadata as possible.
-     * @param start the beginning index, inclusive; <code>0 <= start
-     * <= limit</code>.
-     * @param limit the ending index, exclusive; <code>start <= limit
-     * <= length()</code>.
-     * @param text the text to replace characters <code>start</code>
-     * to <code>limit - 1</code> 
-     * @stable ICU 2.0
-     */
-    virtual void handleReplaceBetween(int32_t start,
-                                      int32_t limit,
-                                      const UnicodeString& text) = 0;
-    // Note: All other methods in this class take the names of
-    // existing UnicodeString methods.  This method is the exception.
-    // It is named differently because all replace methods of
-    // UnicodeString return a UnicodeString&.  The 'between' is
-    // required in order to conform to the UnicodeString naming
-    // convention; API taking start/length are named <operation>, and
-    // those taking start/limit are named <operationBetween>.  The
-    // 'handle' is added because 'replaceBetween' and
-    // 'doReplaceBetween' are already taken.
-
-    /**
-     * Copies a substring of this object, retaining metadata.
-     * This method is used to duplicate or reorder substrings.
-     * The destination index must not overlap the source range.
-     * 
-     * @param start the beginning index, inclusive; <code>0 <= start <=
-     * limit</code>.
-     * @param limit the ending index, exclusive; <code>start <= limit <=
-     * length()</code>.
-     * @param dest the destination index.  The characters from
-     * <code>start..limit-1</code> will be copied to <code>dest</code>.
-     * Implementations of this method may assume that <code>dest <= start ||
-     * dest >= limit</code>.
-     * @stable ICU 2.0
-     */
-    virtual void copy(int32_t start, int32_t limit, int32_t dest) = 0;
-
-    /**
-     * Returns true if this object contains metadata.  If a
-     * Replaceable object has metadata, calls to the Replaceable API
-     * must be made so as to preserve metadata.  If it does not, calls
-     * to the Replaceable API may be optimized to improve performance.
-     * The default implementation returns true.
-     * @return true if this object contains metadata
-     * @stable ICU 2.2
-     */
-    virtual UBool hasMetaData() const;
-
-    /**
-     * Clone this object, an instance of a subclass of Replaceable.
-     * Clones can be used concurrently in multiple threads.
-     * If a subclass does not implement clone(), or if an error occurs,
-     * then NULL is returned.
-     * The clone functions in all subclasses return a pointer to a Replaceable
-     * because some compilers do not support covariant (same-as-this)
-     * return types; cast to the appropriate subclass if necessary.
-     * The caller must delete the clone.
-     *
-     * @return a clone of this object
-     *
-     * @see getDynamicClassID
-     * @stable ICU 2.6
-     */
-    virtual Replaceable *clone() const;
-
-protected:
-
-    /**
-     * Default constructor.
-     * @stable ICU 2.4
-     */
-    Replaceable();
-
-    /*
-     * Assignment operator not declared. The compiler will provide one
-     * which does nothing since this class does not contain any data members.
-     * API/code coverage may show the assignment operator as present and
-     * untested - ignore.
-     * Subclasses need this assignment operator if they use compiler-provided
-     * assignment operators of their own. An alternative to not declaring one
-     * here would be to declare and empty-implement a protected or public one.
-    Replaceable &Replaceable::operator=(const Replaceable &);
-     */
-
-    /**
-     * Virtual version of length().
-     * @stable ICU 2.4
-     */ 
-    virtual int32_t getLength() const = 0;
-
-    /**
-     * Virtual version of charAt().
-     * @stable ICU 2.4
-     */
-    virtual UChar getCharAt(int32_t offset) const = 0;
-
-    /**
-     * Virtual version of char32At().
-     * @stable ICU 2.4
-     */
-    virtual UChar32 getChar32At(int32_t offset) const = 0;
-};
-
-inline int32_t
-Replaceable::length() const {
-    return getLength();
-}
-
-inline UChar
-Replaceable::charAt(int32_t offset) const {
-    return getCharAt(offset);
-}
-
-inline UChar32
-Replaceable::char32At(int32_t offset) const {
-    return getChar32At(offset);
-}
-
-// There is no rep.cpp, see unistr.cpp for Replaceable function implementations.
-
-U_NAMESPACE_END
-
-#endif

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/resbund.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/resbund.h b/apps/couch_collate/platform/osx/icu/unicode/resbund.h
deleted file mode 100644
index 6d6b991..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/resbund.h
+++ /dev/null
@@ -1,485 +0,0 @@
-/*
-******************************************************************************
-*
-*   Copyright (C) 1996-2007, International Business Machines Corporation
-*   and others.  All Rights Reserved.
-*
-******************************************************************************
-*
-* File resbund.h
-*
-*   CREATED BY
-*       Richard Gillam
-*
-* Modification History:
-*
-*   Date        Name        Description
-*   2/5/97      aliu        Added scanForLocaleInFile.  Added
-*                           constructor which attempts to read resource bundle
-*                           from a specific file, without searching other files.
-*   2/11/97     aliu        Added UErrorCode return values to constructors.  Fixed
-*                           infinite loops in scanForFile and scanForLocale.
-*                           Modified getRawResourceData to not delete storage
-*                           in localeData and resourceData which it doesn't own.
-*                           Added Mac compatibility #ifdefs for tellp() and
-*                           ios::nocreate.
-*   2/18/97     helena      Updated with 100% documentation coverage.
-*   3/13/97     aliu        Rewrote to load in entire resource bundle and store
-*                           it as a Hashtable of ResourceBundleData objects.
-*                           Added state table to govern parsing of files.
-*                           Modified to load locale index out of new file
-*                           distinct from default.txt.
-*   3/25/97     aliu        Modified to support 2-d arrays, needed for timezone
-*                           data. Added support for custom file suffixes.  Again,
-*                           needed to support timezone data.
-*   4/7/97      aliu        Cleaned up.
-* 03/02/99      stephen     Removed dependency on FILE*.
-* 03/29/99      helena      Merged Bertrand and Stephen's changes.
-* 06/11/99      stephen     Removed parsing of .txt files.
-*                           Reworked to use new binary format.
-*                           Cleaned up.
-* 06/14/99      stephen     Removed methods taking a filename suffix.
-* 11/09/99      weiv        Added getLocale(), fRealLocale, removed fRealLocaleID
-******************************************************************************
-*/
-
-#ifndef RESBUND_H
-#define RESBUND_H
-
-#include "unicode/utypes.h"
-#include "unicode/uobject.h"
-#include "unicode/ures.h"
-#include "unicode/unistr.h"
-#include "unicode/locid.h"
-
-/**
- * \file 
- * \brief C++ API: Resource Bundle
- */
- 
-U_NAMESPACE_BEGIN
-
-/**
- * A class representing a collection of resource information pertaining to a given
- * locale. A resource bundle provides a way of accessing locale- specfic information in
- * a data file. You create a resource bundle that manages the resources for a given
- * locale and then ask it for individual resources.
- * <P>
- * Resource bundles in ICU4C are currently defined using text files which conform to the following
- * <a href="http://source.icu-project.org/repos/icu/icuhtml/trunk/design/bnf_rb.txt">BNF definition</a>.
- * More on resource bundle concepts and syntax can be found in the
- * <a href="http://icu-project.org/userguide/ResourceManagement.html">Users Guide</a>.
- * <P>
- *
- * The ResourceBundle class is not suitable for subclassing.
- *
- * @stable ICU 2.0
- */
-class U_COMMON_API ResourceBundle : public UObject {
-public:
-    /**
-     * Constructor
-     *
-     * @param packageName   The packageName and locale together point to an ICU udata object, 
-     *                      as defined by <code> udata_open( packageName, "res", locale, err) </code> 
-     *                      or equivalent.  Typically, packageName will refer to a (.dat) file, or to
-     *                      a package registered with udata_setAppData(). Using a full file or directory
-     *                      pathname for packageName is deprecated.
-     * @param locale  This is the locale this resource bundle is for. To get resources
-     *                for the French locale, for example, you would create a
-     *                ResourceBundle passing Locale::FRENCH for the "locale" parameter,
-     *                and all subsequent calls to that resource bundle will return
-     *                resources that pertain to the French locale. If the caller doesn't
-     *                pass a locale parameter, the default locale for the system (as
-     *                returned by Locale::getDefault()) will be used.
-     * @param err     The Error Code.
-     * The UErrorCode& err parameter is used to return status information to the user. To
-     * check whether the construction succeeded or not, you should check the value of
-     * U_SUCCESS(err). If you wish more detailed information, you can check for
-     * informational error results which still indicate success. U_USING_FALLBACK_WARNING
-     * indicates that a fall back locale was used. For example, 'de_CH' was requested,
-     * but nothing was found there, so 'de' was used. U_USING_DEFAULT_WARNING indicates that
-     * the default locale data was used; neither the requested locale nor any of its
-     * fall back locales could be found.
-     * @stable ICU 2.0
-     */
-    ResourceBundle(const UnicodeString&    packageName,
-                   const Locale&           locale,
-                   UErrorCode&              err);
-
-    /**
-     * Construct a resource bundle for the default bundle in the specified package.
-     *
-     * @param packageName   The packageName and locale together point to an ICU udata object, 
-     *                      as defined by <code> udata_open( packageName, "res", locale, err) </code> 
-     *                      or equivalent.  Typically, packageName will refer to a (.dat) file, or to
-     *                      a package registered with udata_setAppData(). Using a full file or directory
-     *                      pathname for packageName is deprecated.
-     * @param err A UErrorCode value
-     * @stable ICU 2.0
-     */
-    ResourceBundle(const UnicodeString&    packageName,
-                   UErrorCode&              err);
-
-    /**
-     * Construct a resource bundle for the ICU default bundle.
-     *
-     * @param err A UErrorCode value
-     * @stable ICU 2.0
-     */
-    ResourceBundle(UErrorCode &err);
-
-    /**
-     * Standard constructor, onstructs a resource bundle for the locale-specific
-     * bundle in the specified package.
-     *
-     * @param packageName   The packageName and locale together point to an ICU udata object, 
-     *                      as defined by <code> udata_open( packageName, "res", locale, err) </code> 
-     *                      or equivalent.  Typically, packageName will refer to a (.dat) file, or to
-     *                      a package registered with udata_setAppData(). Using a full file or directory
-     *                      pathname for packageName is deprecated.
-     *                      NULL is used to refer to ICU data.
-     * @param locale The locale for which to open a resource bundle.
-     * @param err A UErrorCode value
-     * @stable ICU 2.0
-     */
-    ResourceBundle(const char* packageName,
-                   const Locale& locale,
-                   UErrorCode& err);
-
-    /**
-     * Copy constructor.
-     *
-     * @param original The resource bundle to copy.
-     * @stable ICU 2.0
-     */
-    ResourceBundle(const ResourceBundle &original);
-
-    /**
-     * Constructor from a C UResourceBundle. The resource bundle is
-     * copied and not adopted. ures_close will still need to be used on the
-     * original resource bundle.
-     *
-     * @param res A pointer to the C resource bundle.
-     * @param status A UErrorCode value.
-     * @stable ICU 2.0
-     */
-    ResourceBundle(UResourceBundle *res,
-                   UErrorCode &status);
-
-    /**
-     * Assignment operator.
-     *
-     * @param other The resource bundle to copy.
-     * @stable ICU 2.0
-     */
-    ResourceBundle&
-      operator=(const ResourceBundle& other);
-
-    /** Destructor.
-     * @stable ICU 2.0
-     */
-    virtual ~ResourceBundle();
-
-    /**
-     * Clone this object.
-     * Clones can be used concurrently in multiple threads.
-     * If an error occurs, then NULL is returned.
-     * The caller must delete the clone.
-     *
-     * @return a clone of this object
-     *
-     * @see getDynamicClassID
-     * @stable ICU 2.8
-     */
-    ResourceBundle *clone() const;
-
-    /**
-     * Returns the size of a resource. Size for scalar types is always 1, and for vector/table types is
-     * the number of child resources.
-     * @warning Integer array is treated as a scalar type. There are no
-     *          APIs to access individual members of an integer array. It
-     *          is always returned as a whole.
-     *
-     * @return number of resources in a given resource.
-     * @stable ICU 2.0
-     */
-    int32_t
-      getSize(void) const;
-
-    /**
-     * returns a string from a string resource type
-     *
-     * @param status  fills in the outgoing error code
-     *                could be <TT>U_MISSING_RESOURCE_ERROR</TT> if the key is not found
-     *                could be a warning
-     *                e.g.: <TT>U_USING_FALLBACK_WARNING</TT>,<TT>U_USING_DEFAULT_WARNING </TT>
-     * @return a pointer to a zero-terminated UChar array which lives in a memory mapped/DLL file.
-     * @stable ICU 2.0
-     */
-    UnicodeString
-      getString(UErrorCode& status) const;
-
-    /**
-     * returns a binary data from a resource. Can be used at most primitive resource types (binaries,
-     * strings, ints)
-     *
-     * @param len     fills in the length of resulting byte chunk
-     * @param status  fills in the outgoing error code
-     *                could be <TT>U_MISSING_RESOURCE_ERROR</TT> if the key is not found
-     *                could be a warning
-     *                e.g.: <TT>U_USING_FALLBACK_WARNING</TT>,<TT>U_USING_DEFAULT_WARNING </TT>
-     * @return a pointer to a chunk of unsigned bytes which live in a memory mapped/DLL file.
-     * @stable ICU 2.0
-     */
-    const uint8_t*
-      getBinary(int32_t& len, UErrorCode& status) const;
-
-
-    /**
-     * returns an integer vector from a resource.
-     *
-     * @param len     fills in the length of resulting integer vector
-     * @param status  fills in the outgoing error code
-     *                could be <TT>U_MISSING_RESOURCE_ERROR</TT> if the key is not found
-     *                could be a warning
-     *                e.g.: <TT>U_USING_FALLBACK_WARNING</TT>,<TT>U_USING_DEFAULT_WARNING </TT>
-     * @return a pointer to a vector of integers that lives in a memory mapped/DLL file.
-     * @stable ICU 2.0
-     */
-    const int32_t*
-      getIntVector(int32_t& len, UErrorCode& status) const;
-
-    /**
-     * returns an unsigned integer from a resource.
-     * This integer is originally 28 bits.
-     *
-     * @param status  fills in the outgoing error code
-     *                could be <TT>U_MISSING_RESOURCE_ERROR</TT> if the key is not found
-     *                could be a warning
-     *                e.g.: <TT>U_USING_FALLBACK_WARNING</TT>,<TT>U_USING_DEFAULT_WARNING </TT>
-     * @return an unsigned integer value
-     * @stable ICU 2.0
-     */
-    uint32_t
-      getUInt(UErrorCode& status) const;
-
-    /**
-     * returns a signed integer from a resource.
-     * This integer is originally 28 bit and the sign gets propagated.
-     *
-     * @param status  fills in the outgoing error code
-     *                could be <TT>U_MISSING_RESOURCE_ERROR</TT> if the key is not found
-     *                could be a warning
-     *                e.g.: <TT>U_USING_FALLBACK_WARNING</TT>,<TT>U_USING_DEFAULT_WARNING </TT>
-     * @return a signed integer value
-     * @stable ICU 2.0
-     */
-    int32_t
-      getInt(UErrorCode& status) const;
-
-    /**
-     * Checks whether the resource has another element to iterate over.
-     *
-     * @return TRUE if there are more elements, FALSE if there is no more elements
-     * @stable ICU 2.0
-     */
-    UBool
-      hasNext(void) const;
-
-    /**
-     * Resets the internal context of a resource so that iteration starts from the first element.
-     *
-     * @stable ICU 2.0
-     */
-    void
-      resetIterator(void);
-
-    /**
-     * Returns the key associated with this resource. Not all the resources have a key - only
-     * those that are members of a table.
-     *
-     * @return a key associated to this resource, or NULL if it doesn't have a key
-     * @stable ICU 2.0
-     */
-    const char*
-      getKey(void) const;
-
-    /**
-     * Gets the locale ID of the resource bundle as a string.
-     * Same as getLocale().getName() .
-     *
-     * @return the locale ID of the resource bundle as a string
-     * @stable ICU 2.0
-     */
-    const char*
-      getName(void) const;
-
-
-    /**
-     * Returns the type of a resource. Available types are defined in enum UResType
-     *
-     * @return type of the given resource.
-     * @stable ICU 2.0
-     */
-    UResType
-      getType(void) const;
-
-    /**
-     * Returns the next resource in a given resource or NULL if there are no more resources
-     *
-     * @param status            fills in the outgoing error code
-     * @return                  ResourceBundle object.
-     * @stable ICU 2.0
-     */
-    ResourceBundle
-      getNext(UErrorCode& status);
-
-    /**
-     * Returns the next string in a resource or NULL if there are no more resources
-     * to iterate over.
-     *
-     * @param status            fills in the outgoing error code
-     * @return an UnicodeString object.
-     * @stable ICU 2.0
-     */
-    UnicodeString
-      getNextString(UErrorCode& status);
-
-    /**
-     * Returns the next string in a resource or NULL if there are no more resources
-     * to iterate over.
-     *
-     * @param key               fill in for key associated with this string
-     * @param status            fills in the outgoing error code
-     * @return an UnicodeString object.
-     * @stable ICU 2.0
-     */
-    UnicodeString
-      getNextString(const char ** key,
-                    UErrorCode& status);
-
-    /**
-     * Returns the resource in a resource at the specified index.
-     *
-     * @param index             an index to the wanted resource.
-     * @param status            fills in the outgoing error code
-     * @return                  ResourceBundle object. If there is an error, resource is invalid.
-     * @stable ICU 2.0
-     */
-    ResourceBundle
-      get(int32_t index,
-          UErrorCode& status) const;
-
-    /**
-     * Returns the string in a given resource at the specified index.
-     *
-     * @param index             an index to the wanted string.
-     * @param status            fills in the outgoing error code
-     * @return                  an UnicodeString object. If there is an error, string is bogus
-     * @stable ICU 2.0
-     */
-    UnicodeString
-      getStringEx(int32_t index,
-                  UErrorCode& status) const;
-
-    /**
-     * Returns a resource in a resource that has a given key. This procedure works only with table
-     * resources.
-     *
-     * @param key               a key associated with the wanted resource
-     * @param status            fills in the outgoing error code.
-     * @return                  ResourceBundle object. If there is an error, resource is invalid.
-     * @stable ICU 2.0
-     */
-    ResourceBundle
-      get(const char* key,
-          UErrorCode& status) const;
-
-    /**
-     * Returns a string in a resource that has a given key. This procedure works only with table
-     * resources.
-     *
-     * @param key               a key associated with the wanted string
-     * @param status            fills in the outgoing error code
-     * @return                  an UnicodeString object. If there is an error, string is bogus
-     * @stable ICU 2.0
-     */
-    UnicodeString
-      getStringEx(const char* key,
-                  UErrorCode& status) const;
-
-    /**
-     * Return the version number associated with this ResourceBundle as a string. Please
-     * use getVersion, as this method is going to be deprecated.
-     *
-     * @return  A version number string as specified in the resource bundle or its parent.
-     *          The caller does not own this string.
-     * @see getVersion
-     * @deprecated ICU 2.8 Use getVersion instead.
-     */
-    const char*
-      getVersionNumber(void) const;
-
-    /**
-     * Return the version number associated with this ResourceBundle as a UVersionInfo array.
-     *
-     * @param versionInfo A UVersionInfo array that is filled with the version number
-     *                    as specified in the resource bundle or its parent.
-     * @stable ICU 2.0
-     */
-    void
-      getVersion(UVersionInfo versionInfo) const;
-
-    /**
-     * Return the Locale associated with this ResourceBundle.
-     *
-     * @return a Locale object
-     * @deprecated ICU 2.8 Use getLocale(ULocDataLocaleType type, UErrorCode &status) overload instead.
-     */
-    const Locale&
-      getLocale(void) const;
-
-    /**
-     * Return the Locale associated with this ResourceBundle.
-     * @param type You can choose between requested, valid and actual
-     *             locale. For description see the definition of
-     *             ULocDataLocaleType in uloc.h
-     * @param status just for catching illegal arguments
-     *
-     * @return a Locale object
-     * @stable ICU 2.8
-     */
-    const Locale
-      getLocale(ULocDataLocaleType type, UErrorCode &status) const;
-    /**
-     * This API implements multilevel fallback
-     * @internal
-     */
-    ResourceBundle
-        getWithFallback(const char* key, UErrorCode& status);
-    /**
-     * ICU "poor man's RTTI", returns a UClassID for the actual class.
-     *
-     * @stable ICU 2.2
-     */
-    virtual UClassID getDynamicClassID() const;
-
-    /**
-     * ICU "poor man's RTTI", returns a UClassID for this class.
-     *
-     * @stable ICU 2.2
-     */
-    static UClassID U_EXPORT2 getStaticClassID();
-
-private:
-    ResourceBundle(); // default constructor not implemented
-
-    UResourceBundle *fResource;
-    void constructForLocale(const UnicodeString& path, const Locale& locale, UErrorCode& error);
-    Locale *fLocale;
-
-};
-
-U_NAMESPACE_END
-#endif


[40/57] [abbrv] remove couch_collate

Posted by be...@apache.org.
http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/caniter.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/caniter.h b/apps/couch_collate/platform/osx/icu/unicode/caniter.h
deleted file mode 100644
index 84a6595..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/caniter.h
+++ /dev/null
@@ -1,201 +0,0 @@
-/*
- *******************************************************************************
- * Copyright (C) 1996-2006, International Business Machines Corporation and    *
- * others. All Rights Reserved.                                                *
- *******************************************************************************
- */
-
-#ifndef CANITER_H
-#define CANITER_H
-
-#include "unicode/utypes.h"
-
-#if !UCONFIG_NO_NORMALIZATION
-
-#include "unicode/uobject.h"
-#include "unicode/unistr.h"
-
-/**
- * \file
- * \brief C++ API: Canonical Iterator
- */
- 
-/** Should permutation skip characters with combining class zero
- *  Should be either TRUE or FALSE. This is a compile time option
- *  @stable ICU 2.4
- */
-#ifndef CANITER_SKIP_ZEROES
-#define CANITER_SKIP_ZEROES TRUE
-#endif
-
-U_NAMESPACE_BEGIN
-
-class Hashtable;
-
-/**
- * This class allows one to iterate through all the strings that are canonically equivalent to a given
- * string. For example, here are some sample results:
-Results for: {LATIN CAPITAL LETTER A WITH RING ABOVE}{LATIN SMALL LETTER D}{COMBINING DOT ABOVE}{COMBINING CEDILLA}
-1: \\u0041\\u030A\\u0064\\u0307\\u0327
- = {LATIN CAPITAL LETTER A}{COMBINING RING ABOVE}{LATIN SMALL LETTER D}{COMBINING DOT ABOVE}{COMBINING CEDILLA}
-2: \\u0041\\u030A\\u0064\\u0327\\u0307
- = {LATIN CAPITAL LETTER A}{COMBINING RING ABOVE}{LATIN SMALL LETTER D}{COMBINING CEDILLA}{COMBINING DOT ABOVE}
-3: \\u0041\\u030A\\u1E0B\\u0327
- = {LATIN CAPITAL LETTER A}{COMBINING RING ABOVE}{LATIN SMALL LETTER D WITH DOT ABOVE}{COMBINING CEDILLA}
-4: \\u0041\\u030A\\u1E11\\u0307
- = {LATIN CAPITAL LETTER A}{COMBINING RING ABOVE}{LATIN SMALL LETTER D WITH CEDILLA}{COMBINING DOT ABOVE}
-5: \\u00C5\\u0064\\u0307\\u0327
- = {LATIN CAPITAL LETTER A WITH RING ABOVE}{LATIN SMALL LETTER D}{COMBINING DOT ABOVE}{COMBINING CEDILLA}
-6: \\u00C5\\u0064\\u0327\\u0307
- = {LATIN CAPITAL LETTER A WITH RING ABOVE}{LATIN SMALL LETTER D}{COMBINING CEDILLA}{COMBINING DOT ABOVE}
-7: \\u00C5\\u1E0B\\u0327
- = {LATIN CAPITAL LETTER A WITH RING ABOVE}{LATIN SMALL LETTER D WITH DOT ABOVE}{COMBINING CEDILLA}
-8: \\u00C5\\u1E11\\u0307
- = {LATIN CAPITAL LETTER A WITH RING ABOVE}{LATIN SMALL LETTER D WITH CEDILLA}{COMBINING DOT ABOVE}
-9: \\u212B\\u0064\\u0307\\u0327
- = {ANGSTROM SIGN}{LATIN SMALL LETTER D}{COMBINING DOT ABOVE}{COMBINING CEDILLA}
-10: \\u212B\\u0064\\u0327\\u0307
- = {ANGSTROM SIGN}{LATIN SMALL LETTER D}{COMBINING CEDILLA}{COMBINING DOT ABOVE}
-11: \\u212B\\u1E0B\\u0327
- = {ANGSTROM SIGN}{LATIN SMALL LETTER D WITH DOT ABOVE}{COMBINING CEDILLA}
-12: \\u212B\\u1E11\\u0307
- = {ANGSTROM SIGN}{LATIN SMALL LETTER D WITH CEDILLA}{COMBINING DOT ABOVE}
- *<br>Note: the code is intended for use with small strings, and is not suitable for larger ones,
- * since it has not been optimized for that situation.
- * Note, CanonicalIterator is not intended to be subclassed.
- * @author M. Davis
- * @author C++ port by V. Weinstein
- * @stable ICU 2.4
- */
-class U_COMMON_API CanonicalIterator : public UObject {
-public:
-    /**
-     * Construct a CanonicalIterator object
-     * @param source    string to get results for
-     * @param status    Fill-in parameter which receives the status of this operation.
-     * @stable ICU 2.4
-     */
-    CanonicalIterator(const UnicodeString &source, UErrorCode &status);
-
-    /** Destructor
-     *  Cleans pieces
-     * @stable ICU 2.4
-     */
-    virtual ~CanonicalIterator();
-
-    /**
-     * Gets the NFD form of the current source we are iterating over.
-     * @return gets the source: NOTE: it is the NFD form of source
-     * @stable ICU 2.4
-     */
-    UnicodeString getSource();
-
-    /**
-     * Resets the iterator so that one can start again from the beginning.
-     * @stable ICU 2.4
-     */
-    void reset();
-
-    /**
-     * Get the next canonically equivalent string.
-     * <br><b>Warning: The strings are not guaranteed to be in any particular order.</b>
-     * @return the next string that is canonically equivalent. A bogus string is returned when
-     * the iteration is done.
-     * @stable ICU 2.4
-     */
-    UnicodeString next();
-
-    /**
-     * Set a new source for this iterator. Allows object reuse.
-     * @param newSource     the source string to iterate against. This allows the same iterator to be used
-     *                     while changing the source string, saving object creation.
-     * @param status        Fill-in parameter which receives the status of this operation.
-     * @stable ICU 2.4
-     */
-    void setSource(const UnicodeString &newSource, UErrorCode &status);
-
-    /**
-     * Dumb recursive implementation of permutation.
-     * TODO: optimize
-     * @param source     the string to find permutations for
-     * @param skipZeros  determine if skip zeros
-     * @param result     the results in a set.
-     * @param status       Fill-in parameter which receives the status of this operation.
-     * @internal
-     */
-    static void U_EXPORT2 permute(UnicodeString &source, UBool skipZeros, Hashtable *result, UErrorCode &status);
-
-    /**
-     * ICU "poor man's RTTI", returns a UClassID for this class.
-     *
-     * @stable ICU 2.2
-     */
-    static UClassID U_EXPORT2 getStaticClassID();
-
-    /**
-     * ICU "poor man's RTTI", returns a UClassID for the actual class.
-     *
-     * @stable ICU 2.2
-     */
-    virtual UClassID getDynamicClassID() const;
-
-private:
-    // ===================== PRIVATES ==============================
-    // private default constructor
-    CanonicalIterator();
-
-
-    /**
-     * Copy constructor. Private for now.
-     * @internal
-     */
-    CanonicalIterator(const CanonicalIterator& other);
-
-    /**
-     * Assignment operator. Private for now.
-     * @internal
-     */
-    CanonicalIterator& operator=(const CanonicalIterator& other);
-
-    // fields
-    UnicodeString source;
-    UBool done;
-
-    // 2 dimensional array holds the pieces of the string with
-    // their different canonically equivalent representations
-    UnicodeString **pieces;
-    int32_t pieces_length;
-    int32_t *pieces_lengths;
-
-    // current is used in iterating to combine pieces
-    int32_t *current;
-    int32_t current_length;
-
-    // transient fields
-    UnicodeString buffer;
-
-    // we have a segment, in NFD. Find all the strings that are canonically equivalent to it.
-    UnicodeString *getEquivalents(const UnicodeString &segment, int32_t &result_len, UErrorCode &status); //private String[] getEquivalents(String segment)
-
-    //Set getEquivalents2(String segment);
-    Hashtable *getEquivalents2(Hashtable *fillinResult, const UChar *segment, int32_t segLen, UErrorCode &status);
-    //Hashtable *getEquivalents2(const UnicodeString &segment, int32_t segLen, UErrorCode &status);
-
-    /**
-     * See if the decomposition of cp2 is at segment starting at segmentPos
-     * (with canonical rearrangment!)
-     * If so, take the remainder, and return the equivalents
-     */
-    //Set extract(int comp, String segment, int segmentPos, StringBuffer buffer);
-    Hashtable *extract(Hashtable *fillinResult, UChar32 comp, const UChar *segment, int32_t segLen, int32_t segmentPos, UErrorCode &status);
-    //Hashtable *extract(UChar32 comp, const UnicodeString &segment, int32_t segLen, int32_t segmentPos, UErrorCode &status);
-
-    void cleanPieces();
-
-};
-
-U_NAMESPACE_END
-
-#endif /* #if !UCONFIG_NO_NORMALIZATION */
-
-#endif

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/chariter.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/chariter.h b/apps/couch_collate/platform/osx/icu/unicode/chariter.h
deleted file mode 100644
index 12fc924..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/chariter.h
+++ /dev/null
@@ -1,716 +0,0 @@
-/*
-********************************************************************
-*
-*   Copyright (C) 1997-2005, International Business Machines
-*   Corporation and others.  All Rights Reserved.
-*
-********************************************************************
-*/
-
-#ifndef CHARITER_H
-#define CHARITER_H
-
-#include "unicode/utypes.h"
-#include "unicode/uobject.h"
-#include "unicode/unistr.h"
-/**
- * \file
- * \brief C++ API: Character Iterator
- */
- 
-U_NAMESPACE_BEGIN
-/**
- * Abstract class that defines an API for forward-only iteration
- * on text objects.
- * This is a minimal interface for iteration without random access
- * or backwards iteration. It is especially useful for wrapping
- * streams with converters into an object for collation or
- * normalization.
- *
- * <p>Characters can be accessed in two ways: as code units or as
- * code points.
- * Unicode code points are 21-bit integers and are the scalar values
- * of Unicode characters. ICU uses the type UChar32 for them.
- * Unicode code units are the storage units of a given
- * Unicode/UCS Transformation Format (a character encoding scheme).
- * With UTF-16, all code points can be represented with either one
- * or two code units ("surrogates").
- * String storage is typically based on code units, while properties
- * of characters are typically determined using code point values.
- * Some processes may be designed to work with sequences of code units,
- * or it may be known that all characters that are important to an
- * algorithm can be represented with single code units.
- * Other processes will need to use the code point access functions.</p>
- *
- * <p>ForwardCharacterIterator provides nextPostInc() to access
- * a code unit and advance an internal position into the text object,
- * similar to a <code>return text[position++]</code>.<br>
- * It provides next32PostInc() to access a code point and advance an internal
- * position.</p>
- *
- * <p>next32PostInc() assumes that the current position is that of
- * the beginning of a code point, i.e., of its first code unit.
- * After next32PostInc(), this will be true again.
- * In general, access to code units and code points in the same
- * iteration loop should not be mixed. In UTF-16, if the current position
- * is on a second code unit (Low Surrogate), then only that code unit
- * is returned even by next32PostInc().</p>
- *
- * <p>For iteration with either function, there are two ways to
- * check for the end of the iteration. When there are no more
- * characters in the text object:
- * <ul>
- * <li>The hasNext() function returns FALSE.</li>
- * <li>nextPostInc() and next32PostInc() return DONE
- *     when one attempts to read beyond the end of the text object.</li>
- * </ul>
- *
- * Example:
- * \code 
- * void function1(ForwardCharacterIterator &it) {
- *     UChar32 c;
- *     while(it.hasNext()) {
- *         c=it.next32PostInc();
- *         // use c
- *     }
- * }
- *
- * void function1(ForwardCharacterIterator &it) {
- *     UChar c;
- *     while((c=it.nextPostInc())!=ForwardCharacterIterator::DONE) {
- *         // use c
- *      }
- *  }
- * \endcode
- * </p>
- *
- * @stable ICU 2.0
- */
-class U_COMMON_API ForwardCharacterIterator : public UObject {
-public:
-    /**
-     * Value returned by most of ForwardCharacterIterator's functions
-     * when the iterator has reached the limits of its iteration.
-     * @stable ICU 2.0
-     */
-    enum { DONE = 0xffff };
-    
-    /**
-     * Destructor.  
-     * @stable ICU 2.0
-     */
-    virtual ~ForwardCharacterIterator();
-    
-    /**
-     * Returns true when both iterators refer to the same
-     * character in the same character-storage object.  
-     * @param that The ForwardCharacterIterator to be compared for equality
-     * @return true when both iterators refer to the same
-     * character in the same character-storage object
-     * @stable ICU 2.0
-     */
-    virtual UBool operator==(const ForwardCharacterIterator& that) const = 0;
-    
-    /**
-     * Returns true when the iterators refer to different
-     * text-storage objects, or to different characters in the
-     * same text-storage object.  
-     * @param that The ForwardCharacterIterator to be compared for inequality
-     * @return true when the iterators refer to different
-     * text-storage objects, or to different characters in the
-     * same text-storage object
-     * @stable ICU 2.0
-     */
-    inline UBool operator!=(const ForwardCharacterIterator& that) const;
-    
-    /**
-     * Generates a hash code for this iterator.  
-     * @return the hash code.
-     * @stable ICU 2.0
-     */
-    virtual int32_t hashCode(void) const = 0;
-    
-    /**
-     * Returns a UClassID for this ForwardCharacterIterator ("poor man's
-     * RTTI").<P> Despite the fact that this function is public,
-     * DO NOT CONSIDER IT PART OF CHARACTERITERATOR'S API! 
-     * @return a UClassID for this ForwardCharacterIterator 
-     * @stable ICU 2.0
-     */
-    virtual UClassID getDynamicClassID(void) const = 0;
-    
-    /**
-     * Gets the current code unit for returning and advances to the next code unit
-     * in the iteration range
-     * (toward endIndex()).  If there are
-     * no more code units to return, returns DONE.
-     * @return the current code unit.
-     * @stable ICU 2.0
-     */
-    virtual UChar         nextPostInc(void) = 0;
-    
-    /**
-     * Gets the current code point for returning and advances to the next code point
-     * in the iteration range
-     * (toward endIndex()).  If there are
-     * no more code points to return, returns DONE.
-     * @return the current code point.
-     * @stable ICU 2.0
-     */
-    virtual UChar32       next32PostInc(void) = 0;
-    
-    /**
-     * Returns FALSE if there are no more code units or code points
-     * at or after the current position in the iteration range.
-     * This is used with nextPostInc() or next32PostInc() in forward
-     * iteration.
-     * @returns FALSE if there are no more code units or code points
-     * at or after the current position in the iteration range.
-     * @stable ICU 2.0
-     */
-    virtual UBool        hasNext() = 0;
-    
-protected:
-    /** Default constructor to be overridden in the implementing class. @stable ICU 2.0*/
-    ForwardCharacterIterator();
-    
-    /** Copy constructor to be overridden in the implementing class. @stable ICU 2.0*/
-    ForwardCharacterIterator(const ForwardCharacterIterator &other);
-    
-    /**
-     * Assignment operator to be overridden in the implementing class.
-     * @stable ICU 2.0
-     */
-    ForwardCharacterIterator &operator=(const ForwardCharacterIterator&) { return *this; }
-};
-
-/**
- * Abstract class that defines an API for iteration
- * on text objects.
- * This is an interface for forward and backward iteration
- * and random access into a text object.
- *
- * <p>The API provides backward compatibility to the Java and older ICU
- * CharacterIterator classes but extends them significantly:
- * <ol>
- * <li>CharacterIterator is now a subclass of ForwardCharacterIterator.</li>
- * <li>While the old API functions provided forward iteration with
- *     "pre-increment" semantics, the new one also provides functions
- *     with "post-increment" semantics. They are more efficient and should
- *     be the preferred iterator functions for new implementations.
- *     The backward iteration always had "pre-decrement" semantics, which
- *     are efficient.</li>
- * <li>Just like ForwardCharacterIterator, it provides access to
- *     both code units and code points. Code point access versions are available
- *     for the old and the new iteration semantics.</li>
- * <li>There are new functions for setting and moving the current position
- *     without returning a character, for efficiency.</li>
- * </ol>
- *
- * See ForwardCharacterIterator for examples for using the new forward iteration
- * functions. For backward iteration, there is also a hasPrevious() function
- * that can be used analogously to hasNext().
- * The old functions work as before and are shown below.</p>
- *
- * <p>Examples for some of the new functions:</p>
- *
- * Forward iteration with hasNext():
- * \code
- * void forward1(CharacterIterator &it) {
- *     UChar32 c;
- *     for(it.setToStart(); it.hasNext();) {
- *         c=it.next32PostInc();
- *         // use c
- *     }
- *  }
- * \endcode
- * Forward iteration more similar to loops with the old forward iteration,
- * showing a way to convert simple for() loops:
- * \code
- * void forward2(CharacterIterator &it) {
- *     UChar c;
- *     for(c=it.firstPostInc(); c!=CharacterIterator::DONE; c=it.nextPostInc()) {
- *          // use c
- *      }
- * }
- * \endcode
- * Backward iteration with setToEnd() and hasPrevious():
- * \code
- *  void backward1(CharacterIterator &it) {
- *      UChar32 c;
- *      for(it.setToEnd(); it.hasPrevious();) {
- *         c=it.previous32();
- *          // use c
- *      }
- *  }
- * \endcode
- * Backward iteration with a more traditional for() loop:
- * \code
- * void backward2(CharacterIterator &it) {
- *     UChar c;
- *     for(c=it.last(); c!=CharacterIterator::DONE; c=it.previous()) {
- *         // use c
- *      }
- *  }
- * \endcode
- *
- * Example for random access:
- * \code
- *  void random(CharacterIterator &it) {
- *      // set to the third code point from the beginning
- *      it.move32(3, CharacterIterator::kStart);
- *      // get a code point from here without moving the position
- *      UChar32 c=it.current32();
- *      // get the position
- *      int32_t pos=it.getIndex();
- *      // get the previous code unit
- *      UChar u=it.previous();
- *      // move back one more code unit
- *      it.move(-1, CharacterIterator::kCurrent);
- *      // set the position back to where it was
- *      // and read the same code point c and move beyond it
- *      it.setIndex(pos);
- *      if(c!=it.next32PostInc()) {
- *          exit(1); // CharacterIterator inconsistent
- *      }
- *  }
- * \endcode
- *
- * <p>Examples, especially for the old API:</p>
- *
- * Function processing characters, in this example simple output
- * <pre>
- * \code
- *  void processChar( UChar c )
- *  {
- *      cout << " " << c;
- *  }
- * \endcode
- * </pre>
- * Traverse the text from start to finish
- * <pre> 
- * \code
- *  void traverseForward(CharacterIterator& iter)
- *  {
- *      for(UChar c = iter.first(); c != CharacterIterator.DONE; c = iter.next()) {
- *          processChar(c);
- *      }
- *  }
- * \endcode
- * </pre>
- * Traverse the text backwards, from end to start
- * <pre>
- * \code
- *  void traverseBackward(CharacterIterator& iter)
- *  {
- *      for(UChar c = iter.last(); c != CharacterIterator.DONE; c = iter.previous()) {
- *          processChar(c);
- *      }
- *  }
- * \endcode
- * </pre>
- * Traverse both forward and backward from a given position in the text. 
- * Calls to notBoundary() in this example represents some additional stopping criteria.
- * <pre>
- * \code
- * void traverseOut(CharacterIterator& iter, int32_t pos)
- * {
- *      UChar c;
- *      for (c = iter.setIndex(pos);
- *      c != CharacterIterator.DONE && (Unicode::isLetter(c) || Unicode::isDigit(c));
- *          c = iter.next()) {}
- *      int32_t end = iter.getIndex();
- *      for (c = iter.setIndex(pos);
- *          c != CharacterIterator.DONE && (Unicode::isLetter(c) || Unicode::isDigit(c));
- *          c = iter.previous()) {}
- *      int32_t start = iter.getIndex() + 1;
- *  
- *      cout << "start: " << start << " end: " << end << endl;
- *      for (c = iter.setIndex(start); iter.getIndex() < end; c = iter.next() ) {
- *          processChar(c);
- *     }
- *  }
- * \endcode
- * </pre>
- * Creating a StringCharacterIterator and calling the test functions
- * <pre>
- * \code
- *  void CharacterIterator_Example( void )
- *   {
- *       cout << endl << "===== CharacterIterator_Example: =====" << endl;
- *       UnicodeString text("Ein kleiner Satz.");
- *       StringCharacterIterator iterator(text);
- *       cout << "----- traverseForward: -----------" << endl;
- *       traverseForward( iterator );
- *       cout << endl << endl << "----- traverseBackward: ----------" << endl;
- *       traverseBackward( iterator );
- *       cout << endl << endl << "----- traverseOut: ---------------" << endl;
- *       traverseOut( iterator, 7 );
- *       cout << endl << endl << "-----" << endl;
- *   }
- * \endcode
- * </pre>
- *
- * @stable ICU 2.0
- */
-class U_COMMON_API CharacterIterator : public ForwardCharacterIterator {
-public:
-    /**
-     * Origin enumeration for the move() and move32() functions.
-     * @stable ICU 2.0
-     */
-    enum EOrigin { kStart, kCurrent, kEnd };
-
-    /**
-     * Returns a pointer to a new CharacterIterator of the same
-     * concrete class as this one, and referring to the same
-     * character in the same text-storage object as this one.  The
-     * caller is responsible for deleting the new clone.  
-     * @return a pointer to a new CharacterIterator
-     * @stable ICU 2.0
-     */
-    virtual CharacterIterator* clone(void) const = 0;
-
-    /**
-     * Sets the iterator to refer to the first code unit in its
-     * iteration range, and returns that code unit.
-     * This can be used to begin an iteration with next().
-     * @return the first code unit in its iteration range.
-     * @stable ICU 2.0
-     */
-    virtual UChar         first(void) = 0;
-
-    /**
-     * Sets the iterator to refer to the first code unit in its
-     * iteration range, returns that code unit, and moves the position
-     * to the second code unit. This is an alternative to setToStart()
-     * for forward iteration with nextPostInc().
-     * @return the first code unit in its iteration range.
-     * @stable ICU 2.0
-     */
-    virtual UChar         firstPostInc(void);
-
-    /**
-     * Sets the iterator to refer to the first code point in its
-     * iteration range, and returns that code unit,
-     * This can be used to begin an iteration with next32().
-     * Note that an iteration with next32PostInc(), beginning with,
-     * e.g., setToStart() or firstPostInc(), is more efficient.
-     * @return the first code point in its iteration range.
-     * @stable ICU 2.0
-     */
-    virtual UChar32       first32(void) = 0;
-
-    /**
-     * Sets the iterator to refer to the first code point in its
-     * iteration range, returns that code point, and moves the position
-     * to the second code point. This is an alternative to setToStart()
-     * for forward iteration with next32PostInc().
-     * @return the first code point in its iteration range.
-     * @stable ICU 2.0
-     */
-    virtual UChar32       first32PostInc(void);
-
-    /**
-     * Sets the iterator to refer to the first code unit or code point in its
-     * iteration range. This can be used to begin a forward
-     * iteration with nextPostInc() or next32PostInc().
-     * @return the start position of the iteration range
-     * @stable ICU 2.0
-     */
-    inline int32_t    setToStart();
-
-    /**
-     * Sets the iterator to refer to the last code unit in its
-     * iteration range, and returns that code unit.
-     * This can be used to begin an iteration with previous().
-     * @return the last code unit.
-     * @stable ICU 2.0
-     */
-    virtual UChar         last(void) = 0;
-        
-    /**
-     * Sets the iterator to refer to the last code point in its
-     * iteration range, and returns that code unit.
-     * This can be used to begin an iteration with previous32().
-     * @return the last code point.
-     * @stable ICU 2.0
-     */
-    virtual UChar32       last32(void) = 0;
-
-    /**
-     * Sets the iterator to the end of its iteration range, just behind
-     * the last code unit or code point. This can be used to begin a backward
-     * iteration with previous() or previous32().
-     * @return the end position of the iteration range
-     * @stable ICU 2.0
-     */
-    inline int32_t    setToEnd();
-
-    /**
-     * Sets the iterator to refer to the "position"-th code unit
-     * in the text-storage object the iterator refers to, and
-     * returns that code unit.  
-     * @param position the "position"-th code unit in the text-storage object
-     * @return the "position"-th code unit.
-     * @stable ICU 2.0
-     */
-    virtual UChar         setIndex(int32_t position) = 0;
-
-    /**
-     * Sets the iterator to refer to the beginning of the code point
-     * that contains the "position"-th code unit
-     * in the text-storage object the iterator refers to, and
-     * returns that code point.
-     * The current position is adjusted to the beginning of the code point
-     * (its first code unit).
-     * @param position the "position"-th code unit in the text-storage object
-     * @return the "position"-th code point.
-     * @stable ICU 2.0
-     */
-    virtual UChar32       setIndex32(int32_t position) = 0;
-
-    /**
-     * Returns the code unit the iterator currently refers to. 
-     * @return the current code unit. 
-     * @stable ICU 2.0
-     */
-    virtual UChar         current(void) const = 0;
-        
-    /**
-     * Returns the code point the iterator currently refers to.  
-     * @return the current code point.
-     * @stable ICU 2.0
-     */
-    virtual UChar32       current32(void) const = 0;
-        
-    /**
-     * Advances to the next code unit in the iteration range
-     * (toward endIndex()), and returns that code unit.  If there are
-     * no more code units to return, returns DONE.
-     * @return the next code unit.
-     * @stable ICU 2.0
-     */
-    virtual UChar         next(void) = 0;
-        
-    /**
-     * Advances to the next code point in the iteration range
-     * (toward endIndex()), and returns that code point.  If there are
-     * no more code points to return, returns DONE.
-     * Note that iteration with "pre-increment" semantics is less
-     * efficient than iteration with "post-increment" semantics
-     * that is provided by next32PostInc().
-     * @return the next code point.
-     * @stable ICU 2.0
-     */
-    virtual UChar32       next32(void) = 0;
-        
-    /**
-     * Advances to the previous code unit in the iteration range
-     * (toward startIndex()), and returns that code unit.  If there are
-     * no more code units to return, returns DONE.  
-     * @return the previous code unit.
-     * @stable ICU 2.0
-     */
-    virtual UChar         previous(void) = 0;
-
-    /**
-     * Advances to the previous code point in the iteration range
-     * (toward startIndex()), and returns that code point.  If there are
-     * no more code points to return, returns DONE. 
-     * @return the previous code point. 
-     * @stable ICU 2.0
-     */
-    virtual UChar32       previous32(void) = 0;
-
-    /**
-     * Returns FALSE if there are no more code units or code points
-     * before the current position in the iteration range.
-     * This is used with previous() or previous32() in backward
-     * iteration.
-     * @return FALSE if there are no more code units or code points
-     * before the current position in the iteration range, return TRUE otherwise.
-     * @stable ICU 2.0
-     */
-    virtual UBool        hasPrevious() = 0;
-
-    /**
-     * Returns the numeric index in the underlying text-storage
-     * object of the character returned by first().  Since it's
-     * possible to create an iterator that iterates across only
-     * part of a text-storage object, this number isn't
-     * necessarily 0.  
-     * @returns the numeric index in the underlying text-storage
-     * object of the character returned by first().
-     * @stable ICU 2.0
-     */
-    inline int32_t       startIndex(void) const;
-        
-    /**
-     * Returns the numeric index in the underlying text-storage
-     * object of the position immediately BEYOND the character
-     * returned by last().  
-     * @return the numeric index in the underlying text-storage
-     * object of the position immediately BEYOND the character
-     * returned by last().
-     * @stable ICU 2.0
-     */
-    inline int32_t       endIndex(void) const;
-        
-    /**
-     * Returns the numeric index in the underlying text-storage
-     * object of the character the iterator currently refers to
-     * (i.e., the character returned by current()).  
-     * @return the numberic index in the text-storage object of 
-     * the character the iterator currently refers to
-     * @stable ICU 2.0
-     */
-    inline int32_t       getIndex(void) const;
-
-    /**
-     * Returns the length of the entire text in the underlying
-     * text-storage object.
-     * @return the length of the entire text in the text-storage object
-     * @stable ICU 2.0
-     */
-    inline int32_t           getLength() const;
-
-    /**
-     * Moves the current position relative to the start or end of the
-     * iteration range, or relative to the current position itself.
-     * The movement is expressed in numbers of code units forward
-     * or backward by specifying a positive or negative delta.
-     * @param delta the position relative to origin. A positive delta means forward;
-     * a negative delta means backward.
-     * @param origin Origin enumeration {kStart, kCurrent, kEnd}
-     * @return the new position
-     * @stable ICU 2.0
-     */
-    virtual int32_t      move(int32_t delta, EOrigin origin) = 0;
-
-    /**
-     * Moves the current position relative to the start or end of the
-     * iteration range, or relative to the current position itself.
-     * The movement is expressed in numbers of code points forward
-     * or backward by specifying a positive or negative delta.
-     * @param delta the position relative to origin. A positive delta means forward;
-     * a negative delta means backward.
-     * @param origin Origin enumeration {kStart, kCurrent, kEnd}
-     * @return the new position
-     * @stable ICU 2.0
-     */
-    virtual int32_t      move32(int32_t delta, EOrigin origin) = 0;
-
-    /**
-     * Copies the text under iteration into the UnicodeString
-     * referred to by "result".  
-     * @param result Receives a copy of the text under iteration.  
-     * @stable ICU 2.0
-     */
-    virtual void            getText(UnicodeString&  result) = 0;
-
-protected:
-    /**
-     * Empty constructor.
-     * @stable ICU 2.0
-     */
-    CharacterIterator();
-
-    /**
-     * Constructor, just setting the length field in this base class.
-     * @stable ICU 2.0
-     */
-    CharacterIterator(int32_t length);
-
-    /**
-     * Constructor, just setting the length and position fields in this base class.
-     * @stable ICU 2.0
-     */
-    CharacterIterator(int32_t length, int32_t position);
-
-    /**
-     * Constructor, just setting the length, start, end, and position fields in this base class.
-     * @stable ICU 2.0
-     */
-    CharacterIterator(int32_t length, int32_t textBegin, int32_t textEnd, int32_t position);
-  
-    /**
-     * Copy constructor.
-     *
-     * @param that The CharacterIterator to be copied
-     * @stable ICU 2.0
-     */
-    CharacterIterator(const CharacterIterator &that);
-
-    /**
-     * Assignment operator.  Sets this CharacterIterator to have the same behavior,
-     * as the one passed in.
-     * @param that The CharacterIterator passed in.
-     * @return the newly set CharacterIterator.
-     * @stable ICU 2.0
-     */
-    CharacterIterator &operator=(const CharacterIterator &that);
-
-    /**
-     * Base class text length field.
-     * Necessary this for correct getText() and hashCode().
-     * @stable ICU 2.0
-     */
-    int32_t textLength;
-
-    /**
-     * Base class field for the current position.
-     * @stable ICU 2.0
-     */
-    int32_t  pos;
-
-    /**
-     * Base class field for the start of the iteration range.
-     * @stable ICU 2.0
-     */
-    int32_t  begin;
-
-    /**
-     * Base class field for the end of the iteration range.
-     * @stable ICU 2.0
-     */
-    int32_t  end;
-};
-
-inline UBool
-ForwardCharacterIterator::operator!=(const ForwardCharacterIterator& that) const {
-    return !operator==(that);
-}
-
-inline int32_t
-CharacterIterator::setToStart() {
-    return move(0, kStart);
-}
-
-inline int32_t
-CharacterIterator::setToEnd() {
-    return move(0, kEnd);
-}
-
-inline int32_t
-CharacterIterator::startIndex(void) const {
-    return begin;
-}
-
-inline int32_t
-CharacterIterator::endIndex(void) const {
-    return end;
-}
-
-inline int32_t
-CharacterIterator::getIndex(void) const {
-    return pos;
-}
-
-inline int32_t
-CharacterIterator::getLength(void) const {
-    return textLength;
-}
-
-U_NAMESPACE_END
-#endif

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/choicfmt.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/choicfmt.h b/apps/couch_collate/platform/osx/icu/unicode/choicfmt.h
deleted file mode 100644
index 8484648..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/choicfmt.h
+++ /dev/null
@@ -1,746 +0,0 @@
-/*
-********************************************************************************
-*   Copyright (C) 1997-2008, International Business Machines
-*   Corporation and others.  All Rights Reserved.
-********************************************************************************
-*
-* File CHOICFMT.H
-*
-* Modification History:
-*
-*   Date        Name        Description
-*   02/19/97    aliu        Converted from java.
-*   03/20/97    helena      Finished first cut of implementation and got rid 
-*                           of nextDouble/previousDouble and replaced with
-*                           boolean array.
-*   4/10/97     aliu        Clean up.  Modified to work on AIX.
-*   8/6/97      nos         Removed overloaded constructor, member var 'buffer'.
-*   07/22/98    stephen     Removed operator!= (implemented in Format)
-********************************************************************************
-*/
- 
-#ifndef CHOICFMT_H
-#define CHOICFMT_H
- 
-#include "unicode/utypes.h"
-
-/**
- * \file 
- * \brief C++ API: Choice Format.
- */
- 
-#if !UCONFIG_NO_FORMATTING
-
-#include "unicode/unistr.h"
-#include "unicode/numfmt.h"
-#include "unicode/fieldpos.h"
-#include "unicode/format.h"
-
-U_NAMESPACE_BEGIN
-
-class MessageFormat;
-
-/**
- * ChoiceFormat converts between ranges of numeric values
- * and string names for those ranges. A <code>ChoiceFormat</code> splits
- * the real number line <code>-Inf</code> to <code>+Inf</code> into two
- * or more contiguous ranges. Each range is mapped to a
- * string. <code>ChoiceFormat</code> is generally used in a
- * <code>MessageFormat</code> for displaying grammatically correct
- * plurals such as &quot;There are 2 files.&quot;</p>
- * 
- * <p>There are two methods of defining a <code>ChoiceFormat</code>; both
- * are equivalent.  The first is by using a string pattern. This is the
- * preferred method in most cases.  The second method is through direct
- * specification of the arrays that make up the
- * <code>ChoiceFormat</code>.</p>
- * 
- * <p><strong>Patterns</strong></p>
- * 
- * <p>In most cases, the preferred way to define a
- * <code>ChoiceFormat</code> is with a pattern. Here is an example of a
- * <code>ChoiceFormat</code> pattern:</p>
- *
- * \htmlonly<pre>    0&#x2264;are no files|1&#x2264;is one file|1&lt;are many files</pre>\endhtmlonly
- * 
- * <p>or equivalently,</p>
- * 
- * \htmlonly<pre>    0#are no files|1#is one file|1&lt;are many files</pre>\endhtmlonly
- * 
- * <p>The pattern consists of a number or <em>range specifiers</em>
- * separated by vertical bars '|' (U+007C). There is no
- * vertical bar after the last range.  Each range specifier is of the
- * form:</p>
- *
- * \htmlonly<blockquote><em>Number Separator String</em></blockquote>\endhtmlonly
- * 
- * <p><em>Number</em> is a floating point number that can be parsed by a
- * default <code>NumberFormat</code> for the US locale. It gives the
- * lower limit of this range. The lower limit is either inclusive or
- * exclusive, depending on the <em>separator</em>. The upper limit is
- * given by the lower limit of the next range.  The Unicode infinity
- * sign \htmlonly&#x221E \endhtmlonly (U+221E) is recognized for positive infinity. It may be preceded by
- * '-' (U+002D) to indicate negative infinity.</p>
- * 
- * <p><em>String</em> is the format string for this range, with special
- * characters enclosed in single quotes (<code>'The #
- * sign'</code>). Single quotes themselves are indicated by two single
- * quotes in a row (<code>'o''clock'</code>).</p>
- * 
- * <p><em>Separator</em> is one of the following single characters:
- * 
- * <ul>
- *   <li>\htmlonly'&#x2264;' \endhtmlonly (U+2264) or '#' (U+0023)
- *   indicates that the lower limit given by <em>Number</em> is
- *   inclusive.  (The two characters are equivalent to ChoiceFormat.)
- *   This means that the limit value <em>Number</em> belongs to this
- *   range.  Another way of saying this is that the corresponding
- *   closure is <code>FALSE</code>.</li>
- *
- *   <li>'<' (U+003C) indicates that the lower limit given by
- *   <em>Number</em> is exclusive.  This means that the value
- *   <em>Number</em> belongs to the prior range.</li> Another way of
- *   saying this is that the corresponding closure is
- *   <code>TRUE</code>.
- * </ul>
- * 
- * <p>See below for more information about closures.</p>
- * 
- * <p><strong>Arrays</strong></p>
- * 
- * <p>A <code>ChoiceFormat</code> defining <code>n</code> intervals
- * (<code>n</code> &gt;= 2) is specified by three arrays of
- * <code>n</code> items:
- * 
- * <ul>
- *   <li><code>double limits[]</code> gives the start of each
- *     interval. This must be a non-decreasing list of values, none of
- *     which may be <code>NaN</code>.</li>
- *   <li><code>UBool closures[]</code> determines whether each limit
- *     value is contained in the interval below it or in the interval
- *     above it. If <code>closures[i]</code> is <code>FALSE</code>, then
- *     <code>limits[i]</code> is a member of interval
- *     <code>i</code>. Otherwise it is a member of interval
- *     <code>i+1</code>. If no closures array is specified, this is
- *     equivalent to having all closures be <code>FALSE</code>. Closures
- *     allow one to specify half-open, open, or closed intervals.</li>
- *   <li><code>UnicodeString formats[]</code> gives the string label
- *     associated with each interval.</li>
- * </ul>
- * 
- * <p><strong>Formatting and Parsing</strong></p>
- * 
- * <p>During formatting, a number is converted to a
- * string. <code>ChoiceFormat</code> accomplishes this by mapping the
- * number to an interval using the following rule. Given a number
- * <code>X</code> and and index value <code>j</code> in the range
- * <code>0..n-1</code>, where <code>n</code> is the number of ranges:</p>
- * 
- * \htmlonly<blockquote>\endhtmlonly<code>X</code> matches <code>j</code> if and only if
- * <code>limit[j] &lt;= X &lt; limit[j+1]</code>
- * \htmlonly</blockquote>\endhtmlonly
- * 
- * <p>(This assumes that all closures are <code>FALSE</code>.  If some
- * closures are <code>TRUE</code> then the relations must be changed to
- * <code>&lt;=</code> or <code>&lt;</code> as appropriate.) If there is
- * no match, then either the first or last index is used, depending on
- * whether the number is too low or too high. Once a number is mapped to
- * an interval <code>j</code>, the string <code>formats[j]</code> is
- * output.</p>
- * 
- * <p>During parsing, a string is converted to a
- * number. <code>ChoiceFormat</code> finds the element
- * <code>formats[j]</code> equal to the string, and returns
- * <code>limits[j]</code> as the parsed value.</p>
- * 
- * <p><strong>Notes</strong></p>
- * 
- * <p>The first limit value does not define a range boundary. For
- * example, in the pattern \htmlonly&quot;<code>1.0#a|2.0#b</code>&quot;\endhtmlonly, the
- * intervals are [-Inf, 2.0) and [2.0, +Inf].  It appears that the first
- * interval should be [1.0, 2.0).  However, since all values that are too
- * small are mapped to range zero, the first interval is effectively
- * [-Inf, 2.0).  However, the first limit value <em>is</em> used during
- * formatting. In this example, <code>parse(&quot;a&quot;)</code> returns
- * 1.0.</p>
- * 
- * <p>There are no gaps between intervals and the entire number line is
- * covered.  A <code>ChoiceFormat</code> maps <em>all</em> possible
- * double values to a finite set of intervals.</p>
- * 
- * <p>The non-number <code>NaN</code> is mapped to interval zero during
- * formatting.</p>
- * 
- * <p><strong>Examples</strong></p>
- * 
- * <p>Here is an example of two arrays that map the number
- * <code>1..7</code> to the English day of the week abbreviations
- * <code>Sun..Sat</code>. No closures array is given; this is the same as
- * specifying all closures to be <code>FALSE</code>.</p>
- * 
- * <pre>    {1,2,3,4,5,6,7},
- *     {&quot;Sun&quot;,&quot;Mon&quot;,&quot;Tue&quot;,&quot;Wed&quot;,&quot;Thur&quot;,&quot;Fri&quot;,&quot;Sat&quot;}</pre>
- * 
- * <p>Here is an example that maps the ranges [-Inf, 1), [1, 1], and (1,
- * +Inf] to three strings. That is, the number line is split into three
- * ranges: x &lt; 1.0, x = 1.0, and x &gt; 1.0.</p>
- * 
- * <pre>    {0, 1, 1},
- *     {FALSE, FALSE, TRUE},
- *     {&quot;no files&quot;, &quot;one file&quot;, &quot;many files&quot;}</pre>
- * 
- * <p>Here is a simple example that shows formatting and parsing: </p>
- * 
- * \code
- *   #include <unicode/choicfmt.h>
- *   #include <unicode/unistr.h>
- *   #include <iostream.h>
- *   
- *   int main(int argc, char *argv[]) {
- *       double limits[] = {1,2,3,4,5,6,7};
- *       UnicodeString monthNames[] = {
- *           "Sun","Mon","Tue","Wed","Thu","Fri","Sat"};
- *       ChoiceFormat fmt(limits, monthNames, 7);
- *       UnicodeString str;
- *       char buf[256];
- *       for (double x = 1.0; x <= 8.0; x += 1.0) {
- *           fmt.format(x, str);
- *           str.extract(0, str.length(), buf, 256, "");
- *           str.truncate(0);
- *           cout << x << " -> "
- *                << buf << endl;
- *       }
- *       cout << endl;
- *       return 0;
- *   }
- * \endcode
- * 
- * <p>Here is a more complex example using a <code>ChoiceFormat</code>
- * constructed from a pattern together with a
- * <code>MessageFormat</code>.</p>
- * 
- * \code
- *   #include <unicode/choicfmt.h>
- *   #include <unicode/msgfmt.h>
- *   #include <unicode/unistr.h>
- *   #include <iostream.h>
- * 
- *   int main(int argc, char *argv[]) {
- *       UErrorCode status = U_ZERO_ERROR;
- *       double filelimits[] = {0,1,2};
- *       UnicodeString filepart[] =
- *           {"are no files","is one file","are {0} files"};
- *       ChoiceFormat* fileform = new ChoiceFormat(filelimits, filepart, 3 );
- *       Format* testFormats[] =
- *           {fileform, NULL, NumberFormat::createInstance(status)};
- *       MessageFormat pattform("There {0} on {1}", status );
- *       pattform.adoptFormats(testFormats, 3);
- *       Formattable testArgs[] = {0L, "Disk A"};
- *       FieldPosition fp(0);
- *       UnicodeString str;
- *       char buf[256];
- *       for (int32_t i = 0; i < 4; ++i) {
- *           Formattable fInt(i);
- *           testArgs[0] = fInt;
- *           pattform.format(testArgs, 2, str, fp, status );
- *           str.extract(0, str.length(), buf, "");
- *           str.truncate(0);
- *           cout << "Output for i=" << i << " : " << buf << endl;
- *       }
- *       cout << endl;
- *       return 0;
- *   }
- * \endcode
- *
- * <p><em>User subclasses are not supported.</em> While clients may write
- * subclasses, such code will not necessarily work and will not be
- * guaranteed to work stably from release to release.
- */
-class U_I18N_API ChoiceFormat: public NumberFormat {
-public:
-    /**
-     * Construct a new ChoiceFormat with the limits and the corresponding formats
-     * based on the pattern.
-     *
-     * @param pattern   Pattern used to construct object.
-     * @param status    Output param to receive success code.  If the
-     *                  pattern cannot be parsed, set to failure code.
-     * @stable ICU 2.0
-     */
-    ChoiceFormat(const UnicodeString& pattern,
-                 UErrorCode& status);
-
-
-    /**
-     * Construct a new ChoiceFormat with the given limits and formats.  Copy
-     * the limits and formats instead of adopting them.
-     *
-     * @param limits    Array of limit values.
-     * @param formats   Array of formats.
-     * @param count     Size of 'limits' and 'formats' arrays.
-     * @stable ICU 2.0
-     */
-    
-    ChoiceFormat(const double* limits,
-                 const UnicodeString* formats,
-                 int32_t count );
-
-    /**
-     * Construct a new ChoiceFormat with the given limits and formats.
-     * Copy the limits and formats (instead of adopting them).  By
-     * default, each limit in the array specifies the inclusive lower
-     * bound of its range, and the exclusive upper bound of the previous
-     * range.  However, if the isLimitOpen element corresponding to a
-     * limit is TRUE, then the limit is the exclusive lower bound of its
-     * range, and the inclusive upper bound of the previous range.
-     * @param limits Array of limit values
-     * @param closures Array of booleans specifying whether each
-     * element of 'limits' is open or closed.  If FALSE, then the
-     * corresponding limit is a member of the range above it.  If TRUE,
-     * then the limit belongs to the range below it.
-     * @param formats Array of formats
-     * @param count Size of 'limits', 'closures', and 'formats' arrays
-     * @stable ICU 2.4
-     */
-    ChoiceFormat(const double* limits,
-                 const UBool* closures,
-                 const UnicodeString* formats,
-                 int32_t count);
-
-    /**
-     * Copy constructor.
-     *
-     * @param that   ChoiceFormat object to be copied from
-     * @stable ICU 2.0
-     */
-    ChoiceFormat(const ChoiceFormat& that);
-
-    /**
-     * Assignment operator.
-     *
-     * @param that   ChoiceFormat object to be copied
-     * @stable ICU 2.0
-     */
-    const ChoiceFormat& operator=(const ChoiceFormat& that);
-
-    /**
-     * Destructor.
-     * @stable ICU 2.0
-     */
-    virtual ~ChoiceFormat();
-
-    /**
-     * Clone this Format object polymorphically. The caller owns the
-     * result and should delete it when done.
-     *
-     * @return a copy of this object
-     * @stable ICU 2.0
-     */
-    virtual Format* clone(void) const;
-
-    /**
-     * Return true if the given Format objects are semantically equal.
-     * Objects of different subclasses are considered unequal.
-     *
-     * @param other    ChoiceFormat object to be compared 
-     * @return         true if other is the same as this. 
-     * @stable ICU 2.0
-     */
-    virtual UBool operator==(const Format& other) const;
-
-    /**
-     * Sets the pattern.
-     * @param pattern   The pattern to be applied.
-     * @param status    Output param set to success/failure code on
-     *                  exit. If the pattern is invalid, this will be
-     *                  set to a failure result.
-     * @stable ICU 2.0
-     */
-    virtual void applyPattern(const UnicodeString& pattern,
-                              UErrorCode& status);
-
-    /**
-     * Sets the pattern.
-     * @param pattern    The pattern to be applied.
-     * @param parseError Struct to recieve information on position 
-     *                   of error if an error is encountered
-     * @param status     Output param set to success/failure code on
-     *                   exit. If the pattern is invalid, this will be
-     *                   set to a failure result.
-     * @stable ICU 2.0
-     */
-    virtual void applyPattern(const UnicodeString& pattern,
-                             UParseError& parseError,
-                             UErrorCode& status);
-    /**
-     * Gets the pattern.
-     * 
-     * @param pattern    Output param which will recieve the pattern
-     *                   Previous contents are deleted.
-     * @return    A reference to 'pattern'
-     * @stable ICU 2.0
-     */
-    virtual UnicodeString& toPattern(UnicodeString &pattern) const;
-
-    /**
-     * Set the choices to be used in formatting.
-     *
-     * @param limitsToCopy      Contains the top value that you want
-     *                          parsed with that format,and should be in
-     *                          ascending sorted order. When formatting X,
-     *                          the choice will be the i, where limit[i]
-     *                          &lt;= X &lt; limit[i+1].
-     * @param formatsToCopy     The format strings you want to use for each limit.
-     * @param count             The size of the above arrays.
-     * @stable ICU 2.0
-     */
-    virtual void setChoices(const double* limitsToCopy,
-                            const UnicodeString* formatsToCopy,
-                            int32_t count );    
-
-    /**
-     * Set the choices to be used in formatting.  See class description
-     * for documenatation of the limits, closures, and formats arrays.
-     * @param limits Array of limits
-     * @param closures Array of limit booleans
-     * @param formats Array of format string
-     * @param count The size of the above arrays
-     * @stable ICU 2.4
-     */
-    virtual void setChoices(const double* limits,
-                            const UBool* closures,
-                            const UnicodeString* formats,
-                            int32_t count);
-
-    /**
-     * Get the limits passed in the constructor.
-     *
-     * @param count    The size of the limits arrays
-     * @return the limits.
-     * @stable ICU 2.0
-     */
-    virtual const double* getLimits(int32_t& count) const;
-    
-    /**
-     * Get the limit booleans passed in the constructor.  The caller
-     * must not delete the result.
-     *
-     * @param count   The size of the arrays
-     * @return the closures
-     * @stable ICU 2.4
-     */
-    virtual const UBool* getClosures(int32_t& count) const;
-
-    /**
-     * Get the formats passed in the constructor.
-     *
-     * @param count   The size of the arrays
-     * @return the formats.
-     * @stable ICU 2.0
-     */
-    virtual const UnicodeString* getFormats(int32_t& count) const;
-
-    /**
-     * Format a double or long number using this object's choices.
-     *
-     * @param number    The value to be formatted.
-     * @param appendTo  Output parameter to receive result.
-     *                  Result is appended to existing contents.
-     * @param pos       On input: an alignment field, if desired.
-     *                  On output: the offsets of the alignment field.
-     * @return          Reference to 'appendTo' parameter.
-     * @stable ICU 2.0
-     */
-    virtual UnicodeString& format(double number,
-                                  UnicodeString& appendTo,
-                                  FieldPosition& pos) const;
-    /**
-     * Format a int_32t number using this object's choices.
-     *
-     * @param number    The value to be formatted.
-     * @param appendTo  Output parameter to receive result.
-     *                  Result is appended to existing contents.
-     * @param pos       On input: an alignment field, if desired.
-     *                  On output: the offsets of the alignment field.
-     * @return          Reference to 'appendTo' parameter.
-     * @stable ICU 2.0
-     */
-    virtual UnicodeString& format(int32_t number,
-                                  UnicodeString& appendTo,
-                                  FieldPosition& pos) const;
-
-    /**
-     * Format an int64_t number using this object's choices.
-     *
-     * @param number    The value to be formatted.
-     * @param appendTo  Output parameter to receive result.
-     *                  Result is appended to existing contents.
-     * @param pos       On input: an alignment field, if desired.
-     *                  On output: the offsets of the alignment field.
-     * @return          Reference to 'appendTo' parameter.
-     * @stable ICU 2.8
-     */
-    virtual UnicodeString& format(int64_t number,
-                                  UnicodeString& appendTo,
-                                  FieldPosition& pos) const;
-
-    /**
-     * Format an array of objects using this object's choices.
-     *
-     * @param objs      The array of objects to be formatted.
-     * @param cnt       The size of objs.
-     * @param appendTo  Output parameter to receive result.
-     *                  Result is appended to existing contents.
-     * @param pos       On input: an alignment field, if desired.
-     *                  On output: the offsets of the alignment field.
-     * @param success   Output param set to success/failure code on
-     *                  exit. 
-     * @return          Reference to 'appendTo' parameter.
-     * @stable ICU 2.0
-     */
-    virtual UnicodeString& format(const Formattable* objs,
-                                  int32_t cnt,
-                                  UnicodeString& appendTo,
-                                  FieldPosition& pos,
-                                  UErrorCode& success) const;
-    /**
-     * Format an object using this object's choices.
-     *
-     *
-     * @param obj       The object to be formatted.
-     * @param appendTo  Output parameter to receive result.
-     *                  Result is appended to existing contents.
-     * @param pos       On input: an alignment field, if desired.
-     *                  On output: the offsets of the alignment field.
-     * @param status    Output param set to success/failure code on
-     *                  exit. 
-     * @return          Reference to 'appendTo' parameter.
-     * @stable ICU 2.0
-     */
-    virtual UnicodeString& format(const Formattable& obj,
-                                  UnicodeString& appendTo,
-                                  FieldPosition& pos, 
-                                  UErrorCode& status) const;
-
-    /**
-     * Redeclared NumberFormat method.
-     *
-     * @param obj       The object to be formatted.
-     * @param appendTo  Output parameter to receive result.
-     *                  Result is appended to existing contents.
-     * @param status    Output param set to success/failure code on
-     *                  exit. 
-     * @return          Reference to 'appendTo' parameter.
-     * @stable ICU 2.0
-     */
-    UnicodeString& format(const Formattable& obj,
-                          UnicodeString& appendTo,
-                          UErrorCode& status) const;
-
-    /**
-     * Redeclared NumberFormat method.
-     * Format a double number. These methods call the NumberFormat
-     * pure virtual format() methods with the default FieldPosition.
-     *
-     * @param number    The value to be formatted.
-     * @param appendTo  Output parameter to receive result.
-     *                  Result is appended to existing contents.
-     * @return          Reference to 'appendTo' parameter.
-     * @stable ICU 2.0
-     */
-    UnicodeString& format(  double number,
-                            UnicodeString& appendTo) const;
-
-    /**
-     * Redeclared NumberFormat method.
-     * Format a long number. These methods call the NumberFormat
-     * pure virtual format() methods with the default FieldPosition.
-     *
-     * @param number    The value to be formatted.
-     * @param appendTo  Output parameter to receive result.
-     *                  Result is appended to existing contents.
-     * @return          Reference to 'appendTo' parameter.
-     * @stable ICU 2.0
-     */
-    UnicodeString& format(  int32_t number,
-                            UnicodeString& appendTo) const;
-
-   /**
-    * Return a long if possible (e.g. within range LONG_MAX,
-    * LONG_MAX], and with no decimals), otherwise a double.  If
-    * IntegerOnly is set, will stop at a decimal point (or equivalent;
-    * e.g. for rational numbers "1 2/3", will stop after the 1).
-    * <P>
-    * If no object can be parsed, parsePosition is unchanged, and NULL is
-    * returned.
-    *
-    * @param text           The text to be parsed.
-    * @param result         Formattable to be set to the parse result.
-    *                       If parse fails, return contents are undefined.
-    * @param parsePosition  The position to start parsing at on input.
-    *                       On output, moved to after the last successfully
-    *                       parse character. On parse failure, does not change.
-    * @see                  NumberFormat::isParseIntegerOnly
-    * @stable ICU 2.0
-    */
-    virtual void parse(const UnicodeString& text,
-                       Formattable& result,
-                       ParsePosition& parsePosition) const;
-    
-    /**
-    * Return a long if possible (e.g. within range LONG_MAX,
-    * LONG_MAX], and with no decimals), otherwise a double.  If
-    * IntegerOnly is set, will stop at a decimal point (or equivalent;
-    * e.g. for rational numbers "1 2/3", will stop after the 1).
-    * <P>
-    * If no object can be parsed, parsePosition is unchanged, and NULL is
-    * returned.
-    *
-    * @param text           The text to be parsed.
-    * @param result         Formattable to be set to the parse result.
-    *                       If parse fails, return contents are undefined.
-    * @param status         Output param with the formatted string.
-    * @see                  NumberFormat::isParseIntegerOnly
-    * @stable ICU 2.0
-    */
-    virtual void parse(const UnicodeString& text,
-                       Formattable& result,
-                       UErrorCode& status) const;
-    
-    
-public:
-    /**
-     * Returns a unique class ID POLYMORPHICALLY.  Pure virtual override.
-     * This method is to implement a simple version of RTTI, since not all
-     * C++ compilers support genuine RTTI.  Polymorphic operator==() and
-     * clone() methods call this method.
-     *
-     * @return          The class ID for this object. All objects of a
-     *                  given class have the same class ID.  Objects of
-     *                  other classes have different class IDs.
-     * @stable ICU 2.0
-     */
-    virtual UClassID getDynamicClassID(void) const;
-
-    /**
-     * Return the class ID for this class.  This is useful only for
-     * comparing to a return value from getDynamicClassID().  For example:
-     * <pre>
-     * .       Base* polymorphic_pointer = createPolymorphicObject();
-     * .       if (polymorphic_pointer->getDynamicClassID() ==
-     * .           Derived::getStaticClassID()) ...
-     * </pre>
-     * @return          The class ID for all objects of this class.
-     * @stable ICU 2.0
-     */
-    static UClassID U_EXPORT2 getStaticClassID(void);
-
-private:
-    // static cache management (thread-safe)
-  //  static NumberFormat* getNumberFormat(UErrorCode &status); // call this function to 'check out' a numberformat from the cache.
-  //  static void          releaseNumberFormat(NumberFormat *adopt); // call this function to 'return' the number format to the cache.
-    
-    /**
-     * Converts a string to a double value using a default NumberFormat object
-     * which is static (shared by all ChoiceFormat instances).
-     * @param string the string to be converted with.
-     * @return the converted double number.
-     */
-    static double stod(const UnicodeString& string);
-
-    /**
-     * Converts a double value to a string using a default NumberFormat object
-     * which is static (shared by all ChoiceFormat instances).
-     * @param value the double number to be converted with.
-     * @param string the result string.
-     * @return the converted string.
-     */
-    static UnicodeString& dtos(double value, UnicodeString& string);
-
-    ChoiceFormat(); // default constructor not implemented
-
-    /**
-     * Construct a new ChoiceFormat with the limits and the corresponding formats
-     * based on the pattern.
-     *
-     * @param newPattern   Pattern used to construct object.
-     * @param parseError   Struct to recieve information on position 
-     *                     of error if an error is encountered.
-     * @param status       Output param to receive success code.  If the
-     *                     pattern cannot be parsed, set to failure code.
-     * @stable ICU 2.0
-     */
-    ChoiceFormat(const UnicodeString& newPattern,
-                 UParseError& parseError,
-                 UErrorCode& status);
-
-    friend class MessageFormat;
-    /**
-     * Each ChoiceFormat divides the range -Inf..+Inf into fCount
-     * intervals.  The intervals are:
-     *
-     *         0: fChoiceLimits[0]..fChoiceLimits[1]
-     *         1: fChoiceLimits[1]..fChoiceLimits[2]
-     *        ...
-     *  fCount-2: fChoiceLimits[fCount-2]..fChoiceLimits[fCount-1]
-     *  fCount-1: fChoiceLimits[fCount-1]..+Inf
-     *
-     * Interval 0 is special; during formatting (mapping numbers to
-     * strings), it also contains all numbers less than
-     * fChoiceLimits[0], as well as NaN values.
-     *
-     * Interval i maps to and from string fChoiceFormats[i].  When
-     * parsing (mapping strings to numbers), then intervals map to
-     * their lower limit, that is, interval i maps to fChoiceLimit[i].
-     *
-     * The intervals may be closed, half open, or open.  This affects
-     * formatting but does not affect parsing.  Interval i is affected
-     * by fClosures[i] and fClosures[i+1].  If fClosures[i]
-     * is FALSE, then the value fChoiceLimits[i] is in interval i.
-     * That is, intervals i and i are:
-     *
-     *  i-1:                 ... x < fChoiceLimits[i]
-     *    i: fChoiceLimits[i] <= x ...
-     *
-     * If fClosures[i] is TRUE, then the value fChoiceLimits[i] is
-     * in interval i-1.  That is, intervals i-1 and i are:
-     *
-     *  i-1:                ... x <= fChoiceLimits[i]
-     *    i: fChoiceLimits[i] < x ...
-     *
-     * Because of the nature of interval 0, fClosures[0] has no
-     * effect.
-
-     */
-    double*         fChoiceLimits;
-    UBool*          fClosures;
-    UnicodeString*  fChoiceFormats;
-    int32_t         fCount;
-};
- 
-inline UnicodeString&
-ChoiceFormat::format(const Formattable& obj,
-                     UnicodeString& appendTo,
-                     UErrorCode& status) const {
-    // Don't use Format:: - use immediate base class only,
-    // in case immediate base modifies behavior later.
-    return NumberFormat::format(obj, appendTo, status);
-}
-
-inline UnicodeString&
-ChoiceFormat::format(double number,
-                     UnicodeString& appendTo) const {
-    return NumberFormat::format(number, appendTo);
-}
-
-inline UnicodeString&
-ChoiceFormat::format(int32_t number,
-                     UnicodeString& appendTo) const {
-    return NumberFormat::format(number, appendTo);
-}
-U_NAMESPACE_END
-
-#endif /* #if !UCONFIG_NO_FORMATTING */
-
-#endif // _CHOICFMT
-//eof

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/coleitr.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/coleitr.h b/apps/couch_collate/platform/osx/icu/unicode/coleitr.h
deleted file mode 100644
index 4025a41..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/coleitr.h
+++ /dev/null
@@ -1,400 +0,0 @@
-/*
- ******************************************************************************
- *   Copyright (C) 1997-2008, International Business Machines
- *   Corporation and others.  All Rights Reserved.
- ******************************************************************************
- */
-
-/**
- * \file 
- * \brief C++ API: Collation Element Iterator.
- */
-
-/**
-* File coleitr.h
-*
-* 
-*
-* Created by: Helena Shih
-*
-* Modification History:
-*
-*  Date       Name        Description
-*
-*  8/18/97    helena      Added internal API documentation.
-* 08/03/98    erm         Synched with 1.2 version CollationElementIterator.java
-* 12/10/99    aliu        Ported Thai collation support from Java.
-* 01/25/01    swquek      Modified into a C++ wrapper calling C APIs (ucoliter.h)
-* 02/19/01    swquek      Removed CollationElementsIterator() since it is 
-*                         private constructor and no calls are made to it
-*/
-
-#ifndef COLEITR_H
-#define COLEITR_H
-
-#include "unicode/utypes.h"
-
- 
-#if !UCONFIG_NO_COLLATION
-
-#include "unicode/uobject.h"
-#include "unicode/tblcoll.h"
-#include "unicode/ucoleitr.h"
-
-/** 
- * The UCollationElements struct.
- * For usage in C programs.
- * @stable ICU 2.0
- */
-typedef struct UCollationElements UCollationElements;
-
-U_NAMESPACE_BEGIN
-
-/**
-* The CollationElementIterator class is used as an iterator to walk through     
-* each character of an international string. Use the iterator to return the
-* ordering priority of the positioned character. The ordering priority of a 
-* character, which we refer to as a key, defines how a character is collated in 
-* the given collation object.
-* For example, consider the following in Spanish:
-* <pre>
-*        "ca" -> the first key is key('c') and second key is key('a').
-*        "cha" -> the first key is key('ch') and second key is key('a').</pre>
-* And in German,
-* <pre> \htmlonly       "&#x00E6;b"-> the first key is key('a'), the second key is key('e'), and
-*        the third key is key('b'). \endhtmlonly </pre>
-* The key of a character, is an integer composed of primary order(short),
-* secondary order(char), and tertiary order(char). Java strictly defines the 
-* size and signedness of its primitive data types. Therefore, the static
-* functions primaryOrder(), secondaryOrder(), and tertiaryOrder() return 
-* int32_t to ensure the correctness of the key value.
-* <p>Example of the iterator usage: (without error checking)
-* <pre>
-* \code
-*   void CollationElementIterator_Example()
-*   {
-*       UnicodeString str = "This is a test";
-*       UErrorCode success = U_ZERO_ERROR;
-*       RuleBasedCollator* rbc =
-*           (RuleBasedCollator*) RuleBasedCollator::createInstance(success);
-*       CollationElementIterator* c =
-*           rbc->createCollationElementIterator( str );
-*       int32_t order = c->next(success);
-*       c->reset();
-*       order = c->previous(success);
-*       delete c;
-*       delete rbc;
-*   }
-* \endcode
-* </pre>
-* <p>
-* CollationElementIterator::next returns the collation order of the next
-* character based on the comparison level of the collator. 
-* CollationElementIterator::previous returns the collation order of the 
-* previous character based on the comparison level of the collator. 
-* The Collation Element Iterator moves only in one direction between calls to
-* CollationElementIterator::reset. That is, CollationElementIterator::next() 
-* and CollationElementIterator::previous can not be inter-used. Whenever 
-* CollationElementIterator::previous is to be called after 
-* CollationElementIterator::next() or vice versa, 
-* CollationElementIterator::reset has to be called first to reset the status, 
-* shifting pointers to either the end or the start of the string. Hence at the 
-* next call of CollationElementIterator::previous or 
-* CollationElementIterator::next(), the first or last collation order will be 
-* returned. 
-* If a change of direction is done without a CollationElementIterator::reset(), 
-* the result is undefined.
-* The result of a forward iterate (CollationElementIterator::next) and 
-* reversed result of the backward iterate (CollationElementIterator::previous) 
-* on the same string are equivalent, if collation orders with the value 
-* UCOL_IGNORABLE are ignored.
-* Character based on the comparison level of the collator.  A collation order 
-* consists of primary order, secondary order and tertiary order.  The data 
-* type of the collation order is <strong>t_int32</strong>. 
-*
-* Note, CollationElementIterator should not be subclassed.
-* @see     Collator
-* @see     RuleBasedCollator
-* @version 1.8 Jan 16 2001
-*/
-class U_I18N_API CollationElementIterator : public UObject {
-public: 
-
-    // CollationElementIterator public data member ------------------------------
-
-    enum {
-        /**
-         * NULLORDER indicates that an error has occured while processing
-         * @stable ICU 2.0
-         */
-        NULLORDER = (int32_t)0xffffffff
-    };
-
-    // CollationElementIterator public constructor/destructor -------------------
-
-    /**
-    * Copy constructor.
-    *
-    * @param other    the object to be copied from
-    * @stable ICU 2.0
-    */
-    CollationElementIterator(const CollationElementIterator& other);
-
-    /** 
-    * Destructor
-    * @stable ICU 2.0
-    */
-    virtual ~CollationElementIterator();
-
-    // CollationElementIterator public methods ----------------------------------
-
-    /**
-    * Returns true if "other" is the same as "this"
-    *
-    * @param other    the object to be compared
-    * @return         true if "other" is the same as "this"
-    * @stable ICU 2.0
-    */
-    UBool operator==(const CollationElementIterator& other) const;
-
-    /**
-    * Returns true if "other" is not the same as "this".
-    *
-    * @param other    the object to be compared
-    * @return         true if "other" is not the same as "this"
-    * @stable ICU 2.0
-    */
-    UBool operator!=(const CollationElementIterator& other) const;
-
-    /**
-    * Resets the cursor to the beginning of the string.
-    * @stable ICU 2.0
-    */
-    void reset(void);
-
-    /**
-    * Gets the ordering priority of the next character in the string.
-    * @param status the error code status.
-    * @return the next character's ordering. otherwise returns NULLORDER if an 
-    *         error has occured or if the end of string has been reached
-    * @stable ICU 2.0
-    */
-    int32_t next(UErrorCode& status);
-
-    /**
-    * Get the ordering priority of the previous collation element in the string.
-    * @param status the error code status.
-    * @return the previous element's ordering. otherwise returns NULLORDER if an 
-    *         error has occured or if the start of string has been reached
-    * @stable ICU 2.0
-    */
-    int32_t previous(UErrorCode& status);
-
-    /**
-    * Gets the primary order of a collation order.
-    * @param order the collation order
-    * @return the primary order of a collation order.
-    * @stable ICU 2.0
-    */
-    static inline int32_t primaryOrder(int32_t order);
-
-    /**
-    * Gets the secondary order of a collation order.
-    * @param order the collation order
-    * @return the secondary order of a collation order.
-    * @stable ICU 2.0
-    */
-    static inline int32_t secondaryOrder(int32_t order);
-
-    /**
-    * Gets the tertiary order of a collation order.
-    * @param order the collation order
-    * @return the tertiary order of a collation order.
-    * @stable ICU 2.0
-    */
-    static inline int32_t tertiaryOrder(int32_t order);
-
-    /**
-    * Return the maximum length of any expansion sequences that end with the 
-    * specified comparison order.
-    * @param order a collation order returned by previous or next.
-    * @return maximum size of the expansion sequences ending with the collation 
-    *         element or 1 if collation element does not occur at the end of any 
-    *         expansion sequence
-    * @stable ICU 2.0
-    */
-    int32_t getMaxExpansion(int32_t order) const;
-
-    /**
-    * Gets the comparison order in the desired strength. Ignore the other
-    * differences.
-    * @param order The order value
-    * @stable ICU 2.0
-    */
-    int32_t strengthOrder(int32_t order) const;
-
-    /**
-    * Sets the source string.
-    * @param str the source string.
-    * @param status the error code status.
-    * @stable ICU 2.0
-    */
-    void setText(const UnicodeString& str, UErrorCode& status);
-
-    /**
-    * Sets the source string.
-    * @param str the source character iterator.
-    * @param status the error code status.
-    * @stable ICU 2.0
-    */
-    void setText(CharacterIterator& str, UErrorCode& status);
-
-    /**
-    * Checks if a comparison order is ignorable.
-    * @param order the collation order.
-    * @return TRUE if a character is ignorable, FALSE otherwise.
-    * @stable ICU 2.0
-    */
-    static inline UBool isIgnorable(int32_t order);
-
-    /**
-    * Gets the offset of the currently processed character in the source string.
-    * @return the offset of the character.
-    * @stable ICU 2.0
-    */
-    int32_t getOffset(void) const;
-
-    /**
-    * Sets the offset of the currently processed character in the source string.
-    * @param newOffset the new offset.
-    * @param status the error code status.
-    * @return the offset of the character.
-    * @stable ICU 2.0
-    */
-    void setOffset(int32_t newOffset, UErrorCode& status);
-
-    /**
-    * ICU "poor man's RTTI", returns a UClassID for the actual class.
-    *
-    * @stable ICU 2.2
-    */
-    virtual UClassID getDynamicClassID() const;
-
-    /**
-    * ICU "poor man's RTTI", returns a UClassID for this class.
-    *
-    * @stable ICU 2.2
-    */
-    static UClassID U_EXPORT2 getStaticClassID();
-
-protected:
-  
-    // CollationElementIterator protected constructors --------------------------
-    /**
-    * @stable ICU 2.0
-    */
-    friend class RuleBasedCollator;
-
-    /**
-    * CollationElementIterator constructor. This takes the source string and the 
-    * collation object. The cursor will walk thru the source string based on the 
-    * predefined collation rules. If the source string is empty, NULLORDER will 
-    * be returned on the calls to next().
-    * @param sourceText    the source string.
-    * @param order         the collation object.
-    * @param status        the error code status.
-    * @stable ICU 2.0
-    */
-    CollationElementIterator(const UnicodeString& sourceText,
-        const RuleBasedCollator* order, UErrorCode& status);
-
-    /**
-    * CollationElementIterator constructor. This takes the source string and the 
-    * collation object.  The cursor will walk thru the source string based on the 
-    * predefined collation rules.  If the source string is empty, NULLORDER will 
-    * be returned on the calls to next().
-    * @param sourceText    the source string.
-    * @param order         the collation object.
-    * @param status        the error code status.
-    * @stable ICU 2.0
-    */
-    CollationElementIterator(const CharacterIterator& sourceText,
-        const RuleBasedCollator* order, UErrorCode& status);
-
-    // CollationElementIterator protected methods -------------------------------
-
-    /**
-    * Assignment operator
-    *
-    * @param other    the object to be copied
-    * @stable ICU 2.0
-    */
-    const CollationElementIterator&
-        operator=(const CollationElementIterator& other);
-
-private:
-    CollationElementIterator(); // default constructor not implemented
-
-    // CollationElementIterator private data members ----------------------------
-
-    /**
-    * Data wrapper for collation elements
-    */
-    UCollationElements *m_data_;
-
-    /**
-    * Indicates if m_data_ belongs to this object.
-    */
-    UBool isDataOwned_;
-
-};
-
-// CollationElementIterator inline method defination --------------------------
-
-/**
-* Get the primary order of a collation order.
-* @param order the collation order
-* @return the primary order of a collation order.
-*/
-inline int32_t CollationElementIterator::primaryOrder(int32_t order)
-{
-    order &= RuleBasedCollator::PRIMARYORDERMASK;
-    return (order >> RuleBasedCollator::PRIMARYORDERSHIFT);
-}
-
-/**
-* Get the secondary order of a collation order.
-* @param order the collation order
-* @return the secondary order of a collation order.
-*/
-inline int32_t CollationElementIterator::secondaryOrder(int32_t order)
-{
-    order = order & RuleBasedCollator::SECONDARYORDERMASK;
-    return (order >> RuleBasedCollator::SECONDARYORDERSHIFT);
-}
-
-/**
-* Get the tertiary order of a collation order.
-* @param order the collation order
-* @return the tertiary order of a collation order.
-*/
-inline int32_t CollationElementIterator::tertiaryOrder(int32_t order)
-{
-    return (order &= RuleBasedCollator::TERTIARYORDERMASK);
-}
-
-inline int32_t CollationElementIterator::getMaxExpansion(int32_t order) const
-{
-    return ucol_getMaxExpansion(m_data_, (uint32_t)order);
-}
-
-inline UBool CollationElementIterator::isIgnorable(int32_t order)
-{
-    return (primaryOrder(order) == RuleBasedCollator::PRIMIGNORABLE);
-}
-
-U_NAMESPACE_END
-
-#endif /* #if !UCONFIG_NO_COLLATION */
-
-#endif


[23/57] [abbrv] remove couch_collate

Posted by be...@apache.org.
http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/tzrule.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/tzrule.h b/apps/couch_collate/platform/osx/icu/unicode/tzrule.h
deleted file mode 100644
index 95ad1d0..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/tzrule.h
+++ /dev/null
@@ -1,828 +0,0 @@
-/*
-*******************************************************************************
-* Copyright (C) 2007-2008, International Business Machines Corporation and    *
-* others. All Rights Reserved.                                                *
-*******************************************************************************
-*/
-#ifndef TZRULE_H
-#define TZRULE_H
-
-/**
- * \file 
- * \brief C++ API: Time zone rule classes
- */
-
-#include "unicode/utypes.h"
-
-#if !UCONFIG_NO_FORMATTING
-
-#include "unicode/uobject.h"
-#include "unicode/unistr.h"
-#include "unicode/dtrule.h"
-
-U_NAMESPACE_BEGIN
-
-/**
- * <code>TimeZoneRule</code> is a class representing a rule for time zone.
- * <code>TimeZoneRule</code> has a set of time zone attributes, such as zone name,
- * raw offset (UTC offset for standard time) and daylight saving time offset.
- * 
- * @stable ICU 4.0
- */
-class U_I18N_API TimeZoneRule : public UObject {
-public:
-    /**
-     * Destructor.
-     * @stable ICU 4.0
-     */
-    virtual ~TimeZoneRule();
-
-    /**
-     * Clone this TimeZoneRule object polymorphically. The caller owns the result and
-     * should delete it when done.
-     * @return  A copy of the object.
-     * @stable ICU 4.0
-     */
-    virtual TimeZoneRule* clone(void) const = 0;
-
-    /**
-     * Return true if the given <code>TimeZoneRule</code> objects are semantically equal. Objects
-     * of different subclasses are considered unequal.
-     * @param that  The object to be compared with.
-     * @return  true if the given <code>TimeZoneRule</code> objects are semantically equal.
-     * @stable ICU 4.0
-     */
-    virtual UBool operator==(const TimeZoneRule& that) const;
-
-    /**
-     * Return true if the given <code>TimeZoneRule</code> objects are semantically unequal. Objects
-     * of different subclasses are considered unequal.
-     * @param that  The object to be compared with.
-     * @return  true if the given <code>TimeZoneRule</code> objects are semantically unequal.
-     * @stable ICU 4.0
-     */
-    virtual UBool operator!=(const TimeZoneRule& that) const;
-
-    /**
-     * Fills in "name" with the name of this time zone.
-     * @param name  Receives the name of this time zone.
-     * @return  A reference to "name"
-     * @stable ICU 4.0
-     */
-    UnicodeString& getName(UnicodeString& name) const;
-
-    /**
-     * Gets the standard time offset.
-     * @return  The standard time offset from UTC in milliseconds.
-     * @stable ICU 4.0
-     */
-    int32_t getRawOffset(void) const;
-
-    /**
-     * Gets the amount of daylight saving delta time from the standard time.
-     * @return  The amount of daylight saving offset used by this rule
-     *          in milliseconds.
-     * @stable ICU 4.0
-     */
-    int32_t getDSTSavings(void) const;
-
-    /**
-     * Returns if this rule represents the same rule and offsets as another.
-     * When two <code>TimeZoneRule</code> objects differ only its names, this method
-     * returns true.
-     * @param other The <code>TimeZoneRule</code> object to be compared with.
-     * @return  true if the other <code>TimeZoneRule</code> is the same as this one.
-     * @stable ICU 4.0
-     */
-    virtual UBool isEquivalentTo(const TimeZoneRule& other) const;
-
-    /**
-     * Gets the very first time when this rule takes effect.
-     * @param prevRawOffset     The standard time offset from UTC before this rule
-     *                          takes effect in milliseconds.
-     * @param prevDSTSavings    The amount of daylight saving offset from the
-     *                          standard time.
-     * @param result            Receives the very first time when this rule takes effect.
-     * @return  true if the start time is available.  When false is returned, output parameter
-     *          "result" is unchanged.
-     * @stable ICU 4.0
-     */
-    virtual UBool getFirstStart(int32_t prevRawOffset, int32_t prevDSTSavings, UDate& result) const = 0;
-
-    /**
-     * Gets the final time when this rule takes effect.
-     * @param prevRawOffset     The standard time offset from UTC before this rule
-     *                          takes effect in milliseconds.
-     * @param prevDSTSavings    The amount of daylight saving offset from the
-     *                          standard time.
-     * @param result            Receives the final time when this rule takes effect.
-     * @return  true if the start time is available.  When false is returned, output parameter
-     *          "result" is unchanged.
-     * @stable ICU 4.0
-     */
-    virtual UBool getFinalStart(int32_t prevRawOffset, int32_t prevDSTSavings, UDate& result) const = 0;
-
-    /**
-     * Gets the first time when this rule takes effect after the specified time.
-     * @param base              The first start time after this base time will be returned.
-     * @param prevRawOffset     The standard time offset from UTC before this rule
-     *                          takes effect in milliseconds.
-     * @param prevDSTSavings    The amount of daylight saving offset from the
-     *                          standard time.
-     * @param inclusive         Whether the base time is inclusive or not.
-     * @param result            Receives The first time when this rule takes effect after
-     *                          the specified base time.
-     * @return  true if the start time is available.  When false is returned, output parameter
-     *          "result" is unchanged.
-     * @stable ICU 4.0
-     */
-    virtual UBool getNextStart(UDate base, int32_t prevRawOffset, int32_t prevDSTSavings,
-        UBool inclusive, UDate& result) const = 0;
-
-    /**
-     * Gets the most recent time when this rule takes effect before the specified time.
-     * @param base              The most recent time before this base time will be returned.
-     * @param prevRawOffset     The standard time offset from UTC before this rule
-     *                          takes effect in milliseconds.
-     * @param prevDSTSavings    The amount of daylight saving offset from the
-     *                          standard time.
-     * @param inclusive         Whether the base time is inclusive or not.
-     * @param result            Receives The most recent time when this rule takes effect before
-     *                          the specified base time.
-     * @return  true if the start time is available.  When false is returned, output parameter
-     *          "result" is unchanged.
-     * @stable ICU 4.0
-     */
-    virtual UBool getPreviousStart(UDate base, int32_t prevRawOffset, int32_t prevDSTSavings,
-        UBool inclusive, UDate& result) const = 0;
-
-protected:
-
-    /**
-     * Constructs a <code>TimeZoneRule</code> with the name, the GMT offset of its
-     * standard time and the amount of daylight saving offset adjustment.
-     * @param name          The time zone name.
-     * @param rawOffset     The UTC offset of its standard time in milliseconds.
-     * @param dstSavings    The amount of daylight saving offset adjustment in milliseconds.
-     *                      If this ia a rule for standard time, the value of this argument is 0.
-     * @stable ICU 4.0
-     */
-    TimeZoneRule(const UnicodeString& name, int32_t rawOffset, int32_t dstSavings);
-
-    /**
-     * Copy constructor.
-     * @param source    The TimeZoneRule object to be copied.
-     * @stable ICU 4.0
-     */
-    TimeZoneRule(const TimeZoneRule& source);
-
-    /**
-     * Assignment operator.
-     * @param right The object to be copied.
-     * @stable ICU 4.0
-     */
-    TimeZoneRule& operator=(const TimeZoneRule& right);
-
-private:
-    UnicodeString fName; // time name
-    int32_t fRawOffset;  // UTC offset of the standard time in milliseconds
-    int32_t fDSTSavings; // DST saving amount in milliseconds
-};
-
-/**
- * <code>InitialTimeZoneRule</code> represents a time zone rule
- * representing a time zone effective from the beginning and
- * has no actual start times.
- * @stable ICU 4.0
- */
-class U_I18N_API InitialTimeZoneRule : public TimeZoneRule {
-public:
-    /**
-     * Constructs an <code>InitialTimeZoneRule</code> with the name, the GMT offset of its
-     * standard time and the amount of daylight saving offset adjustment.
-     * @param name          The time zone name.
-     * @param rawOffset     The UTC offset of its standard time in milliseconds.
-     * @param dstSavings    The amount of daylight saving offset adjustment in milliseconds.
-     *                      If this ia a rule for standard time, the value of this argument is 0.
-     * @stable ICU 4.0
-     */
-    InitialTimeZoneRule(const UnicodeString& name, int32_t rawOffset, int32_t dstSavings);
-
-    /**
-     * Copy constructor.
-     * @param source    The InitialTimeZoneRule object to be copied.
-     * @stable ICU 4.0
-     */
-    InitialTimeZoneRule(const InitialTimeZoneRule& source);
-
-    /**
-     * Destructor.
-     * @stable ICU 4.0
-     */
-    virtual ~InitialTimeZoneRule();
-
-    /**
-     * Clone this InitialTimeZoneRule object polymorphically. The caller owns the result and
-     * should delete it when done.
-     * @return    A copy of the object.
-     * @stable ICU 4.0
-     */
-    virtual InitialTimeZoneRule* clone(void) const;
-
-    /**
-     * Assignment operator.
-     * @param right The object to be copied.
-     * @stable ICU 4.0
-     */
-    InitialTimeZoneRule& operator=(const InitialTimeZoneRule& right);
-
-    /**
-     * Return true if the given <code>TimeZoneRule</code> objects are semantically equal. Objects
-     * of different subclasses are considered unequal.
-     * @param that  The object to be compared with.
-     * @return  true if the given <code>TimeZoneRule</code> objects are semantically equal.
-     * @stable ICU 4.0
-     */
-    virtual UBool operator==(const TimeZoneRule& that) const;
-
-    /**
-     * Return true if the given <code>TimeZoneRule</code> objects are semantically unequal. Objects
-     * of different subclasses are considered unequal.
-     * @param that  The object to be compared with.
-     * @return  true if the given <code>TimeZoneRule</code> objects are semantically unequal.
-     * @stable ICU 4.0
-     */
-    virtual UBool operator!=(const TimeZoneRule& that) const;
-
-    /**
-     * Gets the time when this rule takes effect in the given year.
-     * @param year              The Gregorian year, with 0 == 1 BCE, -1 == 2 BCE, etc.
-     * @param prevRawOffset     The standard time offset from UTC before this rule
-     *                          takes effect in milliseconds.
-     * @param prevDSTSavings    The amount of daylight saving offset from the
-     *                          standard time.
-     * @param result            Receives the start time in the year.
-     * @return  true if this rule takes effect in the year and the result is set to
-     *          "result".
-     * @stable ICU 4.0
-     */
-    UBool getStartInYear(int32_t year, int32_t prevRawOffset, int32_t prevDSTSavings, UDate& result) const;
-
-    /**
-     * Returns if this rule represents the same rule and offsets as another.
-     * When two <code>TimeZoneRule</code> objects differ only its names, this method
-     * returns true.
-     * @param that  The <code>TimeZoneRule</code> object to be compared with.
-     * @return  true if the other <code>TimeZoneRule</code> is equivalent to this one.
-     * @stable ICU 4.0
-     */
-    virtual UBool isEquivalentTo(const TimeZoneRule& that) const;
-
-    /**
-     * Gets the very first time when this rule takes effect.
-     * @param prevRawOffset     The standard time offset from UTC before this rule
-     *                          takes effect in milliseconds.
-     * @param prevDSTSavings    The amount of daylight saving offset from the
-     *                          standard time.
-     * @param result            Receives the very first time when this rule takes effect.
-     * @return  true if the start time is available.  When false is returned, output parameter
-     *          "result" is unchanged.
-     * @stable ICU 4.0
-     */
-    virtual UBool getFirstStart(int32_t prevRawOffset, int32_t prevDSTSavings, UDate& result) const;
-
-    /**
-     * Gets the final time when this rule takes effect.
-     * @param prevRawOffset     The standard time offset from UTC before this rule
-     *                          takes effect in milliseconds.
-     * @param prevDSTSavings    The amount of daylight saving offset from the
-     *                          standard time.
-     * @param result            Receives the final time when this rule takes effect.
-     * @return  true if the start time is available.  When false is returned, output parameter
-     *          "result" is unchanged.
-     * @stable ICU 4.0
-     */
-    virtual UBool getFinalStart(int32_t prevRawOffset, int32_t prevDSTSavings, UDate& result) const;
-
-    /**
-     * Gets the first time when this rule takes effect after the specified time.
-     * @param base              The first start time after this base time will be returned.
-     * @param prevRawOffset     The standard time offset from UTC before this rule
-     *                          takes effect in milliseconds.
-     * @param prevDSTSavings    The amount of daylight saving offset from the
-     *                          standard time.
-     * @param inclusive         Whether the base time is inclusive or not.
-     * @param result            Receives The first time when this rule takes effect after
-     *                          the specified base time.
-     * @return  true if the start time is available.  When false is returned, output parameter
-     *          "result" is unchanged.
-     * @stable ICU 4.0
-     */
-    virtual UBool getNextStart(UDate base, int32_t prevRawOffset, int32_t prevDSTSavings,
-        UBool inclusive, UDate& result) const;
-
-    /**
-     * Gets the most recent time when this rule takes effect before the specified time.
-     * @param base              The most recent time before this base time will be returned.
-     * @param prevRawOffset     The standard time offset from UTC before this rule
-     *                          takes effect in milliseconds.
-     * @param prevDSTSavings    The amount of daylight saving offset from the
-     *                          standard time.
-     * @param inclusive         Whether the base time is inclusive or not.
-     * @param result            Receives The most recent time when this rule takes effect before
-     *                          the specified base time.
-     * @return  true if the start time is available.  When false is returned, output parameter
-     *          "result" is unchanged.
-     * @stable ICU 4.0
-     */
-    virtual UBool getPreviousStart(UDate base, int32_t prevRawOffset, int32_t prevDSTSavings,
-        UBool inclusive, UDate& result) const;
-
-public:
-    /**
-     * Return the class ID for this class. This is useful only for comparing to
-     * a return value from getDynamicClassID(). For example:
-     * <pre>
-     * .   Base* polymorphic_pointer = createPolymorphicObject();
-     * .   if (polymorphic_pointer->getDynamicClassID() ==
-     * .       erived::getStaticClassID()) ...
-     * </pre>
-     * @return          The class ID for all objects of this class.
-     * @stable ICU 4.0
-     */
-    static UClassID U_EXPORT2 getStaticClassID(void);
-
-    /**
-     * Returns a unique class ID POLYMORPHICALLY. Pure virtual override. This
-     * method is to implement a simple version of RTTI, since not all C++
-     * compilers support genuine RTTI. Polymorphic operator==() and clone()
-     * methods call this method.
-     *
-     * @return          The class ID for this object. All objects of a
-     *                  given class have the same class ID.  Objects of
-     *                  other classes have different class IDs.
-     * @stable ICU 4.0
-     */
-    virtual UClassID getDynamicClassID(void) const;
-};
-
-/**
- * <code>AnnualTimeZoneRule</code> is a class used for representing a time zone
- * rule which takes effect annually.  The calenday system used for the rule is
- * is based on Gregorian calendar
- * 
- * @stable ICU 4.0
- */
-class U_I18N_API AnnualTimeZoneRule : public TimeZoneRule {
-public:
-    /**
-     * The constant representing the maximum year used for designating
-     * a rule is permanent.
-     */
-    static const int32_t MAX_YEAR;
-
-    /**
-     * Constructs a <code>AnnualTimeZoneRule</code> with the name, the GMT offset of its
-     * standard time, the amount of daylight saving offset adjustment, the annual start
-     * time rule and the start/until years.  The input DateTimeRule is copied by this
-     * constructor, so the caller remains responsible for deleting the object.
-     * @param name          The time zone name.
-     * @param rawOffset     The GMT offset of its standard time in milliseconds.
-     * @param dstSavings    The amount of daylight saving offset adjustment in
-     *                      milliseconds.  If this ia a rule for standard time,
-     *                      the value of this argument is 0.
-     * @param dateTimeRule  The start date/time rule repeated annually.
-     * @param startYear     The first year when this rule takes effect.
-     * @param endYear       The last year when this rule takes effect.  If this
-     *                      rule is effective forever in future, specify MAX_YEAR.
-     * @stable ICU 4.0
-     */
-    AnnualTimeZoneRule(const UnicodeString& name, int32_t rawOffset, int32_t dstSavings,
-            const DateTimeRule& dateTimeRule, int32_t startYear, int32_t endYear);
-
-    /**
-     * Constructs a <code>AnnualTimeZoneRule</code> with the name, the GMT offset of its
-     * standard time, the amount of daylight saving offset adjustment, the annual start
-     * time rule and the start/until years.  The input DateTimeRule object is adopted
-     * by this object, therefore, the caller must not delete the object.
-     * @param name          The time zone name.
-     * @param rawOffset     The GMT offset of its standard time in milliseconds.
-     * @param dstSavings    The amount of daylight saving offset adjustment in
-     *                      milliseconds.  If this ia a rule for standard time,
-     *                      the value of this argument is 0.
-     * @param dateTimeRule  The start date/time rule repeated annually.
-     * @param startYear     The first year when this rule takes effect.
-     * @param endYear       The last year when this rule takes effect.  If this
-     *                      rule is effective forever in future, specify MAX_YEAR.
-     * @stable ICU 4.0
-     */
-    AnnualTimeZoneRule(const UnicodeString& name, int32_t rawOffset, int32_t dstSavings,
-            DateTimeRule* dateTimeRule, int32_t startYear, int32_t endYear);
-
-    /**
-     * Copy constructor.
-     * @param source    The AnnualTimeZoneRule object to be copied.
-     * @stable ICU 4.0
-     */
-    AnnualTimeZoneRule(const AnnualTimeZoneRule& source);
-
-    /**
-     * Destructor.
-     * @stable ICU 4.0
-     */
-    virtual ~AnnualTimeZoneRule();
-
-    /**
-     * Clone this AnnualTimeZoneRule object polymorphically. The caller owns the result and
-     * should delete it when done.
-     * @return    A copy of the object.
-     * @stable ICU 4.0
-     */
-    virtual AnnualTimeZoneRule* clone(void) const;
-
-    /**
-     * Assignment operator.
-     * @param right The object to be copied.
-     * @stable ICU 4.0
-     */
-    AnnualTimeZoneRule& operator=(const AnnualTimeZoneRule& right);
-
-    /**
-     * Return true if the given <code>TimeZoneRule</code> objects are semantically equal. Objects
-     * of different subclasses are considered unequal.
-     * @param that  The object to be compared with.
-     * @return  true if the given <code>TimeZoneRule</code> objects are semantically equal.
-     * @stable ICU 4.0
-     */
-    virtual UBool operator==(const TimeZoneRule& that) const;
-
-    /**
-     * Return true if the given <code>TimeZoneRule</code> objects are semantically unequal. Objects
-     * of different subclasses are considered unequal.
-     * @param that  The object to be compared with.
-     * @return  true if the given <code>TimeZoneRule</code> objects are semantically unequal.
-     * @stable ICU 4.0
-     */
-    virtual UBool operator!=(const TimeZoneRule& that) const;
-
-    /**
-     * Gets the start date/time rule used by this rule.
-     * @return  The <code>AnnualDateTimeRule</code> which represents the start date/time
-     *          rule used by this time zone rule.
-     * @stable ICU 4.0
-     */
-    const DateTimeRule* getRule(void) const;
-
-    /**
-     * Gets the first year when this rule takes effect.
-     * @return  The start year of this rule.  The year is in Gregorian calendar
-     *          with 0 == 1 BCE, -1 == 2 BCE, etc.
-     * @stable ICU 4.0
-     */
-    int32_t getStartYear(void) const;
-
-    /**
-     * Gets the end year when this rule takes effect.
-     * @return  The end year of this rule (inclusive). The year is in Gregorian calendar
-     *          with 0 == 1 BCE, -1 == 2 BCE, etc.
-     * @stable ICU 4.0
-     */
-    int32_t getEndYear(void) const;
-
-    /**
-     * Gets the time when this rule takes effect in the given year.
-     * @param year              The Gregorian year, with 0 == 1 BCE, -1 == 2 BCE, etc.
-     * @param prevRawOffset     The standard time offset from UTC before this rule
-     *                          takes effect in milliseconds.
-     * @param prevDSTSavings    The amount of daylight saving offset from the
-     *                          standard time.
-     * @param result            Receives the start time in the year.
-     * @return  true if this rule takes effect in the year and the result is set to
-     *          "result".
-     * @stable ICU 4.0
-     */
-    UBool getStartInYear(int32_t year, int32_t prevRawOffset, int32_t prevDSTSavings, UDate& result) const;
-
-    /**
-     * Returns if this rule represents the same rule and offsets as another.
-     * When two <code>TimeZoneRule</code> objects differ only its names, this method
-     * returns true.
-     * @param that  The <code>TimeZoneRule</code> object to be compared with.
-     * @return  true if the other <code>TimeZoneRule</code> is equivalent to this one.
-     * @stable ICU 4.0
-     */
-    virtual UBool isEquivalentTo(const TimeZoneRule& that) const;
-
-    /**
-     * Gets the very first time when this rule takes effect.
-     * @param prevRawOffset     The standard time offset from UTC before this rule
-     *                          takes effect in milliseconds.
-     * @param prevDSTSavings    The amount of daylight saving offset from the
-     *                          standard time.
-     * @param result            Receives the very first time when this rule takes effect.
-     * @return  true if the start time is available.  When false is returned, output parameter
-     *          "result" is unchanged.
-     * @stable ICU 4.0
-     */
-    virtual UBool getFirstStart(int32_t prevRawOffset, int32_t prevDSTSavings, UDate& result) const;
-
-    /**
-     * Gets the final time when this rule takes effect.
-     * @param prevRawOffset     The standard time offset from UTC before this rule
-     *                          takes effect in milliseconds.
-     * @param prevDSTSavings    The amount of daylight saving offset from the
-     *                          standard time.
-     * @param result            Receives the final time when this rule takes effect.
-     * @return  true if the start time is available.  When false is returned, output parameter
-     *          "result" is unchanged.
-     * @stable ICU 4.0
-     */
-    virtual UBool getFinalStart(int32_t prevRawOffset, int32_t prevDSTSavings, UDate& result) const;
-
-    /**
-     * Gets the first time when this rule takes effect after the specified time.
-     * @param base              The first start time after this base time will be returned.
-     * @param prevRawOffset     The standard time offset from UTC before this rule
-     *                          takes effect in milliseconds.
-     * @param prevDSTSavings    The amount of daylight saving offset from the
-     *                          standard time.
-     * @param inclusive         Whether the base time is inclusive or not.
-     * @param result            Receives The first time when this rule takes effect after
-     *                          the specified base time.
-     * @return  true if the start time is available.  When false is returned, output parameter
-     *          "result" is unchanged.
-     * @stable ICU 4.0
-     */
-    virtual UBool getNextStart(UDate base, int32_t prevRawOffset, int32_t prevDSTSavings,
-        UBool inclusive, UDate& result) const;
-
-    /**
-     * Gets the most recent time when this rule takes effect before the specified time.
-     * @param base              The most recent time before this base time will be returned.
-     * @param prevRawOffset     The standard time offset from UTC before this rule
-     *                          takes effect in milliseconds.
-     * @param prevDSTSavings    The amount of daylight saving offset from the
-     *                          standard time.
-     * @param inclusive         Whether the base time is inclusive or not.
-     * @param result            Receives The most recent time when this rule takes effect before
-     *                          the specified base time.
-     * @return  true if the start time is available.  When false is returned, output parameter
-     *          "result" is unchanged.
-     * @stable ICU 4.0
-     */
-    virtual UBool getPreviousStart(UDate base, int32_t prevRawOffset, int32_t prevDSTSavings,
-        UBool inclusive, UDate& result) const;
-
-
-private:
-    DateTimeRule* fDateTimeRule;
-    int32_t fStartYear;
-    int32_t fEndYear;
-
-public:
-    /**
-     * Return the class ID for this class. This is useful only for comparing to
-     * a return value from getDynamicClassID(). For example:
-     * <pre>
-     * .   Base* polymorphic_pointer = createPolymorphicObject();
-     * .   if (polymorphic_pointer->getDynamicClassID() ==
-     * .       erived::getStaticClassID()) ...
-     * </pre>
-     * @return          The class ID for all objects of this class.
-     * @stable ICU 4.0
-     */
-    static UClassID U_EXPORT2 getStaticClassID(void);
-
-    /**
-     * Returns a unique class ID POLYMORPHICALLY. Pure virtual override. This
-     * method is to implement a simple version of RTTI, since not all C++
-     * compilers support genuine RTTI. Polymorphic operator==() and clone()
-     * methods call this method.
-     *
-     * @return          The class ID for this object. All objects of a
-     *                  given class have the same class ID.  Objects of
-     *                  other classes have different class IDs.
-     * @stable ICU 4.0
-     */
-    virtual UClassID getDynamicClassID(void) const;
-};
-
-/**
- * <code>TimeArrayTimeZoneRule</code> represents a time zone rule whose start times are
- * defined by an array of milliseconds since the standard base time.
- * 
- * @stable ICU 4.0
- */
-class U_I18N_API TimeArrayTimeZoneRule : public TimeZoneRule {
-public:
-    /**
-     * Constructs a <code>TimeArrayTimeZoneRule</code> with the name, the GMT offset of its
-     * standard time, the amount of daylight saving offset adjustment and
-     * the array of times when this rule takes effect.
-     * @param name          The time zone name.
-     * @param rawOffset     The UTC offset of its standard time in milliseconds.
-     * @param dstSavings    The amount of daylight saving offset adjustment in
-     *                      milliseconds.  If this ia a rule for standard time,
-     *                      the value of this argument is 0.
-     * @param startTimes    The array start times in milliseconds since the base time
-     *                      (January 1, 1970, 00:00:00).
-     * @param numStartTimes The number of elements in the parameter "startTimes"
-     * @param timeRuleType  The time type of the start times, which is one of
-     *                      <code>DataTimeRule::WALL_TIME</code>, <code>STANDARD_TIME</code>
-     *                      and <code>UTC_TIME</code>.
-     * @stable ICU 4.0
-     */
-    TimeArrayTimeZoneRule(const UnicodeString& name, int32_t rawOffset, int32_t dstSavings,
-        const UDate* startTimes, int32_t numStartTimes, DateTimeRule::TimeRuleType timeRuleType);
-
-    /**
-     * Copy constructor.
-     * @param source    The TimeArrayTimeZoneRule object to be copied.
-     * @stable ICU 4.0
-     */
-    TimeArrayTimeZoneRule(const TimeArrayTimeZoneRule& source);
-
-    /**
-     * Destructor.
-     * @stable ICU 4.0
-     */
-    virtual ~TimeArrayTimeZoneRule();
-
-    /**
-     * Clone this TimeArrayTimeZoneRule object polymorphically. The caller owns the result and
-     * should delete it when done.
-     * @return    A copy of the object.
-     * @stable ICU 4.0
-     */
-    virtual TimeArrayTimeZoneRule* clone(void) const;
-
-    /**
-     * Assignment operator.
-     * @param right The object to be copied.
-     * @stable ICU 4.0
-     */
-    TimeArrayTimeZoneRule& operator=(const TimeArrayTimeZoneRule& right);
-
-    /**
-     * Return true if the given <code>TimeZoneRule</code> objects are semantically equal. Objects
-     * of different subclasses are considered unequal.
-     * @param that  The object to be compared with.
-     * @return  true if the given <code>TimeZoneRule</code> objects are semantically equal.
-     * @stable ICU 4.0
-     */
-    virtual UBool operator==(const TimeZoneRule& that) const;
-
-    /**
-     * Return true if the given <code>TimeZoneRule</code> objects are semantically unequal. Objects
-     * of different subclasses are considered unequal.
-     * @param that  The object to be compared with.
-     * @return  true if the given <code>TimeZoneRule</code> objects are semantically unequal.
-     * @stable ICU 4.0
-     */
-    virtual UBool operator!=(const TimeZoneRule& that) const;
-
-    /**
-     * Gets the time type of the start times used by this rule.  The return value
-     * is either <code>DateTimeRule::WALL_TIME</code> or <code>STANDARD_TIME</code>
-     * or <code>UTC_TIME</code>.
-     * 
-     * @return The time type used of the start times used by this rule.
-     * @stable ICU 4.0
-     */
-    DateTimeRule::TimeRuleType getTimeType(void) const;
-
-    /**
-     * Gets a start time at the index stored in this rule.
-     * @param index     The index of start times
-     * @param result    Receives the start time at the index
-     * @return  true if the index is within the valid range and
-     *          and the result is set.  When false, the output
-     *          parameger "result" is unchanged.
-     * @stable ICU 4.0
-     */
-    UBool getStartTimeAt(int32_t index, UDate& result) const;
-
-    /**
-     * Returns the number of start times stored in this rule
-     * @return The number of start times.
-     * @stable ICU 4.0
-     */
-    int32_t countStartTimes(void) const;
-
-    /**
-     * Returns if this rule represents the same rule and offsets as another.
-     * When two <code>TimeZoneRule</code> objects differ only its names, this method
-     * returns true.
-     * @param that  The <code>TimeZoneRule</code> object to be compared with.
-     * @return  true if the other <code>TimeZoneRule</code> is equivalent to this one.
-     * @stable ICU 4.0
-     */
-    virtual UBool isEquivalentTo(const TimeZoneRule& that) const;
-
-    /**
-     * Gets the very first time when this rule takes effect.
-     * @param prevRawOffset     The standard time offset from UTC before this rule
-     *                          takes effect in milliseconds.
-     * @param prevDSTSavings    The amount of daylight saving offset from the
-     *                          standard time.
-     * @param result            Receives the very first time when this rule takes effect.
-     * @return  true if the start time is available.  When false is returned, output parameter
-     *          "result" is unchanged.
-     * @stable ICU 4.0
-     */
-    virtual UBool getFirstStart(int32_t prevRawOffset, int32_t prevDSTSavings, UDate& result) const;
-
-    /**
-     * Gets the final time when this rule takes effect.
-     * @param prevRawOffset     The standard time offset from UTC before this rule
-     *                          takes effect in milliseconds.
-     * @param prevDSTSavings    The amount of daylight saving offset from the
-     *                          standard time.
-     * @param result            Receives the final time when this rule takes effect.
-     * @return  true if the start time is available.  When false is returned, output parameter
-     *          "result" is unchanged.
-     * @stable ICU 4.0
-     */
-    virtual UBool getFinalStart(int32_t prevRawOffset, int32_t prevDSTSavings, UDate& result) const;
-
-    /**
-     * Gets the first time when this rule takes effect after the specified time.
-     * @param base              The first start time after this base time will be returned.
-     * @param prevRawOffset     The standard time offset from UTC before this rule
-     *                          takes effect in milliseconds.
-     * @param prevDSTSavings    The amount of daylight saving offset from the
-     *                          standard time.
-     * @param inclusive         Whether the base time is inclusive or not.
-     * @param result            Receives The first time when this rule takes effect after
-     *                          the specified base time.
-     * @return  true if the start time is available.  When false is returned, output parameter
-     *          "result" is unchanged.
-     * @stable ICU 4.0
-     */
-    virtual UBool getNextStart(UDate base, int32_t prevRawOffset, int32_t prevDSTSavings,
-        UBool inclusive, UDate& result) const;
-
-    /**
-     * Gets the most recent time when this rule takes effect before the specified time.
-     * @param base              The most recent time before this base time will be returned.
-     * @param prevRawOffset     The standard time offset from UTC before this rule
-     *                          takes effect in milliseconds.
-     * @param prevDSTSavings    The amount of daylight saving offset from the
-     *                          standard time.
-     * @param inclusive         Whether the base time is inclusive or not.
-     * @param result            Receives The most recent time when this rule takes effect before
-     *                          the specified base time.
-     * @return  true if the start time is available.  When false is returned, output parameter
-     *          "result" is unchanged.
-     * @stable ICU 4.0
-     */
-    virtual UBool getPreviousStart(UDate base, int32_t prevRawOffset, int32_t prevDSTSavings,
-        UBool inclusive, UDate& result) const;
-
-
-private:
-    enum { TIMEARRAY_STACK_BUFFER_SIZE = 32 };
-    UBool initStartTimes(const UDate source[], int32_t size, UErrorCode& ec);
-    UDate getUTC(UDate time, int32_t raw, int32_t dst) const;
-
-    DateTimeRule::TimeRuleType  fTimeRuleType;
-    int32_t fNumStartTimes;
-    UDate*  fStartTimes;
-    UDate   fLocalStartTimes[TIMEARRAY_STACK_BUFFER_SIZE];
-
-public:
-    /**
-     * Return the class ID for this class. This is useful only for comparing to
-     * a return value from getDynamicClassID(). For example:
-     * <pre>
-     * .   Base* polymorphic_pointer = createPolymorphicObject();
-     * .   if (polymorphic_pointer->getDynamicClassID() ==
-     * .       erived::getStaticClassID()) ...
-     * </pre>
-     * @return          The class ID for all objects of this class.
-     * @stable ICU 4.0
-     */
-    static UClassID U_EXPORT2 getStaticClassID(void);
-
-    /**
-     * Returns a unique class ID POLYMORPHICALLY. Pure virtual override. This
-     * method is to implement a simple version of RTTI, since not all C++
-     * compilers support genuine RTTI. Polymorphic operator==() and clone()
-     * methods call this method.
-     *
-     * @return          The class ID for this object. All objects of a
-     *                  given class have the same class ID.  Objects of
-     *                  other classes have different class IDs.
-     * @stable ICU 4.0
-     */
-    virtual UClassID getDynamicClassID(void) const;
-};
-
-
-U_NAMESPACE_END
-
-#endif /* #if !UCONFIG_NO_FORMATTING */
-
-#endif // TZRULE_H
-
-//eof

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/tztrans.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/tztrans.h b/apps/couch_collate/platform/osx/icu/unicode/tztrans.h
deleted file mode 100644
index 12f85d6..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/tztrans.h
+++ /dev/null
@@ -1,195 +0,0 @@
-/*
-*******************************************************************************
-* Copyright (C) 2007-2008, International Business Machines Corporation and         *
-* others. All Rights Reserved.                                                *
-*******************************************************************************
-*/
-#ifndef TZTRANS_H
-#define TZTRANS_H
-
-/**
- * \file 
- * \brief C++ API: Time zone transition
- */
-
-#include "unicode/utypes.h"
-
-#if !UCONFIG_NO_FORMATTING
-
-#include "unicode/uobject.h"
-
-U_NAMESPACE_BEGIN
-
-// Forward declaration
-class TimeZoneRule;
-
-/**
- * <code>TimeZoneTransition</code> is a class representing a time zone transition.
- * An instance has a time of transition and rules for both before and after the transition.
- * @stable ICU 4.0
- */
-class U_I18N_API TimeZoneTransition : public UObject {
-public:
-    /**
-     * Constructs a <code>TimeZoneTransition</code> with the time and the rules before/after
-     * the transition.
-     * 
-     * @param time  The time of transition in milliseconds since the base time.
-     * @param from  The time zone rule used before the transition.
-     * @param to    The time zone rule used after the transition.
-     * @stable ICU 4.0
-     */
-    TimeZoneTransition(UDate time, const TimeZoneRule& from, const TimeZoneRule& to);
-
-    /**
-     * Constructs an empty <code>TimeZoneTransition</code>
-     * @stable ICU 4.0
-     */
-    TimeZoneTransition();
-
-    /**
-     * Copy constructor.
-     * @param source    The TimeZoneTransition object to be copied.
-     * @stable ICU 4.0
-     */
-    TimeZoneTransition(const TimeZoneTransition& source);
-
-    /**
-     * Destructor.
-     * @stable ICU 4.0
-     */
-    ~TimeZoneTransition();
-
-    /**
-     * Clone this TimeZoneTransition object polymorphically. The caller owns the result and
-     * should delete it when done.
-     * @return  A copy of the object.
-     * @stable ICU 4.0
-     */
-    TimeZoneTransition* clone(void) const;
-
-    /**
-     * Assignment operator.
-     * @param right The object to be copied.
-     * @stable ICU 4.0
-     */
-    TimeZoneTransition& operator=(const TimeZoneTransition& right);
-
-    /**
-     * Return true if the given TimeZoneTransition objects are semantically equal. Objects
-     * of different subclasses are considered unequal.
-     * @param that  The object to be compared with.
-     * @return  true if the given TimeZoneTransition objects are semantically equal.
-     * @stable ICU 4.0
-     */
-    UBool operator==(const TimeZoneTransition& that) const;
-
-    /**
-     * Return true if the given TimeZoneTransition objects are semantically unequal. Objects
-     * of different subclasses are considered unequal.
-     * @param that  The object to be compared with.
-     * @return  true if the given TimeZoneTransition objects are semantically unequal.
-     * @stable ICU 4.0
-     */
-    UBool operator!=(const TimeZoneTransition& that) const;
-
-    /**
-     * Returns the time of transition in milliseconds.
-     * @return The time of the transition in milliseconds since the 1970 Jan 1 epoch time.
-     * @stable ICU 4.0
-     */
-    UDate getTime(void) const;
-
-    /**
-     * Sets the time of transition in milliseconds.
-     * @param time The time of the transition in milliseconds since the 1970 Jan 1 epoch time.
-     * @stable ICU 4.0
-     */
-    void setTime(UDate time);
-
-    /**
-     * Returns the rule used before the transition.
-     * @return The time zone rule used after the transition.
-     * @stable ICU 4.0
-     */
-    const TimeZoneRule* getFrom(void) const;
-
-    /**
-     * Sets the rule used before the transition.  The caller remains
-     * responsible for deleting the <code>TimeZoneRule</code> object.
-     * @param from The time zone rule used before the transition.
-     * @stable ICU 4.0
-     */
-    void setFrom(const TimeZoneRule& from);
-
-    /**
-     * Adopts the rule used before the transition.  The caller must
-     * not delete the <code>TimeZoneRule</code> object passed in.
-     * @param from The time zone rule used before the transition.
-     * @stable ICU 4.0
-     */
-    void adoptFrom(TimeZoneRule* from);
-
-    /**
-     * Sets the rule used after the transition.  The caller remains
-     * responsible for deleting the <code>TimeZoneRule</code> object.
-     * @param to The time zone rule used after the transition.
-     * @stable ICU 4.0
-     */
-    void setTo(const TimeZoneRule& to);
-
-    /**
-     * Adopts the rule used after the transition.  The caller must
-     * not delete the <code>TimeZoneRule</code> object passed in.
-     * @param to The time zone rule used after the transition.
-     * @stable ICU 4.0
-     */
-    void adoptTo(TimeZoneRule* to);
-
-    /**
-     * Returns the rule used after the transition.
-     * @return The time zone rule used after the transition.
-     * @stable ICU 4.0
-     */
-    const TimeZoneRule* getTo(void) const;
-
-private:
-    UDate   fTime;
-    TimeZoneRule*   fFrom;
-    TimeZoneRule*   fTo;
-
-public:
-    /**
-     * Return the class ID for this class. This is useful only for comparing to
-     * a return value from getDynamicClassID(). For example:
-     * <pre>
-     * .   Base* polymorphic_pointer = createPolymorphicObject();
-     * .   if (polymorphic_pointer->getDynamicClassID() ==
-     * .       erived::getStaticClassID()) ...
-     * </pre>
-     * @return          The class ID for all objects of this class.
-     * @stable ICU 4.0
-     */
-    static UClassID U_EXPORT2 getStaticClassID(void);
-
-    /**
-     * Returns a unique class ID POLYMORPHICALLY. Pure virtual override. This
-     * method is to implement a simple version of RTTI, since not all C++
-     * compilers support genuine RTTI. Polymorphic operator==() and clone()
-     * methods call this method.
-     *
-     * @return          The class ID for this object. All objects of a
-     *                  given class have the same class ID.  Objects of
-     *                  other classes have different class IDs.
-     * @stable ICU 4.0
-     */
-    virtual UClassID getDynamicClassID(void) const;
-};
-
-U_NAMESPACE_END
-
-#endif /* #if !UCONFIG_NO_FORMATTING */
-
-#endif // TZTRANS_H
-
-//eof


[50/57] [abbrv] couchdb commit: updated refs/heads/1994-merge-rcouch-multi-repo to b19d055

Posted by be...@apache.org.
remove couch_mrview


Project: http://git-wip-us.apache.org/repos/asf/couchdb/repo
Commit: http://git-wip-us.apache.org/repos/asf/couchdb/commit/75150a18
Tree: http://git-wip-us.apache.org/repos/asf/couchdb/tree/75150a18
Diff: http://git-wip-us.apache.org/repos/asf/couchdb/diff/75150a18

Branch: refs/heads/1994-merge-rcouch-multi-repo
Commit: 75150a181219f06e0aebee6538fb655cf6ca2a40
Parents: 4c39d7a
Author: Benoit Chesneau <bc...@gmail.com>
Authored: Thu Feb 13 16:39:28 2014 +0100
Committer: Benoit Chesneau <bc...@gmail.com>
Committed: Thu Feb 13 16:39:28 2014 +0100

----------------------------------------------------------------------
 apps/couch_mrview/include/couch_mrview.hrl      |  86 --
 apps/couch_mrview/src/couch_mrview.app.src      |  28 -
 apps/couch_mrview/src/couch_mrview.erl          | 509 ----------
 apps/couch_mrview/src/couch_mrview_changes.erl  | 195 ----
 apps/couch_mrview/src/couch_mrview_cleanup.erl  |  45 -
 .../couch_mrview/src/couch_mrview_compactor.erl | 248 -----
 apps/couch_mrview/src/couch_mrview_http.erl     | 429 ---------
 apps/couch_mrview/src/couch_mrview_index.erl    | 180 ----
 apps/couch_mrview/src/couch_mrview_show.erl     | 368 -------
 .../couch_mrview/src/couch_mrview_test_util.erl | 111 ---
 apps/couch_mrview/src/couch_mrview_updater.erl  | 424 ---------
 apps/couch_mrview/src/couch_mrview_util.erl     | 950 -------------------
 apps/couch_mrview/test/01-load.t                |  35 -
 apps/couch_mrview/test/02-map-views.t           | 131 ---
 apps/couch_mrview/test/03-red-views.t           |  81 --
 apps/couch_mrview/test/04-index-info.t          |  62 --
 apps/couch_mrview/test/05-collation.t           | 166 ----
 apps/couch_mrview/test/06-all-docs.t            | 129 ---
 apps/couch_mrview/test/07-compact-swap.t        |  62 --
 apps/couch_mrview/test/08-changes_since.t       | 157 ---
 apps/couch_mrview/test/09-index-events.t        |  74 --
 apps/couch_mrview/test/10-index-changes.t       | 217 -----
 22 files changed, 4687 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/couchdb/blob/75150a18/apps/couch_mrview/include/couch_mrview.hrl
----------------------------------------------------------------------
diff --git a/apps/couch_mrview/include/couch_mrview.hrl b/apps/couch_mrview/include/couch_mrview.hrl
deleted file mode 100644
index 8c51932..0000000
--- a/apps/couch_mrview/include/couch_mrview.hrl
+++ /dev/null
@@ -1,86 +0,0 @@
-% Licensed 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.
-
--record(mrst, {
-    sig=nil,
-    fd=nil,
-    refc,
-    db_name,
-    idx_name,
-    language,
-    design_opts=[],
-    seq_indexed=false,
-    lib,
-    views,
-    id_btree=nil,
-    log_btree=nil,
-    update_seq=0,
-    purge_seq=0,
-    first_build,
-    partial_resp_pid,
-    doc_acc,
-    doc_queue,
-    write_queue,
-    qserver=nil
-}).
-
-
--record(mrview, {
-    id_num,
-    update_seq=0,
-    purge_seq=0,
-    map_names=[],
-    reduce_funs=[],
-    def,
-    btree=nil,
-    seq_btree=nil,
-    key_byseq_btree=nil,
-    seq_indexed=false,
-    options=[]
-}).
-
-
--record(mrheader, {
-    seq=0,
-    purge_seq=0,
-    id_btree_state=nil,
-    log_btree_state=nil,
-    view_states=nil
-}).
-
-
--record(mrargs, {
-    view_type,
-    reduce,
-
-    preflight_fun,
-
-    start_key,
-    start_key_docid,
-    end_key,
-    end_key_docid,
-    keys,
-
-    direction = fwd,
-    limit = 16#10000000,
-    skip = 0,
-    group_level = 0,
-    stale = false,
-    inclusive_end = true,
-    include_docs = false,
-    doc_options = [],
-    update_seq=false,
-    conflicts,
-    callback,
-    list,
-    extra = []
-}).

http://git-wip-us.apache.org/repos/asf/couchdb/blob/75150a18/apps/couch_mrview/src/couch_mrview.app.src
----------------------------------------------------------------------
diff --git a/apps/couch_mrview/src/couch_mrview.app.src b/apps/couch_mrview/src/couch_mrview.app.src
deleted file mode 100644
index cce2c97..0000000
--- a/apps/couch_mrview/src/couch_mrview.app.src
+++ /dev/null
@@ -1,28 +0,0 @@
-% Licensed 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.
-
-{application, couch_mrview, [
-    {description, "CouchDB Map/Reduce Views"},
-    {vsn, "1.3.0"},
-    {modules, [
-        couch_mrview,
-        couch_mrview_compactor,
-        couch_mrview_http,
-        couch_mrview_index,
-        couch_mrview_show,
-        couch_mrview_test_util,
-        couch_mrview_updater,
-        couch_mrview_util
-    ]},
-    {registered, []},
-    {applications, [kernel, stdlib, couch_index]}
-]}.

http://git-wip-us.apache.org/repos/asf/couchdb/blob/75150a18/apps/couch_mrview/src/couch_mrview.erl
----------------------------------------------------------------------
diff --git a/apps/couch_mrview/src/couch_mrview.erl b/apps/couch_mrview/src/couch_mrview.erl
deleted file mode 100644
index a578b85..0000000
--- a/apps/couch_mrview/src/couch_mrview.erl
+++ /dev/null
@@ -1,509 +0,0 @@
-% Licensed 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.
-
--module(couch_mrview).
-
--export([query_all_docs/2, query_all_docs/4]).
--export([query_view/3, query_view/4, query_view/6]).
--export([view_changes_since/6, view_changes_since/7]).
--export([count_view_changes_since/4, count_view_changes_since/5]).
--export([get_info/2]).
--export([get_view_info/3]).
--export([refresh/2]).
--export([compact/2, compact/3, cancel_compaction/2]).
--export([cleanup/1]).
-
--include_lib("couch/include/couch_db.hrl").
--include_lib("couch_mrview/include/couch_mrview.hrl").
-
--record(mracc, {
-    db,
-    meta_sent=false,
-    total_rows,
-    offset,
-    limit,
-    skip,
-    group_level,
-    doc_info,
-    callback,
-    user_acc,
-    last_go=ok,
-    reduce_fun,
-    update_seq,
-    args
-}).
-
-
-query_all_docs(Db, Args) ->
-    query_all_docs(Db, Args, fun default_cb/2, []).
-
-
-query_all_docs(Db, Args, Callback, Acc) when is_list(Args) ->
-    query_all_docs(Db, to_mrargs(Args), Callback, Acc);
-query_all_docs(Db, Args0, Callback, Acc) ->
-    Sig = couch_util:with_db(Db, fun(WDb) ->
-        {ok, Info} = couch_db:get_db_info(WDb),
-        couch_index_util:hexsig(couch_util:md5(term_to_binary(Info)))
-    end),
-    Args1 = Args0#mrargs{view_type=map},
-    Args2 = couch_mrview_util:validate_args(Args1),
-    {ok, Acc1} = case Args2#mrargs.preflight_fun of
-        PFFun when is_function(PFFun, 2) -> PFFun(Sig, Acc);
-        _ -> {ok, Acc}
-    end,
-    all_docs_fold(Db, Args2, Callback, Acc1).
-
-
-query_view(Db, DDoc, VName) ->
-    query_view(Db, DDoc, VName, #mrargs{}).
-
-
-query_view(Db, DDoc, VName, Args) when is_list(Args) ->
-    query_view(Db, DDoc, VName, to_mrargs(Args), fun default_cb/2, []);
-query_view(Db, DDoc, VName, Args) ->
-    query_view(Db, DDoc, VName, Args, fun default_cb/2, []).
-
-
-query_view(Db, DDoc, VName, Args, Callback, Acc) when is_list(Args) ->
-    query_view(Db, DDoc, VName, to_mrargs(Args), Callback, Acc);
-query_view(Db, DDoc, VName, Args0, Callback, Acc0) ->
-    {ok, VInfo, Sig, Args} = couch_mrview_util:get_view(Db, DDoc, VName, Args0),
-    {ok, Acc1} = case Args#mrargs.preflight_fun of
-        PFFun when is_function(PFFun, 2) -> PFFun(Sig, Acc0);
-        _ -> {ok, Acc0}
-    end,
-    query_view(Db, VInfo, Args, Callback, Acc1).
-
-
-query_view(Db, {Type, View}, Args, Callback, Acc) ->
-    case Type of
-        map -> map_fold(Db, View, Args, Callback, Acc);
-        red -> red_fold(Db, View, Args, Callback, Acc)
-    end.
-
-view_changes_since(Db, DDoc, VName, StartSeq, Fun, Acc) ->
-    view_changes_since(Db, DDoc, VName, StartSeq, Fun, [], Acc).
-
-view_changes_since(Db, DDoc, VName, StartSeq, Fun, Options, Acc) ->
-    Args0 = make_view_changes_args(Options),
-    {ok, {_, View}, _, Args} = couch_mrview_util:get_view(Db, DDoc, VName,
-                                                          Args0),
-    case View#mrview.seq_indexed of
-        true ->
-            OptList = make_view_changes_opts(StartSeq, Options, Args),
-            Btree = case is_key_byseq(Options) of
-                true -> View#mrview.key_byseq_btree;
-                _ -> View#mrview.seq_btree
-            end,
-            AccOut = lists:foldl(fun(Opts, Acc0) ->
-                        {ok, _R, A} = couch_mrview_util:fold_changes(
-                                    Btree, Fun, Acc0, Opts),
-                        A
-                end, Acc, OptList),
-            {ok, AccOut};
-        _ ->
-            {error, seqs_not_indexed}
-    end.
-
-
-count_view_changes_since(Db, DDoc, VName, SinceSeq) ->
-    count_view_changes_since(Db, DDoc, VName, SinceSeq, []).
-
-count_view_changes_since(Db, DDoc, VName, SinceSeq, Options) ->
-    Args0 = make_view_changes_args(Options),
-    {ok, {_, View}, _, Args} = couch_mrview_util:get_view(Db, DDoc, VName,
-                                                          Args0),
-    case View#mrview.seq_indexed of
-        true ->
-            OptList = make_view_changes_opts(SinceSeq, Options, Args),
-            Btree = case is_key_byseq(Options) of
-                true -> View#mrview.key_byseq_btree;
-                _ -> View#mrview.seq_btree
-            end,
-            lists:foldl(fun(Opts, Acc0) ->
-                            {ok, N} = couch_btree:fold_reduce(
-                                    Btree, fun(_SeqStart, PartialReds, 0) ->
-                                        {ok, couch_btree:final_reduce(
-                                                    Btree, PartialReds)}
-                                    end,
-                                0, Opts),
-                            Acc0 + N
-                    end, 0, OptList);
-        _ ->
-            {error, seqs_not_indexed}
-    end.
-
-
-get_info(Db, DDoc) ->
-    {ok, Pid} = couch_index_server:get_index(couch_mrview_index, Db, DDoc),
-    couch_index:get_info(Pid).
-
-
-%% get informations on a view
-get_view_info(Db, DDoc, VName) ->
-    {ok, {_, View}, _, _Args} = couch_mrview_util:get_view(Db, DDoc, VName,
-                                                          #mrargs{}),
-
-    %% get the total number of rows
-    {ok, TotalRows} =  couch_mrview_util:get_row_count(View),
-
-    %% get the total number of sequence logged in this view
-    SeqBtree = View#mrview.seq_btree,
-    {ok, TotalSeqs} = case SeqBtree of
-        nil -> {ok, 0};
-        _ ->
-            couch_btree:full_reduce(SeqBtree)
-    end,
-
-    {ok, [{seq_indexed, View#mrview.seq_indexed},
-          {update_seq, View#mrview.update_seq},
-          {purge_seq, View#mrview.purge_seq},
-          {total_rows, TotalRows},
-          {total_seqs, TotalSeqs}]}.
-
-
-
-%% @doc refresh a view index
-refresh(#db{name=DbName}, DDoc) ->
-    refresh(DbName, DDoc);
-
-refresh(Db, DDoc) ->
-    UpdateSeq = couch_util:with_db(Db, fun(WDb) ->
-                    couch_db:get_update_seq(WDb)
-            end),
-
-    case couch_index_server:get_index(couch_mrview_index, Db, DDoc) of
-        {ok, Pid} ->
-            case catch couch_index:get_state(Pid, UpdateSeq) of
-                {ok, _} -> ok;
-                Error -> {error, Error}
-            end;
-        Error ->
-            {error, Error}
-    end.
-
-compact(Db, DDoc) ->
-    compact(Db, DDoc, []).
-
-
-compact(Db, DDoc, Opts) ->
-    {ok, Pid} = couch_index_server:get_index(couch_mrview_index, Db, DDoc),
-    couch_index:compact(Pid, Opts).
-
-
-cancel_compaction(Db, DDoc) ->
-    {ok, IPid} = couch_index_server:get_index(couch_mrview_index, Db, DDoc),
-    {ok, CPid} = couch_index:get_compactor_pid(IPid),
-    ok = couch_index_compactor:cancel(CPid),
-
-    % Cleanup the compaction file if it exists
-    {ok, #mrst{sig=Sig, db_name=DbName}} = couch_index:get_state(IPid, 0),
-    couch_mrview_util:delete_compaction_file(DbName, Sig),
-    ok.
-
-
-cleanup(Db) ->
-    couch_mrview_cleanup:run(Db).
-
-
-all_docs_fold(Db, #mrargs{keys=undefined}=Args, Callback, UAcc) ->
-    {ok, Info} = couch_db:get_db_info(Db),
-    Total = couch_util:get_value(doc_count, Info),
-    UpdateSeq = couch_db:get_update_seq(Db),
-    Acc = #mracc{
-        db=Db,
-        total_rows=Total,
-        limit=Args#mrargs.limit,
-        skip=Args#mrargs.skip,
-        callback=Callback,
-        user_acc=UAcc,
-        reduce_fun=fun couch_mrview_util:all_docs_reduce_to_count/1,
-        update_seq=UpdateSeq,
-        args=Args
-    },
-    [Opts] = couch_mrview_util:all_docs_key_opts(Args),
-    {ok, Offset, FinalAcc} = couch_db:enum_docs(Db, fun map_fold/3, Acc, Opts),
-    finish_fold(FinalAcc, [{total, Total}, {offset, Offset}]);
-all_docs_fold(Db, #mrargs{direction=Dir, keys=Keys0}=Args, Callback, UAcc) ->
-    {ok, Info} = couch_db:get_db_info(Db),
-    Total = couch_util:get_value(doc_count, Info),
-    UpdateSeq = couch_db:get_update_seq(Db),
-    Acc = #mracc{
-        db=Db,
-        total_rows=Total,
-        limit=Args#mrargs.limit,
-        skip=Args#mrargs.skip,
-        callback=Callback,
-        user_acc=UAcc,
-        reduce_fun=fun couch_mrview_util:all_docs_reduce_to_count/1,
-        update_seq=UpdateSeq,
-        args=Args
-    },
-    % Backwards compatibility hack. The old _all_docs iterates keys
-    % in reverse if descending=true was passed. Here we'll just
-    % reverse the list instead.
-    Keys = if Dir =:= fwd -> Keys0; true -> lists:reverse(Keys0) end,
-
-    FoldFun = fun(Key, Acc0) ->
-        DocInfo = (catch couch_db:get_doc_info(Db, Key)),
-        {Doc, Acc1} = case DocInfo of
-            {ok, #doc_info{id=Id, revs=[RevInfo | _RestRevs]}=DI} ->
-                Rev = couch_doc:rev_to_str(RevInfo#rev_info.rev),
-                Props = [{rev, Rev}] ++ case RevInfo#rev_info.deleted of
-                    true -> [{deleted, true}];
-                    false -> []
-                end,
-                {{{Id, Id}, {Props}}, Acc0#mracc{doc_info=DI}};
-            not_found ->
-                {{{Key, error}, not_found}, Acc0}
-        end,
-        {_, Acc2} = map_fold(Doc, {[], [{0, 0, 0}]}, Acc1),
-        Acc2
-    end,
-    FinalAcc = lists:foldl(FoldFun, Acc, Keys),
-    finish_fold(FinalAcc, [{total, Total}]).
-
-
-map_fold(Db, View, Args, Callback, UAcc) ->
-    {ok, Total} = couch_mrview_util:get_row_count(View),
-    Acc = #mracc{
-        db=Db,
-        total_rows=Total,
-        limit=Args#mrargs.limit,
-        skip=Args#mrargs.skip,
-        callback=Callback,
-        user_acc=UAcc,
-        reduce_fun=fun couch_mrview_util:reduce_to_count/1,
-        update_seq=View#mrview.update_seq,
-        args=Args
-    },
-    OptList = couch_mrview_util:key_opts(Args),
-    {Reds, Acc2} = lists:foldl(fun(Opts, {_, Acc0}) ->
-        {ok, R, A} = couch_mrview_util:fold(View, fun map_fold/3, Acc0, Opts),
-        {R, A}
-    end, {nil, Acc}, OptList),
-    Offset = couch_mrview_util:reduce_to_count(Reds),
-    finish_fold(Acc2, [{total, Total}, {offset, Offset}]).
-
-
-map_fold(#full_doc_info{} = FullDocInfo, OffsetReds, Acc) ->
-    % matches for _all_docs and translates #full_doc_info{} -> KV pair
-    case couch_doc:to_doc_info(FullDocInfo) of
-        #doc_info{id=Id, revs=[#rev_info{deleted=false, rev=Rev}|_]} = DI ->
-            Value = {[{rev, couch_doc:rev_to_str(Rev)}]},
-            map_fold({{Id, Id}, Value}, OffsetReds, Acc#mracc{doc_info=DI});
-        #doc_info{revs=[#rev_info{deleted=true}|_]} ->
-            {ok, Acc}
-    end;
-map_fold(_KV, _Offset, #mracc{skip=N}=Acc) when N > 0 ->
-    {ok, Acc#mracc{skip=N-1, last_go=ok}};
-map_fold(KV, OffsetReds, #mracc{offset=undefined}=Acc) ->
-    #mracc{
-        total_rows=Total,
-        callback=Callback,
-        user_acc=UAcc0,
-        reduce_fun=Reduce,
-        update_seq=UpdateSeq,
-        args=Args
-    } = Acc,
-    Offset = Reduce(OffsetReds),
-    Meta = make_meta(Args, UpdateSeq, [{total, Total}, {offset, Offset}]),
-    {Go, UAcc1} = Callback(Meta, UAcc0),
-    Acc1 = Acc#mracc{meta_sent=true, offset=Offset, user_acc=UAcc1, last_go=Go},
-    case Go of
-        ok -> map_fold(KV, OffsetReds, Acc1);
-        stop -> {stop, Acc1}
-    end;
-map_fold(_KV, _Offset, #mracc{limit=0}=Acc) ->
-    {stop, Acc};
-map_fold({{Key, Id}, Val}, _Offset, Acc) ->
-    #mracc{
-        db=Db,
-        limit=Limit,
-        doc_info=DI,
-        callback=Callback,
-        user_acc=UAcc0,
-        args=Args
-    } = Acc,
-    Doc = case DI of
-        #doc_info{} -> couch_mrview_util:maybe_load_doc(Db, DI, Args);
-        _ -> couch_mrview_util:maybe_load_doc(Db, Id, Val, Args)
-    end,
-    Row = [{id, Id}, {key, Key}, {value, Val}] ++ Doc,
-    {Go, UAcc1} = Callback({row, Row}, UAcc0),
-    {Go, Acc#mracc{
-        limit=Limit-1,
-        doc_info=undefined,
-        user_acc=UAcc1,
-        last_go=Go
-    }}.
-
-
-red_fold(Db, {_Nth, _Lang, View}=RedView, Args, Callback, UAcc) ->
-    Acc = #mracc{
-        db=Db,
-        total_rows=null,
-        limit=Args#mrargs.limit,
-        skip=Args#mrargs.skip,
-        group_level=Args#mrargs.group_level,
-        callback=Callback,
-        user_acc=UAcc,
-        update_seq=View#mrview.update_seq,
-        args=Args
-    },
-    GroupFun = group_rows_fun(Args#mrargs.group_level),
-    OptList = couch_mrview_util:key_opts(Args, [{key_group_fun, GroupFun}]),
-    Acc2 = lists:foldl(fun(Opts, Acc0) ->
-        {ok, Acc1} =
-            couch_mrview_util:fold_reduce(RedView, fun red_fold/3,  Acc0, Opts),
-        Acc1
-    end, Acc, OptList),
-    finish_fold(Acc2, []).
-
-red_fold(_Key, _Red, #mracc{skip=N}=Acc) when N > 0 ->
-    {ok, Acc#mracc{skip=N-1, last_go=ok}};
-red_fold(Key, Red, #mracc{meta_sent=false}=Acc) ->
-    #mracc{
-        args=Args,
-        callback=Callback,
-        user_acc=UAcc0,
-        update_seq=UpdateSeq
-    } = Acc,
-    Meta = make_meta(Args, UpdateSeq, []),
-    {Go, UAcc1} = Callback(Meta, UAcc0),
-    Acc1 = Acc#mracc{user_acc=UAcc1, meta_sent=true, last_go=Go},
-    case Go of
-        ok -> red_fold(Key, Red, Acc1);
-        _ -> {Go, Acc1}
-    end;
-red_fold(_Key, _Red, #mracc{limit=0} = Acc) ->
-    {stop, Acc};
-red_fold(_Key, Red, #mracc{group_level=0} = Acc) ->
-    #mracc{
-        limit=Limit,
-        callback=Callback,
-        user_acc=UAcc0
-    } = Acc,
-    Row = [{key, null}, {value, Red}],
-    {Go, UAcc1} = Callback({row, Row}, UAcc0),
-    {Go, Acc#mracc{user_acc=UAcc1, limit=Limit-1, last_go=Go}};
-red_fold(Key, Red, #mracc{group_level=exact} = Acc) ->
-    #mracc{
-        limit=Limit,
-        callback=Callback,
-        user_acc=UAcc0
-    } = Acc,
-    Row = [{key, Key}, {value, Red}],
-    {Go, UAcc1} = Callback({row, Row}, UAcc0),
-    {Go, Acc#mracc{user_acc=UAcc1, limit=Limit-1, last_go=Go}};
-red_fold(K, Red, #mracc{group_level=I} = Acc) when I > 0, is_list(K) ->
-    #mracc{
-        limit=Limit,
-        callback=Callback,
-        user_acc=UAcc0
-    } = Acc,
-    Row = [{key, lists:sublist(K, I)}, {value, Red}],
-    {Go, UAcc1} = Callback({row, Row}, UAcc0),
-    {Go, Acc#mracc{user_acc=UAcc1, limit=Limit-1, last_go=Go}};
-red_fold(K, Red, #mracc{group_level=I} = Acc) when I > 0 ->
-    #mracc{
-        limit=Limit,
-        callback=Callback,
-        user_acc=UAcc0
-    } = Acc,
-    Row = [{key, K}, {value, Red}],
-    {Go, UAcc1} = Callback({row, Row}, UAcc0),
-    {Go, Acc#mracc{user_acc=UAcc1, limit=Limit-1, last_go=Go}}.
-
-
-finish_fold(#mracc{last_go=ok, update_seq=UpdateSeq}=Acc,  ExtraMeta) ->
-    #mracc{callback=Callback, user_acc=UAcc, args=Args}=Acc,
-    % Possible send meta info
-    Meta = make_meta(Args, UpdateSeq, ExtraMeta),
-    {Go, UAcc1} = case Acc#mracc.meta_sent of
-        false -> Callback(Meta, UAcc);
-        _ -> {ok, Acc#mracc.user_acc}
-    end,
-    % Notify callback that the fold is complete.
-    {_, UAcc2} = case Go of
-        ok -> Callback(complete, UAcc1);
-        _ -> {ok, UAcc1}
-    end,
-    {ok, UAcc2};
-finish_fold(#mracc{user_acc=UAcc}, _ExtraMeta) ->
-    {ok, UAcc}.
-
-
-make_meta(Args, UpdateSeq, Base) ->
-    case Args#mrargs.update_seq of
-        true -> {meta, Base ++ [{update_seq, UpdateSeq}]};
-        _ -> {meta, Base}
-    end.
-
-
-group_rows_fun(exact) ->
-    fun({Key1,_}, {Key2,_}) -> Key1 == Key2 end;
-group_rows_fun(0) ->
-    fun(_A, _B) -> true end;
-group_rows_fun(GroupLevel) when is_integer(GroupLevel) ->
-    fun({[_|_] = Key1,_}, {[_|_] = Key2,_}) ->
-        lists:sublist(Key1, GroupLevel) == lists:sublist(Key2, GroupLevel);
-    ({Key1,_}, {Key2,_}) ->
-        Key1 == Key2
-    end.
-
-
-default_cb(complete, Acc) ->
-    {ok, lists:reverse(Acc)};
-default_cb({final, Info}, []) ->
-    {ok, [Info]};
-default_cb({final, _}, Acc) ->
-    {ok, Acc};
-default_cb(Row, Acc) ->
-    {ok, [Row | Acc]}.
-
-
-to_mrargs(KeyList) ->
-    lists:foldl(fun({Key, Value}, Acc) ->
-        Index = lookup_index(couch_util:to_existing_atom(Key)),
-        setelement(Index, Acc, Value)
-    end, #mrargs{}, KeyList).
-
-
-lookup_index(Key) ->
-    Index = lists:zip(
-        record_info(fields, mrargs), lists:seq(2, record_info(size, mrargs))
-    ),
-    couch_util:get_value(Key, Index).
-
-
-is_key_byseq(Options) ->
-    lists:any(fun({K, _}) ->
-                lists:member(K, [start_key, end_key, start_key_docid,
-                                 end_key_docid, keys])
-        end, Options).
-
-make_view_changes_args(Options) ->
-    case is_key_byseq(Options) of
-        true ->
-            to_mrargs(Options);
-        false ->
-            #mrargs{}
-    end.
-
-make_view_changes_opts(StartSeq, Options, Args) ->
-    case is_key_byseq(Options) of
-        true ->
-            couch_mrview_util:changes_key_opts(StartSeq, Args);
-        false ->
-            [[{start_key, {StartSeq+1, <<>>}}] ++ Options]
-    end.

http://git-wip-us.apache.org/repos/asf/couchdb/blob/75150a18/apps/couch_mrview/src/couch_mrview_changes.erl
----------------------------------------------------------------------
diff --git a/apps/couch_mrview/src/couch_mrview_changes.erl b/apps/couch_mrview/src/couch_mrview_changes.erl
deleted file mode 100644
index c31624e..0000000
--- a/apps/couch_mrview/src/couch_mrview_changes.erl
+++ /dev/null
@@ -1,195 +0,0 @@
-% Licensed 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.
-%
--module(couch_mrview_changes).
-
--export([handle_changes/6]).
-
--include_lib("couch/include/couch_db.hrl").
-
--record(vst, {dbname,
-              ddoc,
-              view,
-              view_options,
-              since,
-              callback,
-              acc,
-              user_timeout,
-              timeout,
-              heartbeat,
-              timeout_acc=0,
-              notifier,
-              stream,
-              refresh}).
-
--type changes_stream() :: true | false | once.
--type changes_options() :: [{stream, changes_stream()} |
-                            {since, integer()} |
-                            {view_options, list()} |
-                            {timeout, integer()} |
-                            {heartbeat, true | integer()} |
-                            {refresh, true | false}].
-
--export_type([changes_stream/0]).
--export_type([changes_options/0]).
-
-%% @doc function returning changes in a streaming fashion if needed.
--spec handle_changes(binary(), binary(), binary(), function(), term(),
-                     changes_options()) -> ok | {error, term()}.
-handle_changes(DbName, DDocId, View, Fun, Acc, Options) ->
-    Since = proplists:get_value(since, Options, 0),
-    Stream = proplists:get_value(stream, Options, false),
-    ViewOptions = proplists:get_value(view_options, Options, []),
-    Refresh = proplists:get_value(refresh, Options, false),
-
-    State0 = #vst{dbname=DbName,
-                  ddoc=DDocId,
-                  view=View,
-                  view_options=ViewOptions,
-                  since=Since,
-                  callback=Fun,
-                  acc=Acc},
-
-    maybe_acquire_indexer(Refresh, DbName, DDocId),
-    try
-        case view_changes_since(State0) of
-            {ok, #vst{since=LastSeq, acc=Acc2}=State} ->
-                case Stream of
-                    true ->
-                        start_loop(State#vst{stream=true}, Options);
-                    once when LastSeq =:= Since ->
-                        start_loop(State#vst{stream=once}, Options);
-                    _ ->
-                        Fun(stop, {LastSeq, Acc2})
-                end;
-            {stop, #vst{since=LastSeq, acc=Acc2}} ->
-                Fun(stop, {LastSeq, Acc2});
-            Error ->
-                Error
-        end
-    after
-        maybe_release_indexer(Refresh, DbName, DDocId)
-    end.
-
-start_loop(#vst{dbname=DbName, ddoc=DDocId}=State, Options) ->
-    {UserTimeout, Timeout, Heartbeat} = changes_timeout(Options),
-    Notifier = index_update_notifier(DbName, DDocId),
-    try
-        loop(State#vst{notifier=Notifier,
-                       user_timeout=UserTimeout,
-                       timeout=Timeout,
-                       heartbeat=Heartbeat})
-    after
-        couch_index_event:stop(Notifier)
-    end.
-
-loop(#vst{since=Since, callback=Callback, acc=Acc,
-          user_timeout=UserTimeout, timeout=Timeout,
-          heartbeat=Heartbeat, timeout_acc=TimeoutAcc,
-          stream=Stream}=State) ->
-    receive
-        index_update ->
-            case view_changes_since(State) of
-                {ok, State2} when Stream =:= true ->
-                    loop(State2#vst{timeout_acc=0});
-                {ok, #vst{since=LastSeq, acc=Acc2}} ->
-                    Callback(stop, {LastSeq, Acc2});
-                {stop, #vst{since=LastSeq, acc=Acc2}} ->
-                    Callback(stop, {LastSeq, Acc2})
-            end;
-        index_delete ->
-            Callback(stop, {Since, Acc})
-    after Timeout ->
-            TimeoutAcc2 = TimeoutAcc + Timeout,
-            case UserTimeout =< TimeoutAcc2 of
-                true ->
-                    Callback(stop, {Since, Acc});
-                false when Heartbeat =:= true ->
-                    case Callback(heartbeat, Acc) of
-                        {ok, Acc2} ->
-                            loop(State#vst{acc=Acc2, timeout_acc=TimeoutAcc2});
-                        {stop, Acc2} ->
-                            Callback(stop, {Since, Acc2})
-                    end;
-                _ ->
-                    Callback(stop, {Since, Acc})
-            end
-    end.
-
-changes_timeout(Options) ->
-    DefaultTimeout = list_to_integer(
-            couch_config:get("httpd", "changes_timeout", "60000")
-    ),
-    UserTimeout = proplists:get_value(timeout, Options, DefaultTimeout),
-    {Timeout, Heartbeat} = case proplists:get_value(heartbeat, Options) of
-        undefined -> {UserTimeout, false};
-        true ->
-            T = erlang:min(DefaultTimeout, UserTimeout),
-            {T, true};
-        H ->
-            T = erlang:min(H, UserTimeout),
-            {T, true}
-    end,
-    {UserTimeout, Timeout, Heartbeat}.
-
-view_changes_since(#vst{dbname=DbName, ddoc=DDocId, view=View,
-                        view_options=Options, since=Since,
-                        callback=Callback, acc=UserAcc}=State) ->
-    Wrapper = fun ({{Seq, _Key, _DocId}, _Val}=KV, {Go, Acc2, OldSeq}) ->
-            LastSeq = if OldSeq < Seq -> Seq;
-                true -> OldSeq
-            end,
-
-            {Go, Acc3} = Callback(KV, Acc2),
-            {Go, {Go, Acc3, LastSeq}}
-    end,
-
-    Acc0 = {ok, UserAcc, Since},
-    case couch_mrview:view_changes_since(DbName, DDocId, View, Since,
-                                         Wrapper, Options, Acc0) of
-        {ok, {Go, UserAcc2, Since2}}->
-            {Go, State#vst{since=Since2, acc=UserAcc2}};
-        Error ->
-            Error
-    end.
-
-index_update_notifier(#db{name=DbName}, DDocId) ->
-    index_update_notifier(DbName, DDocId);
-index_update_notifier(DbName, DDocId) ->
-    Self = self(),
-    {ok, NotifierPid} = couch_index_event:start_link(fun
-                ({index_update, {Name, Id, couch_mrview_index}})
-                        when Name =:= DbName, Id =:= DDocId ->
-                    Self ! index_update;
-                ({index_delete, {Name, Id, couch_mrview_index}})
-                        when Name =:= DbName, Id =:= DDocId ->
-                    Self ! index_delete;
-                (_) ->
-                    ok
-            end),
-    NotifierPid.
-
-%% acquire the background indexing task so it can eventually be started
-%% if the process close the background task will be automatically
-%% released.
-maybe_acquire_indexer(false, _, _) ->
-    ok;
-maybe_acquire_indexer(true, DbName, DDocId) ->
-    couch_index_server:acquire_indexer(couch_mrview_index, DbName,
-                                       DDocId).
-
-%% release the background indexing task so it can eventually be stopped
-maybe_release_indexer(false, _, _) ->
-    ok;
-maybe_release_indexer(true, DbName, DDocId) ->
-    couch_index_server:release_indexer(couch_mrview_index, DbName,
-                                       DDocId).

http://git-wip-us.apache.org/repos/asf/couchdb/blob/75150a18/apps/couch_mrview/src/couch_mrview_cleanup.erl
----------------------------------------------------------------------
diff --git a/apps/couch_mrview/src/couch_mrview_cleanup.erl b/apps/couch_mrview/src/couch_mrview_cleanup.erl
deleted file mode 100644
index 0593570..0000000
--- a/apps/couch_mrview/src/couch_mrview_cleanup.erl
+++ /dev/null
@@ -1,45 +0,0 @@
-% Licensed 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
-%-include_lib("couch/include/couch_db.hrl").
-%   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.
-
--module(couch_mrview_cleanup).
-
--export([run/1]).
-
--include_lib("couch/include/couch_db.hrl").
--include_lib("couch_mrview/include/couch_mrview.hrl").
-
-run(Db) ->
-    RootDir = couch_index_util:root_dir(),
-    DbName = couch_db:name(Db),
-
-    DesignDocs = couch_db:get_design_docs(Db),
-    SigFiles = lists:foldl(fun(DDocInfo, SFAcc) ->
-        {ok, DDoc} = couch_db:open_doc_int(Db, DDocInfo, [ejson_body]),
-        {ok, InitState} = couch_mrview_util:ddoc_to_mrst(DbName, DDoc),
-        Sig = InitState#mrst.sig,
-        IFName = couch_mrview_util:index_file(DbName, Sig),
-        CFName = couch_mrview_util:compaction_file(DbName, Sig),
-        [IFName, CFName | SFAcc]
-    end, [], [DD || DD <- DesignDocs, DD#full_doc_info.deleted == false]),
-
-    IdxDir = couch_index_util:index_dir(mrview, DbName),
-    DiskFiles = filelib:wildcard(filename:join(IdxDir, "*")),
-
-    % We need to delete files that have no ddoc.
-    ToDelete = DiskFiles -- SigFiles,
-
-    lists:foreach(fun(FN) ->
-        ?LOG_DEBUG("Deleting stale view file: ~s", [FN]),
-        couch_file:delete(RootDir, FN, false)
-    end, ToDelete),
-
-    ok.

http://git-wip-us.apache.org/repos/asf/couchdb/blob/75150a18/apps/couch_mrview/src/couch_mrview_compactor.erl
----------------------------------------------------------------------
diff --git a/apps/couch_mrview/src/couch_mrview_compactor.erl b/apps/couch_mrview/src/couch_mrview_compactor.erl
deleted file mode 100644
index a7e594f..0000000
--- a/apps/couch_mrview/src/couch_mrview_compactor.erl
+++ /dev/null
@@ -1,248 +0,0 @@
-% Licensed 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.
-
--module(couch_mrview_compactor).
-
--include_lib("couch/include/couch_db.hrl").
--include_lib("couch_mrview/include/couch_mrview.hrl").
-
--export([compact/3, swap_compacted/2]).
-
--record(acc, {
-   btree = nil,
-   last_id = nil,
-   kvs = [],
-   kvs_size = 0,
-   changes = 0,
-   total_changes
-}).
-
-
-compact(_Db, State, Opts) ->
-    case lists:member(recompact, Opts) of
-        false -> compact(State);
-        true -> recompact(State)
-    end.
-
-compact(State) ->
-    #mrst{
-        db_name=DbName,
-        idx_name=IdxName,
-        sig=Sig,
-        update_seq=Seq,
-        id_btree=IdBtree,
-        log_btree=LogBtree,
-        seq_indexed=SeqIndexed,
-        views=Views
-    } = State,
-
-    {EmptyState, NumDocIds} = couch_util:with_db(DbName, fun(Db) ->
-        CompactFName = couch_mrview_util:compaction_file(DbName, Sig),
-        {ok, Fd} = couch_mrview_util:open_file(CompactFName),
-        ESt = couch_mrview_util:reset_index(Db, Fd, State),
-
-        {ok, DbReduce} = couch_btree:full_reduce(Db#db.fulldocinfo_by_id_btree),
-        Count = element(1, DbReduce),
-
-        {ESt, Count}
-    end),
-
-    #mrst{
-        id_btree = EmptyIdBtree,
-        log_btree = EmptyLogBtree,
-        views = EmptyViews
-    } = EmptyState,
-
-    TotalChanges0 = case SeqIndexed of
-        true -> NumDocIds * 2;
-        _ -> NumDocIds
-    end,
-
-    TotalChanges = lists:foldl(
-        fun(View, Acc) ->
-            {ok, Kvs} = couch_mrview_util:get_row_count(View),
-            case SeqIndexed of
-                true ->
-                    {ok, SKvs} = couch_mrview_util:get_view_changes_count(View),
-                    Acc + Kvs + SKvs * 2;
-                false ->
-                    Acc + Kvs
-            end
-        end,
-        TotalChanges0, Views),
-
-    couch_task_status:add_task([
-        {type, view_compaction},
-        {database, DbName},
-        {design_document, IdxName},
-        {progress, 0}
-    ]),
-
-    BufferSize0 = couch_config:get(
-        "view_compaction", "keyvalue_buffer_size", "2097152"
-    ),
-    BufferSize = list_to_integer(BufferSize0),
-
-    FoldFun = fun({DocId, _} = KV, Acc) ->
-        #acc{btree = Bt, kvs = Kvs, kvs_size = KvsSize, last_id = LastId} = Acc,
-        if DocId =:= LastId ->
-            % COUCHDB-999 regression test
-            ?LOG_ERROR("Duplicate docid `~s` detected in view group `~s`"
-                ++ ", database `~s` - This view needs to be rebuilt.",
-                [DocId, IdxName, DbName]
-            ),
-            exit({view_duplicate_id, DocId});
-        true -> ok end,
-        KvsSize2 = KvsSize + ?term_size(KV),
-        case KvsSize2 >= BufferSize of
-            true ->
-                {ok, Bt2} = couch_btree:add(Bt, lists:reverse([KV | Kvs])),
-                Acc2 = update_task(Acc, 1 + length(Kvs)),
-                {ok, Acc2#acc{
-                    btree = Bt2, kvs = [], kvs_size = 0, last_id = DocId}};
-            _ ->
-                {ok, Acc#acc{
-                    kvs = [KV | Kvs], kvs_size = KvsSize2, last_id = DocId}}
-        end
-    end,
-
-    InitAcc = #acc{total_changes = TotalChanges, btree = EmptyIdBtree},
-    {ok, _, FinalAcc} = couch_btree:foldl(IdBtree, FoldFun, InitAcc),
-    #acc{btree = Bt3, kvs = Uncopied} = FinalAcc,
-    {ok, NewIdBtree} = couch_btree:add(Bt3, lists:reverse(Uncopied)),
-    FinalAcc2 = update_task(FinalAcc, length(Uncopied)),
-
-
-    {NewLogBtree, FinalAcc3} = case SeqIndexed of
-        true ->
-            compact_log(LogBtree, BufferSize,
-                        FinalAcc2#acc{kvs=[],
-                                      kvs_size=0,
-                                      btree=EmptyLogBtree});
-        _ ->
-            {nil, FinalAcc2}
-    end,
-
-    {NewViews, _} = lists:mapfoldl(fun({View, EmptyView}, Acc) ->
-        compact_view(View, EmptyView, BufferSize, Acc)
-    end, FinalAcc3, lists:zip(Views, EmptyViews)),
-
-    unlink(EmptyState#mrst.fd),
-    {ok, EmptyState#mrst{
-        id_btree=NewIdBtree,
-        log_btree=NewLogBtree,
-        views=NewViews,
-        update_seq=Seq
-    }}.
-
-
-recompact(State) ->
-    link(State#mrst.fd),
-    {Pid, Ref} = erlang:spawn_monitor(fun() ->
-        couch_index_updater:update(couch_mrview_index, State)
-    end),
-    receive
-        {'DOWN', Ref, _, _, {updated, Pid, State2}} ->
-            unlink(State#mrst.fd),
-            {ok, State2}
-    end.
-
-compact_log(LogBtree, BufferSize, Acc0) ->
-    FoldFun = fun({DocId, _} = KV, Acc) ->
-        #acc{btree = Bt, kvs = Kvs, kvs_size = KvsSize} = Acc,
-        KvsSize2 = KvsSize + ?term_size(KV),
-        case KvsSize2 >= BufferSize of
-            true ->
-                {ok, Bt2} = couch_btree:add(Bt, lists:reverse([KV | Kvs])),
-                Acc2 = update_task(Acc, 1 + length(Kvs)),
-                {ok, Acc2#acc{
-                    btree = Bt2, kvs = [], kvs_size = 0}};
-            _ ->
-                {ok, Acc#acc{
-                    kvs = [KV | Kvs], kvs_size = KvsSize2}}
-        end
-    end,
-
-    {ok, _, FinalAcc} = couch_btree:foldl(LogBtree, FoldFun, Acc0),
-    #acc{btree = Bt3, kvs = Uncopied} = FinalAcc,
-    {ok, NewLogBtree} = couch_btree:add(Bt3, lists:reverse(Uncopied)),
-    FinalAcc2 = update_task(FinalAcc, length(Uncopied)),
-    {NewLogBtree, FinalAcc2}.
-
-%% @spec compact_view(View, EmptyView, Retry, Acc) -> {CompactView, NewAcc}
-compact_view(View, EmptyView, BufferSize, Acc0) ->
-
-    {NewBt, Acc1} = compact_view_btree(View#mrview.btree,
-                                       EmptyView#mrview.btree,
-                                       BufferSize, Acc0),
-
-    %% are we indexing changes by sequences?
-    {NewSeqBt, NewKeyBySeqBt, FinalAcc} = case View#mrview.seq_indexed of
-        true ->
-            {SBt, Acc2} = compact_view_btree(View#mrview.seq_btree,
-                                             EmptyView#mrview.seq_btree,
-                                             BufferSize, Acc1),
-            {KSBt, Acc3} = compact_view_btree(View#mrview.key_byseq_btree,
-                                              EmptyView#mrview.key_byseq_btree,
-                                              BufferSize, Acc2),
-            {SBt, KSBt, Acc3};
-        _ ->
-            {nil, nil, Acc1}
-    end,
-    {EmptyView#mrview{btree=NewBt,
-                      seq_btree=NewSeqBt,
-                      key_byseq_btree=NewKeyBySeqBt}, FinalAcc}.
-
-compact_view_btree(Btree, EmptyBtree, BufferSize, Acc0) ->
-    Fun = fun(KV, #acc{btree = Bt, kvs = Kvs, kvs_size = KvsSize} = Acc) ->
-        KvsSize2 = KvsSize + ?term_size(KV),
-        if KvsSize2 >= BufferSize ->
-            {ok, Bt2} = couch_btree:add(Bt, lists:reverse([KV | Kvs])),
-            Acc2 = update_task(Acc, 1 + length(Kvs)),
-            {ok, Acc2#acc{btree = Bt2, kvs = [], kvs_size = 0}};
-        true ->
-            {ok, Acc#acc{kvs = [KV | Kvs], kvs_size = KvsSize2}}
-        end
-    end,
-
-    InitAcc = Acc0#acc{kvs = [], kvs_size = 0, btree = EmptyBtree},
-    {ok, _, FinalAcc} = couch_btree:foldl(Btree, Fun, InitAcc),
-    #acc{btree = Bt3, kvs = Uncopied} = FinalAcc,
-    {ok, NewBt} = couch_btree:add(Bt3, lists:reverse(Uncopied)),
-    FinalAcc2 = update_task(FinalAcc, length(Uncopied)),
-    {NewBt, FinalAcc2}.
-
-update_task(#acc{changes = Changes, total_changes = Total} = Acc, ChangesInc) ->
-    Changes2 = Changes + ChangesInc,
-    couch_task_status:update([{progress, (Changes2 * 100) div Total}]),
-    Acc#acc{changes = Changes2}.
-
-
-swap_compacted(OldState, NewState) ->
-    #mrst{
-        sig=Sig,
-        db_name=DbName
-    } = NewState,
-
-    link(NewState#mrst.fd),
-
-    RootDir = couch_index_util:root_dir(),
-    IndexFName = couch_mrview_util:index_file(DbName, Sig),
-    CompactFName = couch_mrview_util:compaction_file(DbName, Sig),
-    ok = couch_file:delete(RootDir, IndexFName),
-    ok = file:rename(CompactFName, IndexFName),
-
-    unlink(OldState#mrst.fd),
-    couch_ref_counter:drop(OldState#mrst.refc),
-    {ok, NewRefCounter} = couch_ref_counter:start([NewState#mrst.fd]),
-
-    {ok, NewState#mrst{refc=NewRefCounter}}.

http://git-wip-us.apache.org/repos/asf/couchdb/blob/75150a18/apps/couch_mrview/src/couch_mrview_http.erl
----------------------------------------------------------------------
diff --git a/apps/couch_mrview/src/couch_mrview_http.erl b/apps/couch_mrview/src/couch_mrview_http.erl
deleted file mode 100644
index 64c9fb1..0000000
--- a/apps/couch_mrview/src/couch_mrview_http.erl
+++ /dev/null
@@ -1,429 +0,0 @@
-% Licensed 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.
-
--module(couch_mrview_http).
-
--export([
-    handle_all_docs_req/2,
-    handle_view_req/3,
-    handle_temp_view_req/2,
-    handle_info_req/3,
-    handle_compact_req/3,
-    handle_cleanup_req/2,
-    parse_qs/2
-]).
-
--export([parse_boolean/1,
-         parse_int/1,
-         parse_pos_int/1]).
-
--include_lib("couch/include/couch_db.hrl").
--include_lib("couch_mrview/include/couch_mrview.hrl").
-
-
--record(vacc, {
-    db,
-    req,
-    resp,
-    prepend,
-    etag
-}).
-
-
-handle_all_docs_req(#httpd{method='GET'}=Req, Db) ->
-    all_docs_req(Req, Db, undefined);
-handle_all_docs_req(#httpd{method='POST'}=Req, Db) ->
-    Keys = get_view_keys(couch_httpd:json_body_obj(Req)),
-    all_docs_req(Req, Db, Keys);
-handle_all_docs_req(Req, _Db) ->
-    couch_httpd:send_method_not_allowed(Req, "GET,POST,HEAD").
-
-
-handle_view_req(#httpd{method='GET',
-                      path_parts=[_, _, DDocName, _, VName, <<"_info">>]}=Req,
-                Db, _DDoc) ->
-
-    DDocId = <<"_design/", DDocName/binary >>,
-    {ok, Info} = couch_mrview:get_view_info(Db#db.name, DDocId, VName),
-
-    FinalInfo = [{db_name, Db#db.name},
-                 {ddoc, DDocId},
-                 {view, VName}] ++ Info,
-    couch_httpd:send_json(Req, 200, {FinalInfo});
-
-handle_view_req(#httpd{method='GET'}=Req, Db, DDoc) ->
-    [_, _, _, _, ViewName] = Req#httpd.path_parts,
-    couch_stats_collector:increment({httpd, view_reads}),
-    design_doc_view(Req, Db, DDoc, ViewName, undefined);
-handle_view_req(#httpd{method='POST'}=Req, Db, DDoc) ->
-    [_, _, _, _, ViewName] = Req#httpd.path_parts,
-    Keys = get_view_keys(couch_httpd:json_body_obj(Req)),
-    couch_stats_collector:increment({httpd, view_reads}),
-    design_doc_view(Req, Db, DDoc, ViewName, Keys);
-handle_view_req(Req, _Db, _DDoc) ->
-    couch_httpd:send_method_not_allowed(Req, "GET,POST,HEAD").
-
-
-handle_temp_view_req(#httpd{method='POST'}=Req, Db) ->
-    couch_httpd:validate_ctype(Req, "application/json"),
-    ok = couch_db:check_is_admin(Db),
-    {Body} = couch_httpd:json_body_obj(Req),
-    DDoc = couch_mrview_util:temp_view_to_ddoc({Body}),
-    Keys = get_view_keys({Body}),
-    couch_stats_collector:increment({httpd, temporary_view_reads}),
-    design_doc_view(Req, Db, DDoc, <<"temp">>, Keys);
-handle_temp_view_req(Req, _Db) ->
-    couch_httpd:send_method_not_allowed(Req, "POST").
-
-
-handle_info_req(#httpd{method='GET'}=Req, Db, DDoc) ->
-    [_, _, Name, _] = Req#httpd.path_parts,
-    {ok, Info} = couch_mrview:get_info(Db, DDoc),
-    couch_httpd:send_json(Req, 200, {[
-        {name, Name},
-        {view_index, {Info}}
-    ]});
-handle_info_req(Req, _Db, _DDoc) ->
-    couch_httpd:send_method_not_allowed(Req, "GET").
-
-
-handle_compact_req(#httpd{method='POST'}=Req, Db, DDoc) ->
-    ok = couch_db:check_is_admin(Db),
-    couch_httpd:validate_ctype(Req, "application/json"),
-    ok = couch_mrview:compact(Db, DDoc),
-    couch_httpd:send_json(Req, 202, {[{ok, true}]});
-handle_compact_req(Req, _Db, _DDoc) ->
-    couch_httpd:send_method_not_allowed(Req, "POST").
-
-
-handle_cleanup_req(#httpd{method='POST'}=Req, Db) ->
-    ok = couch_db:check_is_admin(Db),
-    couch_httpd:validate_ctype(Req, "application/json"),
-    ok = couch_mrview:cleanup(Db),
-    couch_httpd:send_json(Req, 202, {[{ok, true}]});
-handle_cleanup_req(Req, _Db) ->
-    couch_httpd:send_method_not_allowed(Req, "POST").
-
-
-all_docs_req(Req, Db, Keys) ->
-    case couch_db:is_system_db(Db) of
-    true ->
-        case (catch couch_db:check_is_admin(Db)) of
-        ok ->
-            do_all_docs_req(Req, Db, Keys);
-        _ ->
-            DbName = ?b2l(Db#db.name),
-            case couch_config:get("couch_httpd_auth",
-                                  "authentication_db",
-                                  "_users") of
-            DbName ->
-                UsersDbPublic = couch_config:get("couch_httpd_auth", "users_db_public", "false"),
-                PublicFields = couch_config:get("couch_httpd_auth", "public_fields"),
-                case {UsersDbPublic, PublicFields} of
-                {"true", PublicFields} when PublicFields =/= undefined ->
-                    do_all_docs_req(Req, Db, Keys);
-                {_, _} ->
-                    throw({forbidden, <<"Only admins can access _all_docs",
-                                        " of system databases.">>})
-                end;
-            _ ->
-                throw({forbidden, <<"Only admins can access _all_docs",
-                                    " of system databases.">>})
-            end
-        end;
-    false ->
-        do_all_docs_req(Req, Db, Keys)
-    end.
-
-do_all_docs_req(Req, Db, Keys) ->
-    Args0 = parse_qs(Req, Keys),
-    ETagFun = fun(Sig, Acc0) ->
-        ETag = couch_httpd:make_etag(Sig),
-        case couch_httpd:etag_match(Req, ETag) of
-            true -> throw({etag_match, ETag});
-            false -> {ok, Acc0#vacc{etag=ETag}}
-        end
-    end,
-    Args = Args0#mrargs{preflight_fun=ETagFun},
-    {ok, Resp} = couch_httpd:etag_maybe(Req, fun() ->
-        VAcc0 = #vacc{db=Db, req=Req},
-        DbName = ?b2l(Db#db.name),
-        UsersDbName = couch_config:get("couch_httpd_auth",
-                                         "authentication_db",
-                                         "_users"),
-        IsAdmin = is_admin(Db),
-        Callback = get_view_callback(DbName, UsersDbName, IsAdmin),
-        couch_mrview:query_all_docs(Db, Args, Callback, VAcc0)
-    end),
-    case is_record(Resp, vacc) of
-        true -> {ok, Resp#vacc.resp};
-        _ -> {ok, Resp}
-    end.
-
-is_admin(Db) ->
-    case catch couch_db:check_is_admin(Db) of
-    {unauthorized, _} ->
-        false;
-    ok ->
-        true
-    end.
-
-
-% admin users always get all fields
-get_view_callback(_, _, true) ->
-    fun view_cb/2;
-% if we are operating on the users db and we aren't
-% admin, filter the view
-get_view_callback(_DbName, _DbName, false) ->
-    fun filtered_view_cb/2;
-% non _users databases get all fields
-get_view_callback(_, _, _) ->
-    fun view_cb/2.
-
-
-design_doc_view(Req, Db, DDoc, ViewName, Keys) ->
-    Args0 = parse_qs(Req, Keys),
-    ETagFun = fun(Sig, Acc0) ->
-        ETag = couch_httpd:make_etag(Sig),
-        case couch_httpd:etag_match(Req, ETag) of
-            true -> throw({etag_match, ETag});
-            false -> {ok, Acc0#vacc{etag=ETag}}
-        end
-    end,
-    Args = Args0#mrargs{preflight_fun=ETagFun},
-    {ok, Resp} = couch_httpd:etag_maybe(Req, fun() ->
-        VAcc0 = #vacc{db=Db, req=Req},
-        couch_mrview:query_view(Db, DDoc, ViewName, Args, fun view_cb/2, VAcc0)
-    end),
-    case is_record(Resp, vacc) of
-        true -> {ok, Resp#vacc.resp};
-        _ -> {ok, Resp}
-    end.
-
-
-filtered_view_cb({row, Row0}, Acc) ->
-  Row1 = lists:map(fun({doc, null}) ->
-        {doc, null};
-    ({doc, Body}) ->
-        Doc = couch_users_db:strip_non_public_fields(#doc{body=Body}),
-        {doc, Doc#doc.body};
-    (KV) ->
-        KV
-    end, Row0),
-    view_cb({row, Row1}, Acc);
-filtered_view_cb(Obj, Acc) ->
-    view_cb(Obj, Acc).
-
-
-view_cb({meta, Meta}, #vacc{resp=undefined}=Acc) ->
-    Headers = [{"ETag", Acc#vacc.etag}],
-    {ok, Resp} = couch_httpd:start_json_response(Acc#vacc.req, 200, Headers),
-    % Map function starting
-    Parts = case couch_util:get_value(total, Meta) of
-        undefined -> [];
-        Total -> [io_lib:format("\"total_rows\":~p", [Total])]
-    end ++ case couch_util:get_value(offset, Meta) of
-        undefined -> [];
-        Offset -> [io_lib:format("\"offset\":~p", [Offset])]
-    end ++ case couch_util:get_value(update_seq, Meta) of
-        undefined -> [];
-        UpdateSeq -> [io_lib:format("\"update_seq\":~p", [UpdateSeq])]
-    end ++ ["\"rows\":["],
-    Chunk = lists:flatten("{" ++ string:join(Parts, ",") ++ "\r\n"),
-    couch_httpd:send_chunk(Resp, Chunk),
-    {ok, Acc#vacc{resp=Resp, prepend=""}};
-view_cb({row, Row}, #vacc{resp=undefined}=Acc) ->
-    % Reduce function starting
-    Headers = [{"ETag", Acc#vacc.etag}],
-    {ok, Resp} = couch_httpd:start_json_response(Acc#vacc.req, 200, Headers),
-    couch_httpd:send_chunk(Resp, ["{\"rows\":[\r\n", row_to_json(Row)]),
-    {ok, #vacc{resp=Resp, prepend=",\r\n"}};
-view_cb({row, Row}, Acc) ->
-    % Adding another row
-    couch_httpd:send_chunk(Acc#vacc.resp, [Acc#vacc.prepend, row_to_json(Row)]),
-    {ok, Acc#vacc{prepend=",\r\n"}};
-view_cb(complete, #vacc{resp=undefined}=Acc) ->
-    % Nothing in view
-    {ok, Resp} = couch_httpd:send_json(Acc#vacc.req, 200, {[{rows, []}]}),
-    {ok, Acc#vacc{resp=Resp}};
-view_cb(complete, Acc) ->
-    % Finish view output
-    couch_httpd:send_chunk(Acc#vacc.resp, "\r\n]}"),
-    couch_httpd:end_json_response(Acc#vacc.resp),
-    {ok, Acc}.
-
-
-row_to_json(Row) ->
-    Id = couch_util:get_value(id, Row),
-    row_to_json(Id, Row).
-
-
-row_to_json(error, Row) ->
-    % Special case for _all_docs request with KEYS to
-    % match prior behavior.
-    Key = couch_util:get_value(key, Row),
-    Val = couch_util:get_value(value, Row),
-    Obj = {[{key, Key}, {error, Val}]},
-    ?JSON_ENCODE(Obj);
-row_to_json(Id0, Row) ->
-    Id = case Id0 of
-        undefined -> [];
-        Id0 -> [{id, Id0}]
-    end,
-    Key = couch_util:get_value(key, Row, null),
-    Val = couch_util:get_value(value, Row),
-    Doc = case couch_util:get_value(doc, Row) of
-        undefined -> [];
-        Doc0 -> [{doc, Doc0}]
-    end,
-    Obj = {Id ++ [{key, Key}, {value, Val}] ++ Doc},
-    ?JSON_ENCODE(Obj).
-
-
-get_view_keys({Props}) ->
-    case couch_util:get_value(<<"keys">>, Props) of
-        undefined ->
-            ?LOG_DEBUG("POST with no keys member.", []),
-            undefined;
-        Keys when is_list(Keys) ->
-            Keys;
-        _ ->
-            throw({bad_request, "`keys` member must be a array."})
-    end.
-
-
-parse_qs(Req, Keys) ->
-    Args = #mrargs{keys=Keys},
-    lists:foldl(fun({K, V}, Acc) ->
-        parse_qs(K, V, Acc)
-    end, Args, couch_httpd:qs(Req)).
-
-
-parse_qs(Key, Val, Args) ->
-    case Key of
-        "" ->
-            Args;
-        "reduce" ->
-            Args#mrargs{reduce=parse_boolean(Val)};
-        "key" ->
-            JsonKey = ?JSON_DECODE(Val),
-            Args#mrargs{start_key=JsonKey, end_key=JsonKey};
-        "keys" ->
-            Args#mrargs{keys=?JSON_DECODE(Val)};
-        "startkey" ->
-            Args#mrargs{start_key=?JSON_DECODE(Val)};
-        "start_key" ->
-            Args#mrargs{start_key=?JSON_DECODE(Val)};
-        "startkey_docid" ->
-            Args#mrargs{start_key_docid=list_to_binary(Val)};
-        "start_key_doc_id" ->
-            Args#mrargs{start_key_docid=list_to_binary(Val)};
-        "endkey" ->
-            Args#mrargs{end_key=?JSON_DECODE(Val)};
-        "end_key" ->
-            Args#mrargs{end_key=?JSON_DECODE(Val)};
-        "endkey_docid" ->
-            Args#mrargs{end_key_docid=list_to_binary(Val)};
-        "end_key_doc_id" ->
-            Args#mrargs{end_key_docid=list_to_binary(Val)};
-        "limit" ->
-            Args#mrargs{limit=parse_pos_int(Val)};
-        "count" ->
-            throw({query_parse_error, <<"QS param `count` is not `limit`">>});
-        "stale" when Val == "ok" ->
-            Args#mrargs{stale=ok};
-        "stale" when Val == "update_after" ->
-            Args#mrargs{stale=update_after};
-        "stale" ->
-            throw({query_parse_error, <<"Invalid value for `stale`.">>});
-        "descending" ->
-            case parse_boolean(Val) of
-                true -> Args#mrargs{direction=rev};
-                _ -> Args#mrargs{direction=fwd}
-            end;
-        "skip" ->
-            Args#mrargs{skip=parse_pos_int(Val)};
-        "group" ->
-            case parse_boolean(Val) of
-                true -> Args#mrargs{group_level=exact};
-                _ -> Args#mrargs{group_level=0}
-            end;
-        "group_level" ->
-            Args#mrargs{group_level=parse_pos_int(Val)};
-        "inclusive_end" ->
-            Args#mrargs{inclusive_end=parse_boolean(Val)};
-        "include_docs" ->
-            Args#mrargs{include_docs=parse_boolean(Val)};
-        "attachments" ->
-            case parse_boolean(Val) of
-            true ->
-                Opts = Args#mrargs.doc_options,
-                Args#mrargs{doc_options=[attachments|Opts]};
-            false ->
-                Args
-            end;
-        "att_encoding_info" ->
-            case parse_boolean(Val) of
-            true ->
-                Opts = Args#mrargs.doc_options,
-                Args#mrargs{doc_options=[att_encoding_info|Opts]};
-            false ->
-                Args
-            end;
-        "update_seq" ->
-            Args#mrargs{update_seq=parse_boolean(Val)};
-        "conflicts" ->
-            Args#mrargs{conflicts=parse_boolean(Val)};
-        "list" ->
-            Args#mrargs{list=list_to_binary(Val)};
-        "callback" ->
-            Args#mrargs{callback=list_to_binary(Val)};
-        _ ->
-            BKey = list_to_binary(Key),
-            BVal = list_to_binary(Val),
-            Args#mrargs{extra=[{BKey, BVal} | Args#mrargs.extra]}
-    end.
-
-
-parse_boolean(true) ->
-    true;
-parse_boolean(false) ->
-    false;
-parse_boolean(Val) ->
-    case string:to_lower(Val) of
-    "true" -> true;
-    "false" -> false;
-    _ ->
-        Msg = io_lib:format("Invalid boolean parameter: ~p", [Val]),
-        throw({query_parse_error, ?l2b(Msg)})
-    end.
-
-parse_int(Val) when is_integer(Val) ->
-    Val;
-parse_int(Val) ->
-    case (catch list_to_integer(Val)) of
-    IntVal when is_integer(IntVal) ->
-        IntVal;
-    _ ->
-        Msg = io_lib:format("Invalid value for integer: ~p", [Val]),
-        throw({query_parse_error, ?l2b(Msg)})
-    end.
-
-parse_pos_int(Val) ->
-    case parse_int(Val) of
-    IntVal when IntVal >= 0 ->
-        IntVal;
-    _ ->
-        Fmt = "Invalid value for positive integer: ~p",
-        Msg = io_lib:format(Fmt, [Val]),
-        throw({query_parse_error, ?l2b(Msg)})
-    end.

http://git-wip-us.apache.org/repos/asf/couchdb/blob/75150a18/apps/couch_mrview/src/couch_mrview_index.erl
----------------------------------------------------------------------
diff --git a/apps/couch_mrview/src/couch_mrview_index.erl b/apps/couch_mrview/src/couch_mrview_index.erl
deleted file mode 100644
index 5f5ae88..0000000
--- a/apps/couch_mrview/src/couch_mrview_index.erl
+++ /dev/null
@@ -1,180 +0,0 @@
-% Licensed 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.
-
--module(couch_mrview_index).
-
-
--export([get/2]).
--export([init/2, open/2, close/1, reset/1, delete/1]).
--export([start_update/3, purge/4, process_doc/3, finish_update/1, commit/1]).
--export([compact/3, swap_compacted/2]).
-
--include_lib("couch/include/couch_db.hrl").
--include_lib("couch_mrview/include/couch_mrview.hrl").
-
-
-get(Property, State) ->
-    case Property of
-        db_name ->
-            State#mrst.db_name;
-        idx_name ->
-            State#mrst.idx_name;
-        signature ->
-            State#mrst.sig;
-        update_seq ->
-            State#mrst.update_seq;
-        purge_seq ->
-            State#mrst.purge_seq;
-        update_options ->
-            Opts = State#mrst.design_opts,
-            IncDesign = couch_util:get_value(<<"include_design">>, Opts, false),
-            LocalSeq = couch_util:get_value(<<"local_seq">>, Opts, false),
-            SeqIndexed = couch_util:get_value(<<"seq_indexed">>, Opts, false),
-            if IncDesign -> [include_design]; true -> [] end
-                ++ if LocalSeq -> [local_seq]; true -> [] end
-                ++ if SeqIndexed -> [seq_indexed]; true -> [] end;
-        info ->
-            #mrst{
-                fd = Fd,
-                sig = Sig,
-                id_btree = IdBtree,
-                log_btree = LogBtree,
-                language = Lang,
-                update_seq = UpdateSeq,
-                purge_seq = PurgeSeq,
-                views = Views,
-                design_opts = Opts
-            } = State,
-            {ok, Size} = couch_file:bytes(Fd),
-            {ok, DataSize} = couch_mrview_util:calculate_data_size(IdBtree,
-                                                                   LogBtree,
-                                                                   Views),
-
-
-            IncDesign = couch_util:get_value(<<"include_design">>, Opts, false),
-            LocalSeq = couch_util:get_value(<<"local_seq">>, Opts, false),
-            SeqIndexed = couch_util:get_value(<<"seq_indexed">>, Opts, false),
-            UpdateOptions =
-                if IncDesign -> [<<"include_design">>]; true -> [] end
-                ++ if LocalSeq -> [<<"local_seq">>]; true -> [] end
-                ++ if SeqIndexed -> [<<"seq_indexed">>]; true -> [] end,
-
-
-            {ok, [
-                {signature, list_to_binary(couch_index_util:hexsig(Sig))},
-                {language, Lang},
-                {disk_size, Size},
-                {data_size, DataSize},
-                {update_seq, UpdateSeq},
-                {purge_seq, PurgeSeq},
-                {update_options, UpdateOptions}
-            ]};
-        Other ->
-            throw({unknown_index_property, Other})
-    end.
-
-
-init(Db, DDoc) ->
-    couch_mrview_util:ddoc_to_mrst(couch_db:name(Db), DDoc).
-
-
-open(Db, State) ->
-    #mrst{
-        db_name=DbName,
-        sig=Sig
-    } = State,
-    IndexFName = couch_mrview_util:index_file(DbName, Sig),
-
-    % If we are upgrading from <=1.2.x, we upgrade the view
-    % index file on the fly, avoiding an index reset.
-    %
-    % OldSig is `ok` if no upgrade happened.
-    %
-    % To remove suppport for 1.2.x auto-upgrades in the
-    % future, just remove the next line and the code
-    % between "upgrade code for <= 1.2.x" and
-    % "end upgrade code for <= 1.2.x" and the corresponding
-    % code in couch_mrview_util
-
-    OldSig = couch_mrview_util:maybe_update_index_file(State),
-
-    case couch_mrview_util:open_file(IndexFName) of
-        {ok, Fd} ->
-            case (catch couch_file:read_header(Fd)) of
-                % upgrade code for <= 1.2.x
-                {ok, {OldSig, Header}} ->
-                    % Matching view signatures.
-                    NewSt = couch_mrview_util:init_state(Db, Fd, State, Header),
-                    {ok, RefCounter} = couch_ref_counter:start([Fd]),
-                    {ok, NewSt#mrst{refc=RefCounter}};
-                % end of upgrade code for <= 1.2.x
-                {ok, {Sig, Header}} ->
-                    % Matching view signatures.
-                    NewSt = couch_mrview_util:init_state(Db, Fd, State, Header),
-                    {ok, RefCounter} = couch_ref_counter:start([Fd]),
-                    {ok, NewSt#mrst{refc=RefCounter}};
-                _ ->
-                    NewSt = couch_mrview_util:reset_index(Db, Fd, State),
-                    {ok, RefCounter} = couch_ref_counter:start([Fd]),
-                    {ok, NewSt#mrst{refc=RefCounter}}
-            end;
-        {error, Reason} = Error ->
-            ?LOG_ERROR("Failed to open view file '~s': ~s",
-                       [IndexFName, file:format_error(Reason)]),
-            Error
-    end.
-
-
-close(State) ->
-    couch_file:close(State#mrst.fd).
-
-
-delete(#mrst{db_name=DbName, sig=Sig}=State) ->
-    couch_file:close(State#mrst.fd),
-    catch couch_mrview_util:delete_files(DbName, Sig).
-
-
-reset(State) ->
-    couch_util:with_db(State#mrst.db_name, fun(Db) ->
-        NewState = couch_mrview_util:reset_index(Db, State#mrst.fd, State),
-        {ok, NewState}
-    end).
-
-
-start_update(PartialDest, State, NumChanges) ->
-    couch_mrview_updater:start_update(PartialDest, State, NumChanges).
-
-
-purge(Db, PurgeSeq, PurgedIdRevs, State) ->
-    couch_mrview_updater:purge(Db, PurgeSeq, PurgedIdRevs, State).
-
-
-process_doc(Doc, Seq, State) ->
-    couch_mrview_updater:process_doc(Doc, Seq, State).
-
-
-finish_update(State) ->
-    couch_mrview_updater:finish_update(State).
-
-
-commit(State) ->
-    Header = {State#mrst.sig, couch_mrview_util:make_header(State)},
-    couch_file:write_header(State#mrst.fd, Header).
-
-
-compact(Db, State, Opts) ->
-    couch_mrview_compactor:compact(Db, State, Opts).
-
-
-swap_compacted(OldState, NewState) ->
-    couch_mrview_compactor:swap_compacted(OldState, NewState).
-

http://git-wip-us.apache.org/repos/asf/couchdb/blob/75150a18/apps/couch_mrview/src/couch_mrview_show.erl
----------------------------------------------------------------------
diff --git a/apps/couch_mrview/src/couch_mrview_show.erl b/apps/couch_mrview/src/couch_mrview_show.erl
deleted file mode 100644
index 4ab8e17..0000000
--- a/apps/couch_mrview/src/couch_mrview_show.erl
+++ /dev/null
@@ -1,368 +0,0 @@
-% Licensed 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.
-
--module(couch_mrview_show).
-
--export([
-    handle_doc_show_req/3,
-    handle_doc_update_req/3,
-    handle_view_list_req/3
-]).
-
--include_lib("couch/include/couch_db.hrl").
--include_lib("couch_mrview/include/couch_mrview.hrl").
-
--record(lacc, {
-    db,
-    req,
-    resp,
-    qserver,
-    lname,
-    etag,
-    code,
-    headers
-}).
-
-% /db/_design/foo/_show/bar/docid
-% show converts a json doc to a response of any content-type.
-% it looks up the doc an then passes it to the query server.
-% then it sends the response from the query server to the http client.
-
-maybe_open_doc(Db, DocId) ->
-    case catch couch_httpd_db:couch_doc_open(Db, DocId, nil, [conflicts]) of
-        #doc{} = Doc -> Doc;
-        {not_found, _} -> nil
-    end.
-
-handle_doc_show_req(#httpd{
-        path_parts=[_, _, _, _, ShowName, DocId]
-    }=Req, Db, DDoc) ->
-
-    % open the doc
-    Doc = maybe_open_doc(Db, DocId),
-
-    % we don't handle revs here b/c they are an internal api
-    % returns 404 if there is no doc with DocId
-    handle_doc_show(Req, Db, DDoc, ShowName, Doc, DocId);
-
-handle_doc_show_req(#httpd{
-        path_parts=[_, _, _, _, ShowName, DocId|Rest]
-    }=Req, Db, DDoc) ->
-
-    DocParts = [DocId|Rest],
-    DocId1 = ?l2b(string:join([?b2l(P)|| P <- DocParts], "/")),
-
-    % open the doc
-    Doc = maybe_open_doc(Db, DocId1),
-
-    % we don't handle revs here b/c they are an internal api
-    % pass 404 docs to the show function
-    handle_doc_show(Req, Db, DDoc, ShowName, Doc, DocId1);
-
-handle_doc_show_req(#httpd{
-        path_parts=[_, _, _, _, ShowName]
-    }=Req, Db, DDoc) ->
-    % with no docid the doc is nil
-    handle_doc_show(Req, Db, DDoc, ShowName, nil);
-
-handle_doc_show_req(Req, _Db, _DDoc) ->
-    couch_httpd:send_error(Req, 404, <<"show_error">>, <<"Invalid path.">>).
-
-handle_doc_show(Req, Db, DDoc, ShowName, Doc) ->
-    handle_doc_show(Req, Db, DDoc, ShowName, Doc, null).
-
-handle_doc_show(Req, Db, DDoc, ShowName, Doc, DocId) ->
-    % get responder for ddoc/showname
-    CurrentEtag = show_etag(Req, Doc, DDoc, []),
-    couch_httpd:etag_respond(Req, CurrentEtag, fun() ->
-        JsonReq = couch_httpd_external:json_req_obj(Req, Db, DocId),
-        JsonDoc = couch_query_servers:json_doc(Doc),
-        [<<"resp">>, ExternalResp] =
-            couch_query_servers:ddoc_prompt(DDoc, [<<"shows">>, ShowName],
-                [JsonDoc, JsonReq]),
-        JsonResp = apply_etag(ExternalResp, CurrentEtag),
-        couch_httpd_external:send_external_response(Req, JsonResp)
-    end).
-
-
-show_etag(#httpd{user_ctx=UserCtx}=Req, Doc, DDoc, More) ->
-    Accept = couch_httpd:header_value(Req, "Accept"),
-    DocPart = case Doc of
-        nil -> nil;
-        Doc -> couch_httpd:doc_etag(Doc)
-    end,
-    couch_httpd:make_etag({couch_httpd:doc_etag(DDoc), DocPart, Accept,
-        {UserCtx#user_ctx.name, UserCtx#user_ctx.roles}, More}).
-
-% updates a doc based on a request
-% handle_doc_update_req(#httpd{method = 'GET'}=Req, _Db, _DDoc) ->
-%     % anything but GET
-%     send_method_not_allowed(Req, "POST,PUT,DELETE,ETC");
-
-% This call is creating a new doc using an _update function to
-% modify the provided request body.
-% /db/_design/foo/_update/bar
-handle_doc_update_req(#httpd{
-        path_parts=[_, _, _, _, UpdateName]
-    }=Req, Db, DDoc) ->
-    send_doc_update_response(Req, Db, DDoc, UpdateName, nil, null);
-
-% /db/_design/foo/_update/bar/docid
-handle_doc_update_req(#httpd{
-        path_parts=[_, _, _, _, UpdateName | DocIdParts]
-    }=Req, Db, DDoc) ->
-    DocId = ?l2b(string:join([?b2l(P) || P <- DocIdParts], "/")),
-    Doc = maybe_open_doc(Db, DocId),
-    send_doc_update_response(Req, Db, DDoc, UpdateName, Doc, DocId);
-
-
-handle_doc_update_req(Req, _Db, _DDoc) ->
-    couch_httpd:send_error(Req, 404, <<"update_error">>, <<"Invalid path.">>).
-
-send_doc_update_response(Req, Db, DDoc, UpdateName, Doc, DocId) ->
-    JsonReq = couch_httpd_external:json_req_obj(Req, Db, DocId),
-    JsonDoc = couch_query_servers:json_doc(Doc),
-    Cmd = [<<"updates">>, UpdateName],
-    UpdateResp = couch_query_servers:ddoc_prompt(DDoc, Cmd, [JsonDoc, JsonReq]),
-    JsonResp = case UpdateResp of
-        [<<"up">>, {NewJsonDoc}, {JsonResp0}] ->
-            case couch_httpd:header_value(
-                    Req, "X-Couch-Full-Commit", "false") of
-                "true" ->
-                    Options = [full_commit, {user_ctx, Req#httpd.user_ctx}];
-                _ ->
-                    Options = [{user_ctx, Req#httpd.user_ctx}]
-            end,
-            NewDoc = couch_doc:from_json_obj({NewJsonDoc}),
-            couch_doc:validate_docid(NewDoc#doc.id),
-            {ok, NewRev} = couch_db:update_doc(Db, NewDoc, Options),
-            NewRevStr = couch_doc:rev_to_str(NewRev),
-            {[
-                {<<"code">>, 201},
-                {<<"headers">>, {[
-                    {<<"X-Couch-Update-NewRev">>, NewRevStr},
-                    {<<"X-Couch-Id">>, NewDoc#doc.id}
-                ]}}
-                | JsonResp0]};
-        [<<"up">>, _Other, {JsonResp0}] ->
-            {[{<<"code">>, 200} | JsonResp0]}
-    end,
-    % todo set location field
-    couch_httpd_external:send_external_response(Req, JsonResp).
-
-
-handle_view_list_req(#httpd{method=Method}=Req, Db, DDoc)
-    when Method =:= 'GET' orelse Method =:= 'OPTIONS' ->
-    case Req#httpd.path_parts of
-        [_, _, _DName, _, LName, VName] ->
-            % Same design doc for view and list
-            handle_view_list(Req, Db, DDoc, LName, DDoc, VName, undefined);
-        [_, _, _, _, LName, DName, VName] ->
-            % Different design docs for view and list
-            VDocId = <<"_design/", DName/binary>>,
-            {ok, VDDoc} = couch_db:open_doc(Db, VDocId, [ejson_body]),
-            handle_view_list(Req, Db, DDoc, LName, VDDoc, VName, undefined);
-        _ ->
-            couch_httpd:send_error(Req, 404, <<"list_error">>, <<"Bad path.">>)
-    end;
-handle_view_list_req(#httpd{method='POST'}=Req, Db, DDoc) ->
-    {Props} = couch_httpd:json_body_obj(Req),
-    Keys = proplists:get_value(<<"keys">>, Props),
-    case Req#httpd.path_parts of
-        [_, _, _DName, _, LName, VName] ->
-            handle_view_list(Req, Db, DDoc, LName, DDoc, VName, Keys);
-        [_, _, _, _, LName, DName, VName] ->
-            % Different design docs for view and list
-            VDocId = <<"_design/", DName/binary>>,
-            {ok, VDDoc} = couch_db:open_doc(Db, VDocId, [ejson_body]),
-            handle_view_list(Req, Db, DDoc, LName, VDDoc, VName, Keys);
-        _ ->
-            couch_httpd:send_error(Req, 404, <<"list_error">>, <<"Bad path.">>)
-    end;
-handle_view_list_req(Req, _Db, _DDoc) ->
-    couch_httpd:send_method_not_allowed(Req, "GET,POST,HEAD").
-
-
-handle_view_list(Req, Db, DDoc, LName, VDDoc, VName, Keys) ->
-    Args0 = couch_mrview_http:parse_qs(Req, Keys),
-    ETagFun = fun(BaseSig, Acc0) ->
-        UserCtx = Req#httpd.user_ctx,
-        Name = UserCtx#user_ctx.name,
-        Roles = UserCtx#user_ctx.roles,
-        Accept = couch_httpd:header_value(Req, "Accept"),
-        Parts = {couch_httpd:doc_etag(DDoc), Accept, {Name, Roles}},
-        ETag = couch_httpd:make_etag({BaseSig, Parts}),
-        case couch_httpd:etag_match(Req, ETag) of
-            true -> throw({etag_match, ETag});
-            false -> {ok, Acc0#lacc{etag=ETag}}
-        end
-    end,
-    Args = Args0#mrargs{preflight_fun=ETagFun},
-    couch_httpd:etag_maybe(Req, fun() ->
-        couch_query_servers:with_ddoc_proc(DDoc, fun(QServer) ->
-            Acc = #lacc{db=Db, req=Req, qserver=QServer, lname=LName},
-            case VName of
-              <<"_all_docs">> ->
-                couch_mrview:query_all_docs(Db, Args, fun list_cb/2, Acc);
-              _ ->
-                couch_mrview:query_view(Db, VDDoc, VName, Args, fun list_cb/2, Acc)
-            end
-        end)
-    end).
-
-
-list_cb({meta, Meta}, #lacc{code=undefined} = Acc) ->
-    MetaProps = case couch_util:get_value(total, Meta) of
-        undefined -> [];
-        Total -> [{total_rows, Total}]
-    end ++ case couch_util:get_value(offset, Meta) of
-        undefined -> [];
-        Offset -> [{offset, Offset}]
-    end ++ case couch_util:get_value(update_seq, Meta) of
-        undefined -> [];
-        UpdateSeq -> [{update_seq, UpdateSeq}]
-    end,
-    start_list_resp({MetaProps}, Acc);
-list_cb({row, Row}, #lacc{code=undefined} = Acc) ->
-    {ok, NewAcc} = start_list_resp({[]}, Acc),
-    send_list_row(Row, NewAcc);
-list_cb({row, Row}, Acc) ->
-    send_list_row(Row, Acc);
-list_cb(complete, Acc) ->
-    #lacc{qserver = {Proc, _}, resp = Resp0} = Acc,
-    if Resp0 =:= nil ->
-        {ok, #lacc{resp = Resp}} = start_list_resp({[]}, Acc);
-    true ->
-        Resp = Resp0
-    end,
-    case couch_query_servers:proc_prompt(Proc, [<<"list_end">>]) of
-        [<<"end">>, Data, Headers] ->
-            Acc2 = fixup_headers(Headers, Acc#lacc{resp=Resp}),
-            #lacc{resp = Resp2} = send_non_empty_chunk(Acc2, Data);
-        [<<"end">>, Data] ->
-            #lacc{resp = Resp2} = send_non_empty_chunk(Acc#lacc{resp=Resp}, Data)
-    end,
-    couch_httpd:last_chunk(Resp2),
-    {ok, Resp2}.
-
-start_list_resp(Head, Acc) ->
-    #lacc{db=Db, req=Req, qserver=QServer, lname=LName} = Acc,
-    JsonReq = couch_httpd_external:json_req_obj(Req, Db),
-
-    [<<"start">>,Chunk,JsonResp] = couch_query_servers:ddoc_proc_prompt(QServer,
-        [<<"lists">>, LName], [Head, JsonReq]),
-    Acc2 = send_non_empty_chunk(fixup_headers(JsonResp, Acc), Chunk),
-    {ok, Acc2}.
-
-fixup_headers(Headers, #lacc{etag=ETag} = Acc) ->
-    Headers2 = apply_etag(Headers, ETag),
-    #extern_resp_args{
-        code = Code,
-        ctype = CType,
-        headers = ExtHeaders
-    } = couch_httpd_external:parse_external_response(Headers2),
-    Headers3 = couch_httpd_external:default_or_content_type(CType, ExtHeaders),
-    Acc#lacc{code=Code, headers=Headers3}.
-
-send_list_row(Row, #lacc{qserver = {Proc, _}, resp = Resp} = Acc) ->
-    RowObj = case couch_util:get_value(id, Row) of
-        undefined -> [];
-        Id -> [{id, Id}]
-    end ++ case couch_util:get_value(key, Row) of
-        undefined -> [];
-        Key -> [{key, Key}]
-    end ++ case couch_util:get_value(value, Row) of
-        undefined -> [];
-        Val -> [{value, Val}]
-    end ++ case couch_util:get_value(doc, Row) of
-        undefined -> [];
-        Doc -> [{doc, Doc}]
-    end,
-    try couch_query_servers:proc_prompt(Proc, [<<"list_row">>, {RowObj}]) of
-    [<<"chunks">>, Chunk, Headers] ->
-        Acc2 = send_non_empty_chunk(fixup_headers(Headers, Acc), Chunk),
-        {ok, Acc2};
-    [<<"chunks">>, Chunk] ->
-        Acc2 = send_non_empty_chunk(Acc, Chunk),
-        {ok, Acc2};
-    [<<"end">>, Chunk, Headers] ->
-        Acc2 = send_non_empty_chunk(fixup_headers(Headers, Acc), Chunk),
-        #lacc{resp = Resp2} = Acc2,
-        couch_httpd:last_chunk(Resp2),
-        {stop, Acc2};
-    [<<"end">>, Chunk] ->
-        Acc2 = send_non_empty_chunk(Acc, Chunk),
-        #lacc{resp = Resp2} = Acc2,
-        couch_httpd:last_chunk(Resp2),
-        {stop, Acc2}
-    catch Error ->
-        case Resp of
-            undefined ->
-                {Code, _, _} = couch_httpd:error_info(Error),
-                #lacc{req=Req, headers=Headers} = Acc,
-                {ok, Resp2} = couch_httpd:start_chunked_response(Req, Code, Headers),
-                Acc2 = Acc#lacc{resp=Resp2, code=Code};
-            _ -> Resp2 = Resp, Acc2 = Acc
-        end,
-        couch_httpd:send_chunked_error(Resp2, Error),
-        {stop, Acc2}
-    end.
-
-send_non_empty_chunk(Acc, []) ->
-    Acc;
-send_non_empty_chunk(#lacc{resp=undefined} = Acc, Chunk) ->
-    #lacc{req=Req, code=Code, headers=Headers} = Acc,
-    {ok, Resp} = couch_httpd:start_chunked_response(Req, Code, Headers),
-    send_non_empty_chunk(Acc#lacc{resp = Resp}, Chunk);
-send_non_empty_chunk(#lacc{resp=Resp} = Acc, Chunk) ->
-    couch_httpd:send_chunk(Resp, Chunk),
-    Acc.
-
-
-apply_etag({ExternalResponse}, CurrentEtag) ->
-    % Here we embark on the delicate task of replacing or creating the
-    % headers on the JsonResponse object. We need to control the Etag and
-    % Vary headers. If the external function controls the Etag, we'd have to
-    % run it to check for a match, which sort of defeats the purpose.
-    case couch_util:get_value(<<"headers">>, ExternalResponse, nil) of
-    nil ->
-        % no JSON headers
-        % add our Etag and Vary headers to the response
-        {[{<<"headers">>, {[{<<"Etag">>, CurrentEtag}, {<<"Vary">>, <<"Accept">>}]}} | ExternalResponse]};
-    JsonHeaders ->
-        {[case Field of
-        {<<"headers">>, JsonHeaders} -> % add our headers
-            JsonHeadersEtagged = json_apply_field({<<"Etag">>, CurrentEtag}, JsonHeaders),
-            JsonHeadersVaried = json_apply_field({<<"Vary">>, <<"Accept">>}, JsonHeadersEtagged),
-            {<<"headers">>, JsonHeadersVaried};
-        _ -> % skip non-header fields
-            Field
-        end || Field <- ExternalResponse]}
-    end.
-
-
-% Maybe this is in the proplists API
-% todo move to couch_util
-json_apply_field(H, {L}) ->
-    json_apply_field(H, L, []).
-
-
-json_apply_field({Key, NewValue}, [{Key, _OldVal} | Headers], Acc) ->
-    % drop matching keys
-    json_apply_field({Key, NewValue}, Headers, Acc);
-json_apply_field({Key, NewValue}, [{OtherKey, OtherVal} | Headers], Acc) ->
-    % something else is next, leave it alone.
-    json_apply_field({Key, NewValue}, Headers, [{OtherKey, OtherVal} | Acc]);
-json_apply_field({Key, NewValue}, [], Acc) ->
-    % end of list, add ours
-    {[{Key, NewValue}|Acc]}.
-

http://git-wip-us.apache.org/repos/asf/couchdb/blob/75150a18/apps/couch_mrview/src/couch_mrview_test_util.erl
----------------------------------------------------------------------
diff --git a/apps/couch_mrview/src/couch_mrview_test_util.erl b/apps/couch_mrview/src/couch_mrview_test_util.erl
deleted file mode 100644
index bcf8a87..0000000
--- a/apps/couch_mrview/src/couch_mrview_test_util.erl
+++ /dev/null
@@ -1,111 +0,0 @@
-% Licensed 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.
-
--module(couch_mrview_test_util).
-
--compile(export_all).
-
--include_lib("couch/include/couch_db.hrl").
-
--define(ADMIN, #user_ctx{roles=[<<"_admin">>]}).
-
-
-init_db(Name, Type) ->
-    init_db(Name, Type, 10).
-
-
-init_db(Name, Type, Count) ->
-    {ok, Db} = new_db(Name, Type),
-    Docs = make_docs(Count),
-    save_docs(Db, Docs).
-
-
-new_db(Name, Type) ->
-    couch_server:delete(Name, [{user_ctx, ?ADMIN}]),
-    {ok, Db} = couch_db:create(Name, [{user_ctx, ?ADMIN}]),
-    save_docs(Db, [ddoc(Type)]).
-
-delete_db(Name) ->
-    couch_server:delete(Name, [{user_ctx, ?ADMIN}]).
-
-save_docs(Db, Docs) ->
-    {ok, _} = couch_db:update_docs(Db, Docs, []),
-    couch_db:reopen(Db).
-
-
-make_docs(Count) ->
-    [doc(I) || I <- lists:seq(1, Count)].
-
-ddoc(changes) ->
-    couch_doc:from_json_obj({[
-        {<<"_id">>, <<"_design/bar">>},
-        {<<"options">>, {[
-            {<<"seq_indexed">>, true}
-        ]}},
-        {<<"views">>, {[
-            {<<"baz">>, {[
-                {<<"map">>, <<"function(doc) {emit(doc.val, doc.val);}">>}
-            ]}},
-            {<<"bing">>, {[
-                {<<"map">>, <<"function(doc) {}">>}
-            ]}},
-            {<<"zing">>, {[
-                {<<"map">>, <<
-                    "function(doc) {\n"
-                    "  if(doc.foo !== undefined)\n"
-                    "    emit(doc.foo, 0);\n"
-                    "}"
-                >>}
-            ]}}
-        ]}}
-    ]});
-ddoc(map) ->
-    couch_doc:from_json_obj({[
-        {<<"_id">>, <<"_design/bar">>},
-        {<<"views">>, {[
-            {<<"baz">>, {[
-                {<<"map">>, <<"function(doc) {emit(doc.val, doc.val);}">>}
-            ]}},
-            {<<"bing">>, {[
-                {<<"map">>, <<"function(doc) {}">>}
-            ]}},
-            {<<"zing">>, {[
-                {<<"map">>, <<
-                    "function(doc) {\n"
-                    "  if(doc.foo !== undefined)\n"
-                    "    emit(doc.foo, 0);\n"
-                    "}"
-                >>}
-            ]}}
-        ]}}
-    ]});
-ddoc(red) ->
-    couch_doc:from_json_obj({[
-        {<<"_id">>, <<"_design/bar">>},
-        {<<"views">>, {[
-            {<<"baz">>, {[
-                {<<"map">>, <<
-                    "function(doc) {\n"
-                    "  emit([doc.val % 2, doc.val], doc.val);\n"
-                    "}\n"
-                >>},
-                {<<"reduce">>, <<"function(keys, vals) {return sum(vals);}">>}
-            ]}}
-        ]}}
-    ]}).
-
-
-doc(Id) ->
-    couch_doc:from_json_obj({[
-        {<<"_id">>, list_to_binary(integer_to_list(Id))},
-        {<<"val">>, Id}
-    ]}).


[22/57] [abbrv] remove couch_collate

Posted by be...@apache.org.
http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/ubidi.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/ubidi.h b/apps/couch_collate/platform/osx/icu/unicode/ubidi.h
deleted file mode 100644
index 25f22b9..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/ubidi.h
+++ /dev/null
@@ -1,2013 +0,0 @@
-/*
-******************************************************************************
-*
-*   Copyright (C) 1999-2008, International Business Machines
-*   Corporation and others.  All Rights Reserved.
-*
-******************************************************************************
-*   file name:  ubidi.h
-*   encoding:   US-ASCII
-*   tab size:   8 (not used)
-*   indentation:4
-*
-*   created on: 1999jul27
-*   created by: Markus W. Scherer, updated by Matitiahu Allouche
-*/
-
-#ifndef UBIDI_H
-#define UBIDI_H
-
-#include "unicode/utypes.h"
-#include "unicode/uchar.h"
-
-/**
- *\file
- * \brief C API: Bidi algorithm
- *
- * <h2>Bidi algorithm for ICU</h2>
- *
- * This is an implementation of the Unicode Bidirectional algorithm.
- * The algorithm is defined in the
- * <a href="http://www.unicode.org/unicode/reports/tr9/">Unicode Standard Annex #9</a>,
- * version 13, also described in The Unicode Standard, Version 4.0 .<p>
- *
- * Note: Libraries that perform a bidirectional algorithm and
- * reorder strings accordingly are sometimes called "Storage Layout Engines".
- * ICU's Bidi and shaping (u_shapeArabic()) APIs can be used at the core of such
- * "Storage Layout Engines".
- *
- * <h3>General remarks about the API:</h3>
- *
- * In functions with an error code parameter,
- * the <code>pErrorCode</code> pointer must be valid
- * and the value that it points to must not indicate a failure before
- * the function call. Otherwise, the function returns immediately.
- * After the function call, the value indicates success or failure.<p>
- *
- * The &quot;limit&quot; of a sequence of characters is the position just after their
- * last character, i.e., one more than that position.<p>
- *
- * Some of the API functions provide access to &quot;runs&quot;.
- * Such a &quot;run&quot; is defined as a sequence of characters
- * that are at the same embedding level
- * after performing the Bidi algorithm.<p>
- *
- * @author Markus W. Scherer
- * @version 1.0
- *
- *
- * <h4> Sample code for the ICU Bidi API </h4>
- *
- * <h5>Rendering a paragraph with the ICU Bidi API</h5>
- *
- * This is (hypothetical) sample code that illustrates
- * how the ICU Bidi API could be used to render a paragraph of text.
- * Rendering code depends highly on the graphics system,
- * therefore this sample code must make a lot of assumptions,
- * which may or may not match any existing graphics system's properties.
- *
- * <p>The basic assumptions are:</p>
- * <ul>
- * <li>Rendering is done from left to right on a horizontal line.</li>
- * <li>A run of single-style, unidirectional text can be rendered at once.</li>
- * <li>Such a run of text is passed to the graphics system with
- *     characters (code units) in logical order.</li>
- * <li>The line-breaking algorithm is very complicated
- *     and Locale-dependent -
- *     and therefore its implementation omitted from this sample code.</li>
- * </ul>
- *
- * <pre>
- * \code
- *#include "unicode/ubidi.h"
- *
- *typedef enum {
- *     styleNormal=0, styleSelected=1,
- *     styleBold=2, styleItalics=4,
- *     styleSuper=8, styleSub=16
- *} Style;
- *
- *typedef struct { int32_t limit; Style style; } StyleRun;
- *
- *int getTextWidth(const UChar *text, int32_t start, int32_t limit,
- *                  const StyleRun *styleRuns, int styleRunCount);
- *
- * // set *pLimit and *pStyleRunLimit for a line
- * // from text[start] and from styleRuns[styleRunStart]
- * // using ubidi_getLogicalRun(para, ...)
- *void getLineBreak(const UChar *text, int32_t start, int32_t *pLimit,
- *                  UBiDi *para,
- *                  const StyleRun *styleRuns, int styleRunStart, int *pStyleRunLimit,
- *                  int *pLineWidth);
- *
- * // render runs on a line sequentially, always from left to right
- *
- * // prepare rendering a new line
- * void startLine(UBiDiDirection textDirection, int lineWidth);
- *
- * // render a run of text and advance to the right by the run width
- * // the text[start..limit-1] is always in logical order
- * void renderRun(const UChar *text, int32_t start, int32_t limit,
- *               UBiDiDirection textDirection, Style style);
- *
- * // We could compute a cross-product
- * // from the style runs with the directional runs
- * // and then reorder it.
- * // Instead, here we iterate over each run type
- * // and render the intersections -
- * // with shortcuts in simple (and common) cases.
- * // renderParagraph() is the main function.
- *
- * // render a directional run with
- * // (possibly) multiple style runs intersecting with it
- * void renderDirectionalRun(const UChar *text,
- *                           int32_t start, int32_t limit,
- *                           UBiDiDirection direction,
- *                           const StyleRun *styleRuns, int styleRunCount) {
- *     int i;
- *
- *     // iterate over style runs
- *     if(direction==UBIDI_LTR) {
- *         int styleLimit;
- *
- *         for(i=0; i<styleRunCount; ++i) {
- *             styleLimit=styleRun[i].limit;
- *             if(start<styleLimit) {
- *                 if(styleLimit>limit) { styleLimit=limit; }
- *                 renderRun(text, start, styleLimit,
- *                           direction, styleRun[i].style);
- *                 if(styleLimit==limit) { break; }
- *                 start=styleLimit;
- *             }
- *         }
- *     } else {
- *         int styleStart;
- *
- *         for(i=styleRunCount-1; i>=0; --i) {
- *             if(i>0) {
- *                 styleStart=styleRun[i-1].limit;
- *             } else {
- *                 styleStart=0;
- *             }
- *             if(limit>=styleStart) {
- *                 if(styleStart<start) { styleStart=start; }
- *                 renderRun(text, styleStart, limit,
- *                           direction, styleRun[i].style);
- *                 if(styleStart==start) { break; }
- *                 limit=styleStart;
- *             }
- *         }
- *     }
- * }
- *
- * // the line object represents text[start..limit-1]
- * void renderLine(UBiDi *line, const UChar *text,
- *                 int32_t start, int32_t limit,
- *                 const StyleRun *styleRuns, int styleRunCount) {
- *     UBiDiDirection direction=ubidi_getDirection(line);
- *     if(direction!=UBIDI_MIXED) {
- *         // unidirectional
- *         if(styleRunCount<=1) {
- *             renderRun(text, start, limit, direction, styleRuns[0].style);
- *         } else {
- *             renderDirectionalRun(text, start, limit,
- *                                  direction, styleRuns, styleRunCount);
- *         }
- *     } else {
- *         // mixed-directional
- *         int32_t count, i, length;
- *         UBiDiLevel level;
- *
- *         count=ubidi_countRuns(para, pErrorCode);
- *         if(U_SUCCESS(*pErrorCode)) {
- *             if(styleRunCount<=1) {
- *                 Style style=styleRuns[0].style;
- *
- *                 // iterate over directional runs
- *                for(i=0; i<count; ++i) {
- *                    direction=ubidi_getVisualRun(para, i, &start, &length);
- *                     renderRun(text, start, start+length, direction, style);
- *                }
- *             } else {
- *                 int32_t j;
- *
- *                 // iterate over both directional and style runs
- *                 for(i=0; i<count; ++i) {
- *                     direction=ubidi_getVisualRun(line, i, &start, &length);
- *                     renderDirectionalRun(text, start, start+length,
- *                                          direction, styleRuns, styleRunCount);
- *                 }
- *             }
- *         }
- *     }
- * }
- *
- *void renderParagraph(const UChar *text, int32_t length,
- *                     UBiDiDirection textDirection,
- *                      const StyleRun *styleRuns, int styleRunCount,
- *                      int lineWidth,
- *                      UErrorCode *pErrorCode) {
- *     UBiDi *para;
- *
- *     if(pErrorCode==NULL || U_FAILURE(*pErrorCode) || length<=0) {
- *         return;
- *     }
- *
- *     para=ubidi_openSized(length, 0, pErrorCode);
- *     if(para==NULL) { return; }
- *
- *     ubidi_setPara(para, text, length,
- *                   textDirection ? UBIDI_DEFAULT_RTL : UBIDI_DEFAULT_LTR,
- *                   NULL, pErrorCode);
- *     if(U_SUCCESS(*pErrorCode)) {
- *         UBiDiLevel paraLevel=1&ubidi_getParaLevel(para);
- *         StyleRun styleRun={ length, styleNormal };
- *         int width;
- *
- *         if(styleRuns==NULL || styleRunCount<=0) {
- *            styleRunCount=1;
- *             styleRuns=&styleRun;
- *         }
- *
- *        // assume styleRuns[styleRunCount-1].limit>=length
- *
- *         width=getTextWidth(text, 0, length, styleRuns, styleRunCount);
- *         if(width<=lineWidth) {
- *             // everything fits onto one line
- *
- *            // prepare rendering a new line from either left or right
- *             startLine(paraLevel, width);
- *
- *             renderLine(para, text, 0, length,
- *                        styleRuns, styleRunCount);
- *         } else {
- *             UBiDi *line;
- *
- *             // we need to render several lines
- *             line=ubidi_openSized(length, 0, pErrorCode);
- *             if(line!=NULL) {
- *                 int32_t start=0, limit;
- *                 int styleRunStart=0, styleRunLimit;
- *
- *                 for(;;) {
- *                     limit=length;
- *                     styleRunLimit=styleRunCount;
- *                     getLineBreak(text, start, &limit, para,
- *                                  styleRuns, styleRunStart, &styleRunLimit,
- *                                 &width);
- *                     ubidi_setLine(para, start, limit, line, pErrorCode);
- *                     if(U_SUCCESS(*pErrorCode)) {
- *                         // prepare rendering a new line
- *                         // from either left or right
- *                         startLine(paraLevel, width);
- *
- *                         renderLine(line, text, start, limit,
- *                                    styleRuns+styleRunStart,
- *                                    styleRunLimit-styleRunStart);
- *                     }
- *                     if(limit==length) { break; }
- *                     start=limit;
- *                     styleRunStart=styleRunLimit-1;
- *                     if(start>=styleRuns[styleRunStart].limit) {
- *                         ++styleRunStart;
- *                     }
- *                 }
- *
- *                 ubidi_close(line);
- *             }
- *        }
- *    }
- *
- *     ubidi_close(para);
- *}
- *\endcode
- * </pre>
- */
-
-/*DOCXX_TAG*/
-/*@{*/
-
-/**
- * UBiDiLevel is the type of the level values in this
- * Bidi implementation.
- * It holds an embedding level and indicates the visual direction
- * by its bit&nbsp;0 (even/odd value).<p>
- *
- * It can also hold non-level values for the
- * <code>paraLevel</code> and <code>embeddingLevels</code>
- * arguments of <code>ubidi_setPara()</code>; there:
- * <ul>
- * <li>bit&nbsp;7 of an <code>embeddingLevels[]</code>
- * value indicates whether the using application is
- * specifying the level of a character to <i>override</i> whatever the
- * Bidi implementation would resolve it to.</li>
- * <li><code>paraLevel</code> can be set to the
- * pseudo-level values <code>UBIDI_DEFAULT_LTR</code>
- * and <code>UBIDI_DEFAULT_RTL</code>.</li>
- * </ul>
- *
- * @see ubidi_setPara
- *
- * <p>The related constants are not real, valid level values.
- * <code>UBIDI_DEFAULT_XXX</code> can be used to specify
- * a default for the paragraph level for
- * when the <code>ubidi_setPara()</code> function
- * shall determine it but there is no
- * strongly typed character in the input.<p>
- *
- * Note that the value for <code>UBIDI_DEFAULT_LTR</code> is even
- * and the one for <code>UBIDI_DEFAULT_RTL</code> is odd,
- * just like with normal LTR and RTL level values -
- * these special values are designed that way. Also, the implementation
- * assumes that UBIDI_MAX_EXPLICIT_LEVEL is odd.
- *
- * @see UBIDI_DEFAULT_LTR
- * @see UBIDI_DEFAULT_RTL
- * @see UBIDI_LEVEL_OVERRIDE
- * @see UBIDI_MAX_EXPLICIT_LEVEL
- * @stable ICU 2.0
- */
-typedef uint8_t UBiDiLevel;
-
-/** Paragraph level setting.<p>
- *
- * Constant indicating that the base direction depends on the first strong
- * directional character in the text according to the Unicode Bidirectional
- * Algorithm. If no strong directional character is present,
- * then set the paragraph level to 0 (left-to-right).<p>
- *
- * If this value is used in conjunction with reordering modes
- * <code>UBIDI_REORDER_INVERSE_LIKE_DIRECT</code> or
- * <code>UBIDI_REORDER_INVERSE_FOR_NUMBERS_SPECIAL</code>, the text to reorder
- * is assumed to be visual LTR, and the text after reordering is required
- * to be the corresponding logical string with appropriate contextual
- * direction. The direction of the result string will be RTL if either
- * the righmost or leftmost strong character of the source text is RTL
- * or Arabic Letter, the direction will be LTR otherwise.<p>
- *
- * If reordering option <code>UBIDI_OPTION_INSERT_MARKS</code> is set, an RLM may
- * be added at the beginning of the result string to ensure round trip
- * (that the result string, when reordered back to visual, will produce
- * the original source text).
- * @see UBIDI_REORDER_INVERSE_LIKE_DIRECT
- * @see UBIDI_REORDER_INVERSE_FOR_NUMBERS_SPECIAL
- * @stable ICU 2.0
- */
-#define UBIDI_DEFAULT_LTR 0xfe
-
-/** Paragraph level setting.<p>
- *
- * Constant indicating that the base direction depends on the first strong
- * directional character in the text according to the Unicode Bidirectional
- * Algorithm. If no strong directional character is present,
- * then set the paragraph level to 1 (right-to-left).<p>
- *
- * If this value is used in conjunction with reordering modes
- * <code>UBIDI_REORDER_INVERSE_LIKE_DIRECT</code> or
- * <code>UBIDI_REORDER_INVERSE_FOR_NUMBERS_SPECIAL</code>, the text to reorder
- * is assumed to be visual LTR, and the text after reordering is required
- * to be the corresponding logical string with appropriate contextual
- * direction. The direction of the result string will be RTL if either
- * the righmost or leftmost strong character of the source text is RTL
- * or Arabic Letter, or if the text contains no strong character;
- * the direction will be LTR otherwise.<p>
- *
- * If reordering option <code>UBIDI_OPTION_INSERT_MARKS</code> is set, an RLM may
- * be added at the beginning of the result string to ensure round trip
- * (that the result string, when reordered back to visual, will produce
- * the original source text).
- * @see UBIDI_REORDER_INVERSE_LIKE_DIRECT
- * @see UBIDI_REORDER_INVERSE_FOR_NUMBERS_SPECIAL
- * @stable ICU 2.0
- */
-#define UBIDI_DEFAULT_RTL 0xff
-
-/**
- * Maximum explicit embedding level.
- * (The maximum resolved level can be up to <code>UBIDI_MAX_EXPLICIT_LEVEL+1</code>).
- * @stable ICU 2.0
- */
-#define UBIDI_MAX_EXPLICIT_LEVEL 61
-
-/** Bit flag for level input.
- *  Overrides directional properties.
- * @stable ICU 2.0
- */
-#define UBIDI_LEVEL_OVERRIDE 0x80
-
-/**
- * Special value which can be returned by the mapping functions when a logical
- * index has no corresponding visual index or vice-versa. This may happen
- * for the logical-to-visual mapping of a Bidi control when option
- * <code>#UBIDI_OPTION_REMOVE_CONTROLS</code> is specified. This can also happen
- * for the visual-to-logical mapping of a Bidi mark (LRM or RLM) inserted
- * by option <code>#UBIDI_OPTION_INSERT_MARKS</code>.
- * @see ubidi_getVisualIndex
- * @see ubidi_getVisualMap
- * @see ubidi_getLogicalIndex
- * @see ubidi_getLogicalMap
- * @stable ICU 3.6
- */
-#define UBIDI_MAP_NOWHERE   (-1)
-
-/**
- * <code>UBiDiDirection</code> values indicate the text direction.
- * @stable ICU 2.0
- */
-enum UBiDiDirection {
-    /** All left-to-right text. This is a 0 value. @stable ICU 2.0 */
-    UBIDI_LTR,
-    /** All right-to-left text. This is a 1 value. @stable ICU 2.0 */
-    UBIDI_RTL,
-    /** Mixed-directional text. @stable ICU 2.0 */
-    UBIDI_MIXED
-};
-
-/** @stable ICU 2.0 */
-typedef enum UBiDiDirection UBiDiDirection;
-
-/**
- * Forward declaration of the <code>UBiDi</code> structure for the declaration of
- * the API functions. Its fields are implementation-specific.<p>
- * This structure holds information about a paragraph (or multiple paragraphs)
- * of text with Bidi-algorithm-related details, or about one line of
- * such a paragraph.<p>
- * Reordering can be done on a line, or on one or more paragraphs which are
- * then interpreted each as one single line.
- * @stable ICU 2.0
- */
-struct UBiDi;
-
-/** @stable ICU 2.0 */
-typedef struct UBiDi UBiDi;
-
-/**
- * Allocate a <code>UBiDi</code> structure.
- * Such an object is initially empty. It is assigned
- * the Bidi properties of a piece of text containing one or more paragraphs
- * by <code>ubidi_setPara()</code>
- * or the Bidi properties of a line within a paragraph by
- * <code>ubidi_setLine()</code>.<p>
- * This object can be reused for as long as it is not deallocated
- * by calling <code>ubidi_close()</code>.<p>
- * <code>ubidi_setPara()</code> and <code>ubidi_setLine()</code> will allocate
- * additional memory for internal structures as necessary.
- *
- * @return An empty <code>UBiDi</code> object.
- * @stable ICU 2.0
- */
-U_STABLE UBiDi * U_EXPORT2
-ubidi_open(void);
-
-/**
- * Allocate a <code>UBiDi</code> structure with preallocated memory
- * for internal structures.
- * This function provides a <code>UBiDi</code> object like <code>ubidi_open()</code>
- * with no arguments, but it also preallocates memory for internal structures
- * according to the sizings supplied by the caller.<p>
- * Subsequent functions will not allocate any more memory, and are thus
- * guaranteed not to fail because of lack of memory.<p>
- * The preallocation can be limited to some of the internal memory
- * by setting some values to 0 here. That means that if, e.g.,
- * <code>maxRunCount</code> cannot be reasonably predetermined and should not
- * be set to <code>maxLength</code> (the only failproof value) to avoid
- * wasting memory, then <code>maxRunCount</code> could be set to 0 here
- * and the internal structures that are associated with it will be allocated
- * on demand, just like with <code>ubidi_open()</code>.
- *
- * @param maxLength is the maximum text or line length that internal memory
- *        will be preallocated for. An attempt to associate this object with a
- *        longer text will fail, unless this value is 0, which leaves the allocation
- *        up to the implementation.
- *
- * @param maxRunCount is the maximum anticipated number of same-level runs
- *        that internal memory will be preallocated for. An attempt to access
- *        visual runs on an object that was not preallocated for as many runs
- *        as the text was actually resolved to will fail,
- *        unless this value is 0, which leaves the allocation up to the implementation.<br><br>
- *        The number of runs depends on the actual text and maybe anywhere between
- *        1 and <code>maxLength</code>. It is typically small.
- *
- * @param pErrorCode must be a valid pointer to an error code value.
- *
- * @return An empty <code>UBiDi</code> object with preallocated memory.
- * @stable ICU 2.0
- */
-U_STABLE UBiDi * U_EXPORT2
-ubidi_openSized(int32_t maxLength, int32_t maxRunCount, UErrorCode *pErrorCode);
-
-/**
- * <code>ubidi_close()</code> must be called to free the memory
- * associated with a UBiDi object.<p>
- *
- * <strong>Important: </strong>
- * A parent <code>UBiDi</code> object must not be destroyed or reused if
- * it still has children.
- * If a <code>UBiDi</code> object has become the <i>child</i>
- * of another one (its <i>parent</i>) by calling
- * <code>ubidi_setLine()</code>, then the child object must
- * be destroyed (closed) or reused (by calling
- * <code>ubidi_setPara()</code> or <code>ubidi_setLine()</code>)
- * before the parent object.
- *
- * @param pBiDi is a <code>UBiDi</code> object.
- *
- * @see ubidi_setPara
- * @see ubidi_setLine
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2
-ubidi_close(UBiDi *pBiDi);
-
-/**
- * Modify the operation of the Bidi algorithm such that it
- * approximates an "inverse Bidi" algorithm. This function
- * must be called before <code>ubidi_setPara()</code>.
- *
- * <p>The normal operation of the Bidi algorithm as described
- * in the Unicode Technical Report is to take text stored in logical
- * (keyboard, typing) order and to determine the reordering of it for visual
- * rendering.
- * Some legacy systems store text in visual order, and for operations
- * with standard, Unicode-based algorithms, the text needs to be transformed
- * to logical order. This is effectively the inverse algorithm of the
- * described Bidi algorithm. Note that there is no standard algorithm for
- * this "inverse Bidi" and that the current implementation provides only an
- * approximation of "inverse Bidi".</p>
- *
- * <p>With <code>isInverse</code> set to <code>TRUE</code>,
- * this function changes the behavior of some of the subsequent functions
- * in a way that they can be used for the inverse Bidi algorithm.
- * Specifically, runs of text with numeric characters will be treated in a
- * special way and may need to be surrounded with LRM characters when they are
- * written in reordered sequence.</p>
- *
- * <p>Output runs should be retrieved using <code>ubidi_getVisualRun()</code>.
- * Since the actual input for "inverse Bidi" is visually ordered text and
- * <code>ubidi_getVisualRun()</code> gets the reordered runs, these are actually
- * the runs of the logically ordered output.</p>
- *
- * <p>Calling this function with argument <code>isInverse</code> set to
- * <code>TRUE</code> is equivalent to calling
- * <code>ubidi_setReorderingMode</code> with argument
- * <code>reorderingMode</code>
- * set to <code>#UBIDI_REORDER_INVERSE_NUMBERS_AS_L</code>.<br>
- * Calling this function with argument <code>isInverse</code> set to
- * <code>FALSE</code> is equivalent to calling
- * <code>ubidi_setReorderingMode</code> with argument
- * <code>reorderingMode</code>
- * set to <code>#UBIDI_REORDER_DEFAULT</code>.
- *
- * @param pBiDi is a <code>UBiDi</code> object.
- *
- * @param isInverse specifies "forward" or "inverse" Bidi operation.
- *
- * @see ubidi_setPara
- * @see ubidi_writeReordered
- * @see ubidi_setReorderingMode
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2
-ubidi_setInverse(UBiDi *pBiDi, UBool isInverse);
-
-/**
- * Is this Bidi object set to perform the inverse Bidi algorithm?
- * <p>Note: calling this function after setting the reordering mode with
- * <code>ubidi_setReorderingMode</code> will return <code>TRUE</code> if the
- * reordering mode was set to <code>#UBIDI_REORDER_INVERSE_NUMBERS_AS_L</code>,
- * <code>FALSE</code> for all other values.</p>
- *
- * @param pBiDi is a <code>UBiDi</code> object.
- * @return TRUE if the Bidi object is set to perform the inverse Bidi algorithm
- * by handling numbers as L.
- *
- * @see ubidi_setInverse
- * @see ubidi_setReorderingMode
- * @stable ICU 2.0
- */
-
-U_STABLE UBool U_EXPORT2
-ubidi_isInverse(UBiDi *pBiDi);
-
-/**
- * Specify whether block separators must be allocated level zero,
- * so that successive paragraphs will progress from left to right.
- * This function must be called before <code>ubidi_setPara()</code>.
- * Paragraph separators (B) may appear in the text.  Setting them to level zero
- * means that all paragraph separators (including one possibly appearing
- * in the last text position) are kept in the reordered text after the text
- * that they follow in the source text.
- * When this feature is not enabled, a paragraph separator at the last
- * position of the text before reordering will go to the first position
- * of the reordered text when the paragraph level is odd.
- *
- * @param pBiDi is a <code>UBiDi</code> object.
- *
- * @param orderParagraphsLTR specifies whether paragraph separators (B) must
- * receive level 0, so that successive paragraphs progress from left to right.
- *
- * @see ubidi_setPara
- * @stable ICU 3.4
- */
-U_STABLE void U_EXPORT2
-ubidi_orderParagraphsLTR(UBiDi *pBiDi, UBool orderParagraphsLTR);
-
-/**
- * Is this Bidi object set to allocate level 0 to block separators so that
- * successive paragraphs progress from left to right?
- *
- * @param pBiDi is a <code>UBiDi</code> object.
- * @return TRUE if the Bidi object is set to allocate level 0 to block
- *         separators.
- *
- * @see ubidi_orderParagraphsLTR
- * @stable ICU 3.4
- */
-U_STABLE UBool U_EXPORT2
-ubidi_isOrderParagraphsLTR(UBiDi *pBiDi);
-
-/**
- * <code>UBiDiReorderingMode</code> values indicate which variant of the Bidi
- * algorithm to use.
- *
- * @see ubidi_setReorderingMode
- * @stable ICU 3.6
- */
-typedef enum UBiDiReorderingMode {
-    /** Regular Logical to Visual Bidi algorithm according to Unicode.
-      * This is a 0 value.
-      * @stable ICU 3.6 */
-    UBIDI_REORDER_DEFAULT = 0,
-    /** Logical to Visual algorithm which handles numbers in a way which
-      * mimicks the behavior of Windows XP.
-      * @stable ICU 3.6 */
-    UBIDI_REORDER_NUMBERS_SPECIAL,
-    /** Logical to Visual algorithm grouping numbers with adjacent R characters
-      * (reversible algorithm).
-      * @stable ICU 3.6 */
-    UBIDI_REORDER_GROUP_NUMBERS_WITH_R,
-    /** Reorder runs only to transform a Logical LTR string to the Logical RTL
-      * string with the same display, or vice-versa.<br>
-      * If this mode is set together with option
-      * <code>#UBIDI_OPTION_INSERT_MARKS</code>, some Bidi controls in the source
-      * text may be removed and other controls may be added to produce the
-      * minimum combination which has the required display.
-      * @stable ICU 3.6 */
-    UBIDI_REORDER_RUNS_ONLY,
-    /** Visual to Logical algorithm which handles numbers like L
-      * (same algorithm as selected by <code>ubidi_setInverse(TRUE)</code>.
-      * @see ubidi_setInverse
-      * @stable ICU 3.6 */
-    UBIDI_REORDER_INVERSE_NUMBERS_AS_L,
-    /** Visual to Logical algorithm equivalent to the regular Logical to Visual
-      * algorithm.
-      * @stable ICU 3.6 */
-    UBIDI_REORDER_INVERSE_LIKE_DIRECT,
-    /** Inverse Bidi (Visual to Logical) algorithm for the
-      * <code>UBIDI_REORDER_NUMBERS_SPECIAL</code> Bidi algorithm.
-      * @stable ICU 3.6 */
-    UBIDI_REORDER_INVERSE_FOR_NUMBERS_SPECIAL,
-    /** Number of values for reordering mode.
-      * @stable ICU 3.6 */
-    UBIDI_REORDER_COUNT
-} UBiDiReorderingMode;
-
-/**
- * Modify the operation of the Bidi algorithm such that it implements some
- * variant to the basic Bidi algorithm or approximates an "inverse Bidi"
- * algorithm, depending on different values of the "reordering mode".
- * This function must be called before <code>ubidi_setPara()</code>, and stays
- * in effect until called again with a different argument.
- *
- * <p>The normal operation of the Bidi algorithm as described
- * in the Unicode Standard Annex #9 is to take text stored in logical
- * (keyboard, typing) order and to determine how to reorder it for visual
- * rendering.</p>
- *
- * <p>With the reordering mode set to a value other than
- * <code>#UBIDI_REORDER_DEFAULT</code>, this function changes the behavior of
- * some of the subsequent functions in a way such that they implement an
- * inverse Bidi algorithm or some other algorithm variants.</p>
- *
- * <p>Some legacy systems store text in visual order, and for operations
- * with standard, Unicode-based algorithms, the text needs to be transformed
- * into logical order. This is effectively the inverse algorithm of the
- * described Bidi algorithm. Note that there is no standard algorithm for
- * this "inverse Bidi", so a number of variants are implemented here.</p>
- *
- * <p>In other cases, it may be desirable to emulate some variant of the
- * Logical to Visual algorithm (e.g. one used in MS Windows), or perform a
- * Logical to Logical transformation.</p>
- *
- * <ul>
- * <li>When the reordering mode is set to <code>#UBIDI_REORDER_DEFAULT</code>,
- * the standard Bidi Logical to Visual algorithm is applied.</li>
- *
- * <li>When the reordering mode is set to
- * <code>#UBIDI_REORDER_NUMBERS_SPECIAL</code>,
- * the algorithm used to perform Bidi transformations when calling
- * <code>ubidi_setPara</code> should approximate the algorithm used in
- * Microsoft Windows XP rather than strictly conform to the Unicode Bidi
- * algorithm.
- * <br>
- * The differences between the basic algorithm and the algorithm addressed
- * by this option are as follows:
- * <ul>
- *   <li>Within text at an even embedding level, the sequence "123AB"
- *   (where AB represent R or AL letters) is transformed to "123BA" by the
- *   Unicode algorithm and to "BA123" by the Windows algorithm.</li>
- *   <li>Arabic-Indic numbers (AN) are handled by the Windows algorithm just
- *   like regular numbers (EN).</li>
- * </ul></li>
- *
- * <li>When the reordering mode is set to
- * <code>#UBIDI_REORDER_GROUP_NUMBERS_WITH_R</code>,
- * numbers located between LTR text and RTL text are associated with the RTL
- * text. For instance, an LTR paragraph with content "abc 123 DEF" (where
- * upper case letters represent RTL characters) will be transformed to
- * "abc FED 123" (and not "abc 123 FED"), "DEF 123 abc" will be transformed
- * to "123 FED abc" and "123 FED abc" will be transformed to "DEF 123 abc".
- * This makes the algorithm reversible and makes it useful when round trip
- * (from visual to logical and back to visual) must be achieved without
- * adding LRM characters. However, this is a variation from the standard
- * Unicode Bidi algorithm.<br>
- * The source text should not contain Bidi control characters other than LRM
- * or RLM.</li>
- *
- * <li>When the reordering mode is set to
- * <code>#UBIDI_REORDER_RUNS_ONLY</code>,
- * a "Logical to Logical" transformation must be performed:
- * <ul>
- * <li>If the default text level of the source text (argument <code>paraLevel</code>
- * in <code>ubidi_setPara</code>) is even, the source text will be handled as
- * LTR logical text and will be transformed to the RTL logical text which has
- * the same LTR visual display.</li>
- * <li>If the default level of the source text is odd, the source text
- * will be handled as RTL logical text and will be transformed to the
- * LTR logical text which has the same LTR visual display.</li>
- * </ul>
- * This mode may be needed when logical text which is basically Arabic or
- * Hebrew, with possible included numbers or phrases in English, has to be
- * displayed as if it had an even embedding level (this can happen if the
- * displaying application treats all text as if it was basically LTR).
- * <br>
- * This mode may also be needed in the reverse case, when logical text which is
- * basically English, with possible included phrases in Arabic or Hebrew, has to
- * be displayed as if it had an odd embedding level.
- * <br>
- * Both cases could be handled by adding LRE or RLE at the head of the text,
- * if the display subsystem supports these formatting controls. If it does not,
- * the problem may be handled by transforming the source text in this mode
- * before displaying it, so that it will be displayed properly.<br>
- * The source text should not contain Bidi control characters other than LRM
- * or RLM.</li>
- *
- * <li>When the reordering mode is set to
- * <code>#UBIDI_REORDER_INVERSE_NUMBERS_AS_L</code>, an "inverse Bidi" algorithm
- * is applied.
- * Runs of text with numeric characters will be treated like LTR letters and
- * may need to be surrounded with LRM characters when they are written in
- * reordered sequence (the option <code>#UBIDI_INSERT_LRM_FOR_NUMERIC</code> can
- * be used with function <code>ubidi_writeReordered</code> to this end. This
- * mode is equivalent to calling <code>ubidi_setInverse()</code> with
- * argument <code>isInverse</code> set to <code>TRUE</code>.</li>
- *
- * <li>When the reordering mode is set to
- * <code>#UBIDI_REORDER_INVERSE_LIKE_DIRECT</code>, the "direct" Logical to Visual
- * Bidi algorithm is used as an approximation of an "inverse Bidi" algorithm.
- * This mode is similar to mode <code>#UBIDI_REORDER_INVERSE_NUMBERS_AS_L</code>
- * but is closer to the regular Bidi algorithm.
- * <br>
- * For example, an LTR paragraph with the content "FED 123 456 CBA" (where
- * upper case represents RTL characters) will be transformed to
- * "ABC 456 123 DEF", as opposed to "DEF 123 456 ABC"
- * with mode <code>UBIDI_REORDER_INVERSE_NUMBERS_AS_L</code>.<br>
- * When used in conjunction with option
- * <code>#UBIDI_OPTION_INSERT_MARKS</code>, this mode generally
- * adds Bidi marks to the output significantly more sparingly than mode
- * <code>#UBIDI_REORDER_INVERSE_NUMBERS_AS_L</code> with option
- * <code>#UBIDI_INSERT_LRM_FOR_NUMERIC</code> in calls to
- * <code>ubidi_writeReordered</code>.</li>
- *
- * <li>When the reordering mode is set to
- * <code>#UBIDI_REORDER_INVERSE_FOR_NUMBERS_SPECIAL</code>, the Logical to Visual
- * Bidi algorithm used in Windows XP is used as an approximation of an
- * "inverse Bidi" algorithm.
- * <br>
- * For example, an LTR paragraph with the content "abc FED123" (where
- * upper case represents RTL characters) will be transformed to
- * "abc 123DEF.</li>
- * </ul>
- *
- * <p>In all the reordering modes specifying an "inverse Bidi" algorithm
- * (i.e. those with a name starting with <code>UBIDI_REORDER_INVERSE</code>),
- * output runs should be retrieved using
- * <code>ubidi_getVisualRun()</code>, and the output text with
- * <code>ubidi_writeReordered()</code>. The caller should keep in mind that in
- * "inverse Bidi" modes the input is actually visually ordered text and
- * reordered output returned by <code>ubidi_getVisualRun()</code> or
- * <code>ubidi_writeReordered()</code> are actually runs or character string
- * of logically ordered output.<br>
- * For all the "inverse Bidi" modes, the source text should not contain
- * Bidi control characters other than LRM or RLM.</p>
- *
- * <p>Note that option <code>#UBIDI_OUTPUT_REVERSE</code> of
- * <code>ubidi_writeReordered</code> has no useful meaning and should not be
- * used in conjunction with any value of the reordering mode specifying
- * "inverse Bidi" or with value <code>UBIDI_REORDER_RUNS_ONLY</code>.
- *
- * @param pBiDi is a <code>UBiDi</code> object.
- * @param reorderingMode specifies the required variant of the Bidi algorithm.
- *
- * @see UBiDiReorderingMode
- * @see ubidi_setInverse
- * @see ubidi_setPara
- * @see ubidi_writeReordered
- * @stable ICU 3.6
- */
-U_STABLE void U_EXPORT2
-ubidi_setReorderingMode(UBiDi *pBiDi, UBiDiReorderingMode reorderingMode);
-
-/**
- * What is the requested reordering mode for a given Bidi object?
- *
- * @param pBiDi is a <code>UBiDi</code> object.
- * @return the current reordering mode of the Bidi object
- * @see ubidi_setReorderingMode
- * @stable ICU 3.6
- */
-U_STABLE UBiDiReorderingMode U_EXPORT2
-ubidi_getReorderingMode(UBiDi *pBiDi);
-
-/**
- * <code>UBiDiReorderingOption</code> values indicate which options are
- * specified to affect the Bidi algorithm.
- *
- * @see ubidi_setReorderingOptions
- * @stable ICU 3.6
- */
-typedef enum UBiDiReorderingOption {
-    /**
-     * option value for <code>ubidi_setReorderingOptions</code>:
-     * disable all the options which can be set with this function
-     * @see ubidi_setReorderingOptions
-     * @stable ICU 3.6
-     */
-    UBIDI_OPTION_DEFAULT = 0,
-
-    /**
-     * option bit for <code>ubidi_setReorderingOptions</code>:
-     * insert Bidi marks (LRM or RLM) when needed to ensure correct result of
-     * a reordering to a Logical order
-     *
-     * <p>This option must be set or reset before calling
-     * <code>ubidi_setPara</code>.</p>
-     *
-     * <p>This option is significant only with reordering modes which generate
-     * a result with Logical order, specifically:</p>
-     * <ul>
-     *   <li><code>#UBIDI_REORDER_RUNS_ONLY</code></li>
-     *   <li><code>#UBIDI_REORDER_INVERSE_NUMBERS_AS_L</code></li>
-     *   <li><code>#UBIDI_REORDER_INVERSE_LIKE_DIRECT</code></li>
-     *   <li><code>#UBIDI_REORDER_INVERSE_FOR_NUMBERS_SPECIAL</code></li>
-     * </ul>
-     *
-     * <p>If this option is set in conjunction with reordering mode
-     * <code>#UBIDI_REORDER_INVERSE_NUMBERS_AS_L</code> or with calling
-     * <code>ubidi_setInverse(TRUE)</code>, it implies
-     * option <code>#UBIDI_INSERT_LRM_FOR_NUMERIC</code>
-     * in calls to function <code>ubidi_writeReordered()</code>.</p>
-     *
-     * <p>For other reordering modes, a minimum number of LRM or RLM characters
-     * will be added to the source text after reordering it so as to ensure
-     * round trip, i.e. when applying the inverse reordering mode on the
-     * resulting logical text with removal of Bidi marks
-     * (option <code>#UBIDI_OPTION_REMOVE_CONTROLS</code> set before calling
-     * <code>ubidi_setPara()</code> or option <code>#UBIDI_REMOVE_BIDI_CONTROLS</code>
-     * in <code>ubidi_writeReordered</code>), the result will be identical to the
-     * source text in the first transformation.
-     *
-     * <p>This option will be ignored if specified together with option
-     * <code>#UBIDI_OPTION_REMOVE_CONTROLS</code>. It inhibits option
-     * <code>UBIDI_REMOVE_BIDI_CONTROLS</code> in calls to function
-     * <code>ubidi_writeReordered()</code> and it implies option
-     * <code>#UBIDI_INSERT_LRM_FOR_NUMERIC</code> in calls to function
-     * <code>ubidi_writeReordered()</code> if the reordering mode is
-     * <code>#UBIDI_REORDER_INVERSE_NUMBERS_AS_L</code>.</p>
-     *
-     * @see ubidi_setReorderingMode
-     * @see ubidi_setReorderingOptions
-     * @stable ICU 3.6
-     */
-    UBIDI_OPTION_INSERT_MARKS = 1,
-
-    /**
-     * option bit for <code>ubidi_setReorderingOptions</code>:
-     * remove Bidi control characters
-     *
-     * <p>This option must be set or reset before calling
-     * <code>ubidi_setPara</code>.</p>
-     *
-     * <p>This option nullifies option <code>#UBIDI_OPTION_INSERT_MARKS</code>.
-     * It inhibits option <code>#UBIDI_INSERT_LRM_FOR_NUMERIC</code> in calls
-     * to function <code>ubidi_writeReordered()</code> and it implies option
-     * <code>#UBIDI_REMOVE_BIDI_CONTROLS</code> in calls to that function.</p>
-     *
-     * @see ubidi_setReorderingMode
-     * @see ubidi_setReorderingOptions
-     * @stable ICU 3.6
-     */
-    UBIDI_OPTION_REMOVE_CONTROLS = 2,
-
-    /**
-     * option bit for <code>ubidi_setReorderingOptions</code>:
-     * process the output as part of a stream to be continued
-     *
-     * <p>This option must be set or reset before calling
-     * <code>ubidi_setPara</code>.</p>
-     *
-     * <p>This option specifies that the caller is interested in processing large
-     * text object in parts.
-     * The results of the successive calls are expected to be concatenated by the
-     * caller. Only the call for the last part will have this option bit off.</p>
-     *
-     * <p>When this option bit is on, <code>ubidi_setPara()</code> may process
-     * less than the full source text in order to truncate the text at a meaningful
-     * boundary. The caller should call <code>ubidi_getProcessedLength()</code>
-     * immediately after calling <code>ubidi_setPara()</code> in order to
-     * determine how much of the source text has been processed.
-     * Source text beyond that length should be resubmitted in following calls to
-     * <code>ubidi_setPara</code>. The processed length may be less than
-     * the length of the source text if a character preceding the last character of
-     * the source text constitutes a reasonable boundary (like a block separator)
-     * for text to be continued.<br>
-     * If the last character of the source text constitutes a reasonable
-     * boundary, the whole text will be processed at once.<br>
-     * If nowhere in the source text there exists
-     * such a reasonable boundary, the processed length will be zero.<br>
-     * The caller should check for such an occurrence and do one of the following:
-     * <ul><li>submit a larger amount of text with a better chance to include
-     *         a reasonable boundary.</li>
-     *     <li>resubmit the same text after turning off option
-     *         <code>UBIDI_OPTION_STREAMING</code>.</li></ul>
-     * In all cases, this option should be turned off before processing the last
-     * part of the text.</p>
-     *
-     * <p>When the <code>UBIDI_OPTION_STREAMING</code> option is used,
-     * it is recommended to call <code>ubidi_orderParagraphsLTR()</code> with
-     * argument <code>orderParagraphsLTR</code> set to <code>TRUE</code> before
-     * calling <code>ubidi_setPara</code> so that later paragraphs may be
-     * concatenated to previous paragraphs on the right.</p>
-     *
-     * @see ubidi_setReorderingMode
-     * @see ubidi_setReorderingOptions
-     * @see ubidi_getProcessedLength
-     * @see ubidi_orderParagraphsLTR
-     * @stable ICU 3.6
-     */
-    UBIDI_OPTION_STREAMING = 4
-} UBiDiReorderingOption;
-
-/**
- * Specify which of the reordering options
- * should be applied during Bidi transformations.
- *
- * @param pBiDi is a <code>UBiDi</code> object.
- * @param reorderingOptions is a combination of zero or more of the following
- * options:
- * <code>#UBIDI_OPTION_DEFAULT</code>, <code>#UBIDI_OPTION_INSERT_MARKS</code>,
- * <code>#UBIDI_OPTION_REMOVE_CONTROLS</code>, <code>#UBIDI_OPTION_STREAMING</code>.
- *
- * @see ubidi_getReorderingOptions
- * @stable ICU 3.6
- */
-U_STABLE void U_EXPORT2
-ubidi_setReorderingOptions(UBiDi *pBiDi, uint32_t reorderingOptions);
-
-/**
- * What are the reordering options applied to a given Bidi object?
- *
- * @param pBiDi is a <code>UBiDi</code> object.
- * @return the current reordering options of the Bidi object
- * @see ubidi_setReorderingOptions
- * @stable ICU 3.6
- */
-U_STABLE uint32_t U_EXPORT2
-ubidi_getReorderingOptions(UBiDi *pBiDi);
-
-/**
- * Perform the Unicode Bidi algorithm. It is defined in the
- * <a href="http://www.unicode.org/unicode/reports/tr9/">Unicode Standard Anned #9</a>,
- * version 13,
- * also described in The Unicode Standard, Version 4.0 .<p>
- *
- * This function takes a piece of plain text containing one or more paragraphs,
- * with or without externally specified embedding levels from <i>styled</i>
- * text and computes the left-right-directionality of each character.<p>
- *
- * If the entire text is all of the same directionality, then
- * the function may not perform all the steps described by the algorithm,
- * i.e., some levels may not be the same as if all steps were performed.
- * This is not relevant for unidirectional text.<br>
- * For example, in pure LTR text with numbers the numbers would get
- * a resolved level of 2 higher than the surrounding text according to
- * the algorithm. This implementation may set all resolved levels to
- * the same value in such a case.<p>
- *
- * The text can be composed of multiple paragraphs. Occurrence of a block
- * separator in the text terminates a paragraph, and whatever comes next starts
- * a new paragraph. The exception to this rule is when a Carriage Return (CR)
- * is followed by a Line Feed (LF). Both CR and LF are block separators, but
- * in that case, the pair of characters is considered as terminating the
- * preceding paragraph, and a new paragraph will be started by a character
- * coming after the LF.
- *
- * @param pBiDi A <code>UBiDi</code> object allocated with <code>ubidi_open()</code>
- *        which will be set to contain the reordering information,
- *        especially the resolved levels for all the characters in <code>text</code>.
- *
- * @param text is a pointer to the text that the Bidi algorithm will be performed on.
- *        This pointer is stored in the UBiDi object and can be retrieved
- *        with <code>ubidi_getText()</code>.<br>
- *        <strong>Note:</strong> the text must be (at least) <code>length</code> long.
- *
- * @param length is the length of the text; if <code>length==-1</code> then
- *        the text must be zero-terminated.
- *
- * @param paraLevel specifies the default level for the text;
- *        it is typically 0 (LTR) or 1 (RTL).
- *        If the function shall determine the paragraph level from the text,
- *        then <code>paraLevel</code> can be set to
- *        either <code>#UBIDI_DEFAULT_LTR</code>
- *        or <code>#UBIDI_DEFAULT_RTL</code>; if the text contains multiple
- *        paragraphs, the paragraph level shall be determined separately for
- *        each paragraph; if a paragraph does not include any strongly typed
- *        character, then the desired default is used (0 for LTR or 1 for RTL).
- *        Any other value between 0 and <code>#UBIDI_MAX_EXPLICIT_LEVEL</code>
- *        is also valid, with odd levels indicating RTL.
- *
- * @param embeddingLevels (in) may be used to preset the embedding and override levels,
- *        ignoring characters like LRE and PDF in the text.
- *        A level overrides the directional property of its corresponding
- *        (same index) character if the level has the
- *        <code>#UBIDI_LEVEL_OVERRIDE</code> bit set.<br><br>
- *        Except for that bit, it must be
- *        <code>paraLevel<=embeddingLevels[]<=UBIDI_MAX_EXPLICIT_LEVEL</code>,
- *        with one exception: a level of zero may be specified for a paragraph
- *        separator even if <code>paraLevel>0</code> when multiple paragraphs
- *        are submitted in the same call to <code>ubidi_setPara()</code>.<br><br>
- *        <strong>Caution: </strong>A copy of this pointer, not of the levels,
- *        will be stored in the <code>UBiDi</code> object;
- *        the <code>embeddingLevels</code> array must not be
- *        deallocated before the <code>UBiDi</code> structure is destroyed or reused,
- *        and the <code>embeddingLevels</code>
- *        should not be modified to avoid unexpected results on subsequent Bidi operations.
- *        However, the <code>ubidi_setPara()</code> and
- *        <code>ubidi_setLine()</code> functions may modify some or all of the levels.<br><br>
- *        After the <code>UBiDi</code> object is reused or destroyed, the caller
- *        must take care of the deallocation of the <code>embeddingLevels</code> array.<br><br>
- *        <strong>Note:</strong> the <code>embeddingLevels</code> array must be
- *        at least <code>length</code> long.
- *
- * @param pErrorCode must be a valid pointer to an error code value.
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2
-ubidi_setPara(UBiDi *pBiDi, const UChar *text, int32_t length,
-              UBiDiLevel paraLevel, UBiDiLevel *embeddingLevels,
-              UErrorCode *pErrorCode);
-
-/**
- * <code>ubidi_setLine()</code> sets a <code>UBiDi</code> to
- * contain the reordering information, especially the resolved levels,
- * for all the characters in a line of text. This line of text is
- * specified by referring to a <code>UBiDi</code> object representing
- * this information for a piece of text containing one or more paragraphs,
- * and by specifying a range of indexes in this text.<p>
- * In the new line object, the indexes will range from 0 to <code>limit-start-1</code>.<p>
- *
- * This is used after calling <code>ubidi_setPara()</code>
- * for a piece of text, and after line-breaking on that text.
- * It is not necessary if each paragraph is treated as a single line.<p>
- *
- * After line-breaking, rules (L1) and (L2) for the treatment of
- * trailing WS and for reordering are performed on
- * a <code>UBiDi</code> object that represents a line.<p>
- *
- * <strong>Important: </strong><code>pLineBiDi</code> shares data with
- * <code>pParaBiDi</code>.
- * You must destroy or reuse <code>pLineBiDi</code> before <code>pParaBiDi</code>.
- * In other words, you must destroy or reuse the <code>UBiDi</code> object for a line
- * before the object for its parent paragraph.<p>
- *
- * The text pointer that was stored in <code>pParaBiDi</code> is also copied,
- * and <code>start</code> is added to it so that it points to the beginning of the
- * line for this object.
- *
- * @param pParaBiDi is the parent paragraph object. It must have been set
- * by a successful call to ubidi_setPara.
- *
- * @param start is the line's first index into the text.
- *
- * @param limit is just behind the line's last index into the text
- *        (its last index +1).<br>
- *        It must be <code>0<=start<limit<=</code>containing paragraph limit.
- *        If the specified line crosses a paragraph boundary, the function
- *        will terminate with error code U_ILLEGAL_ARGUMENT_ERROR.
- *
- * @param pLineBiDi is the object that will now represent a line of the text.
- *
- * @param pErrorCode must be a valid pointer to an error code value.
- *
- * @see ubidi_setPara
- * @see ubidi_getProcessedLength
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2
-ubidi_setLine(const UBiDi *pParaBiDi,
-              int32_t start, int32_t limit,
-              UBiDi *pLineBiDi,
-              UErrorCode *pErrorCode);
-
-/**
- * Get the directionality of the text.
- *
- * @param pBiDi is the paragraph or line <code>UBiDi</code> object.
- *
- * @return a value of <code>UBIDI_LTR</code>, <code>UBIDI_RTL</code>
- *         or <code>UBIDI_MIXED</code>
- *         that indicates if the entire text
- *         represented by this object is unidirectional,
- *         and which direction, or if it is mixed-directional.
- *
- * @see UBiDiDirection
- * @stable ICU 2.0
- */
-U_STABLE UBiDiDirection U_EXPORT2
-ubidi_getDirection(const UBiDi *pBiDi);
-
-/**
- * Get the pointer to the text.
- *
- * @param pBiDi is the paragraph or line <code>UBiDi</code> object.
- *
- * @return The pointer to the text that the UBiDi object was created for.
- *
- * @see ubidi_setPara
- * @see ubidi_setLine
- * @stable ICU 2.0
- */
-U_STABLE const UChar * U_EXPORT2
-ubidi_getText(const UBiDi *pBiDi);
-
-/**
- * Get the length of the text.
- *
- * @param pBiDi is the paragraph or line <code>UBiDi</code> object.
- *
- * @return The length of the text that the UBiDi object was created for.
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2
-ubidi_getLength(const UBiDi *pBiDi);
-
-/**
- * Get the paragraph level of the text.
- *
- * @param pBiDi is the paragraph or line <code>UBiDi</code> object.
- *
- * @return The paragraph level. If there are multiple paragraphs, their
- *         level may vary if the required paraLevel is UBIDI_DEFAULT_LTR or
- *         UBIDI_DEFAULT_RTL.  In that case, the level of the first paragraph
- *         is returned.
- *
- * @see UBiDiLevel
- * @see ubidi_getParagraph
- * @see ubidi_getParagraphByIndex
- * @stable ICU 2.0
- */
-U_STABLE UBiDiLevel U_EXPORT2
-ubidi_getParaLevel(const UBiDi *pBiDi);
-
-/**
- * Get the number of paragraphs.
- *
- * @param pBiDi is the paragraph or line <code>UBiDi</code> object.
- *
- * @return The number of paragraphs.
- * @stable ICU 3.4
- */
-U_STABLE int32_t U_EXPORT2
-ubidi_countParagraphs(UBiDi *pBiDi);
-
-/**
- * Get a paragraph, given a position within the text.
- * This function returns information about a paragraph.<br>
- * Note: if the paragraph index is known, it is more efficient to
- * retrieve the paragraph information using ubidi_getParagraphByIndex().<p>
- *
- * @param pBiDi is the paragraph or line <code>UBiDi</code> object.
- *
- * @param charIndex is the index of a character within the text, in the
- *        range <code>[0..ubidi_getProcessedLength(pBiDi)-1]</code>.
- *
- * @param pParaStart will receive the index of the first character of the
- *        paragraph in the text.
- *        This pointer can be <code>NULL</code> if this
- *        value is not necessary.
- *
- * @param pParaLimit will receive the limit of the paragraph.
- *        The l-value that you point to here may be the
- *        same expression (variable) as the one for
- *        <code>charIndex</code>.
- *        This pointer can be <code>NULL</code> if this
- *        value is not necessary.
- *
- * @param pParaLevel will receive the level of the paragraph.
- *        This pointer can be <code>NULL</code> if this
- *        value is not necessary.
- *
- * @param pErrorCode must be a valid pointer to an error code value.
- *
- * @return The index of the paragraph containing the specified position.
- *
- * @see ubidi_getProcessedLength
- * @stable ICU 3.4
- */
-U_STABLE int32_t U_EXPORT2
-ubidi_getParagraph(const UBiDi *pBiDi, int32_t charIndex, int32_t *pParaStart,
-                   int32_t *pParaLimit, UBiDiLevel *pParaLevel,
-                   UErrorCode *pErrorCode);
-
-/**
- * Get a paragraph, given the index of this paragraph.
- *
- * This function returns information about a paragraph.<p>
- *
- * @param pBiDi is the paragraph <code>UBiDi</code> object.
- *
- * @param paraIndex is the number of the paragraph, in the
- *        range <code>[0..ubidi_countParagraphs(pBiDi)-1]</code>.
- *
- * @param pParaStart will receive the index of the first character of the
- *        paragraph in the text.
- *        This pointer can be <code>NULL</code> if this
- *        value is not necessary.
- *
- * @param pParaLimit will receive the limit of the paragraph.
- *        This pointer can be <code>NULL</code> if this
- *        value is not necessary.
- *
- * @param pParaLevel will receive the level of the paragraph.
- *        This pointer can be <code>NULL</code> if this
- *        value is not necessary.
- *
- * @param pErrorCode must be a valid pointer to an error code value.
- *
- * @stable ICU 3.4
- */
-U_STABLE void U_EXPORT2
-ubidi_getParagraphByIndex(const UBiDi *pBiDi, int32_t paraIndex,
-                          int32_t *pParaStart, int32_t *pParaLimit,
-                          UBiDiLevel *pParaLevel, UErrorCode *pErrorCode);
-
-/**
- * Get the level for one character.
- *
- * @param pBiDi is the paragraph or line <code>UBiDi</code> object.
- *
- * @param charIndex the index of a character. It must be in the range
- *         [0..ubidi_getProcessedLength(pBiDi)].
- *
- * @return The level for the character at charIndex (0 if charIndex is not
- *         in the valid range).
- *
- * @see UBiDiLevel
- * @see ubidi_getProcessedLength
- * @stable ICU 2.0
- */
-U_STABLE UBiDiLevel U_EXPORT2
-ubidi_getLevelAt(const UBiDi *pBiDi, int32_t charIndex);
-
-/**
- * Get an array of levels for each character.<p>
- *
- * Note that this function may allocate memory under some
- * circumstances, unlike <code>ubidi_getLevelAt()</code>.
- *
- * @param pBiDi is the paragraph or line <code>UBiDi</code> object, whose
- *        text length must be strictly positive.
- *
- * @param pErrorCode must be a valid pointer to an error code value.
- *
- * @return The levels array for the text,
- *         or <code>NULL</code> if an error occurs.
- *
- * @see UBiDiLevel
- * @see ubidi_getProcessedLength
- * @stable ICU 2.0
- */
-U_STABLE const UBiDiLevel * U_EXPORT2
-ubidi_getLevels(UBiDi *pBiDi, UErrorCode *pErrorCode);
-
-/**
- * Get a logical run.
- * This function returns information about a run and is used
- * to retrieve runs in logical order.<p>
- * This is especially useful for line-breaking on a paragraph.
- *
- * @param pBiDi is the paragraph or line <code>UBiDi</code> object.
- *
- * @param logicalPosition is a logical position within the source text.
- *
- * @param pLogicalLimit will receive the limit of the corresponding run.
- *        The l-value that you point to here may be the
- *        same expression (variable) as the one for
- *        <code>logicalPosition</code>.
- *        This pointer can be <code>NULL</code> if this
- *        value is not necessary.
- *
- * @param pLevel will receive the level of the corresponding run.
- *        This pointer can be <code>NULL</code> if this
- *        value is not necessary.
- *
- * @see ubidi_getProcessedLength
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2
-ubidi_getLogicalRun(const UBiDi *pBiDi, int32_t logicalPosition,
-                    int32_t *pLogicalLimit, UBiDiLevel *pLevel);
-
-/**
- * Get the number of runs.
- * This function may invoke the actual reordering on the
- * <code>UBiDi</code> object, after <code>ubidi_setPara()</code>
- * may have resolved only the levels of the text. Therefore,
- * <code>ubidi_countRuns()</code> may have to allocate memory,
- * and may fail doing so.
- *
- * @param pBiDi is the paragraph or line <code>UBiDi</code> object.
- *
- * @param pErrorCode must be a valid pointer to an error code value.
- *
- * @return The number of runs.
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2
-ubidi_countRuns(UBiDi *pBiDi, UErrorCode *pErrorCode);
-
-/**
- * Get one run's logical start, length, and directionality,
- * which can be 0 for LTR or 1 for RTL.
- * In an RTL run, the character at the logical start is
- * visually on the right of the displayed run.
- * The length is the number of characters in the run.<p>
- * <code>ubidi_countRuns()</code> should be called
- * before the runs are retrieved.
- *
- * @param pBiDi is the paragraph or line <code>UBiDi</code> object.
- *
- * @param runIndex is the number of the run in visual order, in the
- *        range <code>[0..ubidi_countRuns(pBiDi)-1]</code>.
- *
- * @param pLogicalStart is the first logical character index in the text.
- *        The pointer may be <code>NULL</code> if this index is not needed.
- *
- * @param pLength is the number of characters (at least one) in the run.
- *        The pointer may be <code>NULL</code> if this is not needed.
- *
- * @return the directionality of the run,
- *         <code>UBIDI_LTR==0</code> or <code>UBIDI_RTL==1</code>,
- *         never <code>UBIDI_MIXED</code>.
- *
- * @see ubidi_countRuns
- *
- * Example:
- * <pre>
- * \code
- * int32_t i, count=ubidi_countRuns(pBiDi),
- *         logicalStart, visualIndex=0, length;
- * for(i=0; i<count; ++i) {
- *    if(UBIDI_LTR==ubidi_getVisualRun(pBiDi, i, &logicalStart, &length)) {
- *         do { // LTR
- *             show_char(text[logicalStart++], visualIndex++);
- *         } while(--length>0);
- *     } else {
- *         logicalStart+=length;  // logicalLimit
- *         do { // RTL
- *             show_char(text[--logicalStart], visualIndex++);
- *         } while(--length>0);
- *     }
- * }
- *\endcode
- * </pre>
- *
- * Note that in right-to-left runs, code like this places
- * second surrogates before first ones (which is generally a bad idea)
- * and combining characters before base characters.
- * <p>
- * Use of <code>ubidi_writeReordered()</code>, optionally with the
- * <code>#UBIDI_KEEP_BASE_COMBINING</code> option, can be considered in order
- * to avoid these issues.
- * @stable ICU 2.0
- */
-U_STABLE UBiDiDirection U_EXPORT2
-ubidi_getVisualRun(UBiDi *pBiDi, int32_t runIndex,
-                   int32_t *pLogicalStart, int32_t *pLength);
-
-/**
- * Get the visual position from a logical text position.
- * If such a mapping is used many times on the same
- * <code>UBiDi</code> object, then calling
- * <code>ubidi_getLogicalMap()</code> is more efficient.<p>
- *
- * The value returned may be <code>#UBIDI_MAP_NOWHERE</code> if there is no
- * visual position because the corresponding text character is a Bidi control
- * removed from output by the option <code>#UBIDI_OPTION_REMOVE_CONTROLS</code>.
- * <p>
- * When the visual output is altered by using options of
- * <code>ubidi_writeReordered()</code> such as <code>UBIDI_INSERT_LRM_FOR_NUMERIC</code>,
- * <code>UBIDI_KEEP_BASE_COMBINING</code>, <code>UBIDI_OUTPUT_REVERSE</code>,
- * <code>UBIDI_REMOVE_BIDI_CONTROLS</code>, the visual position returned may not
- * be correct. It is advised to use, when possible, reordering options
- * such as <code>UBIDI_OPTION_INSERT_MARKS</code> and <code>UBIDI_OPTION_REMOVE_CONTROLS</code>.
- * <p>
- * Note that in right-to-left runs, this mapping places
- * second surrogates before first ones (which is generally a bad idea)
- * and combining characters before base characters.
- * Use of <code>ubidi_writeReordered()</code>, optionally with the
- * <code>#UBIDI_KEEP_BASE_COMBINING</code> option can be considered instead
- * of using the mapping, in order to avoid these issues.
- *
- * @param pBiDi is the paragraph or line <code>UBiDi</code> object.
- *
- * @param logicalIndex is the index of a character in the text.
- *
- * @param pErrorCode must be a valid pointer to an error code value.
- *
- * @return The visual position of this character.
- *
- * @see ubidi_getLogicalMap
- * @see ubidi_getLogicalIndex
- * @see ubidi_getProcessedLength
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2
-ubidi_getVisualIndex(UBiDi *pBiDi, int32_t logicalIndex, UErrorCode *pErrorCode);
-
-/**
- * Get the logical text position from a visual position.
- * If such a mapping is used many times on the same
- * <code>UBiDi</code> object, then calling
- * <code>ubidi_getVisualMap()</code> is more efficient.<p>
- *
- * The value returned may be <code>#UBIDI_MAP_NOWHERE</code> if there is no
- * logical position because the corresponding text character is a Bidi mark
- * inserted in the output by option <code>#UBIDI_OPTION_INSERT_MARKS</code>.
- * <p>
- * This is the inverse function to <code>ubidi_getVisualIndex()</code>.
- * <p>
- * When the visual output is altered by using options of
- * <code>ubidi_writeReordered()</code> such as <code>UBIDI_INSERT_LRM_FOR_NUMERIC</code>,
- * <code>UBIDI_KEEP_BASE_COMBINING</code>, <code>UBIDI_OUTPUT_REVERSE</code>,
- * <code>UBIDI_REMOVE_BIDI_CONTROLS</code>, the logical position returned may not
- * be correct. It is advised to use, when possible, reordering options
- * such as <code>UBIDI_OPTION_INSERT_MARKS</code> and <code>UBIDI_OPTION_REMOVE_CONTROLS</code>.
- *
- * @param pBiDi is the paragraph or line <code>UBiDi</code> object.
- *
- * @param visualIndex is the visual position of a character.
- *
- * @param pErrorCode must be a valid pointer to an error code value.
- *
- * @return The index of this character in the text.
- *
- * @see ubidi_getVisualMap
- * @see ubidi_getVisualIndex
- * @see ubidi_getResultLength
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2
-ubidi_getLogicalIndex(UBiDi *pBiDi, int32_t visualIndex, UErrorCode *pErrorCode);
-
-/**
- * Get a logical-to-visual index map (array) for the characters in the UBiDi
- * (paragraph or line) object.
- * <p>
- * Some values in the map may be <code>#UBIDI_MAP_NOWHERE</code> if the
- * corresponding text characters are Bidi controls removed from the visual
- * output by the option <code>#UBIDI_OPTION_REMOVE_CONTROLS</code>.
- * <p>
- * When the visual output is altered by using options of
- * <code>ubidi_writeReordered()</code> such as <code>UBIDI_INSERT_LRM_FOR_NUMERIC</code>,
- * <code>UBIDI_KEEP_BASE_COMBINING</code>, <code>UBIDI_OUTPUT_REVERSE</code>,
- * <code>UBIDI_REMOVE_BIDI_CONTROLS</code>, the visual positions returned may not
- * be correct. It is advised to use, when possible, reordering options
- * such as <code>UBIDI_OPTION_INSERT_MARKS</code> and <code>UBIDI_OPTION_REMOVE_CONTROLS</code>.
- * <p>
- * Note that in right-to-left runs, this mapping places
- * second surrogates before first ones (which is generally a bad idea)
- * and combining characters before base characters.
- * Use of <code>ubidi_writeReordered()</code>, optionally with the
- * <code>#UBIDI_KEEP_BASE_COMBINING</code> option can be considered instead
- * of using the mapping, in order to avoid these issues.
- *
- * @param pBiDi is the paragraph or line <code>UBiDi</code> object.
- *
- * @param indexMap is a pointer to an array of <code>ubidi_getProcessedLength()</code>
- *        indexes which will reflect the reordering of the characters.
- *        If option <code>#UBIDI_OPTION_INSERT_MARKS</code> is set, the number
- *        of elements allocated in <code>indexMap</code> must be no less than
- *        <code>ubidi_getResultLength()</code>.
- *        The array does not need to be initialized.<br><br>
- *        The index map will result in <code>indexMap[logicalIndex]==visualIndex</code>.
- *
- * @param pErrorCode must be a valid pointer to an error code value.
- *
- * @see ubidi_getVisualMap
- * @see ubidi_getVisualIndex
- * @see ubidi_getProcessedLength
- * @see ubidi_getResultLength
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2
-ubidi_getLogicalMap(UBiDi *pBiDi, int32_t *indexMap, UErrorCode *pErrorCode);
-
-/**
- * Get a visual-to-logical index map (array) for the characters in the UBiDi
- * (paragraph or line) object.
- * <p>
- * Some values in the map may be <code>#UBIDI_MAP_NOWHERE</code> if the
- * corresponding text characters are Bidi marks inserted in the visual output
- * by the option <code>#UBIDI_OPTION_INSERT_MARKS</code>.
- * <p>
- * When the visual output is altered by using options of
- * <code>ubidi_writeReordered()</code> such as <code>UBIDI_INSERT_LRM_FOR_NUMERIC</code>,
- * <code>UBIDI_KEEP_BASE_COMBINING</code>, <code>UBIDI_OUTPUT_REVERSE</code>,
- * <code>UBIDI_REMOVE_BIDI_CONTROLS</code>, the logical positions returned may not
- * be correct. It is advised to use, when possible, reordering options
- * such as <code>UBIDI_OPTION_INSERT_MARKS</code> and <code>UBIDI_OPTION_REMOVE_CONTROLS</code>.
- *
- * @param pBiDi is the paragraph or line <code>UBiDi</code> object.
- *
- * @param indexMap is a pointer to an array of <code>ubidi_getResultLength()</code>
- *        indexes which will reflect the reordering of the characters.
- *        If option <code>#UBIDI_OPTION_REMOVE_CONTROLS</code> is set, the number
- *        of elements allocated in <code>indexMap</code> must be no less than
- *        <code>ubidi_getProcessedLength()</code>.
- *        The array does not need to be initialized.<br><br>
- *        The index map will result in <code>indexMap[visualIndex]==logicalIndex</code>.
- *
- * @param pErrorCode must be a valid pointer to an error code value.
- *
- * @see ubidi_getLogicalMap
- * @see ubidi_getLogicalIndex
- * @see ubidi_getProcessedLength
- * @see ubidi_getResultLength
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2
-ubidi_getVisualMap(UBiDi *pBiDi, int32_t *indexMap, UErrorCode *pErrorCode);
-
-/**
- * This is a convenience function that does not use a UBiDi object.
- * It is intended to be used for when an application has determined the levels
- * of objects (character sequences) and just needs to have them reordered (L2).
- * This is equivalent to using <code>ubidi_getLogicalMap()</code> on a
- * <code>UBiDi</code> object.
- *
- * @param levels is an array with <code>length</code> levels that have been determined by
- *        the application.
- *
- * @param length is the number of levels in the array, or, semantically,
- *        the number of objects to be reordered.
- *        It must be <code>length>0</code>.
- *
- * @param indexMap is a pointer to an array of <code>length</code>
- *        indexes which will reflect the reordering of the characters.
- *        The array does not need to be initialized.<p>
- *        The index map will result in <code>indexMap[logicalIndex]==visualIndex</code>.
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2
-ubidi_reorderLogical(const UBiDiLevel *levels, int32_t length, int32_t *indexMap);
-
-/**
- * This is a convenience function that does not use a UBiDi object.
- * It is intended to be used for when an application has determined the levels
- * of objects (character sequences) and just needs to have them reordered (L2).
- * This is equivalent to using <code>ubidi_getVisualMap()</code> on a
- * <code>UBiDi</code> object.
- *
- * @param levels is an array with <code>length</code> levels that have been determined by
- *        the application.
- *
- * @param length is the number of levels in the array, or, semantically,
- *        the number of objects to be reordered.
- *        It must be <code>length>0</code>.
- *
- * @param indexMap is a pointer to an array of <code>length</code>
- *        indexes which will reflect the reordering of the characters.
- *        The array does not need to be initialized.<p>
- *        The index map will result in <code>indexMap[visualIndex]==logicalIndex</code>.
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2
-ubidi_reorderVisual(const UBiDiLevel *levels, int32_t length, int32_t *indexMap);
-
-/**
- * Invert an index map.
- * The index mapping of the first map is inverted and written to
- * the second one.
- *
- * @param srcMap is an array with <code>length</code> elements
- *        which defines the original mapping from a source array containing
- *        <code>length</code> elements to a destination array.
- *        Some elements of the source array may have no mapping in the
- *        destination array. In that case, their value will be
- *        the special value <code>UBIDI_MAP_NOWHERE</code>.
- *        All elements must be >=0 or equal to <code>UBIDI_MAP_NOWHERE</code>.
- *        Some elements may have a value >= <code>length</code>, if the
- *        destination array has more elements than the source array.
- *        There must be no duplicate indexes (two or more elements with the
- *        same value except <code>UBIDI_MAP_NOWHERE</code>).
- *
- * @param destMap is an array with a number of elements equal to 1 + the highest
- *        value in <code>srcMap</code>.
- *        <code>destMap</code> will be filled with the inverse mapping.
- *        If element with index i in <code>srcMap</code> has a value k different
- *        from <code>UBIDI_MAP_NOWHERE</code>, this means that element i of
- *        the source array maps to element k in the destination array.
- *        The inverse map will have value i in its k-th element.
- *        For all elements of the destination array which do not map to
- *        an element in the source array, the corresponding element in the
- *        inverse map will have a value equal to <code>UBIDI_MAP_NOWHERE</code>.
- *
- * @param length is the length of each array.
- * @see UBIDI_MAP_NOWHERE
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2
-ubidi_invertMap(const int32_t *srcMap, int32_t *destMap, int32_t length);
-
-/** option flags for ubidi_writeReordered() */
-
-/**
- * option bit for ubidi_writeReordered():
- * keep combining characters after their base characters in RTL runs
- *
- * @see ubidi_writeReordered
- * @stable ICU 2.0
- */
-#define UBIDI_KEEP_BASE_COMBINING       1
-
-/**
- * option bit for ubidi_writeReordered():
- * replace characters with the "mirrored" property in RTL runs
- * by their mirror-image mappings
- *
- * @see ubidi_writeReordered
- * @stable ICU 2.0
- */
-#define UBIDI_DO_MIRRORING              2
-
-/**
- * option bit for ubidi_writeReordered():
- * surround the run with LRMs if necessary;
- * this is part of the approximate "inverse Bidi" algorithm
- *
- * <p>This option does not imply corresponding adjustment of the index
- * mappings.</p>
- *
- * @see ubidi_setInverse
- * @see ubidi_writeReordered
- * @stable ICU 2.0
- */
-#define UBIDI_INSERT_LRM_FOR_NUMERIC    4
-
-/**
- * option bit for ubidi_writeReordered():
- * remove Bidi control characters
- * (this does not affect #UBIDI_INSERT_LRM_FOR_NUMERIC)
- *
- * <p>This option does not imply corresponding adjustment of the index
- * mappings.</p>
- *
- * @see ubidi_writeReordered
- * @stable ICU 2.0
- */
-#define UBIDI_REMOVE_BIDI_CONTROLS      8
-
-/**
- * option bit for ubidi_writeReordered():
- * write the output in reverse order
- *
- * <p>This has the same effect as calling <code>ubidi_writeReordered()</code>
- * first without this option, and then calling
- * <code>ubidi_writeReverse()</code> without mirroring.
- * Doing this in the same step is faster and avoids a temporary buffer.
- * An example for using this option is output to a character terminal that
- * is designed for RTL scripts and stores text in reverse order.</p>
- *
- * @see ubidi_writeReordered
- * @stable ICU 2.0
- */
-#define UBIDI_OUTPUT_REVERSE            16
-
-/**
- * Get the length of the source text processed by the last call to
- * <code>ubidi_setPara()</code>. This length may be different from the length
- * of the source text if option <code>#UBIDI_OPTION_STREAMING</code>
- * has been set.
- * <br>
- * Note that whenever the length of the text affects the execution or the
- * result of a function, it is the processed length which must be considered,
- * except for <code>ubidi_setPara</code> (which receives unprocessed source
- * text) and <code>ubidi_getLength</code> (which returns the original length
- * of the source text).<br>
- * In particular, the processed length is the one to consider in the following
- * cases:
- * <ul>
- * <li>maximum value of the <code>limit</code> argument of
- * <code>ubidi_setLine</code></li>
- * <li>maximum value of the <code>charIndex</code> argument of
- * <code>ubidi_getParagraph</code></li>
- * <li>maximum value of the <code>charIndex</code> argument of
- * <code>ubidi_getLevelAt</code></li>
- * <li>number of elements in the array returned by <code>ubidi_getLevels</code></li>
- * <li>maximum value of the <code>logicalStart</code> argument of
- * <code>ubidi_getLogicalRun</code></li>
- * <li>maximum value of the <code>logicalIndex</code> argument of
- * <code>ubidi_getVisualIndex</code></li>
- * <li>number of elements filled in the <code>*indexMap</code> argument of
- * <code>ubidi_getLogicalMap</code></li>
- * <li>length of text processed by <code>ubidi_writeReordered</code></li>
- * </ul>
- *
- * @param pBiDi is the paragraph <code>UBiDi</code> object.
- *
- * @return The length of the part of the source text processed by
- *         the last call to <code>ubidi_setPara</code>.
- * @see ubidi_setPara
- * @see UBIDI_OPTION_STREAMING
- * @stable ICU 3.6
- */
-U_STABLE int32_t U_EXPORT2
-ubidi_getProcessedLength(const UBiDi *pBiDi);
-
-/**
- * Get the length of the reordered text resulting from the last call to
- * <code>ubidi_setPara()</code>. This length may be different from the length
- * of the source text if option <code>#UBIDI_OPTION_INSERT_MARKS</code>
- * or option <code>#UBIDI_OPTION_REMOVE_CONTROLS</code> has been set.
- * <br>
- * This resulting length is the one to consider in the following cases:
- * <ul>
- * <li>maximum value of the <code>visualIndex</code> argument of
- * <code>ubidi_getLogicalIndex</code></li>
- * <li>number of elements of the <code>*indexMap</code> argument of
- * <code>ubidi_getVisualMap</code></li>
- * </ul>
- * Note that this length stays identical to the source text length if
- * Bidi marks are inserted or removed using option bits of
- * <code>ubidi_writeReordered</code>, or if option
- * <code>#UBIDI_REORDER_INVERSE_NUMBERS_AS_L</code> has been set.
- *
- * @param pBiDi is the paragraph <code>UBiDi</code> object.
- *
- * @return The length of the reordered text resulting from
- *         the last call to <code>ubidi_setPara</code>.
- * @see ubidi_setPara
- * @see UBIDI_OPTION_INSERT_MARKS
- * @see UBIDI_OPTION_REMOVE_CONTROLS
- * @stable ICU 3.6
- */
-U_STABLE int32_t U_EXPORT2
-ubidi_getResultLength(const UBiDi *pBiDi);
-
-U_CDECL_BEGIN
-/**
- * value returned by <code>UBiDiClassCallback</code> callbacks when
- * there is no need to override the standard Bidi class for a given code point.
- * @see UBiDiClassCallback
- * @stable ICU 3.6
- */
-#define U_BIDI_CLASS_DEFAULT  U_CHAR_DIRECTION_COUNT
-
-/**
- * Callback type declaration for overriding default Bidi class values with
- * custom ones.
- * <p>Usually, the function pointer will be propagated to a <code>UBiDi</code>
- * object by calling the <code>ubidi_setClassCallback()</code> function;
- * then the callback will be invoked by the UBA implementation any time the
- * class of a character is to be determined.</p>
- *
- * @param context is a pointer to the callback private data.
- *
- * @param c       is the code point to get a Bidi class for.
- *
- * @return The directional property / Bidi class for the given code point
- *         <code>c</code> if the default class has been overridden, or
- *         <code>#U_BIDI_CLASS_DEFAULT</code> if the standard Bidi class value
- *         for <code>c</code> is to be used.
- * @see ubidi_setClassCallback
- * @see ubidi_getClassCallback
- * @stable ICU 3.6
- */
-typedef UCharDirection U_CALLCONV
-UBiDiClassCallback(const void *context, UChar32 c);
-
-U_CDECL_END
-
-/**
- * Retrieve the Bidi class for a given code point.
- * <p>If a <code>#UBiDiClassCallback</code> callback is defined and returns a
- * value other than <code>#U_BIDI_CLASS_DEFAULT</code>, that value is used;
- * otherwise the default class determination mechanism is invoked.</p>
- *
- * @param pBiDi is the paragraph <code>UBiDi</code> object.
- *
- * @param c     is the code point whose Bidi class must be retrieved.
- *
- * @return The Bidi class for character <code>c</code> based
- *         on the given <code>pBiDi</code> instance.
- * @see UBiDiClassCallback
- * @stable ICU 3.6
- */
-U_STABLE UCharDirection U_EXPORT2
-ubidi_getCustomizedClass(UBiDi *pBiDi, UChar32 c);
-
-/**
- * Set the callback function and callback data used by the UBA
- * implementation for Bidi class determination.
- * <p>This may be useful for assigning Bidi classes to PUA characters, or
- * for special application needs. For instance, an application may want to
- * handle all spaces like L or R characters (according to the base direction)
- * when creating the visual ordering of logical lines which are part of a report
- * organized in columns: there should not be interaction between adjacent
- * cells.<p>
- *
- * @param pBiDi is the paragraph <code>UBiDi</code> object.
- *
- * @param newFn is the new callback function pointer.
- *
- * @param newContext is the new callback context pointer. This can be NULL.
- *
- * @param oldFn fillin: Returns the old callback function pointer. This can be
- *                      NULL.
- *
- * @param oldContext fillin: Returns the old callback's context. This can be
- *                           NULL.
- *
- * @param pErrorCode must be a valid pointer to an error code value.
- *
- * @see ubidi_getClassCallback
- * @stable ICU 3.6
- */
-U_STABLE void U_EXPORT2
-ubidi_setClassCallback(UBiDi *pBiDi, UBiDiClassCallback *newFn,
-                       const void *newContext, UBiDiClassCallback **oldFn,
-                       const void **oldContext, UErrorCode *pErrorCode);
-
-/**
- * Get the current callback function used for Bidi class determination.
- *
- * @param pBiDi is the paragraph <code>UBiDi</code> object.
- *
- * @param fn fillin: Returns the callback function pointer.
- *
- * @param context fillin: Returns the callback's private context.
- *
- * @see ubidi_setClassCallback
- * @stable ICU 3.6
- */
-U_STABLE void U_EXPORT2
-ubidi_getClassCallback(UBiDi *pBiDi, UBiDiClassCallback **fn, const void **context);
-
-/**
- * Take a <code>UBiDi</code> object containing the reordering
- * information for a piece of text (one or more paragraphs) set by
- * <code>ubidi_setPara()</code> or for a line of text set by
- * <code>ubidi_setLine()</code> and write a reordered string to the
- * destination buffer.
- *
- * This function preserves the integrity of characters with multiple
- * code units and (optionally) combining characters.
- * Characters in RTL runs can be replaced by mirror-image characters
- * in the destination buffer. Note that "real" mirroring has
- * to be done in a rendering engine by glyph selection
- * and that for many "mirrored" characters there are no
- * Unicode characters as mirror-image equivalents.
- * There are also options to insert or remove Bidi control
- * characters; see the description of the <code>destSize</code>
- * and <code>options</code> parameters and of the option bit flags.
- *
- * @param pBiDi A pointer to a <code>UBiDi</code> object that
- *              is set by <code>ubidi_setPara()</code> or
- *              <code>ubidi_setLine()</code> and contains the reordering
- *              information for the text that it was defined for,
- *              as well as a pointer to that text.<br><br>
- *              The text was aliased (only the pointer was stored
- *              without copying the contents) and must not have been modified
- *              since the <code>ubidi_setPara()</code> call.
- *
- * @param dest A pointer to where the reordered text is to be copied.
- *             The source text and <code>dest[destSize]</code>
- *             must not overlap.
- *
- * @param destSize The size of the <code>dest</code> buffer,
- *                 in number of UChars.
- *                 If the <code>UBIDI_INSERT_LRM_FOR_NUMERIC</code>
- *                 option is set, then the destination length could be
- *                 as large as
- *                 <code>ubidi_getLength(pBiDi)+2*ubidi_countRuns(pBiDi)</code>.
- *                 If the <code>UBIDI_REMOVE_BIDI_CONTROLS</code> option
- *                 is set, then the destination length may be less than
- *                 <code>ubidi_getLength(pBiDi)</code>.
- *                 If none of these options is set, then the destination length
- *                 will be exactly <code>ubidi_getProcessedLength(pBiDi)</code>.
- *
- * @param options A bit set of options for the reordering that control
- *                how the reordered text is written.
- *                The options include mirroring the characters on a code
- *                point basis and inserting LRM characters, which is used
- *                especially for transforming visually stored text
- *                to logically stored text (although this is still an
- *                imperfect implementation of an "inverse Bidi" algorithm
- *                because it uses the "forward Bidi" algorithm at its core).
- *                The available options are:
- *                <code>#UBIDI_DO_MIRRORING</code>,
- *                <code>#UBIDI_INSERT_LRM_FOR_NUMERIC</code>,
- *                <code>#UBIDI_KEEP_BASE_COMBINING</code>,
- *                <code>#UBIDI_OUTPUT_REVERSE</code>,
- *                <code>#UBIDI_REMOVE_BIDI_CONTROLS</code>
- *
- * @param pErrorCode must be a valid pointer to an error code value.
- *
- * @return The length of the output string.
- *
- * @see ubidi_getProcessedLength
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2
-ubidi_writeReordered(UBiDi *pBiDi,
-                     UChar *dest, int32_t destSize,
-                     uint16_t options,
-                     UErrorCode *pErrorCode);
-
-/**
- * Reverse a Right-To-Left run of Unicode text.
- *
- * This function preserves the integrity of characters with multiple
- * code units and (optionally) combining characters.
- * Characters can be replaced by mirror-image characters
- * in the destination buffer. Note that "real" mirroring has
- * to be done in a rendering engine by glyph selection
- * and that for many "mirrored" characters there are no
- * Unicode characters as mirror-image equivalents.
- * There are also options to insert or remove Bidi control
- * characters.
- *
- * This function is the implementation for reversing RTL runs as part
- * of <code>ubidi_writeReordered()</code>. For detailed descriptions
- * of the parameters, see there.
- * Since no Bidi controls are inserted here, the output string length
- * will never exceed <code>srcLength</code>.
- *
- * @see ubidi_writeReordered
- *
- * @param src A pointer to the RTL run text.
- *
- * @param srcLength The length of the RTL run.
- *
- * @param dest A pointer to where the reordered text is to be copied.
- *             <code>src[srcLength]</code> and <code>dest[destSize]</code>
- *             must not overlap.
- *
- * @param destSize The size of the <code>dest</code> buffer,
- *                 in number of UChars.
- *                 If the <code>UBIDI_REMOVE_BIDI_CONTROLS</code> option
- *                 is set, then the destination length may be less than
- *                 <code>srcLength</code>.
- *                 If this option is not set, then the destination length
- *                 will be exactly <code>srcLength</code>.
- *
- * @param options A bit set of options for the reordering that control
- *                how the reordered text is written.
- *                See the <code>options</code> parameter in <code>ubidi_writeReordered()</code>.
- *
- * @param pErrorCode must be a valid pointer to an error code value.
- *
- * @return The length of the output string.
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2
-ubidi_writeReverse(const UChar *src, int32_t srcLength,
-                   UChar *dest, int32_t destSize,
-                   uint16_t options,
-                   UErrorCode *pErrorCode);
-
-/*#define BIDI_SAMPLE_CODE*/
-/*@}*/
-
-#endif


[38/57] [abbrv] remove couch_collate

Posted by be...@apache.org.
http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/dcfmtsym.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/dcfmtsym.h b/apps/couch_collate/platform/osx/icu/unicode/dcfmtsym.h
deleted file mode 100644
index bc5547d..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/dcfmtsym.h
+++ /dev/null
@@ -1,370 +0,0 @@
-/*
-********************************************************************************
-*   Copyright (C) 1997-2007, International Business Machines
-*   Corporation and others.  All Rights Reserved.
-********************************************************************************
-*
-* File DCFMTSYM.H
-*
-* Modification History:
-* 
-*   Date        Name        Description
-*   02/19/97    aliu        Converted from java.
-*   03/18/97    clhuang     Updated per C++ implementation.
-*   03/27/97    helena      Updated to pass the simple test after code review.
-*   08/26/97    aliu        Added currency/intl currency symbol support.
-*   07/22/98    stephen     Changed to match C++ style 
-*                            currencySymbol -> fCurrencySymbol
-*                            Constants changed from CAPS to kCaps
-*   06/24/99    helena      Integrated Alan's NF enhancements and Java2 bug fixes
-*   09/22/00    grhoten     Marked deprecation tags with a pointer to replacement
-*                            functions.
-********************************************************************************
-*/
- 
-#ifndef DCFMTSYM_H
-#define DCFMTSYM_H
- 
-#include "unicode/utypes.h"
-
-#if !UCONFIG_NO_FORMATTING
-
-#include "unicode/uobject.h"
-#include "unicode/locid.h"
-
-/**
- * \file 
- * \brief C++ API: Symbols for formatting numbers.
- */
-
-
-U_NAMESPACE_BEGIN
-
-/**
- * This class represents the set of symbols needed by DecimalFormat
- * to format numbers. DecimalFormat creates for itself an instance of
- * DecimalFormatSymbols from its locale data.  If you need to change any
- * of these symbols, you can get the DecimalFormatSymbols object from
- * your DecimalFormat and modify it.
- * <P>
- * Here are the special characters used in the parts of the
- * subpattern, with notes on their usage.
- * <pre>
- * \code
- *        Symbol   Meaning
- *          0      a digit
- *          #      a digit, zero shows as absent
- *          .      placeholder for decimal separator
- *          ,      placeholder for grouping separator.
- *          ;      separates formats.
- *          -      default negative prefix.
- *          %      divide by 100 and show as percentage
- *          X      any other characters can be used in the prefix or suffix
- *          '      used to quote special characters in a prefix or suffix.
- * \endcode
- *  </pre>
- * [Notes]
- * <P>
- * If there is no explicit negative subpattern, - is prefixed to the
- * positive form. That is, "0.00" alone is equivalent to "0.00;-0.00".
- * <P>
- * The grouping separator is commonly used for thousands, but in some
- * countries for ten-thousands. The interval is a constant number of
- * digits between the grouping characters, such as 100,000,000 or 1,0000,0000.
- * If you supply a pattern with multiple grouping characters, the interval
- * between the last one and the end of the integer is the one that is
- * used. So "#,##,###,####" == "######,####" == "##,####,####".
- * <P>
- * This class only handles localized digits where the 10 digits are
- * contiguous in Unicode, from 0 to 9. Other digits sets (such as
- * superscripts) would need a different subclass.
- */
-class U_I18N_API DecimalFormatSymbols : public UObject {
-public:
-    /**
-     * Constants for specifying a number format symbol.
-     * @stable ICU 2.0
-     */
-    enum ENumberFormatSymbol {
-        /** The decimal separator */
-        kDecimalSeparatorSymbol,
-        /** The grouping separator */
-        kGroupingSeparatorSymbol,
-        /** The pattern separator */
-        kPatternSeparatorSymbol,
-        /** The percent sign */
-        kPercentSymbol,
-        /** Zero*/
-        kZeroDigitSymbol,
-        /** Character representing a digit in the pattern */
-        kDigitSymbol,
-        /** The minus sign */
-        kMinusSignSymbol,
-        /** The plus sign */
-        kPlusSignSymbol,
-        /** The currency symbol */
-        kCurrencySymbol,
-        /** The international currency symbol */
-        kIntlCurrencySymbol,
-        /** The monetary separator */
-        kMonetarySeparatorSymbol,
-        /** The exponential symbol */
-        kExponentialSymbol,
-        /** Per mill symbol - replaces kPermillSymbol */
-        kPerMillSymbol,
-        /** Escape padding character */
-        kPadEscapeSymbol,
-        /** Infinity symbol */
-        kInfinitySymbol,
-        /** Nan symbol */
-        kNaNSymbol,
-        /** Significant digit symbol
-         * @stable ICU 3.0 */
-        kSignificantDigitSymbol,
-        /** The monetary grouping separator 
-         * @stable ICU 3.6
-         */
-        kMonetaryGroupingSeparatorSymbol,
-        /** count symbol constants */
-        kFormatSymbolCount
-    };
-
-    /**
-     * Create a DecimalFormatSymbols object for the given locale.
-     *
-     * @param locale    The locale to get symbols for.
-     * @param status    Input/output parameter, set to success or
-     *                  failure code upon return.
-     * @stable ICU 2.0
-     */
-    DecimalFormatSymbols(const Locale& locale, UErrorCode& status);
-
-    /**
-     * Create a DecimalFormatSymbols object for the default locale.
-     * This constructor will not fail.  If the resource file data is
-     * not available, it will use hard-coded last-resort data and
-     * set status to U_USING_FALLBACK_ERROR.
-     *
-     * @param status    Input/output parameter, set to success or
-     *                  failure code upon return.
-     * @stable ICU 2.0
-     */
-    DecimalFormatSymbols( UErrorCode& status);
-
-    /**
-     * Copy constructor.
-     * @stable ICU 2.0
-     */
-    DecimalFormatSymbols(const DecimalFormatSymbols&);
-
-    /**
-     * Assignment operator.
-     * @stable ICU 2.0
-     */
-    DecimalFormatSymbols& operator=(const DecimalFormatSymbols&);
-
-    /**
-     * Destructor.
-     * @stable ICU 2.0
-     */
-    virtual ~DecimalFormatSymbols();
-
-    /**
-     * Return true if another object is semantically equal to this one.
-     *
-     * @param other    the object to be compared with.
-     * @return         true if another object is semantically equal to this one.
-     * @stable ICU 2.0
-     */
-    UBool operator==(const DecimalFormatSymbols& other) const;
-
-    /**
-     * Return true if another object is semantically unequal to this one.
-     *
-     * @param other    the object to be compared with.
-     * @return         true if another object is semantically unequal to this one.
-     * @stable ICU 2.0
-     */
-    UBool operator!=(const DecimalFormatSymbols& other) const { return !operator==(other); }
-
-    /**
-     * Get one of the format symbols by its enum constant.
-     * Each symbol is stored as a string so that graphemes
-     * (characters with modifyer letters) can be used.
-     *
-     * @param symbol    Constant to indicate a number format symbol.
-     * @return    the format symbols by the param 'symbol'
-     * @stable ICU 2.0
-     */
-    inline UnicodeString getSymbol(ENumberFormatSymbol symbol) const;
-
-    /**
-     * Set one of the format symbols by its enum constant.
-     * Each symbol is stored as a string so that graphemes
-     * (characters with modifyer letters) can be used.
-     *
-     * @param symbol    Constant to indicate a number format symbol.
-     * @param value     value of the format sybmol
-     * @stable ICU 2.0
-     */
-    void setSymbol(ENumberFormatSymbol symbol, const UnicodeString &value);
-
-    /**
-     * Returns the locale for which this object was constructed.
-     * @stable ICU 2.6
-     */
-    inline Locale getLocale() const;
-
-    /**
-     * Returns the locale for this object. Two flavors are available:
-     * valid and actual locale.
-     * @stable ICU 2.8
-     */
-    Locale getLocale(ULocDataLocaleType type, UErrorCode& status) const;
-
-    /**
-     * ICU "poor man's RTTI", returns a UClassID for the actual class.
-     *
-     * @stable ICU 2.2
-     */
-    virtual UClassID getDynamicClassID() const;
-
-    /**
-     * ICU "poor man's RTTI", returns a UClassID for this class.
-     *
-     * @stable ICU 2.2
-     */
-    static UClassID U_EXPORT2 getStaticClassID();
-
-private:
-    DecimalFormatSymbols(); // default constructor not implemented
-
-    /**
-     * Initializes the symbols from the LocaleElements resource bundle.
-     * Note: The organization of LocaleElements badly needs to be
-     * cleaned up.
-     *
-     * @param locale               The locale to get symbols for.
-     * @param success              Input/output parameter, set to success or
-     *                             failure code upon return.
-     * @param useLastResortData    determine if use last resort data
-     */
-    void initialize(const Locale& locale, UErrorCode& success, UBool useLastResortData = FALSE);
-
-    /**
-     * Initialize the symbols from the given array of UnicodeStrings.
-     * The array must be of the correct size.
-     * 
-     * @param numberElements    the number format symbols
-     * @param numberElementsLength length of numberElements
-     */
-    void initialize(const UChar** numberElements, int32_t *numberElementsStrLen, int32_t numberElementsLength);
-
-    /**
-     * Initialize the symbols with default values.
-     */
-    void initialize();
-
-    void setCurrencyForSymbols();
-
-public:
-    /**
-     * _Internal_ function - more efficient version of getSymbol,
-     * returning a const reference to one of the symbol strings.
-     * The returned reference becomes invalid when the symbol is changed
-     * or when the DecimalFormatSymbols are destroyed.
-     * ### TODO markus 2002oct11: Consider proposing getConstSymbol() to be really public.
-     *
-     * @param symbol Constant to indicate a number format symbol.
-     * @return the format symbol by the param 'symbol'
-     * @internal
-     */
-    inline const UnicodeString &getConstSymbol(ENumberFormatSymbol symbol) const;
-
-    /**
-     * Returns that pattern stored in currecy info. Internal API for use by NumberFormat API.
-     * @internal
-     */
-    inline const UChar* getCurrencyPattern(void) const;
-
-private:
-    /**
-     * Private symbol strings.
-     * They are either loaded from a resource bundle or otherwise owned.
-     * setSymbol() clones the symbol string.
-     * Readonly aliases can only come from a resource bundle, so that we can always
-     * use fastCopyFrom() with them.
-     *
-     * If DecimalFormatSymbols becomes subclassable and the status of fSymbols changes
-     * from private to protected,
-     * or when fSymbols can be set any other way that allows them to be readonly aliases
-     * to non-resource bundle strings,
-     * then regular UnicodeString copies must be used instead of fastCopyFrom().
-     *
-     * @internal
-     */
-    UnicodeString fSymbols[kFormatSymbolCount];
-
-    /**
-     * Non-symbol variable for getConstSymbol(). Always empty.
-     * @internal
-     */
-    UnicodeString fNoSymbol;
-
-    Locale locale;
-
-    char actualLocale[ULOC_FULLNAME_CAPACITY];
-    char validLocale[ULOC_FULLNAME_CAPACITY];
-    const UChar* currPattern;
-};
-
-// -------------------------------------
-
-inline UnicodeString
-DecimalFormatSymbols::getSymbol(ENumberFormatSymbol symbol) const {
-    const UnicodeString *strPtr;
-    if(symbol < kFormatSymbolCount) {
-        strPtr = &fSymbols[symbol];
-    } else {
-        strPtr = &fNoSymbol;
-    }
-    return *strPtr;
-}
-
-inline const UnicodeString &
-DecimalFormatSymbols::getConstSymbol(ENumberFormatSymbol symbol) const {
-    const UnicodeString *strPtr;
-    if(symbol < kFormatSymbolCount) {
-        strPtr = &fSymbols[symbol];
-    } else {
-        strPtr = &fNoSymbol;
-    }
-    return *strPtr;
-}
-
-// -------------------------------------
-
-inline void
-DecimalFormatSymbols::setSymbol(ENumberFormatSymbol symbol, const UnicodeString &value) {
-    if(symbol<kFormatSymbolCount) {
-        fSymbols[symbol]=value;
-    }
-}
-
-// -------------------------------------
-
-inline Locale
-DecimalFormatSymbols::getLocale() const {
-    return locale;
-}
-
-inline const UChar*
-DecimalFormatSymbols::getCurrencyPattern() const {
-    return currPattern;
-}
-U_NAMESPACE_END
-
-#endif /* #if !UCONFIG_NO_FORMATTING */
-
-#endif // _DCFMTSYM
-//eof


[34/57] [abbrv] remove couch_collate

Posted by be...@apache.org.
http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/gregocal.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/gregocal.h b/apps/couch_collate/platform/osx/icu/unicode/gregocal.h
deleted file mode 100644
index f2d1b0b..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/gregocal.h
+++ /dev/null
@@ -1,823 +0,0 @@
-/*
-* Copyright (C) 1997-2006, International Business Machines Corporation and others.
-* All Rights Reserved.
-********************************************************************************
-*
-* File GREGOCAL.H
-*
-* Modification History:
-*
-*   Date        Name        Description
-*   04/22/97    aliu        Overhauled header.
-*    07/28/98    stephen        Sync with JDK 1.2
-*    09/04/98    stephen        Re-sync with JDK 8/31 putback
-*    09/14/98    stephen        Changed type of kOneDay, kOneWeek to double.
-*                            Fixed bug in roll()
-*   10/15/99    aliu        Fixed j31, incorrect WEEK_OF_YEAR computation.
-*                           Added documentation of WEEK_OF_YEAR computation.
-*   10/15/99    aliu        Fixed j32, cannot set date to Feb 29 2000 AD.
-*                           {JDK bug 4210209 4209272}
-*   11/07/2003  srl         Update, clean up documentation.
-********************************************************************************
-*/
-
-#ifndef GREGOCAL_H
-#define GREGOCAL_H
-
-#include "unicode/utypes.h"
-
-#if !UCONFIG_NO_FORMATTING
-
-#include "unicode/calendar.h"
-
-/**
- * \file 
- * \brief C++ API: Concrete class which provides the standard calendar.
- */
-
-U_NAMESPACE_BEGIN
-
-/** 
- * Concrete class which provides the standard calendar used by most of the world.
- * <P>
- * The standard (Gregorian) calendar has 2 eras, BC and AD.
- * <P>
- * This implementation handles a single discontinuity, which corresponds by default to
- * the date the Gregorian calendar was originally instituted (October 15, 1582). Not all
- * countries adopted the Gregorian calendar then, so this cutover date may be changed by
- * the caller.
- * <P>
- * Prior to the institution of the Gregorian Calendar, New Year's Day was March 25. To
- * avoid confusion, this Calendar always uses January 1. A manual adjustment may be made
- * if desired for dates that are prior to the Gregorian changeover and which fall
- * between January 1 and March 24.
- *
- * <p>Values calculated for the <code>WEEK_OF_YEAR</code> field range from 1 to
- * 53.  Week 1 for a year is the first week that contains at least
- * <code>getMinimalDaysInFirstWeek()</code> days from that year.  It thus
- * depends on the values of <code>getMinimalDaysInFirstWeek()</code>,
- * <code>getFirstDayOfWeek()</code>, and the day of the week of January 1.
- * Weeks between week 1 of one year and week 1 of the following year are
- * numbered sequentially from 2 to 52 or 53 (as needed).
- *
- * <p>For example, January 1, 1998 was a Thursday.  If
- * <code>getFirstDayOfWeek()</code> is <code>MONDAY</code> and
- * <code>getMinimalDaysInFirstWeek()</code> is 4 (these are the values
- * reflecting ISO 8601 and many national standards), then week 1 of 1998 starts
- * on December 29, 1997, and ends on January 4, 1998.  If, however,
- * <code>getFirstDayOfWeek()</code> is <code>SUNDAY</code>, then week 1 of 1998
- * starts on January 4, 1998, and ends on January 10, 1998; the first three days
- * of 1998 then are part of week 53 of 1997.
- *
- * <p>Example for using GregorianCalendar:
- * <pre>
- * \code
- *     // get the supported ids for GMT-08:00 (Pacific Standard Time)
- *     UErrorCode success = U_ZERO_ERROR;
- *     const StringEnumeration *ids = TimeZone::createEnumeration(-8 * 60 * 60 * 1000);
- *     // if no ids were returned, something is wrong. get out.
- *     if (ids == 0 || ids->count(success) == 0) {
- *         return;
- *     }
- *
- *     // begin output
- *     cout << "Current Time" << endl;
- *
- *     // create a Pacific Standard Time time zone
- *     SimpleTimeZone* pdt = new SimpleTimeZone(-8 * 60 * 60 * 1000, ids->unext(NULL, success)));
- *
- *     // set up rules for daylight savings time
- *     pdt->setStartRule(Calendar::APRIL, 1, Calendar::SUNDAY, 2 * 60 * 60 * 1000);
- *     pdt->setEndRule(Calendar::OCTOBER, -1, Calendar::SUNDAY, 2 * 60 * 60 * 1000);
- *
- *     // create a GregorianCalendar with the Pacific Daylight time zone
- *     // and the current date and time
- *     Calendar* calendar = new GregorianCalendar( pdt, success );
- *
- *     // print out a bunch of interesting things
- *     cout << "ERA: " << calendar->get( Calendar::ERA, success ) << endl;
- *     cout << "YEAR: " << calendar->get( Calendar::YEAR, success ) << endl;
- *     cout << "MONTH: " << calendar->get( Calendar::MONTH, success ) << endl;
- *     cout << "WEEK_OF_YEAR: " << calendar->get( Calendar::WEEK_OF_YEAR, success ) << endl;
- *     cout << "WEEK_OF_MONTH: " << calendar->get( Calendar::WEEK_OF_MONTH, success ) << endl;
- *     cout << "DATE: " << calendar->get( Calendar::DATE, success ) << endl;
- *     cout << "DAY_OF_MONTH: " << calendar->get( Calendar::DAY_OF_MONTH, success ) << endl;
- *     cout << "DAY_OF_YEAR: " << calendar->get( Calendar::DAY_OF_YEAR, success ) << endl;
- *     cout << "DAY_OF_WEEK: " << calendar->get( Calendar::DAY_OF_WEEK, success ) << endl;
- *     cout << "DAY_OF_WEEK_IN_MONTH: " << calendar->get( Calendar::DAY_OF_WEEK_IN_MONTH, success ) << endl;
- *     cout << "AM_PM: " << calendar->get( Calendar::AM_PM, success ) << endl;
- *     cout << "HOUR: " << calendar->get( Calendar::HOUR, success ) << endl;
- *     cout << "HOUR_OF_DAY: " << calendar->get( Calendar::HOUR_OF_DAY, success ) << endl;
- *     cout << "MINUTE: " << calendar->get( Calendar::MINUTE, success ) << endl;
- *     cout << "SECOND: " << calendar->get( Calendar::SECOND, success ) << endl;
- *     cout << "MILLISECOND: " << calendar->get( Calendar::MILLISECOND, success ) << endl;
- *     cout << "ZONE_OFFSET: " << (calendar->get( Calendar::ZONE_OFFSET, success )/(60*60*1000)) << endl;
- *     cout << "DST_OFFSET: " << (calendar->get( Calendar::DST_OFFSET, success )/(60*60*1000)) << endl;
- *
- *     cout << "Current Time, with hour reset to 3" << endl;
- *     calendar->clear(Calendar::HOUR_OF_DAY); // so doesn't override
- *     calendar->set(Calendar::HOUR, 3);
- *     cout << "ERA: " << calendar->get( Calendar::ERA, success ) << endl;
- *     cout << "YEAR: " << calendar->get( Calendar::YEAR, success ) << endl;
- *     cout << "MONTH: " << calendar->get( Calendar::MONTH, success ) << endl;
- *     cout << "WEEK_OF_YEAR: " << calendar->get( Calendar::WEEK_OF_YEAR, success ) << endl;
- *     cout << "WEEK_OF_MONTH: " << calendar->get( Calendar::WEEK_OF_MONTH, success ) << endl;
- *     cout << "DATE: " << calendar->get( Calendar::DATE, success ) << endl;
- *     cout << "DAY_OF_MONTH: " << calendar->get( Calendar::DAY_OF_MONTH, success ) << endl;
- *     cout << "DAY_OF_YEAR: " << calendar->get( Calendar::DAY_OF_YEAR, success ) << endl;
- *     cout << "DAY_OF_WEEK: " << calendar->get( Calendar::DAY_OF_WEEK, success ) << endl;
- *     cout << "DAY_OF_WEEK_IN_MONTH: " << calendar->get( Calendar::DAY_OF_WEEK_IN_MONTH, success ) << endl;
- *     cout << "AM_PM: " << calendar->get( Calendar::AM_PM, success ) << endl;
- *     cout << "HOUR: " << calendar->get( Calendar::HOUR, success ) << endl;
- *     cout << "HOUR_OF_DAY: " << calendar->get( Calendar::HOUR_OF_DAY, success ) << endl;
- *     cout << "MINUTE: " << calendar->get( Calendar::MINUTE, success ) << endl;
- *     cout << "SECOND: " << calendar->get( Calendar::SECOND, success ) << endl;
- *     cout << "MILLISECOND: " << calendar->get( Calendar::MILLISECOND, success ) << endl;
- *     cout << "ZONE_OFFSET: " << (calendar->get( Calendar::ZONE_OFFSET, success )/(60*60*1000)) << endl; // in hours
- *     cout << "DST_OFFSET: " << (calendar->get( Calendar::DST_OFFSET, success )/(60*60*1000)) << endl; // in hours
- *
- *     if (U_FAILURE(success)) {
- *         cout << "An error occured. success=" << u_errorName(success) << endl;
- *     }
- *
- *     delete ids;
- *     delete calendar; // also deletes pdt
- * \endcode
- * </pre>
- * @stable ICU 2.0
- */
-class U_I18N_API GregorianCalendar: public Calendar {
-public:
-
-    /**
-     * Useful constants for GregorianCalendar and TimeZone.
-     * @stable ICU 2.0
-     */
-    enum EEras {
-        BC,
-        AD
-    };
-
-    /**
-     * Constructs a default GregorianCalendar using the current time in the default time
-     * zone with the default locale.
-     *
-     * @param success  Indicates the status of GregorianCalendar object construction.
-     *                 Returns U_ZERO_ERROR if constructed successfully.
-     * @stable ICU 2.0
-     */
-    GregorianCalendar(UErrorCode& success);
-
-    /**
-     * Constructs a GregorianCalendar based on the current time in the given time zone
-     * with the default locale. Clients are no longer responsible for deleting the given
-     * time zone object after it's adopted.
-     *
-     * @param zoneToAdopt     The given timezone.
-     * @param success  Indicates the status of GregorianCalendar object construction.
-     *                 Returns U_ZERO_ERROR if constructed successfully.
-     * @stable ICU 2.0
-     */
-    GregorianCalendar(TimeZone* zoneToAdopt, UErrorCode& success);
-
-    /**
-     * Constructs a GregorianCalendar based on the current time in the given time zone
-     * with the default locale.
-     *
-     * @param zone     The given timezone.
-     * @param success  Indicates the status of GregorianCalendar object construction.
-     *                 Returns U_ZERO_ERROR if constructed successfully.
-     * @stable ICU 2.0
-     */
-    GregorianCalendar(const TimeZone& zone, UErrorCode& success);
-
-    /**
-     * Constructs a GregorianCalendar based on the current time in the default time zone
-     * with the given locale.
-     *
-     * @param aLocale  The given locale.
-     * @param success  Indicates the status of GregorianCalendar object construction.
-     *                 Returns U_ZERO_ERROR if constructed successfully.
-     * @stable ICU 2.0
-     */
-    GregorianCalendar(const Locale& aLocale, UErrorCode& success);
-
-    /**
-     * Constructs a GregorianCalendar based on the current time in the given time zone
-     * with the given locale. Clients are no longer responsible for deleting the given
-     * time zone object after it's adopted.
-     *
-     * @param zoneToAdopt     The given timezone.
-     * @param aLocale  The given locale.
-     * @param success  Indicates the status of GregorianCalendar object construction.
-     *                 Returns U_ZERO_ERROR if constructed successfully.
-     * @stable ICU 2.0
-     */
-    GregorianCalendar(TimeZone* zoneToAdopt, const Locale& aLocale, UErrorCode& success);
-
-    /**
-     * Constructs a GregorianCalendar based on the current time in the given time zone
-     * with the given locale.
-     *
-     * @param zone     The given timezone.
-     * @param aLocale  The given locale.
-     * @param success  Indicates the status of GregorianCalendar object construction.
-     *                 Returns U_ZERO_ERROR if constructed successfully.
-     * @stable ICU 2.0
-     */
-    GregorianCalendar(const TimeZone& zone, const Locale& aLocale, UErrorCode& success);
-
-    /**
-     * Constructs a GregorianCalendar with the given AD date set in the default time
-     * zone with the default locale.
-     *
-     * @param year     The value used to set the YEAR time field in the calendar.
-     * @param month    The value used to set the MONTH time field in the calendar. Month
-     *                 value is 0-based. e.g., 0 for January.
-     * @param date     The value used to set the DATE time field in the calendar.
-     * @param success  Indicates the status of GregorianCalendar object construction.
-     *                 Returns U_ZERO_ERROR if constructed successfully.
-     * @stable ICU 2.0
-     */
-    GregorianCalendar(int32_t year, int32_t month, int32_t date, UErrorCode& success);
-
-    /**
-     * Constructs a GregorianCalendar with the given AD date and time set for the
-     * default time zone with the default locale.
-     *
-     * @param year     The value used to set the YEAR time field in the calendar.
-     * @param month    The value used to set the MONTH time field in the calendar. Month
-     *                 value is 0-based. e.g., 0 for January.
-     * @param date     The value used to set the DATE time field in the calendar.
-     * @param hour     The value used to set the HOUR_OF_DAY time field in the calendar.
-     * @param minute   The value used to set the MINUTE time field in the calendar.
-     * @param success  Indicates the status of GregorianCalendar object construction.
-     *                 Returns U_ZERO_ERROR if constructed successfully.
-     * @stable ICU 2.0
-     */
-    GregorianCalendar(int32_t year, int32_t month, int32_t date, int32_t hour, int32_t minute, UErrorCode& success);
-
-    /**
-     * Constructs a GregorianCalendar with the given AD date and time set for the
-     * default time zone with the default locale.
-     *
-     * @param year     The value used to set the YEAR time field in the calendar.
-     * @param month    The value used to set the MONTH time field in the calendar. Month
-     *                 value is 0-based. e.g., 0 for January.
-     * @param date     The value used to set the DATE time field in the calendar.
-     * @param hour     The value used to set the HOUR_OF_DAY time field in the calendar.
-     * @param minute   The value used to set the MINUTE time field in the calendar.
-     * @param second   The value used to set the SECOND time field in the calendar.
-     * @param success  Indicates the status of GregorianCalendar object construction.
-     *                 Returns U_ZERO_ERROR if constructed successfully.
-     * @stable ICU 2.0
-     */
-    GregorianCalendar(int32_t year, int32_t month, int32_t date, int32_t hour, int32_t minute, int32_t second, UErrorCode& success);
-
-    /**
-     * Destructor
-     * @stable ICU 2.0
-     */
-    virtual ~GregorianCalendar();
-
-    /**
-     * Copy constructor
-     * @param source    the object to be copied.
-     * @stable ICU 2.0
-     */
-    GregorianCalendar(const GregorianCalendar& source);
-
-    /**
-     * Default assignment operator
-     * @param right    the object to be copied.
-     * @stable ICU 2.0
-     */
-    GregorianCalendar& operator=(const GregorianCalendar& right);
-
-    /**
-     * Create and return a polymorphic copy of this calendar.
-     * @return    return a polymorphic copy of this calendar.
-     * @stable ICU 2.0
-     */
-    virtual Calendar* clone(void) const;
-
-    /**
-     * Sets the GregorianCalendar change date. This is the point when the switch from
-     * Julian dates to Gregorian dates occurred. Default is 00:00:00 local time, October
-     * 15, 1582. Previous to this time and date will be Julian dates.
-     *
-     * @param date     The given Gregorian cutover date.
-     * @param success  Output param set to success/failure code on exit.
-     * @stable ICU 2.0
-     */
-    void setGregorianChange(UDate date, UErrorCode& success);
-
-    /**
-     * Gets the Gregorian Calendar change date. This is the point when the switch from
-     * Julian dates to Gregorian dates occurred. Default is 00:00:00 local time, October
-     * 15, 1582. Previous to this time and date will be Julian dates.
-     *
-     * @return   The Gregorian cutover time for this calendar.
-     * @stable ICU 2.0
-     */
-    UDate getGregorianChange(void) const;
-
-    /**
-     * Return true if the given year is a leap year. Determination of whether a year is
-     * a leap year is actually very complicated. We do something crude and mostly
-     * correct here, but for a real determination you need a lot of contextual
-     * information. For example, in Sweden, the change from Julian to Gregorian happened
-     * in a complex way resulting in missed leap years and double leap years between
-     * 1700 and 1753. Another example is that after the start of the Julian calendar in
-     * 45 B.C., the leap years did not regularize until 8 A.D. This method ignores these
-     * quirks, and pays attention only to the Julian onset date and the Gregorian
-     * cutover (which can be changed).
-     *
-     * @param year  The given year.
-     * @return      True if the given year is a leap year; false otherwise.
-     * @stable ICU 2.0
-     */
-    UBool isLeapYear(int32_t year) const;
-
-    /**
-     * Returns TRUE if the given Calendar object is equivalent to this
-     * one.  Calendar override.
-     *
-     * @param other the Calendar to be compared with this Calendar   
-     * @stable ICU 2.4
-     */
-    virtual UBool isEquivalentTo(const Calendar& other) const;
-
-    /**
-     * (Overrides Calendar) Rolls up or down by the given amount in the specified field.
-     * For more information, see the documentation for Calendar::roll().
-     *
-     * @param field   The time field.
-     * @param amount  Indicates amount to roll.
-     * @param status  Output param set to success/failure code on exit. If any value
-     *                previously set in the time field is invalid, this will be set to
-     *                an error status.
-     * @deprecated ICU 2.6. Use roll(UCalendarDateFields field, int32_t amount, UErrorCode& status) instead.
-     */
-    virtual void roll(EDateFields field, int32_t amount, UErrorCode& status);
-
-    /**
-     * (Overrides Calendar) Rolls up or down by the given amount in the specified field.
-     * For more information, see the documentation for Calendar::roll().
-     *
-     * @param field   The time field.
-     * @param amount  Indicates amount to roll.
-     * @param status  Output param set to success/failure code on exit. If any value
-     *                previously set in the time field is invalid, this will be set to
-     *                an error status.
-     * @stable ICU 2.6.
-     */
-    virtual void roll(UCalendarDateFields field, int32_t amount, UErrorCode& status);
-
-    /**
-     * Return the minimum value that this field could have, given the current date.
-     * For the Gregorian calendar, this is the same as getMinimum() and getGreatestMinimum().
-     * @param field    the time field.
-     * @return         the minimum value that this field could have, given the current date.
-     * @deprecated ICU 2.6. Use getActualMinimum(UCalendarDateFields field) instead.
-     */
-    int32_t getActualMinimum(EDateFields field) const;
-
-    /**
-     * Return the minimum value that this field could have, given the current date.
-     * For the Gregorian calendar, this is the same as getMinimum() and getGreatestMinimum().
-     * @param field    the time field.
-     * @param status
-     * @return         the minimum value that this field could have, given the current date.
-     * @deprecated ICU 2.6. Use getActualMinimum(UCalendarDateFields field) instead. (Added to ICU 3.0 for signature consistency)
-     */
-    int32_t getActualMinimum(EDateFields field, UErrorCode& status) const;
-
-    /**
-     * Return the minimum value that this field could have, given the current date.
-     * For the Gregorian calendar, this is the same as getMinimum() and getGreatestMinimum().
-     * @param field    the time field.
-     * @param status   error result.
-     * @return         the minimum value that this field could have, given the current date.
-     * @stable ICU 3.0
-     */
-    int32_t getActualMinimum(UCalendarDateFields field, UErrorCode &status) const;
-
-    /**
-     * Return the maximum value that this field could have, given the current date.
-     * For example, with the date "Feb 3, 1997" and the DAY_OF_MONTH field, the actual
-     * maximum would be 28; for "Feb 3, 1996" it s 29.  Similarly for a Hebrew calendar,
-     * for some years the actual maximum for MONTH is 12, and for others 13.
-     * @param field    the time field.
-     * @return         the maximum value that this field could have, given the current date.
-     * @deprecated ICU 2.6. Use getActualMaximum(UCalendarDateFields field) instead.
-     */
-    int32_t getActualMaximum(EDateFields field) const;
-
-    /**
-     * Return the maximum value that this field could have, given the current date.
-     * For example, with the date "Feb 3, 1997" and the DAY_OF_MONTH field, the actual
-     * maximum would be 28; for "Feb 3, 1996" it s 29.  Similarly for a Hebrew calendar,
-     * for some years the actual maximum for MONTH is 12, and for others 13.
-     * @param field    the time field.
-     * @param status   returns any errors that may result from this function call.
-     * @return         the maximum value that this field could have, given the current date.
-     * @stable ICU 2.6
-     */
-    virtual int32_t getActualMaximum(UCalendarDateFields field, UErrorCode& status) const;
-
-    /**
-     * (Overrides Calendar) Return true if the current date for this Calendar is in
-     * Daylight Savings Time. Recognizes DST_OFFSET, if it is set.
-     *
-     * @param status Fill-in parameter which receives the status of this operation.
-     * @return   True if the current date for this Calendar is in Daylight Savings Time,
-     *           false, otherwise.
-     * @stable ICU 2.0
-     */
-    virtual UBool inDaylightTime(UErrorCode& status) const;
-
-public:
-
-    /**
-     * Override Calendar Returns a unique class ID POLYMORPHICALLY. Pure virtual
-     * override. This method is to implement a simple version of RTTI, since not all C++
-     * compilers support genuine RTTI. Polymorphic operator==() and clone() methods call
-     * this method.
-     *
-     * @return   The class ID for this object. All objects of a given class have the
-     *           same class ID. Objects of other classes have different class IDs.
-     * @stable ICU 2.0
-     */
-    virtual UClassID getDynamicClassID(void) const;
-
-    /**
-     * Return the class ID for this class. This is useful only for comparing to a return
-     * value from getDynamicClassID(). For example:
-     *
-     *      Base* polymorphic_pointer = createPolymorphicObject();
-     *      if (polymorphic_pointer->getDynamicClassID() ==
-     *          Derived::getStaticClassID()) ...
-     *
-     * @return   The class ID for all objects of this class.
-     * @stable ICU 2.0
-     */
-    static UClassID U_EXPORT2 getStaticClassID(void);
-
-    /**
-     * Get the calendar type, "gregorian", for use in DateFormatSymbols.
-     *
-     * @return calendar type
-     * @internal
-     */
-    virtual const char * getType() const;
-
-protected:
-
-    /**
-     * (Overrides Calendar) Converts GMT as milliseconds to time field values.
-     * @param status Fill-in parameter which receives the status of this operation.
-     * @stable ICU 2.0
-     */
-
- private:
-    GregorianCalendar(); // default constructor not implemented
-
- protected:
-    /**
-     * Return the ERA.  We need a special method for this because the
-     * default ERA is AD, but a zero (unset) ERA is BC.
-     * @return    the ERA.
-     * @internal
-     */
-    virtual int32_t internalGetEra() const;
-
-    /**
-     * Return the Julian day number of day before the first day of the
-     * given month in the given extended year.  Subclasses should override
-     * this method to implement their calendar system.
-     * @param eyear the extended year
-     * @param month the zero-based month, or 0 if useMonth is false
-     * @param useMonth if false, compute the day before the first day of
-     * the given year, otherwise, compute the day before the first day of
-     * the given month
-     * @return the Julian day number of the day before the first
-     * day of the given month and year
-     * @internal
-     */
-    virtual int32_t handleComputeMonthStart(int32_t eyear, int32_t month,
-                                                   UBool useMonth) const;
-
-    /**
-     * Subclasses may override this.  This method calls
-     * handleGetMonthLength() to obtain the calendar-specific month
-     * length.
-     * @param bestField which field to use to calculate the date 
-     * @return julian day specified by calendar fields.
-     * @internal
-     */
-    virtual int32_t handleComputeJulianDay(UCalendarDateFields bestField)  ;
-
-    /**
-     * Return the number of days in the given month of the given extended
-     * year of this calendar system.  Subclasses should override this
-     * method if they can provide a more correct or more efficient
-     * implementation than the default implementation in Calendar.
-     * @internal
-     */
-    virtual int32_t handleGetMonthLength(int32_t extendedYear, int32_t month) const;
-
-    /**
-     * Return the number of days in the given extended year of this
-     * calendar system.  Subclasses should override this method if they can
-     * provide a more correct or more efficient implementation than the
-     * default implementation in Calendar.
-     * @stable ICU 2.0
-     */
-    virtual int32_t handleGetYearLength(int32_t eyear) const;
-
-    /**
-     * return the length of the given month.
-     * @param month    the given month.
-     * @return    the length of the given month.
-     * @internal
-     */
-    virtual int32_t monthLength(int32_t month) const;
-
-    /**
-     * return the length of the month according to the given year.
-     * @param month    the given month.
-     * @param year     the given year.
-     * @return         the length of the month
-     * @internal
-     */
-    virtual int32_t monthLength(int32_t month, int32_t year) const;
-    
-    /**
-     * return the length of the given year.
-     * @param year    the given year.
-     * @return        the length of the given year.
-     * @internal
-     */
-    int32_t yearLength(int32_t year) const;
-    
-    /**
-     * return the length of the year field.
-     * @return    the length of the year field
-     * @internal
-     */
-    int32_t yearLength(void) const;
-
-    /**
-     * After adjustments such as add(MONTH), add(YEAR), we don't want the
-     * month to jump around.  E.g., we don't want Jan 31 + 1 month to go to Mar
-     * 3, we want it to go to Feb 28.  Adjustments which might run into this
-     * problem call this method to retain the proper month.
-     * @internal
-     */
-    void pinDayOfMonth(void);
-
-    /**
-     * Return the day number with respect to the epoch.  January 1, 1970 (Gregorian)
-     * is day zero.
-     * @param status Fill-in parameter which receives the status of this operation.
-     * @return       the day number with respect to the epoch.  
-     * @internal
-     */
-    virtual UDate getEpochDay(UErrorCode& status);
-
-    /**
-     * Subclass API for defining limits of different types.
-     * Subclasses must implement this method to return limits for the
-     * following fields:
-     *
-     * <pre>UCAL_ERA
-     * UCAL_YEAR
-     * UCAL_MONTH
-     * UCAL_WEEK_OF_YEAR
-     * UCAL_WEEK_OF_MONTH
-     * UCAL_DATE (DAY_OF_MONTH on Java)
-     * UCAL_DAY_OF_YEAR
-     * UCAL_DAY_OF_WEEK_IN_MONTH
-     * UCAL_YEAR_WOY
-     * UCAL_EXTENDED_YEAR</pre>
-     *
-     * @param field one of the above field numbers
-     * @param limitType one of <code>MINIMUM</code>, <code>GREATEST_MINIMUM</code>,
-     * <code>LEAST_MAXIMUM</code>, or <code>MAXIMUM</code>
-     * @internal
-     */
-    virtual int32_t handleGetLimit(UCalendarDateFields field, ELimitType limitType) const;
-
-    /**
-     * Return the extended year defined by the current fields.  This will
-     * use the UCAL_EXTENDED_YEAR field or the UCAL_YEAR and supra-year fields (such
-     * as UCAL_ERA) specific to the calendar system, depending on which set of
-     * fields is newer.
-     * @return the extended year
-     * @internal
-     */
-    virtual int32_t handleGetExtendedYear();
-
-    /** 
-     * Subclasses may override this to convert from week fields 
-     * (YEAR_WOY and WEEK_OF_YEAR) to an extended year in the case
-     * where YEAR, EXTENDED_YEAR are not set.
-     * The Gregorian implementation assumes a yearWoy in gregorian format, according to the current era.
-     * @return the extended year, UCAL_EXTENDED_YEAR
-     * @internal
-     */
-    virtual int32_t handleGetExtendedYearFromWeekFields(int32_t yearWoy, int32_t woy);
-
-
-    /**
-     * Subclasses may override this method to compute several fields
-     * specific to each calendar system.  These are:
-     *
-     * <ul><li>ERA
-     * <li>YEAR
-     * <li>MONTH
-     * <li>DAY_OF_MONTH
-     * <li>DAY_OF_YEAR
-     * <li>EXTENDED_YEAR</ul>
-     *
-     * <p>The GregorianCalendar implementation implements
-     * a calendar with the specified Julian/Gregorian cutover date.
-     * @internal
-     */
-    virtual void handleComputeFields(int32_t julianDay, UErrorCode &status);
-
- private:
-    /**
-     * Compute the julian day number of the given year.
-     * @param isGregorian    if true, using Gregorian calendar, otherwise using Julian calendar
-     * @param year           the given year.
-     * @param isLeap         true if the year is a leap year.       
-     * @return 
-     */
-    static double computeJulianDayOfYear(UBool isGregorian, int32_t year,
-                                         UBool& isLeap);
-    
-    /**
-     * Validates the values of the set time fields.  True if they're all valid.
-     * @return    True if the set time fields are all valid.
-     */
-    UBool validateFields(void) const;
-
-    /**
-     * Validates the value of the given time field.  True if it's valid.
-     */
-    UBool boundsCheck(int32_t value, UCalendarDateFields field) const;
-
-    /**
-     * Return the pseudo-time-stamp for two fields, given their
-     * individual pseudo-time-stamps.  If either of the fields
-     * is unset, then the aggregate is unset.  Otherwise, the
-     * aggregate is the later of the two stamps.
-     * @param stamp_a    One given field.
-     * @param stamp_b    Another given field.
-     * @return the pseudo-time-stamp for two fields
-     */
-    int32_t aggregateStamp(int32_t stamp_a, int32_t stamp_b);
-
-    /**
-     * The point at which the Gregorian calendar rules are used, measured in
-     * milliseconds from the standard epoch.  Default is October 15, 1582
-     * (Gregorian) 00:00:00 UTC, that is, October 4, 1582 (Julian) is followed
-     * by October 15, 1582 (Gregorian).  This corresponds to Julian day number
-     * 2299161. This is measured from the standard epoch, not in Julian Days.
-     * @internal
-     */
-    UDate                fGregorianCutover;
-
-    /**
-     * Julian day number of the Gregorian cutover
-     */
-    int32_t             fCutoverJulianDay;
-
-    /**
-     * Midnight, local time (using this Calendar's TimeZone) at or before the
-     * gregorianCutover. This is a pure date value with no time of day or
-     * timezone component.
-     */
-    UDate                 fNormalizedGregorianCutover;// = gregorianCutover;
-
-    /**
-     * The year of the gregorianCutover, with 0 representing
-     * 1 BC, -1 representing 2 BC, etc.
-     */
-    int32_t fGregorianCutoverYear;// = 1582;
-
-    /**
-     * The year of the gregorianCutover, with 0 representing
-     * 1 BC, -1 representing 2 BC, etc.
-     */
-    int32_t fGregorianCutoverJulianDay;// = 2299161;
-
-    /**
-     * Converts time as milliseconds to Julian date. The Julian date used here is not a
-     * true Julian date, since it is measured from midnight, not noon.
-     *
-     * @param millis  The given milliseconds.
-     * @return        The Julian date number.
-     */
-    static double millisToJulianDay(UDate millis);
-
-    /**
-     * Converts Julian date to time as milliseconds. The Julian date used here is not a
-     * true Julian date, since it is measured from midnight, not noon.
-     *
-     * @param julian  The given Julian date number.
-     * @return        Time as milliseconds.
-     */
-    static UDate julianDayToMillis(double julian);
-
-    /**
-     * Used by handleComputeJulianDay() and handleComputeMonthStart().
-     * Temporary field indicating whether the calendar is currently Gregorian as opposed to Julian.
-     */
-    UBool fIsGregorian;
-
-    /**
-     * Used by handleComputeJulianDay() and handleComputeMonthStart().
-     * Temporary field indicating that the sense of the gregorian cutover should be inverted
-     * to handle certain calculations on and around the cutover date.
-     */
-    UBool fInvertGregorian;
-
-
- public: // internal implementation
-
-    /**
-     * @internal 
-     * @return TRUE if this calendar has the notion of a default century
-     */
-    virtual UBool haveDefaultCentury() const;
-
-    /**
-     * @internal
-     * @return the start of the default century
-     */
-    virtual UDate defaultCenturyStart() const;
-
-    /**
-     * @internal 
-     * @return the beginning year of the default century
-     */
-    virtual int32_t defaultCenturyStartYear() const;
-
- private:
-    /**
-     * The system maintains a static default century start date.  This is initialized
-     * the first time it is used.  Before then, it is set to SYSTEM_DEFAULT_CENTURY to
-     * indicate an uninitialized state.  Once the system default century date and year
-     * are set, they do not change.
-     */
-    static UDate         fgSystemDefaultCenturyStart;
-
-    /**
-     * See documentation for systemDefaultCenturyStart.
-     */
-    static int32_t          fgSystemDefaultCenturyStartYear;
-
-    /**
-     * Default value that indicates the defaultCenturyStartYear is unitialized
-     */
-    static const int32_t    fgSystemDefaultCenturyYear;
-
-    /**
-     * Default value that indicates the UDate of the beginning of the system default century
-     */
-    static const UDate        fgSystemDefaultCentury;
-
-    /**
-     * Returns the beginning date of the 100-year window that dates with 2-digit years
-     * are considered to fall within.
-     * @return    the beginning date of the 100-year window that dates with 2-digit years
-     *            are considered to fall within.
-     */
-    UDate         internalGetDefaultCenturyStart(void) const;
-
-    /**
-     * Returns the first year of the 100-year window that dates with 2-digit years
-     * are considered to fall within.
-     * @return    the first year of the 100-year window that dates with 2-digit years
-     *            are considered to fall within.
-     */
-    int32_t          internalGetDefaultCenturyStartYear(void) const;
-
-    /**
-     * Initializes the 100-year window that dates with 2-digit years are considered
-     * to fall within so that its start date is 80 years before the current time.
-     */
-    static void  initializeSystemDefaultCentury(void);
-
-};
-
-U_NAMESPACE_END
-
-#endif /* #if !UCONFIG_NO_FORMATTING */
-
-#endif // _GREGOCAL
-//eof
-

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/locid.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/locid.h b/apps/couch_collate/platform/osx/icu/unicode/locid.h
deleted file mode 100644
index a3cc23b..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/locid.h
+++ /dev/null
@@ -1,765 +0,0 @@
-/*
-******************************************************************************
-*
-*   Copyright (C) 1996-2006, International Business Machines
-*   Corporation and others.  All Rights Reserved.
-*
-******************************************************************************
-*
-* File locid.h
-*
-* Created by: Helena Shih
-*
-* Modification History:
-*
-*   Date        Name        Description
-*   02/11/97    aliu        Changed gLocPath to fgLocPath and added methods to
-*                           get and set it.
-*   04/02/97    aliu        Made operator!= inline; fixed return value of getName().
-*   04/15/97    aliu        Cleanup for AIX/Win32.
-*   04/24/97    aliu        Numerous changes per code review.
-*   08/18/98    stephen     Added tokenizeString(),changed getDisplayName()
-*   09/08/98    stephen     Moved definition of kEmptyString for Mac Port
-*   11/09/99    weiv        Added const char * getName() const;
-*   04/12/00    srl         removing unicodestring api's and cached hash code
-*   08/10/01    grhoten     Change the static Locales to accessor functions
-******************************************************************************
-*/
-
-#ifndef LOCID_H
-#define LOCID_H
-
-#include "unicode/utypes.h"
-#include "unicode/uobject.h"
-#include "unicode/unistr.h"
-#include "unicode/putil.h"
-#include "unicode/uloc.h"
-#include "unicode/strenum.h"
-
-/**
- * \file
- * \brief C++ API: Locale ID object.
- */
-
-/**
- * A <code>Locale</code> object represents a specific geographical, political,
- * or cultural region. An operation that requires a <code>Locale</code> to perform
- * its task is called <em>locale-sensitive</em> and uses the <code>Locale</code>
- * to tailor information for the user. For example, displaying a number
- * is a locale-sensitive operation--the number should be formatted
- * according to the customs/conventions of the user's native country,
- * region, or culture.
- *
- * The Locale class is not suitable for subclassing.
- *
- * <P>
- * You can create a <code>Locale</code> object using the constructor in
- * this class:
- * \htmlonly<blockquote>\endhtmlonly
- * <pre>
- *       Locale( const   char*  language,
- *               const   char*  country,
- *               const   char*  variant);
- * </pre>
- * \htmlonly</blockquote>\endhtmlonly
- * The first argument to the constructors is a valid <STRONG>ISO
- * Language Code.</STRONG> These codes are the lower-case two-letter
- * codes as defined by ISO-639.
- * You can find a full list of these codes at:
- * <BR><a href ="http://www.loc.gov/standards/iso639-2/">
- * http://www.loc.gov/standards/iso639-2/</a>
- *
- * <P>
- * The second argument to the constructors is a valid <STRONG>ISO Country
- * Code.</STRONG> These codes are the upper-case two-letter codes
- * as defined by ISO-3166.
- * You can find a full list of these codes at a number of sites, such as:
- * <BR><a href="http://www.iso.org/iso/en/prods-services/iso3166ma/index.html">
- * http://www.iso.org/iso/en/prods-services/iso3166ma/index.html</a>
- *
- * <P>
- * The third constructor requires a third argument--the <STRONG>Variant.</STRONG>
- * The Variant codes are vendor and browser-specific.
- * For example, use REVISED for a langauge's revised script orthography, and POSIX for POSIX.
- * Where there are two variants, separate them with an underscore, and
- * put the most important one first. For
- * example, a Traditional Spanish collation might be referenced, with
- * "ES", "ES", "Traditional_POSIX".
- *
- * <P>
- * Because a <code>Locale</code> object is just an identifier for a region,
- * no validity check is performed when you construct a <code>Locale</code>.
- * If you want to see whether particular resources are available for the
- * <code>Locale</code> you construct, you must query those resources. For
- * example, ask the <code>NumberFormat</code> for the locales it supports
- * using its <code>getAvailableLocales</code> method.
- * <BR><STRONG>Note:</STRONG> When you ask for a resource for a particular
- * locale, you get back the best available match, not necessarily
- * precisely what you asked for. For more information, look at
- * <code>ResourceBundle</code>.
- *
- * <P>
- * The <code>Locale</code> class provides a number of convenient constants
- * that you can use to create <code>Locale</code> objects for commonly used
- * locales. For example, the following refers to a <code>Locale</code> object
- * for the United States:
- * \htmlonly<blockquote>\endhtmlonly
- * <pre>
- *       Locale::getUS()
- * </pre>
- * \htmlonly</blockquote>\endhtmlonly
- *
- * <P>
- * Once you've created a <code>Locale</code> you can query it for information about
- * itself. Use <code>getCountry</code> to get the ISO Country Code and
- * <code>getLanguage</code> to get the ISO Language Code. You can
- * use <code>getDisplayCountry</code> to get the
- * name of the country suitable for displaying to the user. Similarly,
- * you can use <code>getDisplayLanguage</code> to get the name of
- * the language suitable for displaying to the user. Interestingly,
- * the <code>getDisplayXXX</code> methods are themselves locale-sensitive
- * and have two versions: one that uses the default locale and one
- * that takes a locale as an argument and displays the name or country in
- * a language appropriate to that locale.
- *
- * <P>
- * ICU provides a number of classes that perform locale-sensitive
- * operations. For example, the <code>NumberFormat</code> class formats
- * numbers, currency, or percentages in a locale-sensitive manner. Classes
- * such as <code>NumberFormat</code> have a number of convenience methods
- * for creating a default object of that type. For example, the
- * <code>NumberFormat</code> class provides these three convenience methods
- * for creating a default <code>NumberFormat</code> object:
- * \htmlonly<blockquote>\endhtmlonly
- * <pre>
- *     UErrorCode success = U_ZERO_ERROR;
- *     Locale myLocale;
- *     NumberFormat *nf;
- *
- *     nf = NumberFormat::createInstance( success );          delete nf;
- *     nf = NumberFormat::createCurrencyInstance( success );  delete nf;
- *     nf = NumberFormat::createPercentInstance( success );   delete nf;
- * </pre>
- * \htmlonly</blockquote>\endhtmlonly
- * Each of these methods has two variants; one with an explicit locale
- * and one without; the latter using the default locale.
- * \htmlonly<blockquote>\endhtmlonly
- * <pre>
- *     nf = NumberFormat::createInstance( myLocale, success );          delete nf;
- *     nf = NumberFormat::createCurrencyInstance( myLocale, success );  delete nf;
- *     nf = NumberFormat::createPercentInstance( myLocale, success );   delete nf;
- * </pre>
- * \htmlonly</blockquote>\endhtmlonly
- * A <code>Locale</code> is the mechanism for identifying the kind of object
- * (<code>NumberFormat</code>) that you would like to get. The locale is
- * <STRONG>just</STRONG> a mechanism for identifying objects,
- * <STRONG>not</STRONG> a container for the objects themselves.
- *
- * <P>
- * Each class that performs locale-sensitive operations allows you
- * to get all the available objects of that type. You can sift
- * through these objects by language, country, or variant,
- * and use the display names to present a menu to the user.
- * For example, you can create a menu of all the collation objects
- * suitable for a given language. Such classes implement these
- * three class methods:
- * \htmlonly<blockquote>\endhtmlonly
- * <pre>
- *       static Locale* getAvailableLocales(int32_t& numLocales)
- *       static UnicodeString& getDisplayName(const Locale&  objectLocale,
- *                                            const Locale&  displayLocale,
- *                                            UnicodeString& displayName)
- *       static UnicodeString& getDisplayName(const Locale&  objectLocale,
- *                                            UnicodeString& displayName)
- * </pre>
- * \htmlonly</blockquote>\endhtmlonly
- *
- * @stable ICU 2.0
- * @see ResourceBundle
- */
-U_NAMESPACE_BEGIN
-class U_COMMON_API Locale : public UObject {
-public:
-    /** Useful constant for this language. @stable ICU 2.0 */
-    static const Locale &U_EXPORT2 getEnglish(void);
-    /** Useful constant for this language. @stable ICU 2.0 */
-    static const Locale &U_EXPORT2 getFrench(void);
-    /** Useful constant for this language. @stable ICU 2.0 */
-    static const Locale &U_EXPORT2 getGerman(void);
-    /** Useful constant for this language. @stable ICU 2.0 */
-    static const Locale &U_EXPORT2 getItalian(void);
-    /** Useful constant for this language. @stable ICU 2.0 */
-    static const Locale &U_EXPORT2 getJapanese(void);
-    /** Useful constant for this language. @stable ICU 2.0 */
-    static const Locale &U_EXPORT2 getKorean(void);
-    /** Useful constant for this language. @stable ICU 2.0 */
-    static const Locale &U_EXPORT2 getChinese(void);
-    /** Useful constant for this language. @stable ICU 2.0 */
-    static const Locale &U_EXPORT2 getSimplifiedChinese(void);
-    /** Useful constant for this language. @stable ICU 2.0 */
-    static const Locale &U_EXPORT2 getTraditionalChinese(void);
-
-    /** Useful constant for this country/region. @stable ICU 2.0 */
-    static const Locale &U_EXPORT2 getFrance(void);
-    /** Useful constant for this country/region. @stable ICU 2.0 */
-    static const Locale &U_EXPORT2 getGermany(void);
-    /** Useful constant for this country/region. @stable ICU 2.0 */
-    static const Locale &U_EXPORT2 getItaly(void);
-    /** Useful constant for this country/region. @stable ICU 2.0 */
-    static const Locale &U_EXPORT2 getJapan(void);
-    /** Useful constant for this country/region. @stable ICU 2.0 */
-    static const Locale &U_EXPORT2 getKorea(void);
-    /** Useful constant for this country/region. @stable ICU 2.0 */
-    static const Locale &U_EXPORT2 getChina(void);
-    /** Useful constant for this country/region. @stable ICU 2.0 */
-    static const Locale &U_EXPORT2 getPRC(void);
-    /** Useful constant for this country/region. @stable ICU 2.0 */
-    static const Locale &U_EXPORT2 getTaiwan(void);
-    /** Useful constant for this country/region. @stable ICU 2.0 */
-    static const Locale &U_EXPORT2 getUK(void);
-    /** Useful constant for this country/region. @stable ICU 2.0 */
-    static const Locale &U_EXPORT2 getUS(void);
-    /** Useful constant for this country/region. @stable ICU 2.0 */
-    static const Locale &U_EXPORT2 getCanada(void);
-    /** Useful constant for this country/region. @stable ICU 2.0 */
-    static const Locale &U_EXPORT2 getCanadaFrench(void);
-
-
-    /**
-     * Construct a default locale object, a Locale for the default locale ID.
-     *
-     * @see getDefault
-     * @see uloc_getDefault
-     * @stable ICU 2.0
-     */
-    Locale();
-
-    /**
-     * Construct a locale from language, country, variant.
-     * If an error occurs, then the constructed object will be "bogus"
-     * (isBogus() will return TRUE).
-     *
-     * @param language Lowercase two-letter or three-letter ISO-639 code.
-     *  This parameter can instead be an ICU style C locale (e.g. "en_US"),
-     *  but the other parameters must not be used.
-     *  This parameter can be NULL; if so,
-     *  the locale is initialized to match the current default locale.
-     *  (This is the same as using the default constructor.)
-     *  Please note: The Java Locale class does NOT accept the form
-     *  'new Locale("en_US")' but only 'new Locale("en","US")'
-     *
-     * @param country  Uppercase two-letter ISO-3166 code. (optional)
-     * @param variant  Uppercase vendor and browser specific code. See class
-     *                 description. (optional)
-     * @param keywordsAndValues A string consisting of keyword/values pairs, such as
-     *                 "collation=phonebook;currency=euro"
-     *
-     * @see getDefault
-     * @see uloc_getDefault
-     * @stable ICU 2.0
-     */
-    Locale( const   char * language,
-            const   char * country  = 0,
-            const   char * variant  = 0,
-            const   char * keywordsAndValues = 0);
-
-    /**
-     * Initializes a Locale object from another Locale object.
-     *
-     * @param other The Locale object being copied in.
-     * @stable ICU 2.0
-     */
-    Locale(const    Locale& other);
-
-
-    /**
-     * Destructor
-     * @stable ICU 2.0
-     */
-    virtual ~Locale() ;
-
-    /**
-     * Replaces the entire contents of *this with the specified value.
-     *
-     * @param other The Locale object being copied in.
-     * @return      *this
-     * @stable ICU 2.0
-     */
-    Locale& operator=(const Locale& other);
-
-    /**
-     * Checks if two locale keys are the same.
-     *
-     * @param other The locale key object to be compared with this.
-     * @return      True if the two locale keys are the same, false otherwise.
-     * @stable ICU 2.0
-     */
-    UBool   operator==(const    Locale&     other) const;
-
-    /**
-     * Checks if two locale keys are not the same.
-     *
-     * @param other The locale key object to be compared with this.
-     * @return      True if the two locale keys are not the same, false
-     *              otherwise.
-     * @stable ICU 2.0
-     */
-    UBool   operator!=(const    Locale&     other) const;
-
-    /**
-     * Clone this object.
-     * Clones can be used concurrently in multiple threads.
-     * If an error occurs, then NULL is returned.
-     * The caller must delete the clone.
-     *
-     * @return a clone of this object
-     *
-     * @see getDynamicClassID
-     * @stable ICU 2.8
-     */
-    Locale *clone() const;
-
-    /**
-     * Common methods of getting the current default Locale. Used for the
-     * presentation: menus, dialogs, etc. Generally set once when your applet or
-     * application is initialized, then never reset. (If you do reset the
-     * default locale, you probably want to reload your GUI, so that the change
-     * is reflected in your interface.)
-     *
-     * More advanced programs will allow users to use different locales for
-     * different fields, e.g. in a spreadsheet.
-     *
-     * Note that the initial setting will match the host system.
-     * @return a reference to the Locale object for the default locale ID
-     * @system
-     * @stable ICU 2.0
-     */
-    static const Locale& U_EXPORT2 getDefault(void);
-
-    /**
-     * Sets the default. Normally set once at the beginning of a process,
-     * then never reset.
-     * setDefault() only changes ICU's default locale ID, <strong>not</strong>
-     * the default locale ID of the runtime environment.
-     *
-     * @param newLocale Locale to set to.  If NULL, set to the value obtained
-     *                  from the runtime environement.
-     * @param success The error code.
-     * @system
-     * @stable ICU 2.0
-     */
-    static void U_EXPORT2 setDefault(const Locale& newLocale,
-                                     UErrorCode&   success);
-
-    /**
-     * Creates a locale which has had minimal canonicalization
-     * as per uloc_getName().
-     * @param name The name to create from.  If name is null,
-     *  the default Locale is used.
-     * @return new locale object
-     * @stable ICU 2.0
-     * @see uloc_getName
-     */
-    static Locale U_EXPORT2 createFromName(const char *name);
-
-    /**
-     * Creates a locale from the given string after canonicalizing
-     * the string by calling uloc_canonicalize().
-     * @param name the locale ID to create from.  Must not be NULL.
-     * @return a new locale object corresponding to the given name
-     * @stable ICU 3.0
-     * @see uloc_canonicalize
-     */
-    static Locale U_EXPORT2 createCanonical(const char* name);
-
-    /**
-     * Returns the locale's ISO-639 language code.
-     * @return      An alias to the code
-     * @stable ICU 2.0
-     */
-    inline const char *  getLanguage( ) const;
-
-    /**
-     * Returns the locale's ISO-15924 abbreviation script code.
-     * @return      An alias to the code
-     * @see uscript_getShortName
-     * @see uscript_getCode
-     * @stable ICU 2.8
-     */
-    inline const char *  getScript( ) const;
-
-    /**
-     * Returns the locale's ISO-3166 country code.
-     * @return      An alias to the code
-     * @stable ICU 2.0
-     */
-    inline const char *  getCountry( ) const;
-
-    /**
-     * Returns the locale's variant code.
-     * @return      An alias to the code
-     * @stable ICU 2.0
-     */
-    inline const char *  getVariant( ) const;
-
-    /**
-     * Returns the programmatic name of the entire locale, with the language,
-     * country and variant separated by underbars. If a field is missing, up
-     * to two leading underbars will occur. Example: "en", "de_DE", "en_US_WIN",
-     * "de__POSIX", "fr__MAC", "__MAC", "_MT", "_FR_EURO"
-     * @return      A pointer to "name".
-     * @stable ICU 2.0
-     */
-    inline const char * getName() const;
-
-    /**
-     * Returns the programmatic name of the entire locale as getName would return,
-     * but without keywords.
-     * @return      A pointer to "name".
-     * @see getName
-     * @stable ICU 2.8
-     */
-    const char * getBaseName() const;
-
-
-    /**
-     * Gets the list of keywords for the specified locale.
-     *
-     * @return pointer to StringEnumeration class. Client must dispose of it by calling delete.
-     * @param status Returns any error information while performing this operation.
-     * @stable ICU 2.8
-     */
-    StringEnumeration * createKeywords(UErrorCode &status) const;
-
-    /**
-     * Get the value for a keyword.
-     *
-     * @param keywordName name of the keyword for which we want the value. Case insensitive.
-     * @param status Returns any error information while performing this operation.
-     * @param buffer The buffer to receive the keyword value.
-     * @param bufferCapacity The capacity of receiving buffer
-     * @return the length of keyword value
-     *
-     * @stable ICU 2.8
-     */
-    int32_t getKeywordValue(const char* keywordName, char *buffer, int32_t bufferCapacity, UErrorCode &status) const;
-
-    /**
-     * returns the locale's three-letter language code, as specified
-     * in ISO draft standard ISO-639-2.
-     * @return      An alias to the code, or NULL
-     * @stable ICU 2.0
-     */
-    const char * getISO3Language() const;
-
-    /**
-     * Fills in "name" with the locale's three-letter ISO-3166 country code.
-     * @return      An alias to the code, or NULL
-     * @stable ICU 2.0
-     */
-    const char * getISO3Country() const;
-
-    /**
-     * Returns the Windows LCID value corresponding to this locale.
-     * This value is stored in the resource data for the locale as a one-to-four-digit
-     * hexadecimal number.  If the resource is missing, in the wrong format, or
-     * there is no Windows LCID value that corresponds to this locale, returns 0.
-     * @stable ICU 2.0
-     */
-    uint32_t        getLCID(void) const;
-
-    /**
-     * Fills in "dispLang" with the name of this locale's language in a format suitable for
-     * user display in the default locale.  For example, if the locale's language code is
-     * "fr" and the default locale's language code is "en", this function would set
-     * dispLang to "French".
-     * @param dispLang  Receives the language's display name.
-     * @return          A reference to "dispLang".
-     * @stable ICU 2.0
-     */
-    UnicodeString&  getDisplayLanguage(UnicodeString&   dispLang) const;
-
-    /**
-     * Fills in "dispLang" with the name of this locale's language in a format suitable for
-     * user display in the locale specified by "displayLocale".  For example, if the locale's
-     * language code is "en" and displayLocale's language code is "fr", this function would set
-     * dispLang to "Anglais".
-     * @param displayLocale  Specifies the locale to be used to display the name.  In other words,
-     *                  if the locale's language code is "en", passing Locale::getFrench() for
-     *                  displayLocale would result in "Anglais", while passing Locale::getGerman()
-     *                  for displayLocale would result in "Englisch".
-     * @param dispLang  Receives the language's display name.
-     * @return          A reference to "dispLang".
-     * @stable ICU 2.0
-     */
-    UnicodeString&  getDisplayLanguage( const   Locale&         displayLocale,
-                                                UnicodeString&  dispLang) const;
-
-    /**
-     * Fills in "dispScript" with the name of this locale's script in a format suitable
-     * for user display in the default locale.  For example, if the locale's script code
-     * is "LATN" and the default locale's language code is "en", this function would set
-     * dispScript to "Latin".
-     * @param dispScript    Receives the scripts's display name.
-     * @return              A reference to "dispScript".
-     * @stable ICU 2.8
-     */
-    UnicodeString&  getDisplayScript(          UnicodeString& dispScript) const;
-
-    /**
-     * Fills in "dispScript" with the name of this locale's country in a format suitable
-     * for user display in the locale specified by "displayLocale".  For example, if the locale's
-     * script code is "LATN" and displayLocale's language code is "en", this function would set
-     * dispScript to "Latin".
-     * @param displayLocale      Specifies the locale to be used to display the name.  In other
-     *                      words, if the locale's script code is "LATN", passing
-     *                      Locale::getFrench() for displayLocale would result in "", while
-     *                      passing Locale::getGerman() for displayLocale would result in
-     *                      "".
-     * @param dispScript    Receives the scripts's display name.
-     * @return              A reference to "dispScript".
-     * @stable ICU 2.8
-     */
-    UnicodeString&  getDisplayScript(  const   Locale&         displayLocale,
-                                               UnicodeString&  dispScript) const;
-
-    /**
-     * Fills in "dispCountry" with the name of this locale's country in a format suitable
-     * for user display in the default locale.  For example, if the locale's country code
-     * is "FR" and the default locale's language code is "en", this function would set
-     * dispCountry to "France".
-     * @param dispCountry   Receives the country's display name.
-     * @return              A reference to "dispCountry".
-     * @stable ICU 2.0
-     */
-    UnicodeString&  getDisplayCountry(          UnicodeString& dispCountry) const;
-
-    /**
-     * Fills in "dispCountry" with the name of this locale's country in a format suitable
-     * for user display in the locale specified by "displayLocale".  For example, if the locale's
-     * country code is "US" and displayLocale's language code is "fr", this function would set
-     * dispCountry to "&Eacute;tats-Unis".
-     * @param displayLocale      Specifies the locale to be used to display the name.  In other
-     *                      words, if the locale's country code is "US", passing
-     *                      Locale::getFrench() for displayLocale would result in "&Eacute;tats-Unis", while
-     *                      passing Locale::getGerman() for displayLocale would result in
-     *                      "Vereinigte Staaten".
-     * @param dispCountry   Receives the country's display name.
-     * @return              A reference to "dispCountry".
-     * @stable ICU 2.0
-     */
-    UnicodeString&  getDisplayCountry(  const   Locale&         displayLocale,
-                                                UnicodeString&  dispCountry) const;
-
-    /**
-     * Fills in "dispVar" with the name of this locale's variant code in a format suitable
-     * for user display in the default locale.
-     * @param dispVar   Receives the variant's name.
-     * @return          A reference to "dispVar".
-     * @stable ICU 2.0
-     */
-    UnicodeString&  getDisplayVariant(      UnicodeString& dispVar) const;
-
-    /**
-     * Fills in "dispVar" with the name of this locale's variant code in a format
-     * suitable for user display in the locale specified by "displayLocale".
-     * @param displayLocale  Specifies the locale to be used to display the name.
-     * @param dispVar   Receives the variant's display name.
-     * @return          A reference to "dispVar".
-     * @stable ICU 2.0
-     */
-    UnicodeString&  getDisplayVariant(  const   Locale&         displayLocale,
-                                                UnicodeString&  dispVar) const;
-
-    /**
-     * Fills in "name" with the name of this locale in a format suitable for user display
-     * in the default locale.  This function uses getDisplayLanguage(), getDisplayCountry(),
-     * and getDisplayVariant() to do its work, and outputs the display name in the format
-     * "language (country[,variant])".  For example, if the default locale is en_US, then
-     * fr_FR's display name would be "French (France)", and es_MX_Traditional's display name
-     * would be "Spanish (Mexico,Traditional)".
-     * @param name  Receives the locale's display name.
-     * @return      A reference to "name".
-     * @stable ICU 2.0
-     */
-    UnicodeString&  getDisplayName(         UnicodeString&  name) const;
-
-    /**
-     * Fills in "name" with the name of this locale in a format suitable for user display
-     * in the locale specfied by "displayLocale".  This function uses getDisplayLanguage(),
-     * getDisplayCountry(), and getDisplayVariant() to do its work, and outputs the display
-     * name in the format "language (country[,variant])".  For example, if displayLocale is
-     * fr_FR, then en_US's display name would be "Anglais (&Eacute;tats-Unis)", and no_NO_NY's
-     * display name would be "norv&eacute;gien (Norv&egrave;ge,NY)".
-     * @param displayLocale  Specifies the locale to be used to display the name.
-     * @param name      Receives the locale's display name.
-     * @return          A reference to "name".
-     * @stable ICU 2.0
-     */
-    UnicodeString&  getDisplayName( const   Locale&         displayLocale,
-                                            UnicodeString&  name) const;
-
-    /**
-     * Generates a hash code for the locale.
-     * @stable ICU 2.0
-     */
-    int32_t         hashCode(void) const;
-
-    /**
-     * Sets the locale to bogus
-     * A bogus locale represents a non-existing locale associated
-     * with services that can be instantiated from non-locale data
-     * in addition to locale (for example, collation can be
-     * instantiated from a locale and from a rule set).
-     * @stable ICU 2.1
-     */
-    void setToBogus();
-
-    /**
-     * Gets the bogus state. Locale object can be bogus if it doesn't exist
-     * @return FALSE if it is a real locale, TRUE if it is a bogus locale
-     * @stable ICU 2.1
-     */
-    UBool isBogus(void) const;
-
-    /**
-     * Returns a list of all installed locales.
-     * @param count Receives the number of locales in the list.
-     * @return      A pointer to an array of Locale objects.  This array is the list
-     *              of all locales with installed resource files.  The called does NOT
-     *              get ownership of this list, and must NOT delete it.
-     * @stable ICU 2.0
-     */
-    static const Locale* U_EXPORT2 getAvailableLocales(int32_t& count);
-
-    /**
-     * Gets a list of all available 2-letter country codes defined in ISO 639.  This is a
-     * pointer to an array of pointers to arrays of char.  All of these pointers are
-     * owned by ICU-- do not delete them, and do not write through them.  The array is
-     * terminated with a null pointer.
-     * @return a list of all available country codes
-     * @stable ICU 2.0
-     */
-    static const char* const* U_EXPORT2 getISOCountries();
-
-    /**
-     * Gets a list of all available language codes defined in ISO 639.  This is a pointer
-     * to an array of pointers to arrays of char.  All of these pointers are owned
-     * by ICU-- do not delete them, and do not write through them.  The array is
-     * terminated with a null pointer.
-     * @return a list of all available language codes
-     * @stable ICU 2.0
-     */
-    static const char* const* U_EXPORT2 getISOLanguages();
-
-    /**
-     * ICU "poor man's RTTI", returns a UClassID for this class.
-     *
-     * @stable ICU 2.2
-     */
-    static UClassID U_EXPORT2 getStaticClassID();
-
-    /**
-     * ICU "poor man's RTTI", returns a UClassID for the actual class.
-     *
-     * @stable ICU 2.2
-     */
-    virtual UClassID getDynamicClassID() const;
-
-protected: /* only protected for testing purposes. DO NOT USE. */
-    /**
-     * Set this from a single POSIX style locale string.
-     * @internal
-     */
-    void setFromPOSIXID(const char *posixID);
-
-private:
-    /**
-     * Initialize the locale object with a new name.
-     * Was deprecated - used in implementation - moved internal
-     *
-     * @param cLocaleID The new locale name.
-     */
-    Locale& init(const char* cLocaleID, UBool canonicalize);
-
-    /*
-     * Internal constructor to allow construction of a locale object with
-     *   NO side effects.   (Default constructor tries to get
-     *   the default locale.)
-     */
-    enum ELocaleType {
-        eBOGUS
-    };
-    Locale(ELocaleType);
-
-    /**
-     * Initialize the locale cache for commonly used locales
-     */
-    static Locale *getLocaleCache(void);
-
-    char language[ULOC_LANG_CAPACITY];
-    char script[ULOC_SCRIPT_CAPACITY];
-    char country[ULOC_COUNTRY_CAPACITY];
-    int32_t variantBegin;
-    char* fullName;
-    char fullNameBuffer[ULOC_FULLNAME_CAPACITY];
-    // name without keywords
-    char* baseName;
-    char baseNameBuffer[ULOC_FULLNAME_CAPACITY];
-
-    UBool fIsBogus;
-
-    static const Locale &getLocale(int locid);
-
-    /**
-     * A friend to allow the default locale to be set by either the C or C++ API.
-     * @internal
-     */
-    friend void locale_set_default_internal(const char *);
-};
-
-inline UBool
-Locale::operator!=(const    Locale&     other) const
-{
-    return !operator==(other);
-}
-
-inline const char *
-Locale::getCountry() const
-{
-    return country;
-}
-
-inline const char *
-Locale::getLanguage() const
-{
-    return language;
-}
-
-inline const char *
-Locale::getScript() const
-{
-    return script;
-}
-
-inline const char *
-Locale::getVariant() const
-{
-    return &fullName[variantBegin];
-}
-
-inline const char *
-Locale::getName() const
-{
-    return fullName;
-}
-
-inline UBool
-Locale::isBogus(void) const {
-    return fIsBogus;
-}
-
-U_NAMESPACE_END
-
-#endif
-

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/measfmt.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/measfmt.h b/apps/couch_collate/platform/osx/icu/unicode/measfmt.h
deleted file mode 100644
index a5af55e..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/measfmt.h
+++ /dev/null
@@ -1,77 +0,0 @@
-/*
-**********************************************************************
-* Copyright (c) 2004-2006, International Business Machines
-* Corporation and others.  All Rights Reserved.
-**********************************************************************
-* Author: Alan Liu
-* Created: April 20, 2004
-* Since: ICU 3.0
-**********************************************************************
-*/
-#ifndef MEASUREFORMAT_H
-#define MEASUREFORMAT_H
-
-#include "unicode/utypes.h"
-
-#if !UCONFIG_NO_FORMATTING
-
-#include "unicode/format.h"
-
-/**
- * \file 
- * \brief C++ API: Formatter for measure objects.
- */
-
-U_NAMESPACE_BEGIN
-
-/**
- * 
- * A formatter for measure objects.  This is an abstract base class.
- *
- * <p>To format or parse a measure object, first create a formatter
- * object using a MeasureFormat factory method.  Then use that
- * object's format and parse methods.
- *
- * <p>This is an abstract class.
- *
- * @see Format
- * @author Alan Liu
- * @stable ICU 3.0
- */
-class U_I18N_API MeasureFormat : public Format {
-
- public:
-
-    /**
-     * Return a formatter for CurrencyAmount objects in the given
-     * locale.
-     * @param locale desired locale
-     * @param ec input-output error code
-     * @return a formatter object, or NULL upon error
-     * @stable ICU 3.0
-     */
-    static MeasureFormat* U_EXPORT2 createCurrencyFormat(const Locale& locale,
-                                               UErrorCode& ec);
-
-    /**
-     * Return a formatter for CurrencyAmount objects in the default
-     * locale.
-     * @param ec input-output error code
-     * @return a formatter object, or NULL upon error
-     * @stable ICU 3.0
-     */
-    static MeasureFormat* U_EXPORT2 createCurrencyFormat(UErrorCode& ec);
-
- protected:
-
-    /**
-     * Default constructor.
-     * @stable ICU 3.0
-     */
-    MeasureFormat();
-};
-
-U_NAMESPACE_END
-
-#endif // #if !UCONFIG_NO_FORMATTING
-#endif // #ifndef MEASUREFORMAT_H

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/measunit.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/measunit.h b/apps/couch_collate/platform/osx/icu/unicode/measunit.h
deleted file mode 100644
index 9a210e6..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/measunit.h
+++ /dev/null
@@ -1,71 +0,0 @@
-/*
-**********************************************************************
-* Copyright (c) 2004-2006, International Business Machines
-* Corporation and others.  All Rights Reserved.
-**********************************************************************
-* Author: Alan Liu
-* Created: April 26, 2004
-* Since: ICU 3.0
-**********************************************************************
-*/
-#ifndef __MEASUREUNIT_H__
-#define __MEASUREUNIT_H__
-
-#include "unicode/utypes.h"
-
-#if !UCONFIG_NO_FORMATTING
-
-#include "unicode/fmtable.h"
-
-/**
- * \file 
- * \brief C++ API: A unit for measuring a quantity.
- */
- 
-U_NAMESPACE_BEGIN
-
-/**
- * A unit such as length, mass, volume, currency, etc.  A unit is
- * coupled with a numeric amount to produce a Measure.
- *
- * <p>This is an abstract class.
- *
- * @author Alan Liu
- * @stable ICU 3.0
- */
-class U_I18N_API MeasureUnit: public UObject {
- public:
-    /**
-     * Return a polymorphic clone of this object.  The result will
-     * have the same class as returned by getDynamicClassID().
-     * @stable ICU 3.0
-     */
-    virtual UObject* clone() const = 0;
-
-    /**
-     * Destructor
-     * @stable ICU 3.0
-     */
-    virtual ~MeasureUnit();
-    
-    /**
-     * Equality operator.  Return true if this object is equal
-     * to the given object.
-     * @stable ICU 3.0
-     */
-    virtual UBool operator==(const UObject& other) const = 0;
-
- protected:
-    /**
-     * Default constructor.
-     * @stable ICU 3.0
-     */
-    MeasureUnit();
-};
-
-U_NAMESPACE_END
-
-// NOTE: There is no measunit.cpp. For implementation, see measure.cpp. [alan]
-
-#endif // !UCONFIG_NO_FORMATTING
-#endif // __MEASUREUNIT_H__

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/measure.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/measure.h b/apps/couch_collate/platform/osx/icu/unicode/measure.h
deleted file mode 100644
index 6b7a049..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/measure.h
+++ /dev/null
@@ -1,137 +0,0 @@
-/*
-**********************************************************************
-* Copyright (c) 2004-2006, International Business Machines
-* Corporation and others.  All Rights Reserved.
-**********************************************************************
-* Author: Alan Liu
-* Created: April 26, 2004
-* Since: ICU 3.0
-**********************************************************************
-*/
-#ifndef __MEASURE_H__
-#define __MEASURE_H__
-
-#include "unicode/utypes.h"
-
-/**
- * \file 
- * \brief C++ API: MeasureUnit object.
- */
- 
-#if !UCONFIG_NO_FORMATTING
-
-#include "unicode/fmtable.h"
-
-U_NAMESPACE_BEGIN
-
-class MeasureUnit;
-
-/**
- * An amount of a specified unit, consisting of a number and a Unit.
- * For example, a length measure consists of a number and a length
- * unit, such as feet or meters.  This is an abstract class.
- * Subclasses specify a concrete Unit type.
- *
- * <p>Measure objects are parsed and formatted by subclasses of
- * MeasureFormat.
- *
- * <p>Measure objects are immutable.
- *
- * <p>This is an abstract class.
- *
- * @author Alan Liu
- * @stable ICU 3.0
- */
-class U_I18N_API Measure: public UObject {
- public:
-    /**
-     * Construct an object with the given numeric amount and the given
-     * unit.  After this call, the caller must not delete the given
-     * unit object.
-     * @param number a numeric object; amount.isNumeric() must be TRUE
-     * @param adoptedUnit the unit object, which must not be NULL
-     * @param ec input-output error code. If the amount or the unit
-     * is invalid, then this will be set to a failing value.
-     * @stable ICU 3.0
-     */
-    Measure(const Formattable& number, MeasureUnit* adoptedUnit,
-            UErrorCode& ec);
-
-    /**
-     * Copy constructor
-     * @stable ICU 3.0
-     */
-    Measure(const Measure& other);
-
-    /**
-     * Assignment operator
-     * @stable ICU 3.0
-     */
-    Measure& operator=(const Measure& other);
-
-    /**
-     * Return a polymorphic clone of this object.  The result will
-     * have the same class as returned by getDynamicClassID().
-     * @stable ICU 3.0
-     */
-    virtual UObject* clone() const = 0;
-
-    /**
-     * Destructor
-     * @stable ICU 3.0
-     */
-    virtual ~Measure();
-    
-    /**
-     * Equality operator.  Return true if this object is equal
-     * to the given object.
-     * @stable ICU 3.0
-     */
-    UBool operator==(const UObject& other) const;
-
-    /**
-     * Return a reference to the numeric value of this object.  The
-     * numeric value may be of any numeric type supported by
-     * Formattable.
-     * @stable ICU 3.0
-     */
-    inline const Formattable& getNumber() const;
-
-    /**
-     * Return a reference to the unit of this object.
-     * @stable ICU 3.0
-     */
-    inline const MeasureUnit& getUnit() const;
-
- protected:
-    /**
-     * Default constructor.
-     * @stable ICU 3.0
-     */
-    Measure();
-
- private:
-    /**
-     * The numeric value of this object, e.g. 2.54 or 100.
-     */
-    Formattable number;
-
-    /**
-     * The unit of this object, e.g., "millimeter" or "JPY".  This is
-     * owned by this object.
-     */
-    MeasureUnit* unit;
-};
-
-inline const Formattable& Measure::getNumber() const {
-    return number;
-}
-
-inline const MeasureUnit& Measure::getUnit() const {
-    return *unit;
-}
-
-U_NAMESPACE_END
-
-#endif // !UCONFIG_NO_FORMATTING
-#endif // __MEASURE_H__


[44/57] [abbrv] couchdb commit: updated refs/heads/1994-merge-rcouch-multi-repo to b19d055

Posted by be...@apache.org.
remove couch_plugins


Project: http://git-wip-us.apache.org/repos/asf/couchdb/repo
Commit: http://git-wip-us.apache.org/repos/asf/couchdb/commit/20a68fec
Tree: http://git-wip-us.apache.org/repos/asf/couchdb/tree/20a68fec
Diff: http://git-wip-us.apache.org/repos/asf/couchdb/diff/20a68fec

Branch: refs/heads/1994-merge-rcouch-multi-repo
Commit: 20a68fec4d762ccb20862edf6d6b85fbd25344ee
Parents: ae6eae3
Author: Benoit Chesneau <bc...@gmail.com>
Authored: Thu Feb 13 16:38:39 2014 +0100
Committer: Benoit Chesneau <bc...@gmail.com>
Committed: Thu Feb 13 16:38:39 2014 +0100

----------------------------------------------------------------------
 apps/couch_plugins/README.md                   | 159 -----------
 apps/couch_plugins/src/couch_plugins.app.src   |  23 --
 apps/couch_plugins/src/couch_plugins.erl       | 300 --------------------
 apps/couch_plugins/src/couch_plugins_httpd.erl |  65 -----
 4 files changed, 547 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/couchdb/blob/20a68fec/apps/couch_plugins/README.md
----------------------------------------------------------------------
diff --git a/apps/couch_plugins/README.md b/apps/couch_plugins/README.md
deleted file mode 100644
index b00a080..0000000
--- a/apps/couch_plugins/README.md
+++ /dev/null
@@ -1,159 +0,0 @@
-Heya,
-
-I couldn’t help myself thinking about plugin stuff and ended up
-whipping up a proof of concept.
-
-Here’s a <1 minute demo video:
-
-  https://dl.dropboxusercontent.com/u/82149/couchdb-plugins-demo.mov
-
-Alternative encoding:
-
-  https://dl.dropboxusercontent.com/u/82149/couchdb-plugins-demo.m4v)
-
-
-In my head the whole plugin idea is a very wide area, but I was so
-intrigued by the idea of getting something running with a click on a
-button in Futon. So I looked for a minimally viable plugin system.
-
-
-## Design principles
-
-It took me a day to put this all together and this was only possible
-because I took a lot of shortcuts. I believe they are all viable for a
-first iteration of a plugins system:
-
-1. Install with one click on a button in Futon (or HTTP call)
-2. Only pure Erlang plugins are allowed.
-3. The plugin author must provide a binary package for each Erlang (and,
-   later, each CouchDB version).
-4. Complete trust-based system. You trust me to not do any nasty things
-   when you click on the install button. No crypto, no nothing. Only
-   people who can commit to Futon can release new versions of plugins.
-5. Minimal user-friendlyness: won’t install plugins that don’t match
-   the current Erlang version, gives semi-sensible error messages
-   (wrapped in a HTTP 500 response :)
-6. Require a pretty strict format for binary releases.
-
-
-## Roadmap
-
-Here’s a list of things this first iterations does and doesn’t do:
-
-- Pure Erlang plugins only. No C-dependencies, no JavaScript, no nothing.
-- No C-dependencies.
-- Install a plugin via Futon (or HTTP call). Admin only.
-- A hardcoded list of plugins in Futon.
-- Loads a pre-packaged, pre-compiled .tar.gz file from a URL.
-- Only installs if Erlang version matches.
-- No security checking of binaries.
-- No identity checking of binaries.
-- Register installed plugins in the config system.
-- Make sure plugins start with the next restart of CouchDB.
-- Uninstall a plugin via Futon (or HTTP call). Admin only.
-- Show when a particular plugin is installed.
-- Only installs if CouchDB version matches.
-- Serve static web assets (for Futon/Fauxton) from `/_plugins/<name>/`.
-
-I hope you agree we can ship this with a few warnings so people can get a
-hang of it.
-
-
-A roadmap, progress and issues can be found here:
-
-https://issues.apache.org/jira/issues/?jql=component+%3D+Plugins+AND+project+%3D+COUCHDB+AND+resolution+%3D+Unresolved+ORDER+BY+priority+DESC
-
-
-
-## How it works
-
-This plugin system lives in `src/couch_plugins` and is a tiny CouchDB
-module.
-
-It exposes one new API endpoint `/_plugins` that an admin user can
-POST to.
-
-The additional Futon page lives at `/_utils/plugins.html` it is
-hardcoded.
-
-Futon (or you) post an object to `/_plugins` with four properties:
-
-    {
-      "name": "geocouch", // name of the plugin, must be unique
-      "url": "http://people.apache.org/~jan", // “base URL” for plugin releases (see below)
-      "version": "couchdb1.2.x_v0.3.0-11-g4ea0bea", // whatever version internal to the plugin
-      "checksums": {
-        "R15B03": "ZetgdHj2bY2w37buulWVf3USOZs=" // base64’d sha hash over the binary
-      }
-    }
-
-`couch_plugins` then attempts to download a .tar.gz from this
-location:
-
-    http://people.apache.org/~jan/geocouch-couchdb1.2.x_v0.3.0-12-g4ea0bea-R15B03.tar.gz
-
-It should be obvious how the URL is constructed from the POST data.
-(This url is live, feel free to play around with this tarball).
-
-Next it calculates the sha hash for the downloaded .tar.gz file and
-matches it against the correct version in the `checksums` parameter.
-
-If that succeeds, we unpack the .tar.gz file (currently in `/tmp`,
-need to find a better place for this) and adds the extracted directory
-to the Erlang code path
-(`code:add_path("/tmp/couchdb_plugins/geocouch-couchdb1.2.x_v0.3.0-12-g4ea0bea-R15B03/ebin")`)
-and loads the included application (`application:load(geocouch)`).
-
-Then it looks into the `./priv/default.d` directory that lives next to
-`ebin/` in the plugin directory for configuration `.ini` files and loads them.
-On next startup these configuration files are loaded after global defaults,
-and before any local configuration.
-
-If that all goes to plan, we report success back to the HTTP caller.
-
-That’s it! :)
-
-It’s deceptively simple, probably does a few things very wrong and
-leaves a few things open (see above).
-
-One open question I’d like an answer for is finding a good location to
-unpack & install the plugin files that isn’t `tmp`. If the answer is
-different for a pre-BigCouch/rcouch-merge and post-BigCouch/rcouch-
-merge world, I’d love to know :)
-
-
-## Code
-
-The main branch for this is 1867-feature-plugins:
-
-  ASF: https://git-wip-us.apache.org/repos/asf?p=couchdb.git;a=log;h=refs/heads/1867-feature-plugins
-  GitHub: https://github.com/janl/couchdb/compare/apache:master...1867-feature-plugins
-
-I created a branch on GeoCouch that adds a few lines to its `Makefile`
-that shows how a binary package is built:
-
-    https://github.com/janl/geocouch/compare/couchbase:couchdb1.3.x...couchdb1.3.x-plugins
-
-
-## Build
-
-Build CouchDB as usual:
-
-    ./bootstrap
-    ./configure
-    make
-    make dev
-    ./utils/run
-
-* * *
-
-I hope you like this :) Please comment and improve heavily!
-
-Let me know if you have any questions :)
-
-If you have any criticism, please phrase it in a way that we can use
-to improve this, thanks!
-
-Best,
-Jan
---

http://git-wip-us.apache.org/repos/asf/couchdb/blob/20a68fec/apps/couch_plugins/src/couch_plugins.app.src
----------------------------------------------------------------------
diff --git a/apps/couch_plugins/src/couch_plugins.app.src b/apps/couch_plugins/src/couch_plugins.app.src
deleted file mode 100644
index 9e69b84..0000000
--- a/apps/couch_plugins/src/couch_plugins.app.src
+++ /dev/null
@@ -1,23 +0,0 @@
-% Licensed 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.
-{application, couch_plugins,
- [
-  {description, "A CouchDB Plugin Installer"},
-  {vsn, "0.1.0"},
-  {registered, []},
-  {applications, [
-                  kernel,
-                  stdlib
-                 ]},
-  {mod, { couch_plugins_app, []}},
-  {env, []}
- ]}.

http://git-wip-us.apache.org/repos/asf/couchdb/blob/20a68fec/apps/couch_plugins/src/couch_plugins.erl
----------------------------------------------------------------------
diff --git a/apps/couch_plugins/src/couch_plugins.erl b/apps/couch_plugins/src/couch_plugins.erl
deleted file mode 100644
index dcbd2d3..0000000
--- a/apps/couch_plugins/src/couch_plugins.erl
+++ /dev/null
@@ -1,300 +0,0 @@
-% Licensed 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.
--module(couch_plugins).
--include_lib("couch/include/couch_db.hrl").
--export([install/1, uninstall/1]).
-
-% couch_plugins:install({"geocouch", "http://127.0.0.1:8000", "1.0.0", [{"R15B03", "+XOJP6GSzmuO2qKdnjO+mWckXVs="}]}).
-% couch_plugins:install({"geocouch", "http://people.apache.org/~jan/", "couchdb1.2.x_v0.3.0-11-gd83ba22", [{"R15B03", "ZetgdHj2bY2w37buulWVf3USOZs="}]}).
-
-plugin_dir() ->
-  couch_config:get("couchdb", "plugin_dir").
-
-log(T) ->
-  ?LOG_DEBUG("[couch_plugins] ~p ~n", [T]).
-
-%% "geocouch", "http://localhost:8000/dist", "1.0.0"
--type plugin() :: {string(), string(), string(), list()}.
--spec install(plugin()) -> ok | {error, string()}.
-install({Name, _BaseUrl, Version, Checksums}=Plugin) ->
-  log("Installing " ++ Name),
-
-  {ok, LocalFilename} = download(Plugin),
-  log("downloaded to " ++ LocalFilename),
-
-  ok = verify_checksum(LocalFilename, Checksums),
-  log("checksum verified"),
-
-  ok = untargz(LocalFilename),
-  log("extraction done"),
-
-  ok = add_code_path(Name, Version),
-  log("added code path"),
-
-  ok = register_plugin(Name, Version),
-  log("registered plugin"),
-
-  load_config(Name, Version),
-  log("loaded config"),
-
-  ok.
-
-% Idempotent uninstall, if you uninstall a non-existant
-% plugin, you get an `ok`.
--spec uninstall(plugin()) -> ok | {error, string()}.
-uninstall({Name, _BaseUrl, Version, _Checksums}) ->
-  % unload config
-  ok = unload_config(Name, Version),
-  log("config unloaded"),
-
-  % delete files
-  ok = delete_files(Name, Version),
-  log("files deleted"),
-
-  % delete code path
-  ok = del_code_path(Name, Version),
-  log("deleted code path"),
-
-  % unregister plugin
-  ok = unregister_plugin(Name),
-  log("unregistered plugin"),
-
-  % done
-  ok.
-
-%% * * *
-
-
-%% Plugin Registration
-%% On uninstall:
-%%  - add plugins/name = version to config
-%% On uninstall:
-%%  - remove plugins/name from config
-
--spec register_plugin(string(), string()) -> ok.
-register_plugin(Name, Version) ->
-  couch_config:set("plugins", Name, Version).
-
--spec unregister_plugin(string()) -> ok.
-unregister_plugin(Name) ->
-  couch_config:delete("plugins", Name).
-
-%% * * *
-
-
-%% Load Config
-%% Parses <plugindir>/priv/default.d/<pluginname.ini> and applies
-%% the contents to the config system, or removes them on uninstall
-
--spec load_config(string(), string()) -> ok.
-load_config(Name, Version) ->
-    loop_config(Name, Version, fun set_config/1).
-
--spec unload_config(string(), string()) -> ok.
-unload_config(Name, Version) ->
-    loop_config(Name, Version, fun delete_config/1).
-
--spec loop_config(string(), string(), function()) -> ok.
-loop_config(Name, Version, Fun) ->
-    lists:foreach(fun(File) -> load_config_file(File, Fun) end,
-      filelib:wildcard(file_names(Name, Version))).
-
--spec load_config_file(string(), function()) -> ok.
-load_config_file(File, Fun) ->
-    {ok, Config} = couch_config:parse_ini_file(File),
-    lists:foreach(Fun, Config).
-
--spec set_config({{string(), string()}, string()}) -> ok.
-set_config({{Section, Key}, Value}) ->
-    ok = couch_config:set(Section, Key, Value).
-
--spec delete_config({{string(), string()}, _Value}) -> ok.
-delete_config({{Section, Key}, _Value}) ->
-    ok = couch_config:delete(Section, Key).
-
--spec file_names(string(), string()) -> string().
-file_names(Name, Version) ->
-  filename:join(
-    [plugin_dir(), get_file_slug(Name, Version),
-     "priv", "default.d", "*.ini"]).
-
-%% * * *
-
-
-%% Code Path Management
-%% The Erlang code path is where the Erlang runtime looks for `.beam`
-%% files to load on, say, `application:load()`. Since plugin directories
-%% are created on demand and named after CouchDB and Erlang versions,
-%% we manage the Erlang code path semi-automatically here.
-
--spec add_code_path(string(), string()) -> ok | {error, bad_directory}.
-add_code_path(Name, Version) ->
-  PluginPath = plugin_dir() ++ "/" ++ get_file_slug(Name, Version) ++ "/ebin",
-  case code:add_path(PluginPath) of
-    true -> ok;
-    Else ->
-      ?LOG_ERROR("Failed to add PluginPath: '~s'", [PluginPath]),
-      Else
-  end.
-
--spec del_code_path(string(), string()) -> ok | {error, atom()}.
-del_code_path(Name, Version) ->
-  PluginPath = plugin_dir() ++ "/" ++ get_file_slug(Name, Version) ++ "/ebin",
-  case code:del_path(PluginPath) of
-    true -> ok;
-    _Else ->
-      ?LOG_DEBUG("Failed to delete PluginPath: '~s', ignoring", [PluginPath]),
-      ok
-  end.
-
-%% * * *
-
-
--spec untargz(string()) -> {ok, string()} | {error, string()}.
-untargz(Filename) ->
-  % read .gz file
-  {ok, GzData} = file:read_file(Filename),
-  % gunzip
-  log("unzipped"),
-  TarData = zlib:gunzip(GzData),
-  ok = filelib:ensure_dir(plugin_dir()),
-  % untar
-  erl_tar:extract({binary, TarData}, [{cwd, plugin_dir()}, keep_old_files]).
-
--spec delete_files(string(), string()) -> ok | {error, atom()}.
-delete_files(Name, Version) ->
-  PluginPath = plugin_dir() ++ "/" ++ get_file_slug(Name, Version),
-  mochitemp:rmtempdir(PluginPath).
-
-
-% downloads a pluygin .tar.gz into a local plugins directory
--spec download(string()) -> ok | {error, string()}.
-download({Name, _BaseUrl, Version, _Checksums}=Plugin) ->
-  TargetFile = "/tmp/" ++ get_filename(Name, Version),
-  case file_exists(TargetFile) of
-    %% wipe and redownload
-    true -> file:delete(TargetFile);
-    _Else -> ok
-  end,
-  Url = get_url(Plugin),
-  HTTPOptions = [
-    {connect_timeout, 30*1000}, % 30 seconds
-    {timeout, 30*1000} % 30 seconds
-  ],
-  % todo: windows
-  Options = [
-    {stream, TargetFile}, % /tmp/something
-    {body_format, binary},
-    {full_result, false}
-  ],
-  % todo: reduce to just httpc:request()
-  case httpc:request(get, {Url, []}, HTTPOptions, Options) of
-    {ok, _Result} ->
-      log("downloading " ++ Url),
-      {ok, TargetFile};
-    Error -> Error
-  end.
-
--spec verify_checksum(string(), list()) -> ok | {error, string()}.
-verify_checksum(Filename, Checksums) ->
-
-  CouchDBVersion = couchdb_version(),
-  case proplists:get_value(CouchDBVersion, Checksums) of
-  undefined ->
-    ?LOG_ERROR("[couch_plugins] Can't find checksum for CouchDB Version '~s'", [CouchDBVersion]),
-    {error, no_couchdb_checksum};
-  OTPChecksum ->
-    OTPRelease = erlang:system_info(otp_release),
-    case proplists:get_value(OTPRelease, OTPChecksum) of
-    undefined ->
-      ?LOG_ERROR("[couch_plugins] Can't find checksum for Erlang Version '~s'", [OTPRelease]),
-      {error, no_erlang_checksum};
-    Checksum ->
-      do_verify_checksum(Filename, Checksum)
-    end
-  end.
-
--spec do_verify_checksum(string(), string()) -> ok | {error, string()}.
-do_verify_checksum(Filename, Checksum) ->
-  ?LOG_DEBUG("Checking Filename: ~s", [Filename]),
-  case file:read_file(Filename) of
-  {ok, Data} ->
-    ComputedChecksum = binary_to_list(base64:encode(crypto:sha(Data))),
-    case ComputedChecksum of
-    Checksum -> ok;
-    _Else ->
-      ?LOG_ERROR("Checksum mismatch. Wanted: '~p'. Got '~p'", [Checksum, ComputedChecksum]),
-      {error, checksum_mismatch}
-    end;
-  Error -> Error
-  end.
-
-
-%% utils
-
--spec get_url(plugin()) -> string().
-get_url({Name, BaseUrl, Version, _Checksums}) ->
-  BaseUrl ++ "/" ++ get_filename(Name, Version).
-
--spec get_filename(string(), string()) -> string().
-get_filename(Name, Version) ->
-  get_file_slug(Name, Version) ++ ".tar.gz".
-
--spec get_file_slug(string(), string()) -> string().
-get_file_slug(Name, Version) ->
-  % OtpRelease does not include patch levels like the -1 in R15B03-1
-  OTPRelease = erlang:system_info(otp_release),
-  CouchDBVersion = couchdb_version(),
-  string:join([Name, Version, OTPRelease, CouchDBVersion], "-").
-
--spec file_exists(string()) -> boolean().
-file_exists(Filename) ->
-  does_file_exist(file:read_file_info(Filename)).
--spec does_file_exist(term()) -> boolean().
-does_file_exist({error, enoent}) -> false;
-does_file_exist(_Else) -> true.
-
-couchdb_version() ->
-  couch_server:get_version(short).
-
-% installing a plugin:
-%  - POST /_plugins -d {plugin-def}
-%  - get plugin definition
-%  - get download URL (matching erlang version)
-%  - download archive
-%  - match checksum
-%  - untar-gz archive into a plugins dir
-%  - code:add_path(“geocouch-{geocouch_version}-{erlang_version}/ebin”)
-%  - [cp geocouch-{geocouch_version}-{erlang_version}/etc/ ]
-%  - application:start(geocouch)
-%  - register plugin in plugin registry
-
-% Plugin registry impl:
-%  - _plugins database
-%   - pro: known db ops
-%   - con: no need for replication, needs to be system db etc.
-%  - _config/plugins namespace in config
-%   - pro: lightweight, fits rarely-changing nature better
-%   - con: potentially not flexible enough
-
-
-
-% /geocouch
-% /geocouch/dist/
-% /geocouch/dist/geocouch-{geocouch_version}-{erlang_version}.tar.gz
-
-% tar.gz includes:
-% geocouch-{geocouch_version}-{erlang_version}/
-% geocouch-{geocouch_version}-{erlang_version}/ebin
-% [geocouch-{geocouch_version}-{erlang_version}/config/config.erlt]
-% [geocouch-{geocouch_version}-{erlang_version}/share/]
-

http://git-wip-us.apache.org/repos/asf/couchdb/blob/20a68fec/apps/couch_plugins/src/couch_plugins_httpd.erl
----------------------------------------------------------------------
diff --git a/apps/couch_plugins/src/couch_plugins_httpd.erl b/apps/couch_plugins/src/couch_plugins_httpd.erl
deleted file mode 100644
index 4dabbb4..0000000
--- a/apps/couch_plugins/src/couch_plugins_httpd.erl
+++ /dev/null
@@ -1,65 +0,0 @@
-% Licensed 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.
--module(couch_plugins_httpd).
-
--export([handle_req/1]).
-
--include_lib("couch/include/couch_db.hrl").
-
-handle_req(#httpd{method='POST'}=Req) ->
-    ok = couch_httpd:verify_is_server_admin(Req),
-    couch_httpd:validate_ctype(Req, "application/json"),
-
-    {PluginSpec} = couch_httpd:json_body_obj(Req),
-    Url = binary_to_list(couch_util:get_value(<<"url">>, PluginSpec)),
-    Name = binary_to_list(couch_util:get_value(<<"name">>, PluginSpec)),
-    Version = binary_to_list(couch_util:get_value(<<"version">>, PluginSpec)),
-    Delete = couch_util:get_value(<<"delete">>, PluginSpec),
-    {Checksums0} = couch_util:get_value(<<"checksums">>, PluginSpec),
-    Checksums = parse_checksums(Checksums0),
-
-    Plugin = {Name, Url, Version, Checksums},
-    case do_install(Delete, Plugin) of
-    ok ->
-        couch_httpd:send_json(Req, 202, {[{ok, true}]});
-    Error ->
-        ?LOG_DEBUG("Plugin Spec: ~p", [PluginSpec]),
-        couch_httpd:send_error(Req, {bad_request, Error})
-    end;
-% handles /_plugins/<pluginname>/<file>
-% serves <plugin_dir>/<pluginname>-<pluginversion>-<otpversion>-<couchdbversion>/<file>
-handle_req(#httpd{method='GET',path_parts=[_, Name0 | Path0]}=Req) ->
-    Name = ?b2l(Name0),
-    Path = lists:map(fun binary_to_list/1, Path0),
-    OTPRelease = erlang:system_info(otp_release),
-    PluginVersion = couch_config:get("plugins", Name),
-    CouchDBVersion = couch_server:get_version(short),
-    FullName = string:join([Name, PluginVersion, OTPRelease, CouchDBVersion], "-"),
-    FullPath = filename:join([FullName, "priv", "www", string:join(Path, "/")]) ++ "/",
-    ?LOG_DEBUG("Serving ~p from ~p", [FullPath, plugin_dir()]),
-    couch_httpd:serve_file(Req, FullPath, plugin_dir());
-handle_req(Req) ->
-    couch_httpd:send_method_not_allowed(Req, "POST").
-
-plugin_dir() ->
-  couch_config:get("couchdb", "plugin_dir").
-do_install(false, Plugin) ->
-    couch_plugins:install(Plugin);
-do_install(true, Plugin) ->
-    couch_plugins:uninstall(Plugin).
-
-parse_checksums(Checksums) ->
-    lists:map(fun({K, {V}}) ->
-        {binary_to_list(K), parse_checksums(V)};
-      ({K, V}) ->
-         {binary_to_list(K), binary_to_list(V)}
-    end, Checksums).


[26/57] [abbrv] remove couch_collate

Posted by be...@apache.org.
http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/stsearch.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/stsearch.h b/apps/couch_collate/platform/osx/icu/unicode/stsearch.h
deleted file mode 100644
index 8499752..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/stsearch.h
+++ /dev/null
@@ -1,518 +0,0 @@
-/*
-**********************************************************************
-*   Copyright (C) 2001-2008 IBM and others. All rights reserved.
-**********************************************************************
-*   Date        Name        Description
-*  03/22/2000   helena      Creation.
-**********************************************************************
-*/
-
-#ifndef STSEARCH_H
-#define STSEARCH_H
-
-#include "unicode/utypes.h"
-
-/**
- * \file 
- * \brief C++ API: Service for searching text based on RuleBasedCollator.
- */
- 
-#if !UCONFIG_NO_COLLATION && !UCONFIG_NO_BREAK_ITERATION
-
-#include "unicode/tblcoll.h"
-#include "unicode/coleitr.h"
-#include "unicode/search.h"
-
-U_NAMESPACE_BEGIN
-
-/** 
- *
- * <tt>StringSearch</tt> is a <tt>SearchIterator</tt> that provides
- * language-sensitive text searching based on the comparison rules defined
- * in a {@link RuleBasedCollator} object.
- * StringSearch ensures that language eccentricity can be 
- * handled, e.g. for the German collator, characters &szlig; and SS will be matched 
- * if case is chosen to be ignored.
- * See the <a href="http://source.icu-project.org/repos/icu/icuhtml/trunk/design/collation/ICU_collation_design.htm">
- * "ICU Collation Design Document"</a> for more information.
- * <p> 
- * The algorithm implemented is a modified form of the Boyer Moore's search.
- * For more information  see 
- * <a href="http://icu-project.org/docs/papers/efficient_text_searching_in_java.html">
- * "Efficient Text Searching in Java"</a>, published in <i>Java Report</i> 
- * in February, 1999, for further information on the algorithm.
- * <p>
- * There are 2 match options for selection:<br>
- * Let S' be the sub-string of a text string S between the offsets start and 
- * end <start, end>.
- * <br>
- * A pattern string P matches a text string S at the offsets <start, end> 
- * if
- * <pre> 
- * option 1. Some canonical equivalent of P matches some canonical equivalent 
- *           of S'
- * option 2. P matches S' and if P starts or ends with a combining mark, 
- *           there exists no non-ignorable combining mark before or after S? 
- *           in S respectively. 
- * </pre>
- * Option 2. will be the default.
- * <p>
- * This search has APIs similar to that of other text iteration mechanisms 
- * such as the break iterators in <tt>BreakIterator</tt>. Using these 
- * APIs, it is easy to scan through text looking for all occurances of 
- * a given pattern. This search iterator allows changing of direction by 
- * calling a <tt>reset</tt> followed by a <tt>next</tt> or <tt>previous</tt>. 
- * Though a direction change can occur without calling <tt>reset</tt> first,  
- * this operation comes with some speed penalty.
- * Match results in the forward direction will match the result matches in 
- * the backwards direction in the reverse order
- * <p>
- * <tt>SearchIterator</tt> provides APIs to specify the starting position 
- * within the text string to be searched, e.g. <tt>setOffset</tt>,
- * <tt>preceding</tt> and <tt>following</tt>. Since the 
- * starting position will be set as it is specified, please take note that 
- * there are some danger points which the search may render incorrect 
- * results:
- * <ul>
- * <li> The midst of a substring that requires normalization.
- * <li> If the following match is to be found, the position should not be the
- *      second character which requires to be swapped with the preceding 
- *      character. Vice versa, if the preceding match is to be found, 
- *      position to search from should not be the first character which 
- *      requires to be swapped with the next character. E.g certain Thai and
- *      Lao characters require swapping.
- * <li> If a following pattern match is to be found, any position within a 
- *      contracting sequence except the first will fail. Vice versa if a 
- *      preceding pattern match is to be found, a invalid starting point 
- *      would be any character within a contracting sequence except the last.
- * </ul>
- * <p>
- * A breakiterator can be used if only matches at logical breaks are desired.
- * Using a breakiterator will only give you results that exactly matches the
- * boundaries given by the breakiterator. For instance the pattern "e" will
- * not be found in the string "\u00e9" if a character break iterator is used.
- * <p>
- * Options are provided to handle overlapping matches. 
- * E.g. In English, overlapping matches produces the result 0 and 2 
- * for the pattern "abab" in the text "ababab", where else mutually 
- * exclusive matches only produce the result of 0.
- * <p>
- * Though collator attributes will be taken into consideration while 
- * performing matches, there are no APIs here for setting and getting the 
- * attributes. These attributes can be set by getting the collator
- * from <tt>getCollator</tt> and using the APIs in <tt>coll.h</tt>.
- * Lastly to update StringSearch to the new collator attributes, 
- * reset() has to be called.
- * <p> 
- * Restriction: <br>
- * Currently there are no composite characters that consists of a
- * character with combining class > 0 before a character with combining 
- * class == 0. However, if such a character exists in the future,  
- * StringSearch does not guarantee the results for option 1.
- * <p>
- * Consult the <tt>SearchIterator</tt> documentation for information on
- * and examples of how to use instances of this class to implement text
- * searching.
- * <pre><code>
- * UnicodeString target("The quick brown fox jumps over the lazy dog.");
- * UnicodeString pattern("fox");
- *
- * UErrorCode      error = U_ZERO_ERROR;
- * StringSearch iter(pattern, target, Locale::getUS(), NULL, status);
- * for (int pos = iter.first(error);
- *      pos != USEARCH_DONE; 
- *      pos = iter.next(error))
- * {
- *     printf("Found match at %d pos, length is %d\n", pos, 
- *                                             iter.getMatchLength());
- * }
- * </code></pre>
- * <p>
- * Note, StringSearch is not to be subclassed.
- * </p>
- * @see SearchIterator
- * @see RuleBasedCollator
- * @since ICU 2.0
- */
-
-class U_I18N_API StringSearch : public SearchIterator
-{
-public:
-
-    // public constructors and destructors --------------------------------
-
-    /**
-     * Creating a <tt>StringSearch</tt> instance using the argument locale 
-     * language rule set. A collator will be created in the process, which 
-     * will be owned by this instance and will be deleted during 
-     * destruction
-     * @param pattern The text for which this object will search.
-     * @param text    The text in which to search for the pattern.
-     * @param locale  A locale which defines the language-sensitive 
-     *                comparison rules used to determine whether text in the 
-     *                pattern and target matches. 
-     * @param breakiter A <tt>BreakIterator</tt> object used to constrain 
-     *                the matches that are found. Matches whose start and end 
-     *                indices in the target text are not boundaries as 
-     *                determined by the <tt>BreakIterator</tt> are 
-     *                ignored. If this behavior is not desired, 
-     *                <tt>NULL</tt> can be passed in instead.
-     * @param status  for errors if any. If pattern or text is NULL, or if
-     *               either the length of pattern or text is 0 then an 
-     *               U_ILLEGAL_ARGUMENT_ERROR is returned.
-     * @stable ICU 2.0
-     */
-    StringSearch(const UnicodeString &pattern, const UnicodeString &text,
-                 const Locale        &locale,       
-                       BreakIterator *breakiter,
-                       UErrorCode    &status);
-
-    /**
-     * Creating a <tt>StringSearch</tt> instance using the argument collator 
-     * language rule set. Note, user retains the ownership of this collator, 
-     * it does not get destroyed during this instance's destruction.
-     * @param pattern The text for which this object will search.
-     * @param text    The text in which to search for the pattern.
-     * @param coll    A <tt>RuleBasedCollator</tt> object which defines 
-     *                the language-sensitive comparison rules used to 
-     *                determine whether text in the pattern and target 
-     *                matches. User is responsible for the clearing of this
-     *                object.
-     * @param breakiter A <tt>BreakIterator</tt> object used to constrain 
-     *                the matches that are found. Matches whose start and end 
-     *                indices in the target text are not boundaries as 
-     *                determined by the <tt>BreakIterator</tt> are 
-     *                ignored. If this behavior is not desired, 
-     *                <tt>NULL</tt> can be passed in instead.
-     * @param status for errors if any. If either the length of pattern or 
-     *               text is 0 then an U_ILLEGAL_ARGUMENT_ERROR is returned.
-     * @stable ICU 2.0
-     */
-    StringSearch(const UnicodeString     &pattern, 
-                 const UnicodeString     &text,
-                       RuleBasedCollator *coll,       
-                       BreakIterator     *breakiter,
-                       UErrorCode        &status);
-
-    /**
-     * Creating a <tt>StringSearch</tt> instance using the argument locale 
-     * language rule set. A collator will be created in the process, which 
-     * will be owned by this instance and will be deleted during 
-     * destruction
-     * <p>
-     * Note: No parsing of the text within the <tt>CharacterIterator</tt> 
-     * will be done during searching for this version. The block of text 
-     * in <tt>CharacterIterator</tt> will be used as it is.
-     * @param pattern The text for which this object will search.
-     * @param text    The text iterator in which to search for the pattern.
-     * @param locale  A locale which defines the language-sensitive 
-     *                comparison rules used to determine whether text in the 
-     *                pattern and target matches. User is responsible for 
-     *                the clearing of this object.
-     * @param breakiter A <tt>BreakIterator</tt> object used to constrain 
-     *                the matches that are found. Matches whose start and end 
-     *                indices in the target text are not boundaries as 
-     *                determined by the <tt>BreakIterator</tt> are 
-     *                ignored. If this behavior is not desired, 
-     *                <tt>NULL</tt> can be passed in instead.
-     * @param status for errors if any. If either the length of pattern or 
-     *               text is 0 then an U_ILLEGAL_ARGUMENT_ERROR is returned.
-     * @stable ICU 2.0
-     */
-    StringSearch(const UnicodeString &pattern, CharacterIterator &text,
-                 const Locale        &locale, 
-                       BreakIterator *breakiter,
-                       UErrorCode    &status);
-
-    /**
-     * Creating a <tt>StringSearch</tt> instance using the argument collator 
-     * language rule set. Note, user retains the ownership of this collator, 
-     * it does not get destroyed during this instance's destruction.
-     * <p>
-     * Note: No parsing of the text within the <tt>CharacterIterator</tt> 
-     * will be done during searching for this version. The block of text 
-     * in <tt>CharacterIterator</tt> will be used as it is.
-     * @param pattern The text for which this object will search.
-     * @param text    The text in which to search for the pattern.
-     * @param coll    A <tt>RuleBasedCollator</tt> object which defines 
-     *                the language-sensitive comparison rules used to 
-     *                determine whether text in the pattern and target 
-     *                matches. User is responsible for the clearing of this
-     *                object.
-     * @param breakiter A <tt>BreakIterator</tt> object used to constrain 
-     *                the matches that are found. Matches whose start and end 
-     *                indices in the target text are not boundaries as 
-     *                determined by the <tt>BreakIterator</tt> are 
-     *                ignored. If this behavior is not desired, 
-     *                <tt>NULL</tt> can be passed in instead.
-     * @param status for errors if any. If either the length of pattern or 
-     *               text is 0 then an U_ILLEGAL_ARGUMENT_ERROR is returned.
-     * @stable ICU 2.0
-     */
-    StringSearch(const UnicodeString     &pattern, CharacterIterator &text,
-                       RuleBasedCollator *coll, 
-                       BreakIterator     *breakiter,
-                       UErrorCode        &status);
-
-    /**
-     * Copy constructor that creates a StringSearch instance with the same 
-     * behavior, and iterating over the same text.
-     * @param that StringSearch instance to be copied.
-     * @stable ICU 2.0
-     */
-    StringSearch(const StringSearch &that);
-
-    /**
-    * Destructor. Cleans up the search iterator data struct.
-    * If a collator is created in the constructor, it will be destroyed here.
-    * @stable ICU 2.0
-    */
-    virtual ~StringSearch(void);
-
-    /**
-     * Clone this object.
-     * Clones can be used concurrently in multiple threads.
-     * If an error occurs, then NULL is returned.
-     * The caller must delete the clone.
-     *
-     * @return a clone of this object
-     *
-     * @see getDynamicClassID
-     * @stable ICU 2.8
-     */
-    StringSearch *clone() const;
-
-    // operator overloading ---------------------------------------------
-
-    /**
-     * Assignment operator. Sets this iterator to have the same behavior,
-     * and iterate over the same text, as the one passed in.
-     * @param that instance to be copied.
-     * @stable ICU 2.0
-     */
-    StringSearch & operator=(const StringSearch &that);
-
-    /**
-     * Equality operator. 
-     * @param that instance to be compared.
-     * @return TRUE if both instances have the same attributes, 
-     *         breakiterators, collators and iterate over the same text 
-     *         while looking for the same pattern.
-     * @stable ICU 2.0
-     */
-    virtual UBool operator==(const SearchIterator &that) const;
-
-    // public get and set methods ----------------------------------------
-
-    /**
-     * Sets the index to point to the given position, and clears any state 
-     * that's affected.
-     * <p>
-     * This method takes the argument index and sets the position in the text 
-     * string accordingly without checking if the index is pointing to a 
-     * valid starting point to begin searching. 
-     * @param position within the text to be set. If position is less
-     *          than or greater than the text range for searching, 
-     *          an U_INDEX_OUTOFBOUNDS_ERROR will be returned
-     * @param status for errors if it occurs
-     * @stable ICU 2.0
-     */
-    virtual void setOffset(int32_t position, UErrorCode &status);
-
-    /**
-     * Return the current index in the text being searched.
-     * If the iteration has gone past the end of the text
-     * (or past the beginning for a backwards search), USEARCH_DONE
-     * is returned.
-     * @return current index in the text being searched.
-     * @stable ICU 2.0
-     */
-    virtual int32_t getOffset(void) const;
-
-    /**
-     * Set the target text to be searched.
-     * Text iteration will hence begin at the start of the text string. 
-     * This method is 
-     * useful if you want to re-use an iterator to search for the same 
-     * pattern within a different body of text.
-     * @param text text string to be searched
-     * @param status for errors if any. If the text length is 0 then an 
-     *        U_ILLEGAL_ARGUMENT_ERROR is returned.
-     * @stable ICU 2.0
-     */
-    virtual void setText(const UnicodeString &text, UErrorCode &status);
-    
-    /**
-     * Set the target text to be searched.
-     * Text iteration will hence begin at the start of the text string. 
-     * This method is 
-     * useful if you want to re-use an iterator to search for the same 
-     * pattern within a different body of text.
-     * Note: No parsing of the text within the <tt>CharacterIterator</tt> 
-     * will be done during searching for this version. The block of text 
-     * in <tt>CharacterIterator</tt> will be used as it is.
-     * @param text text string to be searched
-     * @param status for errors if any. If the text length is 0 then an 
-     *        U_ILLEGAL_ARGUMENT_ERROR is returned.
-     * @stable ICU 2.0
-     */
-    virtual void setText(CharacterIterator &text, UErrorCode &status);
-
-    /**
-     * Gets the collator used for the language rules.
-     * <p>
-     * Caller may modify but <b>must not</b> delete the <tt>RuleBasedCollator</tt>!
-     * Modifications to this collator will affect the original collator passed in to 
-     * the <tt>StringSearch></tt> constructor or to setCollator, if any.
-     * @return collator used for string search
-     * @stable ICU 2.0
-     */
-    RuleBasedCollator * getCollator() const;
-    
-    /**
-     * Sets the collator used for the language rules. User retains the 
-     * ownership of this collator, thus the responsibility of deletion lies 
-     * with the user. This method causes internal data such as Boyer-Moore 
-     * shift tables to be recalculated, but the iterator's position is 
-     * unchanged.
-     * @param coll    collator 
-     * @param status  for errors if any
-     * @stable ICU 2.0
-     */
-    void setCollator(RuleBasedCollator *coll, UErrorCode &status);
-    
-    /**
-     * Sets the pattern used for matching.
-     * Internal data like the Boyer Moore table will be recalculated, but 
-     * the iterator's position is unchanged.
-     * @param pattern search pattern to be found
-     * @param status for errors if any. If the pattern length is 0 then an 
-     *               U_ILLEGAL_ARGUMENT_ERROR is returned.
-     * @stable ICU 2.0
-     */
-    void setPattern(const UnicodeString &pattern, UErrorCode &status);
-    
-    /**
-     * Gets the search pattern.
-     * @return pattern used for matching
-     * @stable ICU 2.0
-     */
-    const UnicodeString & getPattern() const;
-
-    // public methods ----------------------------------------------------
-
-    /** 
-     * Reset the iteration.
-     * Search will begin at the start of the text string if a forward 
-     * iteration is initiated before a backwards iteration. Otherwise if 
-     * a backwards iteration is initiated before a forwards iteration, the 
-     * search will begin at the end of the text string.
-     * @stable ICU 2.0
-     */
-    virtual void reset();
-
-    /**
-     * Returns a copy of StringSearch with the same behavior, and 
-     * iterating over the same text, as this one. Note that all data will be
-     * replicated, except for the user-specified collator and the
-     * breakiterator.
-     * @return cloned object
-     * @stable ICU 2.0
-     */
-    virtual SearchIterator * safeClone(void) const;
-    
-    /**
-     * ICU "poor man's RTTI", returns a UClassID for the actual class.
-     *
-     * @stable ICU 2.2
-     */
-    virtual UClassID getDynamicClassID() const;
-
-    /**
-     * ICU "poor man's RTTI", returns a UClassID for this class.
-     *
-     * @stable ICU 2.2
-     */
-    static UClassID U_EXPORT2 getStaticClassID();
-
-protected:
-
-    // protected method -------------------------------------------------
-
-    /**
-     * Search forward for matching text, starting at a given location.
-     * Clients should not call this method directly; instead they should 
-     * call {@link SearchIterator#next }.
-     * <p>
-     * If a match is found, this method returns the index at which the match
-     * starts and calls {@link SearchIterator#setMatchLength } with the number 
-     * of characters in the target text that make up the match. If no match 
-     * is found, the method returns <tt>USEARCH_DONE</tt>.
-     * <p>
-     * The <tt>StringSearch</tt> is adjusted so that its current index 
-     * (as returned by {@link #getOffset }) is the match position if one was 
-     * found.
-     * If a match is not found, <tt>USEARCH_DONE</tt> will be returned and
-     * the <tt>StringSearch</tt> will be adjusted to the index USEARCH_DONE.
-     * @param position The index in the target text at which the search 
-     *                 starts
-     * @param status for errors if any occurs
-     * @return The index at which the matched text in the target starts, or 
-     *         USEARCH_DONE if no match was found.
-     * @stable ICU 2.0
-     */
-    virtual int32_t handleNext(int32_t position, UErrorCode &status);
-
-    /**
-     * Search backward for matching text, starting at a given location.
-     * Clients should not call this method directly; instead they should call
-     * <tt>SearchIterator.previous()</tt>, which this method overrides.
-     * <p>
-     * If a match is found, this method returns the index at which the match
-     * starts and calls {@link SearchIterator#setMatchLength } with the number 
-     * of characters in the target text that make up the match. If no match 
-     * is found, the method returns <tt>USEARCH_DONE</tt>.
-     * <p>
-     * The <tt>StringSearch</tt> is adjusted so that its current index 
-     * (as returned by {@link #getOffset }) is the match position if one was 
-     * found.
-     * If a match is not found, <tt>USEARCH_DONE</tt> will be returned and
-     * the <tt>StringSearch</tt> will be adjusted to the index USEARCH_DONE.
-     * @param position The index in the target text at which the search 
-     *                 starts.
-     * @param status for errors if any occurs
-     * @return The index at which the matched text in the target starts, or 
-     *         USEARCH_DONE if no match was found.
-     * @stable ICU 2.0
-     */
-    virtual int32_t handlePrev(int32_t position, UErrorCode &status);
-    
-private :
-    StringSearch(); // default constructor not implemented
-
-    // private data members ----------------------------------------------
-
-    /**
-    * RuleBasedCollator, contains exactly the same UCollator * in m_strsrch_
-    * @stable ICU 2.0
-    */
-    RuleBasedCollator  m_collator_;
-    /**
-    * Pattern text
-    * @stable ICU 2.0
-    */
-    UnicodeString      m_pattern_;
-    /**
-    * String search struct data
-    * @stable ICU 2.0
-    */
-    UStringSearch     *m_strsrch_;
-
-};
-
-U_NAMESPACE_END
-
-#endif /* #if !UCONFIG_NO_COLLATION */
-
-#endif
-

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/symtable.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/symtable.h b/apps/couch_collate/platform/osx/icu/unicode/symtable.h
deleted file mode 100644
index 428f8bf..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/symtable.h
+++ /dev/null
@@ -1,112 +0,0 @@
-/*
-**********************************************************************
-*   Copyright (c) 2000-2005, International Business Machines
-*   Corporation and others.  All Rights Reserved.
-**********************************************************************
-*   Date        Name        Description
-*   02/04/00    aliu        Creation.
-**********************************************************************
-*/
-#ifndef SYMTABLE_H
-#define SYMTABLE_H
-
-#include "unicode/utypes.h"
-#include "unicode/uobject.h"
-
-/**
- * \file 
- * \brief C++ API: An interface that defines both lookup protocol and parsing of
- * symbolic names.
- */
- 
-U_NAMESPACE_BEGIN
-
-class ParsePosition;
-class UnicodeFunctor;
-class UnicodeSet;
-class UnicodeString;
-
-/**
- * An interface that defines both lookup protocol and parsing of
- * symbolic names.
- *
- * <p>A symbol table maintains two kinds of mappings.  The first is
- * between symbolic names and their values.  For example, if the
- * variable with the name "start" is set to the value "alpha"
- * (perhaps, though not necessarily, through an expression such as
- * "$start=alpha"), then the call lookup("start") will return the
- * char[] array ['a', 'l', 'p', 'h', 'a'].
- *
- * <p>The second kind of mapping is between character values and
- * UnicodeMatcher objects.  This is used by RuleBasedTransliterator,
- * which uses characters in the private use area to represent objects
- * such as UnicodeSets.  If U+E015 is mapped to the UnicodeSet [a-z],
- * then lookupMatcher(0xE015) will return the UnicodeSet [a-z].
- *
- * <p>Finally, a symbol table defines parsing behavior for symbolic
- * names.  All symbolic names start with the SYMBOL_REF character.
- * When a parser encounters this character, it calls parseReference()
- * with the position immediately following the SYMBOL_REF.  The symbol
- * table parses the name, if there is one, and returns it.
- *
- * @stable ICU 2.8
- */
-class U_COMMON_API SymbolTable /* not : public UObject because this is an interface/mixin class */ {
-public:
-
-    /**
-     * The character preceding a symbol reference name.
-     * @stable ICU 2.8
-     */
-    enum { SYMBOL_REF = 0x0024 /*$*/ };
-
-    /**
-     * Destructor.
-     * @stable ICU 2.8
-     */
-    virtual ~SymbolTable();
-
-    /**
-     * Lookup the characters associated with this string and return it.
-     * Return <tt>NULL</tt> if no such name exists.  The resultant
-     * string may have length zero.
-     * @param s the symbolic name to lookup
-     * @return a string containing the name's value, or <tt>NULL</tt> if
-     * there is no mapping for s.
-     * @stable ICU 2.8
-     */
-    virtual const UnicodeString* lookup(const UnicodeString& s) const = 0;
-
-    /**
-     * Lookup the UnicodeMatcher associated with the given character, and
-     * return it.  Return <tt>NULL</tt> if not found.
-     * @param ch a 32-bit code point from 0 to 0x10FFFF inclusive.
-     * @return the UnicodeMatcher object represented by the given
-     * character, or NULL if there is no mapping for ch.
-     * @stable ICU 2.8
-     */
-    virtual const UnicodeFunctor* lookupMatcher(UChar32 ch) const = 0;
-
-    /**
-     * Parse a symbol reference name from the given string, starting
-     * at the given position.  If no valid symbol reference name is
-     * found, return the empty string and leave pos unchanged.  That is, if the
-     * character at pos cannot start a name, or if pos is at or after
-     * text.length(), then return an empty string.  This indicates an
-     * isolated SYMBOL_REF character.
-     * @param text the text to parse for the name
-     * @param pos on entry, the index of the first character to parse.
-     * This is the character following the SYMBOL_REF character.  On
-     * exit, the index after the last parsed character.  If the parse
-     * failed, pos is unchanged on exit.
-     * @param limit the index after the last character to be parsed.
-     * @return the parsed name, or an empty string if there is no
-     * valid symbolic name at the given position.
-     * @stable ICU 2.8
-     */
-    virtual UnicodeString parseReference(const UnicodeString& text,
-                                         ParsePosition& pos, int32_t limit) const = 0;
-};
-U_NAMESPACE_END
-
-#endif

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/tblcoll.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/tblcoll.h b/apps/couch_collate/platform/osx/icu/unicode/tblcoll.h
deleted file mode 100644
index 2fdd63b..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/tblcoll.h
+++ /dev/null
@@ -1,926 +0,0 @@
-/*
-******************************************************************************
-* Copyright (C) 1996-2008, International Business Machines Corporation and
-* others. All Rights Reserved.
-******************************************************************************
-*/
-
-/**
- * \file 
- * \brief C++ API: RuleBasedCollator class provides the simple implementation of Collator.
- */
-
-/**
-* File tblcoll.h
-*
-* Created by: Helena Shih
-*
-* Modification History:
-*
-*  Date        Name        Description
-*  2/5/97      aliu        Added streamIn and streamOut methods.  Added
-*                          constructor which reads RuleBasedCollator object from
-*                          a binary file.  Added writeToFile method which streams
-*                          RuleBasedCollator out to a binary file.  The streamIn
-*                          and streamOut methods use istream and ostream objects
-*                          in binary mode.
-*  2/12/97     aliu        Modified to use TableCollationData sub-object to
-*                          hold invariant data.
-*  2/13/97     aliu        Moved several methods into this class from Collation.
-*                          Added a private RuleBasedCollator(Locale&) constructor,
-*                          to be used by Collator::createDefault().  General
-*                          clean up.
-*  2/20/97     helena      Added clone, operator==, operator!=, operator=, and copy
-*                          constructor and getDynamicClassID.
-*  3/5/97      aliu        Modified constructFromFile() to add parameter
-*                          specifying whether or not binary loading is to be
-*                          attempted.  This is required for dynamic rule loading.
-* 05/07/97     helena      Added memory allocation error detection.
-*  6/17/97     helena      Added IDENTICAL strength for compare, changed getRules to
-*                          use MergeCollation::getPattern.
-*  6/20/97     helena      Java class name change.
-*  8/18/97     helena      Added internal API documentation.
-* 09/03/97     helena      Added createCollationKeyValues().
-* 02/10/98     damiba      Added compare with "length" parameter
-* 08/05/98     erm         Synched with 1.2 version of RuleBasedCollator.java
-* 04/23/99     stephen     Removed EDecompositionMode, merged with
-*                          Normalizer::EMode
-* 06/14/99     stephen     Removed kResourceBundleSuffix
-* 11/02/99     helena      Collator performance enhancements.  Eliminates the
-*                          UnicodeString construction and special case for NO_OP.
-* 11/23/99     srl         More performance enhancements. Updates to NormalizerIterator
-*                          internal state management.
-* 12/15/99     aliu        Update to support Thai collation.  Move NormalizerIterator
-*                          to implementation file.
-* 01/29/01     synwee      Modified into a C++ wrapper which calls C API
-*                          (ucol.h)
-*/
-
-#ifndef TBLCOLL_H
-#define TBLCOLL_H
-
-#include "unicode/utypes.h"
-
- 
-#if !UCONFIG_NO_COLLATION
-
-#include "unicode/coll.h"
-#include "unicode/ucol.h"
-#include "unicode/sortkey.h"
-#include "unicode/normlzr.h"
-
-U_NAMESPACE_BEGIN
-
-/**
-* @stable ICU 2.0
-*/
-class StringSearch;
-/**
-* @stable ICU 2.0
-*/
-class CollationElementIterator;
-
-/**
- * The RuleBasedCollator class provides the simple implementation of
- * Collator, using data-driven tables. The user can create a customized
- * table-based collation.
- * <P>
- * <em>Important: </em>The ICU collation service has been reimplemented 
- * in order to achieve better performance and UCA compliance. 
- * For details, see the 
- * <a href="http://source.icu-project.org/repos/icu/icuhtml/trunk/design/collation/ICU_collation_design.htm">
- * collation design document</a>.
- * <p>
- * RuleBasedCollator is a thin C++ wrapper over the C implementation.
- * <p>
- * For more information about the collation service see 
- * <a href="http://icu-project.org/userguide/Collate_Intro.html">the users guide</a>.
- * <p>
- * Collation service provides correct sorting orders for most locales supported in ICU. 
- * If specific data for a locale is not available, the orders eventually falls back
- * to the <a href="http://www.unicode.org/unicode/reports/tr10/">UCA sort order</a>. 
- * <p>
- * Sort ordering may be customized by providing your own set of rules. For more on
- * this subject see the <a href="http://icu-project.org/userguide/Collate_Customization.html">
- * Collation customization</a> section of the users guide.
- * <p>
- * Note, RuleBasedCollator is not to be subclassed.
- * @see        Collator
- * @version    2.0 11/15/2001
- */
-class U_I18N_API RuleBasedCollator : public Collator
-{
-public:
-
-  // constructor -------------------------------------------------------------
-
-    /**
-     * RuleBasedCollator constructor. This takes the table rules and builds a
-     * collation table out of them. Please see RuleBasedCollator class
-     * description for more details on the collation rule syntax.
-     * @param rules the collation rules to build the collation table from.
-     * @param status reporting a success or an error.
-     * @see Locale
-     * @stable ICU 2.0
-     */
-    RuleBasedCollator(const UnicodeString& rules, UErrorCode& status);
-
-    /**
-     * RuleBasedCollator constructor. This takes the table rules and builds a
-     * collation table out of them. Please see RuleBasedCollator class
-     * description for more details on the collation rule syntax.
-     * @param rules the collation rules to build the collation table from.
-     * @param collationStrength default strength for comparison
-     * @param status reporting a success or an error.
-     * @see Locale
-     * @stable ICU 2.0
-     */
-    RuleBasedCollator(const UnicodeString& rules,
-                       ECollationStrength collationStrength,
-                       UErrorCode& status);
-
-    /**
-     * RuleBasedCollator constructor. This takes the table rules and builds a
-     * collation table out of them. Please see RuleBasedCollator class
-     * description for more details on the collation rule syntax.
-     * @param rules the collation rules to build the collation table from.
-     * @param decompositionMode the normalisation mode
-     * @param status reporting a success or an error.
-     * @see Locale
-     * @stable ICU 2.0
-     */
-    RuleBasedCollator(const UnicodeString& rules,
-                    UColAttributeValue decompositionMode,
-                    UErrorCode& status);
-
-    /**
-     * RuleBasedCollator constructor. This takes the table rules and builds a
-     * collation table out of them. Please see RuleBasedCollator class
-     * description for more details on the collation rule syntax.
-     * @param rules the collation rules to build the collation table from.
-     * @param collationStrength default strength for comparison
-     * @param decompositionMode the normalisation mode
-     * @param status reporting a success or an error.
-     * @see Locale
-     * @stable ICU 2.0
-     */
-    RuleBasedCollator(const UnicodeString& rules,
-                    ECollationStrength collationStrength,
-                    UColAttributeValue decompositionMode,
-                    UErrorCode& status);
-
-    /**
-     * Copy constructor.
-     * @param other the RuleBasedCollator object to be copied
-     * @see Locale
-     * @stable ICU 2.0
-     */
-    RuleBasedCollator(const RuleBasedCollator& other);
-
-
-    /** Opens a collator from a collator binary image created using
-    *  cloneBinary. Binary image used in instantiation of the 
-    *  collator remains owned by the user and should stay around for 
-    *  the lifetime of the collator. The API also takes a base collator
-    *  which usualy should be UCA.
-    *  @param bin binary image owned by the user and required through the
-    *             lifetime of the collator
-    *  @param length size of the image. If negative, the API will try to
-    *                figure out the length of the image
-    *  @param base fallback collator, usually UCA. Base is required to be
-    *              present through the lifetime of the collator. Currently 
-    *              it cannot be NULL.
-    *  @param status for catching errors
-    *  @return newly created collator
-    *  @see cloneBinary
-    *  @stable ICU 3.4
-    */
-    RuleBasedCollator(const uint8_t *bin, int32_t length, 
-                    const RuleBasedCollator *base, 
-                    UErrorCode &status);
-    // destructor --------------------------------------------------------------
-
-    /**
-     * Destructor.
-     * @stable ICU 2.0
-     */
-    virtual ~RuleBasedCollator();
-
-    // public methods ----------------------------------------------------------
-
-    /**
-     * Assignment operator.
-     * @param other other RuleBasedCollator object to compare with.
-     * @stable ICU 2.0
-     */
-    RuleBasedCollator& operator=(const RuleBasedCollator& other);
-
-    /**
-     * Returns true if argument is the same as this object.
-     * @param other Collator object to be compared.
-     * @return true if arguments is the same as this object.
-     * @stable ICU 2.0
-     */
-    virtual UBool operator==(const Collator& other) const;
-
-    /**
-     * Returns true if argument is not the same as this object.
-     * @param other Collator object to be compared
-     * @return returns true if argument is not the same as this object.
-     * @stable ICU 2.0
-     */
-    virtual UBool operator!=(const Collator& other) const;
-
-    /**
-     * Makes a deep copy of the object.
-     * The caller owns the returned object.
-     * @return the cloned object.
-     * @stable ICU 2.0
-     */
-    virtual Collator* clone(void) const;
-
-    /**
-     * Creates a collation element iterator for the source string. The caller of
-     * this method is responsible for the memory management of the return
-     * pointer.
-     * @param source the string over which the CollationElementIterator will
-     *        iterate.
-     * @return the collation element iterator of the source string using this as
-     *         the based Collator.
-     * @stable ICU 2.2
-     */
-    virtual CollationElementIterator* createCollationElementIterator(
-                                           const UnicodeString& source) const;
-
-    /**
-     * Creates a collation element iterator for the source. The caller of this
-     * method is responsible for the memory management of the returned pointer.
-     * @param source the CharacterIterator which produces the characters over
-     *        which the CollationElementItgerator will iterate.
-     * @return the collation element iterator of the source using this as the
-     *         based Collator.
-     * @stable ICU 2.2
-     */
-    virtual CollationElementIterator* createCollationElementIterator(
-                                         const CharacterIterator& source) const;
-
-    /**
-     * Compares a range of character data stored in two different strings based
-     * on the collation rules. Returns information about whether a string is
-     * less than, greater than or equal to another string in a language.
-     * This can be overriden in a subclass.
-     * @param source the source string.
-     * @param target the target string to be compared with the source string.
-     * @return the comparison result. GREATER if the source string is greater
-     *         than the target string, LESS if the source is less than the
-     *         target. Otherwise, returns EQUAL.
-     * @deprecated ICU 2.6 Use overload with UErrorCode&
-     */
-    virtual EComparisonResult compare(const UnicodeString& source,
-                                      const UnicodeString& target) const;
-
-
-    /**
-    * The comparison function compares the character data stored in two
-    * different strings. Returns information about whether a string is less 
-    * than, greater than or equal to another string.
-    * @param source the source string to be compared with.
-    * @param target the string that is to be compared with the source string.
-    * @param status possible error code
-    * @return Returns an enum value. UCOL_GREATER if source is greater
-    * than target; UCOL_EQUAL if source is equal to target; UCOL_LESS if source is less
-    * than target
-    * @stable ICU 2.6
-    **/
-    virtual UCollationResult compare(const UnicodeString& source,
-                                      const UnicodeString& target,
-                                      UErrorCode &status) const;
-
-    /**
-     * Compares a range of character data stored in two different strings based
-     * on the collation rules up to the specified length. Returns information
-     * about whether a string is less than, greater than or equal to another
-     * string in a language. This can be overriden in a subclass.
-     * @param source the source string.
-     * @param target the target string to be compared with the source string.
-     * @param length compares up to the specified length
-     * @return the comparison result. GREATER if the source string is greater
-     *         than the target string, LESS if the source is less than the
-     *         target. Otherwise, returns EQUAL.
-     * @deprecated ICU 2.6 Use overload with UErrorCode&
-     */
-    virtual EComparisonResult compare(const UnicodeString& source,
-                                      const UnicodeString&  target,
-                                      int32_t length) const;
-
-    /**
-    * Does the same thing as compare but limits the comparison to a specified 
-    * length
-    * @param source the source string to be compared with.
-    * @param target the string that is to be compared with the source string.
-    * @param length the length the comparison is limited to
-    * @param status possible error code
-    * @return Returns an enum value. UCOL_GREATER if source (up to the specified 
-    *         length) is greater than target; UCOL_EQUAL if source (up to specified 
-    *         length) is equal to target; UCOL_LESS if source (up to the specified 
-    *         length) is less  than target.
-    * @stable ICU 2.6
-    */
-    virtual UCollationResult compare(const UnicodeString& source,
-                                      const UnicodeString& target,
-                                      int32_t length,
-                                      UErrorCode &status) const;
-
-    /**
-     * The comparison function compares the character data stored in two
-     * different string arrays. Returns information about whether a string array
-     * is less than, greater than or equal to another string array.
-     * <p>Example of use:
-     * <pre>
-     * .       UChar ABC[] = {0x41, 0x42, 0x43, 0};  // = "ABC"
-     * .       UChar abc[] = {0x61, 0x62, 0x63, 0};  // = "abc"
-     * .       UErrorCode status = U_ZERO_ERROR;
-     * .       Collator *myCollation =
-     * .                         Collator::createInstance(Locale::US, status);
-     * .       if (U_FAILURE(status)) return;
-     * .       myCollation->setStrength(Collator::PRIMARY);
-     * .       // result would be Collator::EQUAL ("abc" == "ABC")
-     * .       // (no primary difference between "abc" and "ABC")
-     * .       Collator::EComparisonResult result =
-     * .                             myCollation->compare(abc, 3, ABC, 3);
-     * .       myCollation->setStrength(Collator::TERTIARY);
-     * .       // result would be Collator::LESS ("abc" &lt;&lt;&lt; "ABC")
-     * .       // (with tertiary difference between "abc" and "ABC")
-     * .       result =  myCollation->compare(abc, 3, ABC, 3);
-     * </pre>
-     * @param source the source string array to be compared with.
-     * @param sourceLength the length of the source string array. If this value
-     *        is equal to -1, the string array is null-terminated.
-     * @param target the string that is to be compared with the source string.
-     * @param targetLength the length of the target string array. If this value
-     *        is equal to -1, the string array is null-terminated.
-     * @return Returns a byte value. GREATER if source is greater than target;
-     *         EQUAL if source is equal to target; LESS if source is less than
-     *         target
-     * @deprecated ICU 2.6 Use overload with UErrorCode&
-     */
-    virtual EComparisonResult compare(const UChar* source, int32_t sourceLength,
-                                      const UChar* target, int32_t targetLength)
-                                      const;
-
-    /**
-    * The comparison function compares the character data stored in two
-    * different string arrays. Returns information about whether a string array 
-    * is less than, greater than or equal to another string array.
-    * @param source the source string array to be compared with.
-    * @param sourceLength the length of the source string array.  If this value
-    *        is equal to -1, the string array is null-terminated.
-    * @param target the string that is to be compared with the source string.
-    * @param targetLength the length of the target string array.  If this value
-    *        is equal to -1, the string array is null-terminated.
-    * @param status possible error code
-    * @return Returns an enum value. UCOL_GREATER if source is greater
-    * than target; UCOL_EQUAL if source is equal to target; UCOL_LESS if source is less
-    * than target
-    * @stable ICU 2.6
-    */
-    virtual UCollationResult compare(const UChar* source, int32_t sourceLength,
-                                      const UChar* target, int32_t targetLength,
-                                      UErrorCode &status) const;
-
-    /**
-    * Transforms a specified region of the string into a series of characters
-    * that can be compared with CollationKey.compare. Use a CollationKey when
-    * you need to do repeated comparisions on the same string. For a single
-    * comparison the compare method will be faster.
-    * @param source the source string.
-    * @param key the transformed key of the source string.
-    * @param status the error code status.
-    * @return the transformed key.
-    * @see CollationKey
-    * @deprecated ICU 2.8 Use getSortKey(...) instead
-    */
-    virtual CollationKey& getCollationKey(const UnicodeString& source,
-                                          CollationKey& key,
-                                          UErrorCode& status) const;
-
-    /**
-    * Transforms a specified region of the string into a series of characters
-    * that can be compared with CollationKey.compare. Use a CollationKey when
-    * you need to do repeated comparisions on the same string. For a single
-    * comparison the compare method will be faster.
-    * @param source the source string.
-    * @param sourceLength the length of the source string.
-    * @param key the transformed key of the source string.
-    * @param status the error code status.
-    * @return the transformed key.
-    * @see CollationKey
-    * @deprecated ICU 2.8 Use getSortKey(...) instead
-    */
-    virtual CollationKey& getCollationKey(const UChar *source,
-                                          int32_t sourceLength,
-                                          CollationKey& key,
-                                          UErrorCode& status) const;
-
-    /**
-     * Generates the hash code for the rule-based collation object.
-     * @return the hash code.
-     * @stable ICU 2.0
-     */
-    virtual int32_t hashCode(void) const;
-
-    /**
-    * Gets the locale of the Collator
-    * @param type can be either requested, valid or actual locale. For more
-    *             information see the definition of ULocDataLocaleType in
-    *             uloc.h
-    * @param status the error code status.
-    * @return locale where the collation data lives. If the collator
-    *         was instantiated from rules, locale is empty.
-    * @deprecated ICU 2.8 likely to change in ICU 3.0, based on feedback
-    */
-    virtual const Locale getLocale(ULocDataLocaleType type, UErrorCode& status) const;
-
-    /**
-     * Gets the table-based rules for the collation object.
-     * @return returns the collation rules that the table collation object was
-     *         created from.
-     * @stable ICU 2.0
-     */
-    const UnicodeString& getRules(void) const;
-
-    /**
-     * Gets the version information for a Collator.
-     * @param info the version # information, the result will be filled in
-     * @stable ICU 2.0
-     */
-    virtual void getVersion(UVersionInfo info) const;
-
-    /**
-     * Return the maximum length of any expansion sequences that end with the
-     * specified comparison order.
-     * @param order a collation order returned by previous or next.
-     * @return maximum size of the expansion sequences ending with the collation
-     *         element or 1 if collation element does not occur at the end of
-     *         any expansion sequence
-     * @see CollationElementIterator#getMaxExpansion
-     * @stable ICU 2.0
-     */
-    int32_t getMaxExpansion(int32_t order) const;
-
-    /**
-     * Returns a unique class ID POLYMORPHICALLY. Pure virtual override. This
-     * method is to implement a simple version of RTTI, since not all C++
-     * compilers support genuine RTTI. Polymorphic operator==() and clone()
-     * methods call this method.
-     * @return The class ID for this object. All objects of a given class have
-     *         the same class ID. Objects of other classes have different class
-     *         IDs.
-     * @stable ICU 2.0
-     */
-    virtual UClassID getDynamicClassID(void) const;
-
-    /**
-     * Returns the class ID for this class. This is useful only for comparing to
-     * a return value from getDynamicClassID(). For example:
-     * <pre>
-     * Base* polymorphic_pointer = createPolymorphicObject();
-     * if (polymorphic_pointer->getDynamicClassID() ==
-     *                                          Derived::getStaticClassID()) ...
-     * </pre>
-     * @return The class ID for all objects of this class.
-     * @stable ICU 2.0
-     */
-    static UClassID U_EXPORT2 getStaticClassID(void);
-
-    /**
-     * Returns the binary format of the class's rules. The format is that of
-     * .col files.
-     * @param length Returns the length of the data, in bytes
-     * @param status the error code status.
-     * @return memory, owned by the caller, of size 'length' bytes.
-     * @stable ICU 2.2
-     */
-    uint8_t *cloneRuleData(int32_t &length, UErrorCode &status);
-
-
-    /** Creates a binary image of a collator. This binary image can be stored and 
-    *  later used to instantiate a collator using ucol_openBinary.
-    *  This API supports preflighting.
-    *  @param buffer a fill-in buffer to receive the binary image
-    *  @param capacity capacity of the destination buffer
-    *  @param status for catching errors
-    *  @return size of the image
-    *  @see ucol_openBinary
-    *  @stable ICU 3.4
-    */
-    int32_t cloneBinary(uint8_t *buffer, int32_t capacity, UErrorCode &status);
-
-    /**
-     * Returns current rules. Delta defines whether full rules are returned or
-     * just the tailoring.
-     * @param delta one of UCOL_TAILORING_ONLY, UCOL_FULL_RULES.
-     * @param buffer UnicodeString to store the result rules
-     * @stable ICU 2.2
-     */
-    void getRules(UColRuleOption delta, UnicodeString &buffer);
-
-    /**
-     * Universal attribute setter
-     * @param attr attribute type
-     * @param value attribute value
-     * @param status to indicate whether the operation went on smoothly or there were errors
-     * @stable ICU 2.2
-     */
-    virtual void setAttribute(UColAttribute attr, UColAttributeValue value,
-                              UErrorCode &status);
-
-    /**
-     * Universal attribute getter.
-     * @param attr attribute type
-     * @param status to indicate whether the operation went on smoothly or there were errors
-     * @return attribute value
-     * @stable ICU 2.2
-     */
-    virtual UColAttributeValue getAttribute(UColAttribute attr,
-                                            UErrorCode &status);
-
-    /**
-     * Sets the variable top to a collation element value of a string supplied.
-     * @param varTop one or more (if contraction) UChars to which the variable top should be set
-     * @param len length of variable top string. If -1 it is considered to be zero terminated.
-     * @param status error code. If error code is set, the return value is undefined. Errors set by this function are: <br>
-     *    U_CE_NOT_FOUND_ERROR if more than one character was passed and there is no such a contraction<br>
-     *    U_PRIMARY_TOO_LONG_ERROR if the primary for the variable top has more than two bytes
-     * @return a 32 bit value containing the value of the variable top in upper 16 bits. Lower 16 bits are undefined
-     * @stable ICU 2.0
-     */
-    virtual uint32_t setVariableTop(const UChar *varTop, int32_t len, UErrorCode &status);
-
-    /**
-     * Sets the variable top to a collation element value of a string supplied.
-     * @param varTop an UnicodeString size 1 or more (if contraction) of UChars to which the variable top should be set
-     * @param status error code. If error code is set, the return value is undefined. Errors set by this function are: <br>
-     *    U_CE_NOT_FOUND_ERROR if more than one character was passed and there is no such a contraction<br>
-     *    U_PRIMARY_TOO_LONG_ERROR if the primary for the variable top has more than two bytes
-     * @return a 32 bit value containing the value of the variable top in upper 16 bits. Lower 16 bits are undefined
-     * @stable ICU 2.0
-     */
-    virtual uint32_t setVariableTop(const UnicodeString varTop, UErrorCode &status);
-
-    /**
-     * Sets the variable top to a collation element value supplied. Variable top is set to the upper 16 bits.
-     * Lower 16 bits are ignored.
-     * @param varTop CE value, as returned by setVariableTop or ucol)getVariableTop
-     * @param status error code (not changed by function)
-     * @stable ICU 2.0
-     */
-    virtual void setVariableTop(const uint32_t varTop, UErrorCode &status);
-
-    /**
-     * Gets the variable top value of a Collator.
-     * Lower 16 bits are undefined and should be ignored.
-     * @param status error code (not changed by function). If error code is set, the return value is undefined.
-     * @stable ICU 2.0
-     */
-    virtual uint32_t getVariableTop(UErrorCode &status) const;
-
-    /**
-     * Get an UnicodeSet that contains all the characters and sequences tailored in 
-     * this collator.
-     * @param status      error code of the operation
-     * @return a pointer to a UnicodeSet object containing all the 
-     *         code points and sequences that may sort differently than
-     *         in the UCA. The object must be disposed of by using delete
-     * @stable ICU 2.4
-     */
-    virtual UnicodeSet *getTailoredSet(UErrorCode &status) const;
-
-    /**
-     * Thread safe cloning operation.
-     * @return pointer to the new clone, user should remove it.
-     * @stable ICU 2.2
-     */
-    virtual Collator* safeClone(void);
-
-    /**
-     * Get the sort key as an array of bytes from an UnicodeString.
-     * @param source string to be processed.
-     * @param result buffer to store result in. If NULL, number of bytes needed
-     *        will be returned.
-     * @param resultLength length of the result buffer. If if not enough the
-     *        buffer will be filled to capacity.
-     * @return Number of bytes needed for storing the sort key
-     * @stable ICU 2.0
-     */
-    virtual int32_t getSortKey(const UnicodeString& source, uint8_t *result,
-                               int32_t resultLength) const;
-
-    /**
-     * Get the sort key as an array of bytes from an UChar buffer.
-     * @param source string to be processed.
-     * @param sourceLength length of string to be processed. If -1, the string
-     *        is 0 terminated and length will be decided by the function.
-     * @param result buffer to store result in. If NULL, number of bytes needed
-     *        will be returned.
-     * @param resultLength length of the result buffer. If if not enough the
-     *        buffer will be filled to capacity.
-     * @return Number of bytes needed for storing the sort key
-     * @stable ICU 2.2
-     */
-    virtual int32_t getSortKey(const UChar *source, int32_t sourceLength,
-                               uint8_t *result, int32_t resultLength) const;
-
-    /**
-    * Determines the minimum strength that will be use in comparison or
-    * transformation.
-    * <p>E.g. with strength == SECONDARY, the tertiary difference is ignored
-    * <p>E.g. with strength == PRIMARY, the secondary and tertiary difference
-    * are ignored.
-    * @return the current comparison level.
-    * @see RuleBasedCollator#setStrength
-    * @deprecated ICU 2.6 Use getAttribute(UCOL_STRENGTH...) instead
-    */
-    virtual ECollationStrength getStrength(void) const;
-
-    /**
-    * Sets the minimum strength to be used in comparison or transformation.
-    * @see RuleBasedCollator#getStrength
-    * @param newStrength the new comparison level.
-    * @deprecated ICU 2.6 Use setAttribute(UCOL_STRENGTH...) instead
-    */
-    virtual void setStrength(ECollationStrength newStrength);
-
-private:
-
-    // private static constants -----------------------------------------------
-
-    enum {
-        /* need look up in .commit() */
-        CHARINDEX = 0x70000000,
-        /* Expand index follows */
-        EXPANDCHARINDEX = 0x7E000000,
-        /* contract indexes follows */
-        CONTRACTCHARINDEX = 0x7F000000,
-        /* unmapped character values */
-        UNMAPPED = 0xFFFFFFFF,
-        /* primary strength increment */
-        PRIMARYORDERINCREMENT = 0x00010000,
-        /* secondary strength increment */
-        SECONDARYORDERINCREMENT = 0x00000100,
-        /* tertiary strength increment */
-        TERTIARYORDERINCREMENT = 0x00000001,
-        /* mask off anything but primary order */
-        PRIMARYORDERMASK = 0xffff0000,
-        /* mask off anything but secondary order */
-        SECONDARYORDERMASK = 0x0000ff00,
-        /* mask off anything but tertiary order */
-        TERTIARYORDERMASK = 0x000000ff,
-        /* mask off ignorable char order */
-        IGNORABLEMASK = 0x0000ffff,
-        /* use only the primary difference */
-        PRIMARYDIFFERENCEONLY = 0xffff0000,
-        /* use only the primary and secondary difference */
-        SECONDARYDIFFERENCEONLY = 0xffffff00,
-        /* primary order shift */
-        PRIMARYORDERSHIFT = 16,
-        /* secondary order shift */
-        SECONDARYORDERSHIFT = 8,
-        /* starting value for collation elements */
-        COLELEMENTSTART = 0x02020202,
-        /* testing mask for primary low element */
-        PRIMARYLOWZEROMASK = 0x00FF0000,
-        /* reseting value for secondaries and tertiaries */
-        RESETSECONDARYTERTIARY = 0x00000202,
-        /* reseting value for tertiaries */
-        RESETTERTIARY = 0x00000002,
-
-        PRIMIGNORABLE = 0x0202
-    };
-
-    // private data members ---------------------------------------------------
-
-    UBool dataIsOwned;
-
-    UBool isWriteThroughAlias;
-
-    /**
-    * c struct for collation. All initialisation for it has to be done through
-    * setUCollator().
-    */
-    UCollator *ucollator;
-
-    /**
-    * Rule UnicodeString
-    */
-    UnicodeString urulestring;
-
-    // friend classes --------------------------------------------------------
-
-    /**
-    * Used to iterate over collation elements in a character source.
-    */
-    friend class CollationElementIterator;
-
-    /**
-    * Collator ONLY needs access to RuleBasedCollator(const Locale&,
-    *                                                       UErrorCode&)
-    */
-    friend class Collator;
-
-    /**
-    * Searching over collation elements in a character source
-    */
-    friend class StringSearch;
-
-    // private constructors --------------------------------------------------
-
-    /**
-     * Default constructor
-     */
-    RuleBasedCollator();
-
-    /**
-     * RuleBasedCollator constructor. This constructor takes a locale. The
-     * only caller of this class should be Collator::createInstance(). If
-     * createInstance() happens to know that the requested locale's collation is
-     * implemented as a RuleBasedCollator, it can then call this constructor.
-     * OTHERWISE IT SHOULDN'T, since this constructor ALWAYS RETURNS A VALID
-     * COLLATION TABLE. It does this by falling back to defaults.
-     * @param desiredLocale locale used
-     * @param status error code status
-     */
-    RuleBasedCollator(const Locale& desiredLocale, UErrorCode& status);
-
-    /**
-     * common constructor implementation
-     *
-     * @param rules the collation rules to build the collation table from.
-     * @param collationStrength default strength for comparison
-     * @param decompositionMode the normalisation mode
-     * @param status reporting a success or an error.
-     */
-    void
-    construct(const UnicodeString& rules,
-              UColAttributeValue collationStrength,
-              UColAttributeValue decompositionMode,
-              UErrorCode& status);
-
-    // private methods -------------------------------------------------------
-
-    /**
-    * Creates the c struct for ucollator
-    * @param locale desired locale
-    * @param status error status
-    */
-    void setUCollator(const Locale& locale, UErrorCode& status);
-
-    /**
-    * Creates the c struct for ucollator
-    * @param locale desired locale name
-    * @param status error status
-    */
-    void setUCollator(const char* locale, UErrorCode& status);
-
-    /**
-    * Creates the c struct for ucollator. This used internally by StringSearch.
-    * Hence the responsibility of cleaning up the ucollator is not done by
-    * this RuleBasedCollator. The isDataOwned flag is set to FALSE.
-    * @param collator new ucollator data
-    * @param rules corresponding collation rules
-    */
-    void setUCollator(UCollator *collator);
-
-public:
-    /**
-    * Get UCollator data struct. Used only by StringSearch & intltest.
-    * @return UCollator data struct
-    * @internal
-    */
-    const UCollator * getUCollator();
-
-protected:
-   /**
-    * Used internally by registraton to define the requested and valid locales.
-    * @param requestedLocale the requsted locale
-    * @param validLocale the valid locale
-    * @param actualLocale the actual locale
-    * @internal
-    */
-    virtual void setLocales(const Locale& requestedLocale, const Locale& validLocale, const Locale& actualLocale);
-
-private:
-
-    // if not owned and not a write through alias, copy the ucollator
-    void checkOwned(void);
-
-    // utility to init rule string used by checkOwned and construct
-    void setRuleStringFromCollator();
-
-    /**
-    * Converts C's UCollationResult to EComparisonResult
-    * @param result member of the enum UComparisonResult
-    * @return EComparisonResult equivalent of UCollationResult
-    * @deprecated ICU 2.6. We will not need it.
-    */
-    Collator::EComparisonResult getEComparisonResult(
-                                            const UCollationResult &result) const;
-
-    /**
-    * Converts C's UCollationStrength to ECollationStrength
-    * @param strength member of the enum UCollationStrength
-    * @return ECollationStrength equivalent of UCollationStrength
-    */
-    Collator::ECollationStrength getECollationStrength(
-                                        const UCollationStrength &strength) const;
-
-    /**
-    * Converts C++'s ECollationStrength to UCollationStrength
-    * @param strength member of the enum ECollationStrength
-    * @return UCollationStrength equivalent of ECollationStrength
-    */
-    UCollationStrength getUCollationStrength(
-      const Collator::ECollationStrength &strength) const;
-};
-
-// inline method implementation ---------------------------------------------
-
-inline void RuleBasedCollator::setUCollator(const Locale &locale,
-                                               UErrorCode &status)
-{
-    setUCollator(locale.getName(), status);
-}
-
-
-inline void RuleBasedCollator::setUCollator(UCollator     *collator)
-{
-
-    if (ucollator && dataIsOwned) {
-        ucol_close(ucollator);
-    }
-    ucollator   = collator;
-    dataIsOwned = FALSE;
-    isWriteThroughAlias = TRUE;
-    setRuleStringFromCollator();
-}
-
-inline const UCollator * RuleBasedCollator::getUCollator()
-{
-    return ucollator;
-}
-
-inline Collator::EComparisonResult RuleBasedCollator::getEComparisonResult(
-                                           const UCollationResult &result) const
-{
-    switch (result)
-    {
-    case UCOL_LESS :
-        return Collator::LESS;
-    case UCOL_EQUAL :
-        return Collator::EQUAL;
-    default :
-        return Collator::GREATER;
-    }
-}
-
-inline Collator::ECollationStrength RuleBasedCollator::getECollationStrength(
-                                       const UCollationStrength &strength) const
-{
-    switch (strength)
-    {
-    case UCOL_PRIMARY :
-        return Collator::PRIMARY;
-    case UCOL_SECONDARY :
-        return Collator::SECONDARY;
-    case UCOL_TERTIARY :
-        return Collator::TERTIARY;
-    case UCOL_QUATERNARY :
-        return Collator::QUATERNARY;
-    default :
-        return Collator::IDENTICAL;
-    }
-}
-
-inline UCollationStrength RuleBasedCollator::getUCollationStrength(
-                             const Collator::ECollationStrength &strength) const
-{
-    switch (strength)
-    {
-    case Collator::PRIMARY :
-        return UCOL_PRIMARY;
-    case Collator::SECONDARY :
-        return UCOL_SECONDARY;
-    case Collator::TERTIARY :
-        return UCOL_TERTIARY;
-    case Collator::QUATERNARY :
-        return UCOL_QUATERNARY;
-    default :
-        return UCOL_IDENTICAL;
-    }
-}
-
-U_NAMESPACE_END
-
-#endif /* #if !UCONFIG_NO_COLLATION */
-
-#endif


[14/57] [abbrv] remove couch_collate

Posted by be...@apache.org.
http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/uiter.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/uiter.h b/apps/couch_collate/platform/osx/icu/unicode/uiter.h
deleted file mode 100644
index 9409f01..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/uiter.h
+++ /dev/null
@@ -1,707 +0,0 @@
-/*
-*******************************************************************************
-*
-*   Copyright (C) 2002-2006, International Business Machines
-*   Corporation and others.  All Rights Reserved.
-*
-*******************************************************************************
-*   file name:  uiter.h
-*   encoding:   US-ASCII
-*   tab size:   8 (not used)
-*   indentation:4
-*
-*   created on: 2002jan18
-*   created by: Markus W. Scherer
-*/
-
-#ifndef __UITER_H__
-#define __UITER_H__
-
-/**
- * \file
- * \brief C API: Unicode Character Iteration
- *
- * @see UCharIterator
- */
-
-#include "unicode/utypes.h"
-
-#ifdef XP_CPLUSPLUS
-    U_NAMESPACE_BEGIN
-
-    class CharacterIterator;
-    class Replaceable;
-
-    U_NAMESPACE_END
-#endif
-
-U_CDECL_BEGIN
-
-struct UCharIterator;
-typedef struct UCharIterator UCharIterator; /**< C typedef for struct UCharIterator. @stable ICU 2.1 */
-
-/**
- * Origin constants for UCharIterator.getIndex() and UCharIterator.move().
- * @see UCharIteratorMove
- * @see UCharIterator
- * @stable ICU 2.1
- */
-typedef enum UCharIteratorOrigin {
-    UITER_START, UITER_CURRENT, UITER_LIMIT, UITER_ZERO, UITER_LENGTH
-} UCharIteratorOrigin;
-
-/** Constants for UCharIterator. @stable ICU 2.6 */
-enum {
-    /**
-     * Constant value that may be returned by UCharIteratorMove
-     * indicating that the final UTF-16 index is not known, but that the move succeeded.
-     * This can occur when moving relative to limit or length, or
-     * when moving relative to the current index after a setState()
-     * when the current UTF-16 index is not known.
-     *
-     * It would be very inefficient to have to count from the beginning of the text
-     * just to get the current/limit/length index after moving relative to it.
-     * The actual index can be determined with getIndex(UITER_CURRENT)
-     * which will count the UChars if necessary.
-     *
-     * @stable ICU 2.6
-     */
-    UITER_UNKNOWN_INDEX=-2
-};
-
-
-/**
- * Constant for UCharIterator getState() indicating an error or
- * an unknown state.
- * Returned by uiter_getState()/UCharIteratorGetState
- * when an error occurs.
- * Also, some UCharIterator implementations may not be able to return
- * a valid state for each position. This will be clearly documented
- * for each such iterator (none of the public ones here).
- *
- * @stable ICU 2.6
- */
-#define UITER_NO_STATE ((uint32_t)0xffffffff)
-
-/**
- * Function type declaration for UCharIterator.getIndex().
- *
- * Gets the current position, or the start or limit of the
- * iteration range.
- *
- * This function may perform slowly for UITER_CURRENT after setState() was called,
- * or for UITER_LENGTH, because an iterator implementation may have to count
- * UChars if the underlying storage is not UTF-16.
- *
- * @param iter the UCharIterator structure ("this pointer")
- * @param origin get the 0, start, limit, length, or current index
- * @return the requested index, or U_SENTINEL in an error condition
- *
- * @see UCharIteratorOrigin
- * @see UCharIterator
- * @stable ICU 2.1
- */
-typedef int32_t U_CALLCONV
-UCharIteratorGetIndex(UCharIterator *iter, UCharIteratorOrigin origin);
-
-/**
- * Function type declaration for UCharIterator.move().
- *
- * Use iter->move(iter, index, UITER_ZERO) like CharacterIterator::setIndex(index).
- *
- * Moves the current position relative to the start or limit of the
- * iteration range, or relative to the current position itself.
- * The movement is expressed in numbers of code units forward
- * or backward by specifying a positive or negative delta.
- * Out of bounds movement will be pinned to the start or limit.
- *
- * This function may perform slowly for moving relative to UITER_LENGTH
- * because an iterator implementation may have to count the rest of the
- * UChars if the native storage is not UTF-16.
- *
- * When moving relative to the limit or length, or
- * relative to the current position after setState() was called,
- * move() may return UITER_UNKNOWN_INDEX (-2) to avoid an inefficient
- * determination of the actual UTF-16 index.
- * The actual index can be determined with getIndex(UITER_CURRENT)
- * which will count the UChars if necessary.
- * See UITER_UNKNOWN_INDEX for details.
- *
- * @param iter the UCharIterator structure ("this pointer")
- * @param delta can be positive, zero, or negative
- * @param origin move relative to the 0, start, limit, length, or current index
- * @return the new index, or U_SENTINEL on an error condition,
- *         or UITER_UNKNOWN_INDEX when the index is not known.
- *
- * @see UCharIteratorOrigin
- * @see UCharIterator
- * @see UITER_UNKNOWN_INDEX
- * @stable ICU 2.1
- */
-typedef int32_t U_CALLCONV
-UCharIteratorMove(UCharIterator *iter, int32_t delta, UCharIteratorOrigin origin);
-
-/**
- * Function type declaration for UCharIterator.hasNext().
- *
- * Check if current() and next() can still
- * return another code unit.
- *
- * @param iter the UCharIterator structure ("this pointer")
- * @return boolean value for whether current() and next() can still return another code unit
- *
- * @see UCharIterator
- * @stable ICU 2.1
- */
-typedef UBool U_CALLCONV
-UCharIteratorHasNext(UCharIterator *iter);
-
-/**
- * Function type declaration for UCharIterator.hasPrevious().
- *
- * Check if previous() can still return another code unit.
- *
- * @param iter the UCharIterator structure ("this pointer")
- * @return boolean value for whether previous() can still return another code unit
- *
- * @see UCharIterator
- * @stable ICU 2.1
- */
-typedef UBool U_CALLCONV
-UCharIteratorHasPrevious(UCharIterator *iter);
- 
-/**
- * Function type declaration for UCharIterator.current().
- *
- * Return the code unit at the current position,
- * or U_SENTINEL if there is none (index is at the limit).
- *
- * @param iter the UCharIterator structure ("this pointer")
- * @return the current code unit
- *
- * @see UCharIterator
- * @stable ICU 2.1
- */
-typedef UChar32 U_CALLCONV
-UCharIteratorCurrent(UCharIterator *iter);
-
-/**
- * Function type declaration for UCharIterator.next().
- *
- * Return the code unit at the current index and increment
- * the index (post-increment, like s[i++]),
- * or return U_SENTINEL if there is none (index is at the limit).
- *
- * @param iter the UCharIterator structure ("this pointer")
- * @return the current code unit (and post-increment the current index)
- *
- * @see UCharIterator
- * @stable ICU 2.1
- */
-typedef UChar32 U_CALLCONV
-UCharIteratorNext(UCharIterator *iter);
-
-/**
- * Function type declaration for UCharIterator.previous().
- *
- * Decrement the index and return the code unit from there
- * (pre-decrement, like s[--i]),
- * or return U_SENTINEL if there is none (index is at the start).
- *
- * @param iter the UCharIterator structure ("this pointer")
- * @return the previous code unit (after pre-decrementing the current index)
- *
- * @see UCharIterator
- * @stable ICU 2.1
- */
-typedef UChar32 U_CALLCONV
-UCharIteratorPrevious(UCharIterator *iter);
-
-/**
- * Function type declaration for UCharIterator.reservedFn().
- * Reserved for future use.
- *
- * @param iter the UCharIterator structure ("this pointer")
- * @param something some integer argument
- * @return some integer
- *
- * @see UCharIterator
- * @stable ICU 2.1
- */
-typedef int32_t U_CALLCONV
-UCharIteratorReserved(UCharIterator *iter, int32_t something);
-
-/**
- * Function type declaration for UCharIterator.getState().
- *
- * Get the "state" of the iterator in the form of a single 32-bit word.
- * It is recommended that the state value be calculated to be as small as
- * is feasible. For strings with limited lengths, fewer than 32 bits may
- * be sufficient.
- *
- * This is used together with setState()/UCharIteratorSetState
- * to save and restore the iterator position more efficiently than with
- * getIndex()/move().
- *
- * The iterator state is defined as a uint32_t value because it is designed
- * for use in ucol_nextSortKeyPart() which provides 32 bits to store the state
- * of the character iterator.
- *
- * With some UCharIterator implementations (e.g., UTF-8),
- * getting and setting the UTF-16 index with existing functions
- * (getIndex(UITER_CURRENT) followed by move(pos, UITER_ZERO)) is possible but
- * relatively slow because the iterator has to "walk" from a known index
- * to the requested one.
- * This takes more time the farther it needs to go.
- *
- * An opaque state value allows an iterator implementation to provide
- * an internal index (UTF-8: the source byte array index) for
- * fast, constant-time restoration.
- *
- * After calling setState(), a getIndex(UITER_CURRENT) may be slow because
- * the UTF-16 index may not be restored as well, but the iterator can deliver
- * the correct text contents and move relative to the current position
- * without performance degradation.
- *
- * Some UCharIterator implementations may not be able to return
- * a valid state for each position, in which case they return UITER_NO_STATE instead.
- * This will be clearly documented for each such iterator (none of the public ones here).
- *
- * @param iter the UCharIterator structure ("this pointer")
- * @return the state word
- *
- * @see UCharIterator
- * @see UCharIteratorSetState
- * @see UITER_NO_STATE
- * @stable ICU 2.6
- */
-typedef uint32_t U_CALLCONV
-UCharIteratorGetState(const UCharIterator *iter);
-
-/**
- * Function type declaration for UCharIterator.setState().
- *
- * Restore the "state" of the iterator using a state word from a getState() call.
- * The iterator object need not be the same one as for which getState() was called,
- * but it must be of the same type (set up using the same uiter_setXYZ function)
- * and it must iterate over the same string
- * (binary identical regardless of memory address).
- * For more about the state word see UCharIteratorGetState.
- *
- * After calling setState(), a getIndex(UITER_CURRENT) may be slow because
- * the UTF-16 index may not be restored as well, but the iterator can deliver
- * the correct text contents and move relative to the current position
- * without performance degradation.
- *
- * @param iter the UCharIterator structure ("this pointer")
- * @param state the state word from a getState() call
- *              on a same-type, same-string iterator
- * @param pErrorCode Must be a valid pointer to an error code value,
- *                   which must not indicate a failure before the function call.
- *
- * @see UCharIterator
- * @see UCharIteratorGetState
- * @stable ICU 2.6
- */
-typedef void U_CALLCONV
-UCharIteratorSetState(UCharIterator *iter, uint32_t state, UErrorCode *pErrorCode);
-
-
-/**
- * C API for code unit iteration.
- * This can be used as a C wrapper around
- * CharacterIterator, Replaceable, or implemented using simple strings, etc.
- *
- * There are two roles for using UCharIterator:
- *
- * A "provider" sets the necessary function pointers and controls the "protected"
- * fields of the UCharIterator structure. A "provider" passes a UCharIterator
- * into C APIs that need a UCharIterator as an abstract, flexible string interface.
- *
- * Implementations of such C APIs are "callers" of UCharIterator functions;
- * they only use the "public" function pointers and never access the "protected"
- * fields directly.
- *
- * The current() and next() functions only check the current index against the
- * limit, and previous() only checks the current index against the start,
- * to see if the iterator already reached the end of the iteration range.
- *
- * The assumption - in all iterators - is that the index is moved via the API,
- * which means it won't go out of bounds, or the index is modified by
- * user code that knows enough about the iterator implementation to set valid
- * index values.
- *
- * UCharIterator functions return code unit values 0..0xffff,
- * or U_SENTINEL if the iteration bounds are reached.
- *
- * @stable ICU 2.1
- */
-struct UCharIterator {
-    /**
-     * (protected) Pointer to string or wrapped object or similar.
-     * Not used by caller.
-     * @stable ICU 2.1
-     */
-    const void *context;
-
-    /**
-     * (protected) Length of string or similar.
-     * Not used by caller.
-     * @stable ICU 2.1
-     */
-    int32_t length;
-
-    /**
-     * (protected) Start index or similar.
-     * Not used by caller.
-     * @stable ICU 2.1
-     */
-    int32_t start;
-
-    /**
-     * (protected) Current index or similar.
-     * Not used by caller.
-     * @stable ICU 2.1
-     */
-    int32_t index;
-
-    /**
-     * (protected) Limit index or similar.
-     * Not used by caller.
-     * @stable ICU 2.1
-     */
-    int32_t limit;
-
-    /**
-     * (protected) Used by UTF-8 iterators and possibly others.
-     * @stable ICU 2.1
-     */
-    int32_t reservedField;
-
-    /**
-     * (public) Returns the current position or the
-     * start or limit index of the iteration range.
-     *
-     * @see UCharIteratorGetIndex
-     * @stable ICU 2.1
-     */
-    UCharIteratorGetIndex *getIndex;
-
-    /**
-     * (public) Moves the current position relative to the start or limit of the
-     * iteration range, or relative to the current position itself.
-     * The movement is expressed in numbers of code units forward
-     * or backward by specifying a positive or negative delta.
-     *
-     * @see UCharIteratorMove
-     * @stable ICU 2.1
-     */
-    UCharIteratorMove *move;
-
-    /**
-     * (public) Check if current() and next() can still
-     * return another code unit.
-     *
-     * @see UCharIteratorHasNext
-     * @stable ICU 2.1
-     */
-    UCharIteratorHasNext *hasNext;
-
-    /**
-     * (public) Check if previous() can still return another code unit.
-     *
-     * @see UCharIteratorHasPrevious
-     * @stable ICU 2.1
-     */
-    UCharIteratorHasPrevious *hasPrevious;
-
-    /**
-     * (public) Return the code unit at the current position,
-     * or U_SENTINEL if there is none (index is at the limit).
-     *
-     * @see UCharIteratorCurrent
-     * @stable ICU 2.1
-     */
-    UCharIteratorCurrent *current;
-
-    /**
-     * (public) Return the code unit at the current index and increment
-     * the index (post-increment, like s[i++]),
-     * or return U_SENTINEL if there is none (index is at the limit).
-     *
-     * @see UCharIteratorNext
-     * @stable ICU 2.1
-     */
-    UCharIteratorNext *next;
-
-    /**
-     * (public) Decrement the index and return the code unit from there
-     * (pre-decrement, like s[--i]),
-     * or return U_SENTINEL if there is none (index is at the start).
-     *
-     * @see UCharIteratorPrevious
-     * @stable ICU 2.1
-     */
-    UCharIteratorPrevious *previous;
-
-    /**
-     * (public) Reserved for future use. Currently NULL.
-     *
-     * @see UCharIteratorReserved
-     * @stable ICU 2.1
-     */
-    UCharIteratorReserved *reservedFn;
-
-    /**
-     * (public) Return the state of the iterator, to be restored later with setState().
-     * This function pointer is NULL if the iterator does not implement it.
-     *
-     * @see UCharIteratorGet
-     * @stable ICU 2.6
-     */
-    UCharIteratorGetState *getState;
-
-    /**
-     * (public) Restore the iterator state from the state word from a call
-     * to getState().
-     * This function pointer is NULL if the iterator does not implement it.
-     *
-     * @see UCharIteratorSet
-     * @stable ICU 2.6
-     */
-    UCharIteratorSetState *setState;
-};
-
-/**
- * Helper function for UCharIterator to get the code point
- * at the current index.
- *
- * Return the code point that includes the code unit at the current position,
- * or U_SENTINEL if there is none (index is at the limit).
- * If the current code unit is a lead or trail surrogate,
- * then the following or preceding surrogate is used to form
- * the code point value.
- *
- * @param iter the UCharIterator structure ("this pointer")
- * @return the current code point
- *
- * @see UCharIterator
- * @see U16_GET
- * @see UnicodeString::char32At()
- * @stable ICU 2.1
- */
-U_STABLE UChar32 U_EXPORT2
-uiter_current32(UCharIterator *iter);
-
-/**
- * Helper function for UCharIterator to get the next code point.
- *
- * Return the code point at the current index and increment
- * the index (post-increment, like s[i++]),
- * or return U_SENTINEL if there is none (index is at the limit).
- *
- * @param iter the UCharIterator structure ("this pointer")
- * @return the current code point (and post-increment the current index)
- *
- * @see UCharIterator
- * @see U16_NEXT
- * @stable ICU 2.1
- */
-U_STABLE UChar32 U_EXPORT2
-uiter_next32(UCharIterator *iter);
-
-/**
- * Helper function for UCharIterator to get the previous code point.
- *
- * Decrement the index and return the code point from there
- * (pre-decrement, like s[--i]),
- * or return U_SENTINEL if there is none (index is at the start).
- *
- * @param iter the UCharIterator structure ("this pointer")
- * @return the previous code point (after pre-decrementing the current index)
- *
- * @see UCharIterator
- * @see U16_PREV
- * @stable ICU 2.1
- */
-U_STABLE UChar32 U_EXPORT2
-uiter_previous32(UCharIterator *iter);
-
-/**
- * Get the "state" of the iterator in the form of a single 32-bit word.
- * This is a convenience function that calls iter->getState(iter)
- * if iter->getState is not NULL;
- * if it is NULL or any other error occurs, then UITER_NO_STATE is returned.
- *
- * Some UCharIterator implementations may not be able to return
- * a valid state for each position, in which case they return UITER_NO_STATE instead.
- * This will be clearly documented for each such iterator (none of the public ones here).
- *
- * @param iter the UCharIterator structure ("this pointer")
- * @return the state word
- *
- * @see UCharIterator
- * @see UCharIteratorGetState
- * @see UITER_NO_STATE
- * @stable ICU 2.6
- */
-U_STABLE uint32_t U_EXPORT2
-uiter_getState(const UCharIterator *iter);
-
-/**
- * Restore the "state" of the iterator using a state word from a getState() call.
- * This is a convenience function that calls iter->setState(iter, state, pErrorCode)
- * if iter->setState is not NULL; if it is NULL, then U_UNSUPPORTED_ERROR is set.
- *
- * @param iter the UCharIterator structure ("this pointer")
- * @param state the state word from a getState() call
- *              on a same-type, same-string iterator
- * @param pErrorCode Must be a valid pointer to an error code value,
- *                   which must not indicate a failure before the function call.
- *
- * @see UCharIterator
- * @see UCharIteratorSetState
- * @stable ICU 2.6
- */
-U_STABLE void U_EXPORT2
-uiter_setState(UCharIterator *iter, uint32_t state, UErrorCode *pErrorCode);
-
-/**
- * Set up a UCharIterator to iterate over a string.
- *
- * Sets the UCharIterator function pointers for iteration over the string s
- * with iteration boundaries start=index=0 and length=limit=string length.
- * The "provider" may set the start, index, and limit values at any time
- * within the range 0..length.
- * The length field will be ignored.
- *
- * The string pointer s is set into UCharIterator.context without copying
- * or reallocating the string contents.
- *
- * getState() simply returns the current index.
- * move() will always return the final index.
- *
- * @param iter UCharIterator structure to be set for iteration
- * @param s String to iterate over
- * @param length Length of s, or -1 if NUL-terminated
- *
- * @see UCharIterator
- * @stable ICU 2.1
- */
-U_STABLE void U_EXPORT2
-uiter_setString(UCharIterator *iter, const UChar *s, int32_t length);
-
-/**
- * Set up a UCharIterator to iterate over a UTF-16BE string
- * (byte vector with a big-endian pair of bytes per UChar).
- *
- * Everything works just like with a normal UChar iterator (uiter_setString),
- * except that UChars are assembled from byte pairs,
- * and that the length argument here indicates an even number of bytes.
- *
- * getState() simply returns the current index.
- * move() will always return the final index.
- *
- * @param iter UCharIterator structure to be set for iteration
- * @param s UTF-16BE string to iterate over
- * @param length Length of s as an even number of bytes, or -1 if NUL-terminated
- *               (NUL means pair of 0 bytes at even index from s)
- *
- * @see UCharIterator
- * @see uiter_setString
- * @stable ICU 2.6
- */
-U_STABLE void U_EXPORT2
-uiter_setUTF16BE(UCharIterator *iter, const char *s, int32_t length);
-
-/**
- * Set up a UCharIterator to iterate over a UTF-8 string.
- *
- * Sets the UCharIterator function pointers for iteration over the UTF-8 string s
- * with UTF-8 iteration boundaries 0 and length.
- * The implementation counts the UTF-16 index on the fly and
- * lazily evaluates the UTF-16 length of the text.
- *
- * The start field is used as the UTF-8 offset, the limit field as the UTF-8 length.
- * When the reservedField is not 0, then it contains a supplementary code point
- * and the UTF-16 index is between the two corresponding surrogates.
- * At that point, the UTF-8 index is behind that code point.
- *
- * The UTF-8 string pointer s is set into UCharIterator.context without copying
- * or reallocating the string contents.
- *
- * getState() returns a state value consisting of
- * - the current UTF-8 source byte index (bits 31..1)
- * - a flag (bit 0) that indicates whether the UChar position is in the middle
- *   of a surrogate pair
- *   (from a 4-byte UTF-8 sequence for the corresponding supplementary code point)
- *
- * getState() cannot also encode the UTF-16 index in the state value.
- * move(relative to limit or length), or
- * move(relative to current) after setState(), may return UITER_UNKNOWN_INDEX.
- *
- * @param iter UCharIterator structure to be set for iteration
- * @param s UTF-8 string to iterate over
- * @param length Length of s in bytes, or -1 if NUL-terminated
- *
- * @see UCharIterator
- * @stable ICU 2.6
- */
-U_STABLE void U_EXPORT2
-uiter_setUTF8(UCharIterator *iter, const char *s, int32_t length);
-
-#ifdef XP_CPLUSPLUS
-
-/**
- * Set up a UCharIterator to wrap around a C++ CharacterIterator.
- *
- * Sets the UCharIterator function pointers for iteration using the
- * CharacterIterator charIter.
- *
- * The CharacterIterator pointer charIter is set into UCharIterator.context
- * without copying or cloning the CharacterIterator object.
- * The other "protected" UCharIterator fields are set to 0 and will be ignored.
- * The iteration index and boundaries are controlled by the CharacterIterator.
- *
- * getState() simply returns the current index.
- * move() will always return the final index.
- *
- * @param iter UCharIterator structure to be set for iteration
- * @param charIter CharacterIterator to wrap
- *
- * @see UCharIterator
- * @stable ICU 2.1
- */
-U_STABLE void U_EXPORT2
-uiter_setCharacterIterator(UCharIterator *iter, U_NAMESPACE_QUALIFIER CharacterIterator *charIter);
-
-/**
- * Set up a UCharIterator to iterate over a C++ Replaceable.
- *
- * Sets the UCharIterator function pointers for iteration over the
- * Replaceable rep with iteration boundaries start=index=0 and
- * length=limit=rep->length().
- * The "provider" may set the start, index, and limit values at any time
- * within the range 0..length=rep->length().
- * The length field will be ignored.
- *
- * The Replaceable pointer rep is set into UCharIterator.context without copying
- * or cloning/reallocating the Replaceable object.
- *
- * getState() simply returns the current index.
- * move() will always return the final index.
- *
- * @param iter UCharIterator structure to be set for iteration
- * @param rep Replaceable to iterate over
- *
- * @see UCharIterator
- * @stable ICU 2.1
- */
-U_STABLE void U_EXPORT2
-uiter_setReplaceable(UCharIterator *iter, const U_NAMESPACE_QUALIFIER Replaceable *rep);
-
-#endif
-
-U_CDECL_END
-
-#endif

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/uloc.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/uloc.h b/apps/couch_collate/platform/osx/icu/unicode/uloc.h
deleted file mode 100644
index 29c479a..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/uloc.h
+++ /dev/null
@@ -1,1046 +0,0 @@
-/*
-**********************************************************************
-*   Copyright (C) 1997-2008, International Business Machines
-*   Corporation and others.  All Rights Reserved.
-**********************************************************************
-*
-* File ULOC.H
-*
-* Modification History:
-*
-*   Date        Name        Description
-*   04/01/97    aliu        Creation.
-*   08/22/98    stephen     JDK 1.2 sync.
-*   12/08/98    rtg         New C API for Locale
-*   03/30/99    damiba      overhaul
-*   03/31/99    helena      Javadoc for uloc functions.
-*   04/15/99    Madhu       Updated Javadoc
-********************************************************************************
-*/
-
-#ifndef ULOC_H
-#define ULOC_H
-
-#include "unicode/utypes.h"
-#include "unicode/uenum.h"
-
-/**    
- * \file
- * \brief  C API: Locale 
- *
- * <h2> ULoc C API for Locale </h2>
- * A <code>Locale</code> represents a specific geographical, political,
- * or cultural region. An operation that requires a <code>Locale</code> to perform
- * its task is called <em>locale-sensitive</em> and uses the <code>Locale</code>
- * to tailor information for the user. For example, displaying a number
- * is a locale-sensitive operation--the number should be formatted
- * according to the customs/conventions of the user's native country,
- * region, or culture.  In the C APIs, a locales is simply a const char string.
- *
- * <P>
- * You create a <code>Locale</code> with one of the three options listed below.
- * Each of the component is separated by '_' in the locale string.
- * \htmlonly<blockquote>\endhtmlonly
- * <pre>
- * \code
- *       newLanguage
- * 
- *       newLanguage + newCountry
- * 
- *       newLanguage + newCountry + newVariant
- * \endcode
- * </pre>
- * \htmlonly</blockquote>\endhtmlonly
- * The first option is a valid <STRONG>ISO
- * Language Code.</STRONG> These codes are the lower-case two-letter
- * codes as defined by ISO-639.
- * You can find a full list of these codes at a number of sites, such as:
- * <BR><a href ="http://www.ics.uci.edu/pub/ietf/http/related/iso639.txt">
- * http://www.ics.uci.edu/pub/ietf/http/related/iso639.txt</a>
- *
- * <P>
- * The second option includes an additonal <STRONG>ISO Country
- * Code.</STRONG> These codes are the upper-case two-letter codes
- * as defined by ISO-3166.
- * You can find a full list of these codes at a number of sites, such as:
- * <BR><a href="http://www.chemie.fu-berlin.de/diverse/doc/ISO_3166.html">
- * http://www.chemie.fu-berlin.de/diverse/doc/ISO_3166.html</a>
- *
- * <P>
- * The third option requires another additonal information--the 
- * <STRONG>Variant.</STRONG>
- * The Variant codes are vendor and browser-specific.
- * For example, use WIN for Windows, MAC for Macintosh, and POSIX for POSIX.
- * Where there are two variants, separate them with an underscore, and
- * put the most important one first. For
- * example, a Traditional Spanish collation might be referenced, with
- * "ES", "ES", "Traditional_WIN".
- *
- * <P>
- * Because a <code>Locale</code> is just an identifier for a region,
- * no validity check is performed when you specify a <code>Locale</code>.
- * If you want to see whether particular resources are available for the
- * <code>Locale</code> you asked for, you must query those resources. For
- * example, ask the <code>UNumberFormat</code> for the locales it supports
- * using its <code>getAvailable</code> method.
- * <BR><STRONG>Note:</STRONG> When you ask for a resource for a particular
- * locale, you get back the best available match, not necessarily
- * precisely what you asked for. For more information, look at
- * <code>UResourceBundle</code>.
- *
- * <P>
- * The <code>Locale</code> provides a number of convenient constants
- * that you can use to specify the commonly used
- * locales. For example, the following refers to a locale
- * for the United States:
- * \htmlonly<blockquote>\endhtmlonly
- * <pre>
- * \code
- *       ULOC_US
- * \endcode
- * </pre>
- * \htmlonly</blockquote>\endhtmlonly
- *
- * <P>
- * Once you've specified a locale you can query it for information about
- * itself. Use <code>uloc_getCountry</code> to get the ISO Country Code and
- * <code>uloc_getLanguage</code> to get the ISO Language Code. You can
- * use <code>uloc_getDisplayCountry</code> to get the
- * name of the country suitable for displaying to the user. Similarly,
- * you can use <code>uloc_getDisplayLanguage</code> to get the name of
- * the language suitable for displaying to the user. Interestingly,
- * the <code>uloc_getDisplayXXX</code> methods are themselves locale-sensitive
- * and have two versions: one that uses the default locale and one
- * that takes a locale as an argument and displays the name or country in
- * a language appropriate to that locale.
- *
- * <P>
- * The ICU provides a number of services that perform locale-sensitive
- * operations. For example, the <code>unum_xxx</code> functions format
- * numbers, currency, or percentages in a locale-sensitive manner. 
- * </P>
- * \htmlonly<blockquote>\endhtmlonly
- * <pre>
- * \code
- *     UErrorCode success = U_ZERO_ERROR;
- *     UNumberFormat *nf;
- *     const char* myLocale = "fr_FR";
- * 
- *     nf = unum_open( UNUM_DEFAULT, NULL, success );          
- *     unum_close(nf);
- *     nf = unum_open( UNUM_CURRENCY, NULL, success );
- *     unum_close(nf);
- *     nf = unum_open( UNUM_PERCENT, NULL, success );   
- *     unum_close(nf);
- * \endcode
- * </pre>
- * \htmlonly</blockquote>\endhtmlonly
- * Each of these methods has two variants; one with an explicit locale
- * and one without; the latter using the default locale.
- * \htmlonly<blockquote>\endhtmlonly
- * <pre>
- * \code 
- * 
- *     nf = unum_open( UNUM_DEFAULT, myLocale, success );          
- *     unum_close(nf);
- *     nf = unum_open( UNUM_CURRENCY, myLocale, success );
- *     unum_close(nf);
- *     nf = unum_open( UNUM_PERCENT, myLocale, success );   
- *     unum_close(nf);
- * \endcode
- * </pre>
- * \htmlonly</blockquote>\endhtmlonly
- * A <code>Locale</code> is the mechanism for identifying the kind of services
- * (<code>UNumberFormat</code>) that you would like to get. The locale is
- * <STRONG>just</STRONG> a mechanism for identifying these services.
- *
- * <P>
- * Each international serivce that performs locale-sensitive operations 
- * allows you
- * to get all the available objects of that type. You can sift
- * through these objects by language, country, or variant,
- * and use the display names to present a menu to the user.
- * For example, you can create a menu of all the collation objects
- * suitable for a given language. Such classes implement these
- * three class methods:
- * \htmlonly<blockquote>\endhtmlonly
- * <pre>
- * \code
- *       const char* uloc_getAvailable(int32_t index);
- *       int32_t uloc_countAvailable();
- *       int32_t
- *       uloc_getDisplayName(const char* localeID,
- *                 const char* inLocaleID, 
- *                 UChar* result,
- *                 int32_t maxResultSize,
- *                  UErrorCode* err);
- * 
- * \endcode
- * </pre>
- * \htmlonly</blockquote>\endhtmlonly
- * <P>
- * Concerning POSIX/RFC1766 Locale IDs, 
- *  the getLanguage/getCountry/getVariant/getName functions do understand
- * the POSIX type form of  language_COUNTRY.ENCODING\@VARIANT
- * and if there is not an ICU-stype variant, uloc_getVariant() for example
- * will return the one listed after the \@at sign. As well, the hyphen
- * "-" is recognized as a country/variant separator similarly to RFC1766.
- * So for example, "en-us" will be interpreted as en_US.  
- * As a result, uloc_getName() is far from a no-op, and will have the
- * effect of converting POSIX/RFC1766 IDs into ICU form, although it does
- * NOT map any of the actual codes (i.e. russian->ru) in any way.
- * Applications should call uloc_getName() at the point where a locale ID
- * is coming from an external source (user entry, OS, web browser)
- * and pass the resulting string to other ICU functions.  For example,
- * don't use de-de\@EURO as an argument to resourcebundle.
- *
- * @see UResourceBundle
- */
-
-/** Useful constant for this language. @stable ICU 2.0 */
-#define ULOC_CHINESE            "zh"
-/** Useful constant for this language. @stable ICU 2.0 */
-#define ULOC_ENGLISH            "en"
-/** Useful constant for this language. @stable ICU 2.0 */
-#define ULOC_FRENCH             "fr"
-/** Useful constant for this language. @stable ICU 2.0 */
-#define ULOC_GERMAN             "de"
-/** Useful constant for this language. @stable ICU 2.0 */
-#define ULOC_ITALIAN            "it"
-/** Useful constant for this language. @stable ICU 2.0 */
-#define ULOC_JAPANESE           "ja"
-/** Useful constant for this language. @stable ICU 2.0 */
-#define ULOC_KOREAN             "ko"
-/** Useful constant for this language. @stable ICU 2.0 */
-#define ULOC_SIMPLIFIED_CHINESE "zh_CN"
-/** Useful constant for this language. @stable ICU 2.0 */
-#define ULOC_TRADITIONAL_CHINESE "zh_TW"
-
-/** Useful constant for this country/region. @stable ICU 2.0 */
-#define ULOC_CANADA         "en_CA"
-/** Useful constant for this country/region. @stable ICU 2.0 */
-#define ULOC_CANADA_FRENCH  "fr_CA"
-/** Useful constant for this country/region. @stable ICU 2.0 */
-#define ULOC_CHINA          "zh_CN"
-/** Useful constant for this country/region. @stable ICU 2.0 */
-#define ULOC_PRC            "zh_CN"
-/** Useful constant for this country/region. @stable ICU 2.0 */
-#define ULOC_FRANCE         "fr_FR"
-/** Useful constant for this country/region. @stable ICU 2.0 */
-#define ULOC_GERMANY        "de_DE"
-/** Useful constant for this country/region. @stable ICU 2.0 */
-#define ULOC_ITALY          "it_IT"
-/** Useful constant for this country/region. @stable ICU 2.0 */
-#define ULOC_JAPAN          "ja_JP"
-/** Useful constant for this country/region. @stable ICU 2.0 */
-#define ULOC_KOREA          "ko_KR"
-/** Useful constant for this country/region. @stable ICU 2.0 */
-#define ULOC_TAIWAN         "zh_TW"
-/** Useful constant for this country/region. @stable ICU 2.0 */
-#define ULOC_UK             "en_GB"
-/** Useful constant for this country/region. @stable ICU 2.0 */
-#define ULOC_US             "en_US"
-
-/**
- * Useful constant for the maximum size of the language part of a locale ID.
- * (including the terminating NULL).
- * @stable ICU 2.0
- */
-#define ULOC_LANG_CAPACITY 12
-
-/**
- * Useful constant for the maximum size of the country part of a locale ID
- * (including the terminating NULL).
- * @stable ICU 2.0
- */
-#define ULOC_COUNTRY_CAPACITY 4
-/**
- * Useful constant for the maximum size of the whole locale ID
- * (including the terminating NULL).
- * @stable ICU 2.0
- */
-#define ULOC_FULLNAME_CAPACITY 56
-
-/**
- * Useful constant for the maximum size of the script part of a locale ID
- * (including the terminating NULL).
- * @stable ICU 2.8
- */
-#define ULOC_SCRIPT_CAPACITY 6
-
-/**
- * Useful constant for the maximum size of keywords in a locale
- * @stable ICU 2.8
- */
-#define ULOC_KEYWORDS_CAPACITY 50
-
-/**
- * Useful constant for the maximum SIZE of keywords in a locale
- * @stable ICU 2.8
- */
-#define ULOC_KEYWORD_AND_VALUES_CAPACITY 100
-
-/**
- * Character separating keywords from the locale string
- * different for EBCDIC - TODO
- * @stable ICU 2.8
- */
-#define ULOC_KEYWORD_SEPARATOR '@'
-/**
- * Character for assigning value to a keyword
- * @stable ICU 2.8
- */
-#define ULOC_KEYWORD_ASSIGN '='
-/**
- * Character separating keywords
- * @stable ICU 2.8
- */
-#define ULOC_KEYWORD_ITEM_SEPARATOR ';'
-
-/**
- * Constants for *_getLocale()
- * Allow user to select whether she wants information on 
- * requested, valid or actual locale.
- * For example, a collator for "en_US_CALIFORNIA" was
- * requested. In the current state of ICU (2.0), 
- * the requested locale is "en_US_CALIFORNIA",
- * the valid locale is "en_US" (most specific locale supported by ICU)
- * and the actual locale is "root" (the collation data comes unmodified 
- * from the UCA)
- * The locale is considered supported by ICU if there is a core ICU bundle 
- * for that locale (although it may be empty).
- * @stable ICU 2.1
- */
-typedef enum {
-  /** This is locale the data actually comes from 
-   * @stable ICU 2.1
-   */
-  ULOC_ACTUAL_LOCALE    = 0,
-  /** This is the most specific locale supported by ICU 
-   * @stable ICU 2.1
-   */
-  ULOC_VALID_LOCALE    = 1,
-
-#ifndef U_HIDE_DEPRECATED_API
-  /** This is the requested locale
-   *  @deprecated ICU 2.8 
-   */
-  ULOC_REQUESTED_LOCALE = 2,
-#endif /* U_HIDE_DEPRECATED_API */
-
-  ULOC_DATA_LOCALE_TYPE_LIMIT = 3
-} ULocDataLocaleType ;
-
-
-/**
- * Gets ICU's default locale.  
- * The returned string is a snapshot in time, and will remain valid
- *   and unchanged even when uloc_setDefault() is called.
- *   The returned storage is owned by ICU, and must not be altered or deleted
- *   by the caller.
- *  
- * @return the ICU default locale
- * @system
- * @stable ICU 2.0
- */
-U_STABLE const char* U_EXPORT2
-uloc_getDefault(void);
-
-/**
- * Sets ICU's default locale.  
- *    By default (without calling this function), ICU's default locale will be based
- *    on information obtained from the underlying system environment.
- *    <p>
- *    Changes to ICU's default locale do not propagate back to the
- *    system environment.
- *    <p>
- *    Changes to ICU's default locale to not affect any ICU services that
- *    may already be open based on the previous default locale value.
- *
- * @param localeID the new ICU default locale. A value of NULL will try to get
- *                 the system's default locale.
- * @param status the error information if the setting of default locale fails
- * @system
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2
-uloc_setDefault(const char* localeID,
-        UErrorCode*       status);
-
-/**
- * Gets the language code for the specified locale.
- *
- * @param localeID the locale to get the ISO language code with
- * @param language the language code for localeID
- * @param languageCapacity the size of the language buffer to store the  
- * language code with
- * @param err error information if retrieving the language code failed
- * @return the actual buffer size needed for the language code.  If it's greater 
- * than languageCapacity, the returned language code will be truncated.  
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2
-uloc_getLanguage(const char*    localeID,
-         char* language,
-         int32_t languageCapacity,
-         UErrorCode* err);
-
-/**
- * Gets the script code for the specified locale.
- *
- * @param localeID the locale to get the ISO language code with
- * @param script the language code for localeID
- * @param scriptCapacity the size of the language buffer to store the  
- * language code with
- * @param err error information if retrieving the language code failed
- * @return the actual buffer size needed for the language code.  If it's greater 
- * than scriptCapacity, the returned language code will be truncated.  
- * @stable ICU 2.8
- */
-U_STABLE int32_t U_EXPORT2
-uloc_getScript(const char*    localeID,
-         char* script,
-         int32_t scriptCapacity,
-         UErrorCode* err);
-
-/**
- * Gets the  country code for the specified locale.
- *
- * @param localeID the locale to get the country code with
- * @param country the country code for localeID
- * @param countryCapacity the size of the country buffer to store the  
- * country code with
- * @param err error information if retrieving the country code failed
- * @return the actual buffer size needed for the country code.  If it's greater 
- * than countryCapacity, the returned country code will be truncated.  
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2
-uloc_getCountry(const char*    localeID,
-        char* country,
-        int32_t countryCapacity,
-        UErrorCode* err);
-
-/**
- * Gets the variant code for the specified locale.
- *
- * @param localeID the locale to get the variant code with
- * @param variant the variant code for localeID
- * @param variantCapacity the size of the variant buffer to store the 
- * variant code with
- * @param err error information if retrieving the variant code failed
- * @return the actual buffer size needed for the variant code.  If it's greater 
- * than variantCapacity, the returned variant code will be truncated.  
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2
-uloc_getVariant(const char*    localeID,
-        char* variant,
-        int32_t variantCapacity,
-        UErrorCode* err);
-
-
-/**
- * Gets the full name for the specified locale.
- * Note: This has the effect of 'canonicalizing' the ICU locale ID to
- * a certain extent. Upper and lower case are set as needed.
- * It does NOT map aliased names in any way.
- * See the top of this header file.
- * This API supports preflighting.
- *
- * @param localeID the locale to get the full name with
- * @param name fill in buffer for the name without keywords.
- * @param nameCapacity capacity of the fill in buffer.
- * @param err error information if retrieving the full name failed
- * @return the actual buffer size needed for the full name.  If it's greater 
- * than nameCapacity, the returned full name will be truncated.  
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2
-uloc_getName(const char*    localeID,
-         char* name,
-         int32_t nameCapacity,
-         UErrorCode* err);
-
-/**
- * Gets the full name for the specified locale.
- * Note: This has the effect of 'canonicalizing' the string to
- * a certain extent. Upper and lower case are set as needed,
- * and if the components were in 'POSIX' format they are changed to
- * ICU format.  It does NOT map aliased names in any way.
- * See the top of this header file.
- *
- * @param localeID the locale to get the full name with
- * @param name the full name for localeID
- * @param nameCapacity the size of the name buffer to store the 
- * full name with
- * @param err error information if retrieving the full name failed
- * @return the actual buffer size needed for the full name.  If it's greater 
- * than nameCapacity, the returned full name will be truncated.  
- * @stable ICU 2.8
- */
-U_STABLE int32_t U_EXPORT2
-uloc_canonicalize(const char*    localeID,
-         char* name,
-         int32_t nameCapacity,
-         UErrorCode* err);
-
-/**
- * Gets the ISO language code for the specified locale.
- *
- * @param localeID the locale to get the ISO language code with
- * @return language the ISO language code for localeID
- * @stable ICU 2.0
- */
-U_STABLE const char* U_EXPORT2
-uloc_getISO3Language(const char* localeID);
-
-
-/**
- * Gets the ISO country code for the specified locale.
- *
- * @param localeID the locale to get the ISO country code with
- * @return country the ISO country code for localeID
- * @stable ICU 2.0
- */
-U_STABLE const char* U_EXPORT2
-uloc_getISO3Country(const char* localeID);
-
-/**
- * Gets the Win32 LCID value for the specified locale.
- * If the ICU locale is not recognized by Windows, 0 will be returned.
- *
- * @param localeID the locale to get the Win32 LCID value with
- * @return country the Win32 LCID for localeID
- * @stable ICU 2.0
- */
-U_STABLE uint32_t U_EXPORT2
-uloc_getLCID(const char* localeID);
-
-/**
- * Gets the language name suitable for display for the specified locale.
- *
- * @param locale the locale to get the ISO language code with
- * @param displayLocale Specifies the locale to be used to display the name.  In other words,
- *                 if the locale's language code is "en", passing Locale::getFrench() for
- *                 inLocale would result in "Anglais", while passing Locale::getGerman()
- *                 for inLocale would result in "Englisch".
- * @param language the displayable language code for localeID
- * @param languageCapacity the size of the language buffer to store the  
- * displayable language code with
- * @param status error information if retrieving the displayable language code failed
- * @return the actual buffer size needed for the displayable language code.  If it's greater 
- * than languageCapacity, the returned language code will be truncated.  
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2
-uloc_getDisplayLanguage(const char* locale,
-            const char* displayLocale,
-            UChar* language,
-            int32_t languageCapacity,
-            UErrorCode* status);
-
-/**
- * Gets the script name suitable for display for the specified locale.
- *
- * @param locale the locale to get the displayable script code with. NULL may be used to specify the default.
- * @param displayLocale Specifies the locale to be used to display the name.  In other words,
- *                 if the locale's language code is "en", passing Locale::getFrench() for
- *                 inLocale would result in "", while passing Locale::getGerman()
- *                 for inLocale would result in "". NULL may be used to specify the default.
- * @param script the displayable country code for localeID
- * @param scriptCapacity the size of the script buffer to store the  
- * displayable script code with
- * @param status error information if retrieving the displayable script code failed
- * @return the actual buffer size needed for the displayable script code.  If it's greater 
- * than scriptCapacity, the returned displayable script code will be truncated.  
- * @stable ICU 2.8
- */
-U_STABLE int32_t U_EXPORT2
-uloc_getDisplayScript(const char* locale,
-            const char* displayLocale,
-            UChar* script,
-            int32_t scriptCapacity,
-            UErrorCode* status);
-
-/**
- * Gets the country name suitable for display for the specified locale.
- *
- * @param locale the locale to get the displayable country code with. NULL may be used to specify the default.
- * @param displayLocale Specifies the locale to be used to display the name.  In other words,
- *                 if the locale's language code is "en", passing Locale::getFrench() for
- *                 inLocale would result in "Anglais", while passing Locale::getGerman()
- *                 for inLocale would result in "Englisch". NULL may be used to specify the default.
- * @param country the displayable country code for localeID
- * @param countryCapacity the size of the country buffer to store the  
- * displayable country code with
- * @param status error information if retrieving the displayable country code failed
- * @return the actual buffer size needed for the displayable country code.  If it's greater 
- * than countryCapacity, the returned displayable country code will be truncated.  
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2
-uloc_getDisplayCountry(const char* locale,
-                       const char* displayLocale,
-                       UChar* country,
-                       int32_t countryCapacity,
-                       UErrorCode* status);
-
-
-/**
- * Gets the variant name suitable for display for the specified locale.
- *
- * @param locale the locale to get the displayable variant code with. NULL may be used to specify the default.
- * @param displayLocale Specifies the locale to be used to display the name.  In other words,
- *                 if the locale's language code is "en", passing Locale::getFrench() for
- *                 inLocale would result in "Anglais", while passing Locale::getGerman()
- *                 for inLocale would result in "Englisch". NULL may be used to specify the default.
- * @param variant the displayable variant code for localeID
- * @param variantCapacity the size of the variant buffer to store the 
- * displayable variant code with
- * @param status error information if retrieving the displayable variant code failed
- * @return the actual buffer size needed for the displayable variant code.  If it's greater 
- * than variantCapacity, the returned displayable variant code will be truncated.  
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2
-uloc_getDisplayVariant(const char* locale,
-                       const char* displayLocale,
-                       UChar* variant,
-                       int32_t variantCapacity,
-                       UErrorCode* status);
-
-/**
- * Gets the keyword name suitable for display for the specified locale.
- * E.g: for the locale string de_DE\@collation=PHONEBOOK, this API gets the display 
- * string for the keyword collation. 
- * Usage:
- * <code>
- *    UErrorCode status = U_ZERO_ERROR;
- *    const char* keyword =NULL;
- *    int32_t keywordLen = 0;
- *    int32_t keywordCount = 0;
- *    UChar displayKeyword[256];
- *    int32_t displayKeywordLen = 0;
- *    UEnumeration* keywordEnum = uloc_openKeywords("de_DE@collation=PHONEBOOK;calendar=TRADITIONAL", &status);
- *    for(keywordCount = uenum_count(keywordEnum, &status); keywordCount > 0 ; keywordCount--){
- *          if(U_FAILURE(status)){
- *              ...something went wrong so handle the error...
- *              break;
- *          }
- *          // the uenum_next returns NUL terminated string
- *          keyword = uenum_next(keywordEnum, &keywordLen, &status);
- *          displayKeywordLen = uloc_getDisplayKeyword(keyword, "en_US", displayKeyword, 256);
- *          ... do something interesting .....
- *    }
- *    uenum_close(keywordEnum);
- * </code>
- * @param keyword           The keyword whose display string needs to be returned.
- * @param displayLocale     Specifies the locale to be used to display the name.  In other words,
- *                          if the locale's language code is "en", passing Locale::getFrench() for
- *                          inLocale would result in "Anglais", while passing Locale::getGerman()
- *                          for inLocale would result in "Englisch". NULL may be used to specify the default.
- * @param dest              the buffer to which the displayable keyword should be written.
- * @param destCapacity      The size of the buffer (number of UChars). If it is 0, then
- *                          dest may be NULL and the function will only return the length of the 
- *                          result without writing any of the result string (pre-flighting).
- * @param status            error information if retrieving the displayable string failed. 
- *                          Should not be NULL and should not indicate failure on entry.
- * @return the actual buffer size needed for the displayable variant code.  
- * @see #uloc_openKeywords
- * @stable ICU 2.8
- */
-U_STABLE int32_t U_EXPORT2
-uloc_getDisplayKeyword(const char* keyword,
-                       const char* displayLocale,
-                       UChar* dest,
-                       int32_t destCapacity,
-                       UErrorCode* status);
-/**
- * Gets the value of the keyword suitable for display for the specified locale.
- * E.g: for the locale string de_DE\@collation=PHONEBOOK, this API gets the display 
- * string for PHONEBOOK, in the display locale, when "collation" is specified as the keyword.
- *
- * @param locale            The locale to get the displayable variant code with. NULL may be used to specify the default.
- * @param keyword           The keyword for whose value should be used.
- * @param displayLocale     Specifies the locale to be used to display the name.  In other words,
- *                          if the locale's language code is "en", passing Locale::getFrench() for
- *                          inLocale would result in "Anglais", while passing Locale::getGerman()
- *                          for inLocale would result in "Englisch". NULL may be used to specify the default.
- * @param dest              the buffer to which the displayable keyword should be written.
- * @param destCapacity      The size of the buffer (number of UChars). If it is 0, then
- *                          dest may be NULL and the function will only return the length of the 
- *                          result without writing any of the result string (pre-flighting).
- * @param status            error information if retrieving the displayable string failed. 
- *                          Should not be NULL and must not indicate failure on entry.
- * @return the actual buffer size needed for the displayable variant code.  
- * @stable ICU 2.8
- */
-U_STABLE int32_t U_EXPORT2
-uloc_getDisplayKeywordValue(   const char* locale,
-                               const char* keyword,
-                               const char* displayLocale,
-                               UChar* dest,
-                               int32_t destCapacity,
-                               UErrorCode* status);
-/**
- * Gets the full name suitable for display for the specified locale.
- *
- * @param localeID the locale to get the displayable name with. NULL may be used to specify the default.
- * @param inLocaleID Specifies the locale to be used to display the name.  In other words,
- *                   if the locale's language code is "en", passing Locale::getFrench() for
- *                   inLocale would result in "Anglais", while passing Locale::getGerman()
- *                   for inLocale would result in "Englisch". NULL may be used to specify the default.
- * @param result the displayable name for localeID
- * @param maxResultSize the size of the name buffer to store the 
- * displayable full name with
- * @param err error information if retrieving the displayable name failed
- * @return the actual buffer size needed for the displayable name.  If it's greater 
- * than maxResultSize, the returned displayable name will be truncated.  
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2
-uloc_getDisplayName(const char* localeID,
-            const char* inLocaleID,
-            UChar* result,
-            int32_t maxResultSize,
-            UErrorCode* err);
-
-
-/**
- * Gets the specified locale from a list of all available locales.  
- * The return value is a pointer to an item of 
- * a locale name array.  Both this array and the pointers
- * it contains are owned by ICU and should not be deleted or written through
- * by the caller.  The locale name is terminated by a null pointer.
- * @param n the specific locale name index of the available locale list
- * @return a specified locale name of all available locales
- * @stable ICU 2.0
- */
-U_STABLE const char* U_EXPORT2
-uloc_getAvailable(int32_t n);
-
-/**
- * Gets the size of the all available locale list.
- *
- * @return the size of the locale list
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2 uloc_countAvailable(void);
-
-/**
- *
- * Gets a list of all available language codes defined in ISO 639.  This is a pointer
- * to an array of pointers to arrays of char.  All of these pointers are owned
- * by ICU-- do not delete them, and do not write through them.  The array is
- * terminated with a null pointer.
- * @return a list of all available language codes
- * @stable ICU 2.0
- */
-U_STABLE const char* const* U_EXPORT2
-uloc_getISOLanguages(void);
-
-/**
- *
- * Gets a list of all available 2-letter country codes defined in ISO 639.  This is a
- * pointer to an array of pointers to arrays of char.  All of these pointers are
- * owned by ICU-- do not delete them, and do not write through them.  The array is
- * terminated with a null pointer.
- * @return a list of all available country codes
- * @stable ICU 2.0
- */
-U_STABLE const char* const* U_EXPORT2
-uloc_getISOCountries(void);
-
-/**
- * Truncate the locale ID string to get the parent locale ID.
- * Copies the part of the string before the last underscore.
- * The parent locale ID will be an empty string if there is no
- * underscore, or if there is only one underscore at localeID[0].
- *
- * @param localeID Input locale ID string.
- * @param parent   Output string buffer for the parent locale ID.
- * @param parentCapacity Size of the output buffer.
- * @param err A UErrorCode value.
- * @return The length of the parent locale ID.
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2
-uloc_getParent(const char*    localeID,
-                 char* parent,
-                 int32_t parentCapacity,
-                 UErrorCode* err);
-
-
-
-
-/**
- * Gets the full name for the specified locale.
- * Note: This has the effect of 'canonicalizing' the string to
- * a certain extent. Upper and lower case are set as needed,
- * and if the components were in 'POSIX' format they are changed to
- * ICU format.  It does NOT map aliased names in any way.
- * See the top of this header file.
- * This API strips off the keyword part, so "de_DE\@collation=phonebook" 
- * will become "de_DE". 
- * This API supports preflighting.
- *
- * @param localeID the locale to get the full name with
- * @param name fill in buffer for the name without keywords.
- * @param nameCapacity capacity of the fill in buffer.
- * @param err error information if retrieving the full name failed
- * @return the actual buffer size needed for the full name.  If it's greater 
- * than nameCapacity, the returned full name will be truncated.  
- * @stable ICU 2.8
- */
-U_STABLE int32_t U_EXPORT2
-uloc_getBaseName(const char*    localeID,
-         char* name,
-         int32_t nameCapacity,
-         UErrorCode* err);
-
-/**
- * Gets an enumeration of keywords for the specified locale. Enumeration
- * must get disposed of by the client using uenum_close function.
- *
- * @param localeID the locale to get the variant code with
- * @param status error information if retrieving the keywords failed
- * @return enumeration of keywords or NULL if there are no keywords.
- * @stable ICU 2.8
- */
-U_STABLE UEnumeration* U_EXPORT2
-uloc_openKeywords(const char* localeID,
-                        UErrorCode* status);
-
-/**
- * Get the value for a keyword. Locale name does not need to be normalized.
- * 
- * @param localeID locale name containing the keyword ("de_DE@currency=EURO;collation=PHONEBOOK")
- * @param keywordName name of the keyword for which we want the value. Case insensitive.
- * @param buffer receiving buffer
- * @param bufferCapacity capacity of receiving buffer
- * @param status containing error code - buffer not big enough.
- * @return the length of keyword value
- * @stable ICU 2.8
- */
-U_STABLE int32_t U_EXPORT2
-uloc_getKeywordValue(const char* localeID,
-                     const char* keywordName,
-                     char* buffer, int32_t bufferCapacity,
-                     UErrorCode* status);
-
-
-/**
- * Set the value of the specified keyword.
- * NOTE: Unlike almost every other ICU function which takes a
- * buffer, this function will NOT truncate the output text. If a
- * BUFFER_OVERFLOW_ERROR is received, it means that the original
- * buffer is untouched. This is done to prevent incorrect or possibly
- * even malformed locales from being generated and used.
- * 
- * @param keywordName name of the keyword to be set. Case insensitive.
- * @param keywordValue value of the keyword to be set. If 0-length or
- *  NULL, will result in the keyword being removed. No error is given if 
- *  that keyword does not exist.
- * @param buffer input buffer containing locale to be modified.
- * @param bufferCapacity capacity of receiving buffer
- * @param status containing error code - buffer not big enough.
- * @return the length needed for the buffer
- * @see uloc_getKeywordValue
- * @stable ICU 3.2
- */
-U_STABLE int32_t U_EXPORT2
-uloc_setKeywordValue(const char* keywordName,
-                     const char* keywordValue,
-                     char* buffer, int32_t bufferCapacity,
-                     UErrorCode* status);
-
-/**
- * enums for the  return value for the character and line orientation
- * functions.
- * @draft ICU 4.0
- */
-typedef enum {
-  ULOC_LAYOUT_LTR   = 0,  /* left-to-right. */
-  ULOC_LAYOUT_RTL    = 1,  /* right-to-left. */
-  ULOC_LAYOUT_TTB    = 2,  /* top-to-bottom. */
-  ULOC_LAYOUT_BTT    = 3,   /* bottom-to-top. */
-  ULOC_LAYOUT_UNKNOWN
-} ULayoutType;
-
-/**
- * Get the layout character orientation for the specified locale.
- * 
- * @param localeId locale name
- * @param status Error status
- * @return an enum indicating the layout orientation for characters.
- * @draft ICU 4.0
- */
-U_DRAFT ULayoutType U_EXPORT2
-uloc_getCharacterOrientation(const char* localeId,
-                             UErrorCode *status);
-
-/**
- * Get the layout line orientation for the specified locale.
- * 
- * @param localeId locale name
- * @param status Error status
- * @return an enum indicating the layout orientation for lines.
- * @draft ICU 4.0
- */
-U_DRAFT ULayoutType U_EXPORT2
-uloc_getLineOrientation(const char* localeId,
-                        UErrorCode *status);
-
-/**
- * enums for the 'outResult' parameter return value
- * @see uloc_acceptLanguageFromHTTP
- * @see uloc_acceptLanguage
- * @stable ICU 3.2
- */
-typedef enum {
-  ULOC_ACCEPT_FAILED   = 0,  /* No exact match was found. */
-  ULOC_ACCEPT_VALID    = 1,  /* An exact match was found. */
-  ULOC_ACCEPT_FALLBACK = 2   /* A fallback was found, for example, 
-                                Accept list contained 'ja_JP'
-                                which matched available locale 'ja'. */
-} UAcceptResult;
-
-
-/**
- * Based on a HTTP header from a web browser and a list of available locales,
- * determine an acceptable locale for the user.
- * @param result - buffer to accept the result locale
- * @param resultAvailable the size of the result buffer.
- * @param outResult - An out parameter that contains the fallback status
- * @param httpAcceptLanguage - "Accept-Language:" header as per HTTP.
- * @param availableLocales - list of available locales to match
- * @param status Error status, may be BUFFER_OVERFLOW_ERROR
- * @return length needed for the locale.
- * @stable ICU 3.2
- */
-U_STABLE int32_t U_EXPORT2
-uloc_acceptLanguageFromHTTP(char *result, int32_t resultAvailable,
-                            UAcceptResult *outResult,
-                            const char *httpAcceptLanguage,
-                            UEnumeration* availableLocales,
-                            UErrorCode *status);
-
-/**
- * Based on a list of available locales,
- * determine an acceptable locale for the user.
- * @param result - buffer to accept the result locale
- * @param resultAvailable the size of the result buffer.
- * @param outResult - An out parameter that contains the fallback status
- * @param acceptList - list of acceptable languages
- * @param acceptListCount - count of acceptList items
- * @param availableLocales - list of available locales to match
- * @param status Error status, may be BUFFER_OVERFLOW_ERROR
- * @return length needed for the locale.
- * @stable ICU 3.2
- */
-U_STABLE int32_t U_EXPORT2
-uloc_acceptLanguage(char *result, int32_t resultAvailable, 
-                    UAcceptResult *outResult, const char **acceptList,
-                    int32_t acceptListCount,
-                    UEnumeration* availableLocales,
-                    UErrorCode *status);
-
-
-/**
- * Gets the ICU locale ID for the specified Win32 LCID value.
- *
- * @param hostID the Win32 LCID to translate
- * @param locale the output buffer for the ICU locale ID, which will be NUL-terminated
- *  if there is room.
- * @param localeCapacity the size of the output buffer
- * @param status an error is returned if the LCID is unrecognized or the output buffer
- *  is too small
- * @return actual the actual size of the locale ID, not including NUL-termination 
- * @stable ICU 4.0
- */
-U_DRAFT int32_t U_EXPORT2
-uloc_getLocaleForLCID(uint32_t hostID, char *locale, int32_t localeCapacity,
-                    UErrorCode *status);
-
-
-/**
- * Add the likely subtags for a provided locale ID, per the algorithm described
- * in the following CLDR technical report:
- *
- *   http://www.unicode.org/reports/tr35/#Likely_Subtags
- *
- * If localeID is already in the maximal form, or there is no data available
- * for maximization, it will be copied to the output buffer.  For example,
- * "und-Zzzz" cannot be maximized, since there is no reasonable maximization.
- *
- * Examples:
- *
- * "en" maximizes to "en_Latn_US"
- *
- * "de" maximizes to "de_Latn_US"
- *
- * "sr" maximizes to "sr_Cyrl_RS"
- *
- * "sh" maximizes to "sr_Latn_RS" (Note this will not reverse.)
- *
- * "zh_Hani" maximizes to "zh_Hans_CN" (Note this will not reverse.)
- *
- * @param localeID The locale to maximize
- * @param maximizedLocaleID The maximized locale
- * @param maximizedLocaleIDCapacity The capacity of the maximizedLocaleID buffer
- * @param err Error information if maximizing the locale failed.  If the length
- * of the localeID and the null-terminator is greater than the maximum allowed size,
- * or the localeId is not well-formed, the error code is U_ILLEGAL_ARGUMENT_ERROR.
- * @return The actual buffer size needed for the maximized locale.  If it's
- * greater than maximizedLocaleIDCapacity, the returned ID will be truncated.
- * On error, the return value is -1.
- * @draft ICU 4.0
- */
-U_DRAFT int32_t U_EXPORT2
-uloc_addLikelySubtags(const char*    localeID,
-         char* maximizedLocaleID,
-         int32_t maximizedLocaleIDCapacity,
-         UErrorCode* err);
-
-
-/**
- * Minimize the subtags for a provided locale ID, per the algorithm described
- * in the following CLDR technical report:
- *
- *   http://www.unicode.org/reports/tr35/#Likely_Subtags
- *
- * If localeID is already in the minimal form, or there is no data available
- * for minimization, it will be copied to the output buffer.  Since the
- * minimization algorithm relies on proper maximization, see the comments
- * for uloc_addLikelySubtags for reasons why there might not be any data.
- *
- * Examples:
- *
- * "en_Latn_US" minimizes to "en"
- *
- * "de_Latn_US" minimizes to "de"
- *
- * "sr_Cyrl_RS" minimizes to "sr"
- *
- * "zh_Hant_TW" minimizes to "zh_TW" (The region is preferred to the
- * script, and minimizing to "zh" would imply "zh_Hans_CN".)
- *
- * @param localeID The locale to minimize
- * @param minimizedLocaleID The minimized locale
- * @param minimizedLocaleIDCapacity The capacity of the minimizedLocaleID buffer
- * @param err Error information if minimizing the locale failed.  If the length
- * of the localeID and the null-terminator is greater than the maximum allowed size,
- * or the localeId is not well-formed, the error code is U_ILLEGAL_ARGUMENT_ERROR.
- * @return The actual buffer size needed for the minimized locale.  If it's
- * greater than minimizedLocaleIDCapacity, the returned ID will be truncated.
- * On error, the return value is -1.
- * @draft ICU 4.0
- */
-U_DRAFT int32_t U_EXPORT2
-uloc_minimizeSubtags(const char*    localeID,
-         char* minimizedLocaleID,
-         int32_t minimizedLocaleIDCapacity,
-         UErrorCode* err);
-
-#endif /*_ULOC*/

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/ulocdata.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/ulocdata.h b/apps/couch_collate/platform/osx/icu/unicode/ulocdata.h
deleted file mode 100644
index 4a69994..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/ulocdata.h
+++ /dev/null
@@ -1,192 +0,0 @@
-/*
-******************************************************************************
-*                                                                            *
-* Copyright (C) 2003-2007, International Business Machines                   *
-*                Corporation and others. All Rights Reserved.                *
-*                                                                            *
-******************************************************************************
-*   file name:  ulocdata.h
-*   encoding:   US-ASCII
-*   tab size:   8 (not used)
-*   indentation:4
-*
-*   created on: 2003Oct21
-*   created by: Ram Viswanadha
-*/
-
-#ifndef __ULOCDATA_H__
-#define __ULOCDATA_H__
-
-#include "unicode/ures.h"
-#include "unicode/uloc.h"
-#include "unicode/uset.h"
-
-/**
- * \file
- * \brief C API: Provides access to locale data. 
- */
-
-/** Forward declaration of the ULocaleData structure. @stable ICU 3.6 */
-struct ULocaleData;
-
-/** A locale data object. @stable ICU 3.6 */
-typedef struct ULocaleData ULocaleData;
-
-
-
-/** The possible types of exemplar character sets.
-  * @stable ICU 3.4
-  */
-typedef enum ULocaleDataExemplarSetType  {
-     ULOCDATA_ES_STANDARD=0,      /* Basic set */
-     ULOCDATA_ES_AUXILIARY=1,     /* Auxiliary set */
-     ULOCDATA_ES_COUNT=2
-} ULocaleDataExemplarSetType;
-
-/** The possible types of delimiters.
-  * @stable ICU 3.4
-  */
-typedef enum ULocaleDataDelimiterType {
-    ULOCDATA_QUOTATION_START = 0,     /* Quotation start */
-     ULOCDATA_QUOTATION_END = 1,       /* Quotation end */
-     ULOCDATA_ALT_QUOTATION_START = 2, /* Alternate quotation start */
-     ULOCDATA_ALT_QUOTATION_END = 3,   /* Alternate quotation end */
-     ULOCDATA_DELIMITER_COUNT = 4
-} ULocaleDataDelimiterType;
-
-/**
- * Opens a locale data object for the given locale
- *
- * @param localeID  Specifies the locale associated with this locale
- *                  data object.
- * @param status    Pointer to error status code.
- * @stable ICU 3.4
- */
-U_STABLE ULocaleData* U_EXPORT2 
-ulocdata_open(const char *localeID, UErrorCode *status);
-
-/**
- * Closes a locale data object.
- *
- * @param uld       The locale data object to close
- * @stable ICU 3.4
- */
-U_STABLE void U_EXPORT2 
-ulocdata_close(ULocaleData *uld);
-
-/**
- * Sets the "no Substitute" attribute of the locale data
- * object.  If true, then any methods associated with the
- * locale data object will return null when there is no
- * data available for that method, given the locale ID
- * supplied to ulocdata_open().
- *
- * @param uld       The locale data object to set.
- * @param setting   Value of the "no substitute" attribute.
- * @stable ICU 3.4
- */
-U_STABLE void U_EXPORT2 
-ulocdata_setNoSubstitute(ULocaleData *uld, UBool setting);
-
-/**
- * Retrieves the current "no Substitute" value of the locale data
- * object.  If true, then any methods associated with the
- * locale data object will return null when there is no
- * data available for that method, given the locale ID
- * supplied to ulocdata_open().
- *
- * @param uld       Pointer to the The locale data object to set.
- * @return UBool    Value of the "no substitute" attribute.
- * @stable ICU 3.4
- */
-U_STABLE UBool U_EXPORT2 
-ulocdata_getNoSubstitute(ULocaleData *uld);
-
-/**
- * Returns the set of exemplar characters for a locale.
- *
- * @param uld       Pointer to the locale data object from which the 
- *                  exemplar character set is to be retrieved.
- * @param fillIn    Pointer to a USet object to receive the 
- *                  exemplar character set for the given locale.  Previous
- *                  contents of fillIn are lost.  <em>If fillIn is NULL,
- *                  then a new USet is created and returned.  The caller
- *                  owns the result and must dispose of it by calling
- *                  uset_close.</em>
- * @param options   Bitmask for options to apply to the exemplar pattern.
- *                  Specify zero to retrieve the exemplar set as it is
- *                  defined in the locale data.  Specify
- *                  USET_CASE_INSENSITIVE to retrieve a case-folded
- *                  exemplar set.  See uset_applyPattern for a complete
- *                  list of valid options.  The USET_IGNORE_SPACE bit is
- *                  always set, regardless of the value of 'options'.
- * @param extype    Specifies the type of exemplar set to be retrieved.
- * @param status    Pointer to an input-output error code value;
- *                  must not be NULL.
- * @return USet*    Either fillIn, or if fillIn is NULL, a pointer to
- *                  a newly-allocated USet that the user must close.
- * @stable ICU 3.4
- */
-U_STABLE USet* U_EXPORT2 
-ulocdata_getExemplarSet(ULocaleData *uld, USet *fillIn, 
-                        uint32_t options, ULocaleDataExemplarSetType extype, UErrorCode *status);
-
-/**
- * Returns one of the delimiter strings associated with a locale.
- *
- * @param uld           Pointer to the locale data object from which the 
- *                      delimiter string is to be retrieved.
- * @param type          the type of delimiter to be retrieved.
- * @param result        A pointer to a buffer to receive the result.
- * @param resultLength  The maximum size of result.
- * @param status        Pointer to an error code value
- * @return int32_t      The total buffer size needed; if greater than resultLength,
- *                      the output was truncated.
- * @stable ICU 3.4
- */
-U_STABLE int32_t U_EXPORT2 
-ulocdata_getDelimiter(ULocaleData *uld, ULocaleDataDelimiterType type, UChar *result, int32_t resultLength, UErrorCode *status);
-
-/**
- * Enumeration for representing the measurement systems.
- * @stable ICU 2.8
- */
-typedef enum UMeasurementSystem {
-    UMS_SI,     /** Measurement system specified by SI otherwise known as Metric system. */
-    UMS_US,     /** Measurement system followed in the United States of America. */ 
-    UMS_LIMIT
-} UMeasurementSystem;
-
-/**
- * Returns the measurement system used in the locale specified by the localeID.
- * Please note that this API will change in ICU 3.6 and will use an ulocdata object.
- *
- * @param localeID      The id of the locale for which the measurement system to be retrieved.
- * @param status        Must be a valid pointer to an error code value,
- *                      which must not indicate a failure before the function call.
- * @return UMeasurementSystem the measurement system used in the locale.
- * @stable ICU 2.8
- */
-U_STABLE UMeasurementSystem U_EXPORT2
-ulocdata_getMeasurementSystem(const char *localeID, UErrorCode *status);
-
-/**
- * Returns the element gives the normal business letter size, and customary units. 
- * The units for the numbers are always in <em>milli-meters</em>.
- * For US since 8.5 and 11 do not yeild an integral value when converted to milli-meters,
- * the values are rounded off.
- * So for A4 size paper the height and width are 297 mm and 210 mm repectively, 
- * and for US letter size the height and width are 279 mm and 216 mm respectively.
- * Please note that this API will change in ICU 3.6 and will use an ulocdata object.
- *
- * @param localeID      The id of the locale for which the paper size information to be retrieved.
- * @param height        A pointer to int to recieve the height information.
- * @param width         A pointer to int to recieve the width information.
- * @param status        Must be a valid pointer to an error code value,
- *                      which must not indicate a failure before the function call.
- * @stable ICU 2.8
- */
-U_STABLE void U_EXPORT2
-ulocdata_getPaperSize(const char *localeID, int32_t *height, int32_t *width, UErrorCode *status);
-
-#endif

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/umachine.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/umachine.h b/apps/couch_collate/platform/osx/icu/unicode/umachine.h
deleted file mode 100644
index 083f9cf..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/umachine.h
+++ /dev/null
@@ -1,338 +0,0 @@
-/*
-******************************************************************************
-*
-*   Copyright (C) 1999-2006, International Business Machines
-*   Corporation and others.  All Rights Reserved.
-*
-******************************************************************************
-*   file name:  umachine.h
-*   encoding:   US-ASCII
-*   tab size:   8 (not used)
-*   indentation:4
-*
-*   created on: 1999sep13
-*   created by: Markus W. Scherer
-*
-*   This file defines basic types and constants for utf.h to be
-*   platform-independent. umachine.h and utf.h are included into
-*   utypes.h to provide all the general definitions for ICU.
-*   All of these definitions used to be in utypes.h before
-*   the UTF-handling macros made this unmaintainable.
-*/
-
-#ifndef __UMACHINE_H__
-#define __UMACHINE_H__
-
-
-/**
- * \file
- * \brief Basic types and constants for UTF 
- * 
- * <h2> Basic types and constants for UTF </h2>
- *   This file defines basic types and constants for utf.h to be
- *   platform-independent. umachine.h and utf.h are included into
- *   utypes.h to provide all the general definitions for ICU.
- *   All of these definitions used to be in utypes.h before
- *   the UTF-handling macros made this unmaintainable.
- * 
- */
-/*==========================================================================*/
-/* Include platform-dependent definitions                                   */
-/* which are contained in the platform-specific file platform.h             */
-/*==========================================================================*/
-
-#if defined(U_PALMOS)
-#   include "unicode/ppalmos.h"
-#elif defined(WIN32) || defined(_WIN32) || defined(WIN64) || defined(_WIN64)
-#   include "unicode/pwin32.h"
-#else
-#   include "unicode/platform.h"
-#endif
-
-/*
- * ANSI C headers:
- * stddef.h defines wchar_t
- */
-#include <stddef.h>
-
-/*==========================================================================*/
-/* XP_CPLUSPLUS is a cross-platform symbol which should be defined when     */
-/* using C++.  It should not be defined when compiling under C.             */
-/*==========================================================================*/
-
-#ifdef __cplusplus
-#   ifndef XP_CPLUSPLUS
-#       define XP_CPLUSPLUS
-#   endif
-#else
-#   undef XP_CPLUSPLUS
-#endif
-
-/*==========================================================================*/
-/* For C wrappers, we use the symbol U_STABLE.                                */
-/* This works properly if the includer is C or C++.                         */
-/* Functions are declared   U_STABLE return-type U_EXPORT2 function-name()... */
-/*==========================================================================*/
-
-/**
- * \def U_CFUNC
- * This is used in a declaration of a library private ICU C function.
- * @stable ICU 2.4
- */
-
-/**
- * \def U_CDECL_BEGIN
- * This is used to begin a declaration of a library private ICU C API.
- * @stable ICU 2.4
- */
-
-/**
- * \def U_CDECL_END
- * This is used to end a declaration of a library private ICU C API 
- * @stable ICU 2.4
- */
-
-#ifdef XP_CPLUSPLUS
-#   define U_CFUNC extern "C"
-#   define U_CDECL_BEGIN extern "C" {
-#   define U_CDECL_END   }
-#else
-#   define U_CFUNC extern
-#   define U_CDECL_BEGIN
-#   define U_CDECL_END
-#endif
-
-/** This is used to declare a function as a public ICU C API @stable ICU 2.0*/
-#define U_CAPI U_CFUNC U_EXPORT
-#define U_STABLE U_CAPI
-#define U_DRAFT  U_CAPI
-#define U_DEPRECATED U_CAPI
-#define U_OBSOLETE U_CAPI
-#define U_INTERNAL U_CAPI
-
-/*==========================================================================*/
-/* limits for int32_t etc., like in POSIX inttypes.h                        */
-/*==========================================================================*/
-
-#ifndef INT8_MIN
-/** The smallest value an 8 bit signed integer can hold @stable ICU 2.0 */
-#   define INT8_MIN        ((int8_t)(-128))
-#endif
-#ifndef INT16_MIN
-/** The smallest value a 16 bit signed integer can hold @stable ICU 2.0 */
-#   define INT16_MIN       ((int16_t)(-32767-1))
-#endif
-#ifndef INT32_MIN
-/** The smallest value a 32 bit signed integer can hold @stable ICU 2.0 */
-#   define INT32_MIN       ((int32_t)(-2147483647-1))
-#endif
-
-#ifndef INT8_MAX
-/** The largest value an 8 bit signed integer can hold @stable ICU 2.0 */
-#   define INT8_MAX        ((int8_t)(127))
-#endif
-#ifndef INT16_MAX
-/** The largest value a 16 bit signed integer can hold @stable ICU 2.0 */
-#   define INT16_MAX       ((int16_t)(32767))
-#endif
-#ifndef INT32_MAX
-/** The largest value a 32 bit signed integer can hold @stable ICU 2.0 */
-#   define INT32_MAX       ((int32_t)(2147483647))
-#endif
-
-#ifndef UINT8_MAX
-/** The largest value an 8 bit unsigned integer can hold @stable ICU 2.0 */
-#   define UINT8_MAX       ((uint8_t)(255U))
-#endif
-#ifndef UINT16_MAX
-/** The largest value a 16 bit unsigned integer can hold @stable ICU 2.0 */
-#   define UINT16_MAX      ((uint16_t)(65535U))
-#endif
-#ifndef UINT32_MAX
-/** The largest value a 32 bit unsigned integer can hold @stable ICU 2.0 */
-#   define UINT32_MAX      ((uint32_t)(4294967295U))
-#endif
-
-#if defined(U_INT64_T_UNAVAILABLE)
-# error int64_t is required for decimal format and rule-based number format.
-#else
-# ifndef INT64_C
-/**
- * Provides a platform independent way to specify a signed 64-bit integer constant.
- * note: may be wrong for some 64 bit platforms - ensure your compiler provides INT64_C
- * @stable ICU 2.8
- */
-#   define INT64_C(c) c ## LL
-# endif
-# ifndef UINT64_C
-/**
- * Provides a platform independent way to specify an unsigned 64-bit integer constant.
- * note: may be wrong for some 64 bit platforms - ensure your compiler provides UINT64_C
- * @stable ICU 2.8
- */
-#   define UINT64_C(c) c ## ULL
-# endif
-# ifndef U_INT64_MIN
-/** The smallest value a 64 bit signed integer can hold @stable ICU 2.8 */
-#     define U_INT64_MIN       ((int64_t)(INT64_C(-9223372036854775807)-1))
-# endif
-# ifndef U_INT64_MAX
-/** The largest value a 64 bit signed integer can hold @stable ICU 2.8 */
-#     define U_INT64_MAX       ((int64_t)(INT64_C(9223372036854775807)))
-# endif
-# ifndef U_UINT64_MAX
-/** The largest value a 64 bit unsigned integer can hold @stable ICU 2.8 */
-#     define U_UINT64_MAX      ((uint64_t)(UINT64_C(18446744073709551615)))
-# endif
-#endif
-
-/*==========================================================================*/
-/* Boolean data type                                                        */
-/*==========================================================================*/
-
-/** The ICU boolean type @stable ICU 2.0 */
-typedef int8_t UBool;
-
-#ifndef TRUE
-/** The TRUE value of a UBool @stable ICU 2.0 */
-#   define TRUE  1
-#endif
-#ifndef FALSE
-/** The FALSE value of a UBool @stable ICU 2.0 */
-#   define FALSE 0
-#endif
-
-
-/*==========================================================================*/
-/* Unicode data types                                                       */
-/*==========================================================================*/
-
-/* wchar_t-related definitions -------------------------------------------- */
-
-/**
- * \def U_HAVE_WCHAR_H
- * Indicates whether <wchar.h> is available (1) or not (0). Set to 1 by default.
- *
- * @stable ICU 2.0
- */
-#ifndef U_HAVE_WCHAR_H
-#   define U_HAVE_WCHAR_H 1
-#endif
-
-/**
- * \def U_SIZEOF_WCHAR_T
- * U_SIZEOF_WCHAR_T==sizeof(wchar_t) (0 means it is not defined or autoconf could not set it)
- *
- * @stable ICU 2.0
- */
-#if U_SIZEOF_WCHAR_T==0
-#   undef U_SIZEOF_WCHAR_T
-#   define U_SIZEOF_WCHAR_T 4
-#endif
-
-/*
- * \def U_WCHAR_IS_UTF16
- * Defined if wchar_t uses UTF-16.
- *
- * @stable ICU 2.0
- */
-/*
- * \def U_WCHAR_IS_UTF32
- * Defined if wchar_t uses UTF-32.
- *
- * @stable ICU 2.0
- */
-#if !defined(U_WCHAR_IS_UTF16) && !defined(U_WCHAR_IS_UTF32)
-#   ifdef __STDC_ISO_10646__ 
-#       if (U_SIZEOF_WCHAR_T==2)
-#           define U_WCHAR_IS_UTF16
-#       elif (U_SIZEOF_WCHAR_T==4)
-#           define  U_WCHAR_IS_UTF32
-#       endif
-#   elif defined __UCS2__
-#       if (__OS390__ || __OS400__) && (U_SIZEOF_WCHAR_T==2)
-#           define U_WCHAR_IS_UTF16
-#       endif
-#   elif defined __UCS4__
-#       if (U_SIZEOF_WCHAR_T==4)
-#           define U_WCHAR_IS_UTF32
-#       endif
-#   elif defined(U_WINDOWS)
-#       define U_WCHAR_IS_UTF16    
-#   endif
-#endif
-
-/* UChar and UChar32 definitions -------------------------------------------- */
-
-/** Number of bytes in a UChar. @stable ICU 2.0 */
-#define U_SIZEOF_UCHAR 2
-
-/**
- * \var UChar
- * Define UChar to be wchar_t if that is 16 bits wide; always assumed to be unsigned.
- * If wchar_t is not 16 bits wide, then define UChar to be uint16_t.
- * This makes the definition of UChar platform-dependent
- * but allows direct string type compatibility with platforms with
- * 16-bit wchar_t types.
- *
- * @stable ICU 2.0
- */
-
-/* Define UChar to be compatible with wchar_t if possible. */
-#if U_SIZEOF_WCHAR_T==2
-    typedef wchar_t UChar;
-#else
-    typedef uint16_t UChar;
-#endif
-
-/**
- * Define UChar32 as a type for single Unicode code points.
- * UChar32 is a signed 32-bit integer (same as int32_t).
- *
- * The Unicode code point range is 0..0x10ffff.
- * All other values (negative or >=0x110000) are illegal as Unicode code points.
- * They may be used as sentinel values to indicate "done", "error"
- * or similar non-code point conditions.
- *
- * Before ICU 2.4 (Jitterbug 2146), UChar32 was defined
- * to be wchar_t if that is 32 bits wide (wchar_t may be signed or unsigned)
- * or else to be uint32_t.
- * That is, the definition of UChar32 was platform-dependent.
- *
- * @see U_SENTINEL
- * @stable ICU 2.4
- */
-typedef int32_t UChar32;
-
-/*==========================================================================*/
-/* U_INLINE and U_ALIGN_CODE   Set default values if these are not already  */
-/*                             defined.  Definitions normally are in        */
-/*                             platform.h or the corresponding file for     */
-/*                             the OS in use.                               */
-/*==========================================================================*/
-
-#ifndef U_HIDE_INTERNAL_API
-
-/**
- * \def U_ALIGN_CODE
- * This is used to align code fragments to a specific byte boundary.
- * This is useful for getting consistent performance test results.
- * @internal
- */
-#ifndef U_ALIGN_CODE
-#   define U_ALIGN_CODE(n)
-#endif
-
-#endif /* U_HIDE_INTERNAL_API */
-
-#ifndef U_INLINE
-#   ifdef XP_CPLUSPLUS
-#       define U_INLINE inline
-#   else
-#       define U_INLINE
-#   endif
-#endif
-
-#include "unicode/urename.h"
-
-#endif

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/umisc.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/umisc.h b/apps/couch_collate/platform/osx/icu/unicode/umisc.h
deleted file mode 100644
index d85451f..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/umisc.h
+++ /dev/null
@@ -1,60 +0,0 @@
-/*
-**********************************************************************
-*   Copyright (C) 1999-2006, International Business Machines
-*   Corporation and others.  All Rights Reserved.
-**********************************************************************
-*   file name:  umisc.h
-*   encoding:   US-ASCII
-*   tab size:   8 (not used)
-*   indentation:4
-*
-*   created on: 1999oct15
-*   created by: Markus W. Scherer
-*/
-
-#ifndef UMISC_H
-#define UMISC_H
-
-#include "unicode/utypes.h"
-
-/**
- * \file
- * \brief  C API:misc definitions 
- *
- *  This file contains miscellaneous definitions for the C APIs. 
- */
-
-U_CDECL_BEGIN
-
-/** A struct representing a range of text containing a specific field 
- *  @stable ICU 2.0
- */
-typedef struct UFieldPosition {
-  /**
-   * The field 
-   * @stable ICU 2.0
-   */
-  int32_t field;
-  /**
-   * The start of the text range containing field 
-   * @stable ICU 2.0
-   */
-  int32_t beginIndex;
-  /** 
-   * The limit of the text range containing field 
-   * @stable ICU 2.0
-   */
-  int32_t endIndex;
-} UFieldPosition;
-
-#if !UCONFIG_NO_SERVICE
-/**
- * Opaque type returned by registerInstance, registerFactory and unregister for service registration.
- * @stable ICU 2.6
- */
-typedef const void* URegistryKey;
-#endif
-
-U_CDECL_END
-
-#endif


[25/57] [abbrv] remove couch_collate

Posted by be...@apache.org.
http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/timezone.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/timezone.h b/apps/couch_collate/platform/osx/icu/unicode/timezone.h
deleted file mode 100644
index 1b9118b..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/timezone.h
+++ /dev/null
@@ -1,803 +0,0 @@
-/*************************************************************************
-* Copyright (c) 1997-2008, International Business Machines Corporation
-* and others. All Rights Reserved.
-**************************************************************************
-*
-* File TIMEZONE.H
-*
-* Modification History:
-*
-*   Date        Name        Description
-*   04/21/97    aliu        Overhauled header.
-*   07/09/97    helena      Changed createInstance to createDefault.
-*   08/06/97    aliu        Removed dependency on internal header for Hashtable.
-*   08/10/98    stephen        Changed getDisplayName() API conventions to match
-*   08/19/98    stephen        Changed createTimeZone() to never return 0
-*   09/02/98    stephen        Sync to JDK 1.2 8/31
-*                            - Added getOffset(... monthlen ...)
-*                            - Added hasSameRules()
-*   09/15/98    stephen        Added getStaticClassID
-*   12/03/99    aliu        Moved data out of static table into icudata.dll.
-*                           Hashtable replaced by new static data structures.
-*   12/14/99    aliu        Made GMT public.
-*   08/15/01    grhoten     Made GMT private and added the getGMT() function
-**************************************************************************
-*/
-
-#ifndef TIMEZONE_H
-#define TIMEZONE_H
-
-#include "unicode/utypes.h"
-
-/**
- * \file 
- * \brief C++ API: TimeZone object
- */
-
-#if !UCONFIG_NO_FORMATTING
-
-#include "unicode/uobject.h"
-#include "unicode/unistr.h"
-#include "unicode/ures.h"
-
-U_NAMESPACE_BEGIN
-
-class StringEnumeration;
-
-/**
- *
- * <code>TimeZone</code> represents a time zone offset, and also figures out daylight
- * savings.
- *
- * <p>
- * Typically, you get a <code>TimeZone</code> using <code>createDefault</code>
- * which creates a <code>TimeZone</code> based on the time zone where the program
- * is running. For example, for a program running in Japan, <code>createDefault</code>
- * creates a <code>TimeZone</code> object based on Japanese Standard Time.
- *
- * <p>
- * You can also get a <code>TimeZone</code> using <code>createTimeZone</code> along
- * with a time zone ID. For instance, the time zone ID for the Pacific
- * Standard Time zone is "PST". So, you can get a PST <code>TimeZone</code> object
- * with:
- * \htmlonly<blockquote>\endhtmlonly
- * <pre>
- * TimeZone *tz = TimeZone::createTimeZone("PST");
- * </pre>
- * \htmlonly</blockquote>\endhtmlonly
- * You can use <code>getAvailableIDs</code> method to iterate through
- * all the supported time zone IDs. You can then choose a
- * supported ID to get a <code>TimeZone</code>.
- * If the time zone you want is not represented by one of the
- * supported IDs, then you can create a custom time zone ID with
- * the following syntax:
- *
- * \htmlonly<blockquote>\endhtmlonly
- * <pre>
- * GMT[+|-]hh[[:]mm]
- * </pre>
- * \htmlonly</blockquote>\endhtmlonly
- *
- * For example, you might specify GMT+14:00 as a custom
- * time zone ID.  The <code>TimeZone</code> that is returned
- * when you specify a custom time zone ID does not include
- * daylight savings time.
- *
- * TimeZone is an abstract class representing a time zone.  A TimeZone is needed for
- * Calendar to produce local time for a particular time zone.  A TimeZone comprises
- * three basic pieces of information:
- * <ul>
- *    <li>A time zone offset; that, is the number of milliseconds to add or subtract
- *      from a time expressed in terms of GMT to convert it to the same time in that
- *      time zone (without taking daylight savings time into account).</li>
- *    <li>Logic necessary to take daylight savings time into account if daylight savings
- *      time is observed in that time zone (e.g., the days and hours on which daylight
- *      savings time begins and ends).</li>
- *    <li>An ID.  This is a text string that uniquely identifies the time zone.</li>
- * </ul>
- *
- * (Only the ID is actually implemented in TimeZone; subclasses of TimeZone may handle
- * daylight savings time and GMT offset in different ways.  Currently we only have one
- * TimeZone subclass: SimpleTimeZone.)
- * <P>
- * The TimeZone class contains a static list containing a TimeZone object for every
- * combination of GMT offset and daylight-savings time rules currently in use in the
- * world, each with a unique ID.  Each ID consists of a region (usually a continent or
- * ocean) and a city in that region, separated by a slash, (for example, Pacific
- * Standard Time is "America/Los_Angeles.")  Because older versions of this class used
- * three- or four-letter abbreviations instead, there is also a table that maps the older
- * abbreviations to the newer ones (for example, "PST" maps to "America/LosAngeles").
- * Anywhere the API requires an ID, you can use either form.
- * <P>
- * To create a new TimeZone, you call the factory function TimeZone::createTimeZone()
- * and pass it a time zone ID.  You can use the createEnumeration() function to
- * obtain a list of all the time zone IDs recognized by createTimeZone().
- * <P>
- * You can also use TimeZone::createDefault() to create a TimeZone.  This function uses
- * platform-specific APIs to produce a TimeZone for the time zone corresponding to
- * the client's computer's physical location.  For example, if you're in Japan (assuming
- * your machine is set up correctly), TimeZone::createDefault() will return a TimeZone
- * for Japanese Standard Time ("Asia/Tokyo").
- */
-class U_I18N_API TimeZone : public UObject {
-public:
-    /**
-     * @stable ICU 2.0
-     */
-    virtual ~TimeZone();
-
-    /**
-     * The GMT time zone has a raw offset of zero and does not use daylight
-     * savings time. This is a commonly used time zone.
-     * @return the GMT time zone.
-     * @stable ICU 2.0
-     */
-    static const TimeZone* U_EXPORT2 getGMT(void);
-
-    /**
-     * Creates a <code>TimeZone</code> for the given ID.
-     * @param ID the ID for a <code>TimeZone</code>, either an abbreviation such as
-     * "PST", a full name such as "America/Los_Angeles", or a custom ID
-     * such as "GMT-8:00".
-     * @return the specified <code>TimeZone</code>, or the GMT zone if the given ID
-     * cannot be understood.  Return result guaranteed to be non-null.  If you
-     * require that the specific zone asked for be returned, check the ID of the
-     * return result.
-     * @stable ICU 2.0
-     */
-    static TimeZone* U_EXPORT2 createTimeZone(const UnicodeString& ID);
-
-    /**
-     * Returns an enumeration over all recognized time zone IDs. (i.e.,
-     * all strings that createTimeZone() accepts)
-     *
-     * @return an enumeration object, owned by the caller.
-     * @stable ICU 2.4
-     */
-    static StringEnumeration* U_EXPORT2 createEnumeration();
-
-    /**
-     * Returns an enumeration over time zone IDs with a given raw
-     * offset from GMT.  There may be several times zones with the
-     * same GMT offset that differ in the way they handle daylight
-     * savings time.  For example, the state of Arizona doesn't
-     * observe daylight savings time.  If you ask for the time zone
-     * IDs corresponding to GMT-7:00, you'll get back an enumeration
-     * over two time zone IDs: "America/Denver," which corresponds to
-     * Mountain Standard Time in the winter and Mountain Daylight Time
-     * in the summer, and "America/Phoenix", which corresponds to
-     * Mountain Standard Time year-round, even in the summer.
-     *
-     * @param rawOffset an offset from GMT in milliseconds, ignoring
-     * the effect of daylight savings time, if any
-     * @return an enumeration object, owned by the caller
-     * @stable ICU 2.4
-     */
-    static StringEnumeration* U_EXPORT2 createEnumeration(int32_t rawOffset);
-
-    /**
-     * Returns an enumeration over time zone IDs associated with the
-     * given country.  Some zones are affiliated with no country
-     * (e.g., "UTC"); these may also be retrieved, as a group.
-     *
-     * @param country The ISO 3166 two-letter country code, or NULL to
-     * retrieve zones not affiliated with any country.
-     * @return an enumeration object, owned by the caller
-     * @stable ICU 2.4
-     */
-    static StringEnumeration* U_EXPORT2 createEnumeration(const char* country);
-
-#ifdef U_USE_TIMEZONE_OBSOLETE_2_8
-    /**
-     * Returns a list of time zone IDs, one for each time zone with a given GMT offset.
-     * The return value is a list because there may be several times zones with the same
-     * GMT offset that differ in the way they handle daylight savings time.  For example,
-     * the state of Arizona doesn't observe Daylight Savings time.  So if you ask for
-     * the time zone IDs corresponding to GMT-7:00, you'll get back two time zone IDs:
-     * "America/Denver," which corresponds to Mountain Standard Time in the winter and
-     * Mountain Daylight Time in the summer, and "America/Phoenix", which corresponds to
-     * Mountain Standard Time year-round, even in the summer.
-     * <P>
-     * The caller owns the list that is returned, but does not own the strings contained
-     * in that list.  Delete the array with uprv_free(), but DON'T delete the elements in the array.
-     *
-     * <p>NOTE: uprv_free() is declared in the private header source/common/cmemory.h.
-     *
-     * @param rawOffset  An offset from GMT in milliseconds.
-     * @param numIDs     Receives the number of items in the array that is returned.
-     * @return           An array of UnicodeString pointers, where each UnicodeString is
-     *                   a time zone ID for a time zone with the given GMT offset.  If
-     *                   there is no timezone that matches the GMT offset
-     *                   specified, NULL is returned.
-     * @obsolete ICU 2.8.  Use createEnumeration(int32_t) instead since this API will be removed in that release.
-     */
-    static const UnicodeString** createAvailableIDs(int32_t rawOffset, int32_t& numIDs);
-
-    /**
-     * Returns a list of time zone IDs associated with the given
-     * country.  Some zones are affiliated with no country (e.g.,
-     * "UTC"); these may also be retrieved, as a group.
-     *
-     * <P>The caller owns the list that is returned, but does not own
-     * the strings contained in that list.  Delete the array with uprv_free(), but
-     * <b>DON'T</b> delete the elements in the array.
-     *
-     * <p>NOTE: uprv_free() is declared in the private header source/common/cmemory.h.
-     *
-     * @param country The ISO 3166 two-letter country code, or NULL to
-     * retrieve zones not affiliated with any country.
-     * @param numIDs Receives the number of items in the array that is
-     * returned.
-     * @return An array of UnicodeString pointers, where each
-     * UnicodeString is a time zone ID for a time zone with the given
-     * country.  If there is no timezone that matches the country
-     * specified, NULL is returned.
-     * @obsolete ICU 2.8.  Use createEnumeration(const char*) instead since this API will be removed in that release.
-     */
-    static const UnicodeString** createAvailableIDs(const char* country,
-                                                          int32_t& numIDs);
-
-    /**
-     * Returns a list of all time zone IDs supported by the TimeZone class (i.e., all
-     * IDs that it's legal to pass to createTimeZone()).  The caller owns the list that
-     * is returned, but does not own the strings contained in that list.  Delete the array with uprv_free(),
-     * but DON'T delete the elements in the array.
-     *
-     * <p>NOTE: uprv_free() is declared in the private header source/common/cmemory.h.
-     *
-     * @param numIDs  Receives the number of zone IDs returned.
-     * @return        An array of UnicodeString pointers, where each is a time zone ID
-     *                supported by the TimeZone class.
-     * @obsolete ICU 2.8.  Use createEnumeration(void) instead since this API will be removed in that release.
-     */
-    static const UnicodeString** createAvailableIDs(int32_t& numIDs);
-#endif
-
-    /**
-     * Returns the number of IDs in the equivalency group that
-     * includes the given ID.  An equivalency group contains zones
-     * that have the same GMT offset and rules.
-     *
-     * <p>The returned count includes the given ID; it is always >= 1.
-     * The given ID must be a system time zone.  If it is not, returns
-     * zero.
-     * @param id a system time zone ID
-     * @return the number of zones in the equivalency group containing
-     * 'id', or zero if 'id' is not a valid system ID
-     * @see #getEquivalentID
-     * @stable ICU 2.0
-     */
-    static int32_t U_EXPORT2 countEquivalentIDs(const UnicodeString& id);
-
-    /**
-     * Returns an ID in the equivalency group that
-     * includes the given ID.  An equivalency group contains zones
-     * that have the same GMT offset and rules.
-     *
-     * <p>The given index must be in the range 0..n-1, where n is the
-     * value returned by <code>countEquivalentIDs(id)</code>.  For
-     * some value of 'index', the returned value will be equal to the
-     * given id.  If the given id is not a valid system time zone, or
-     * if 'index' is out of range, then returns an empty string.
-     * @param id a system time zone ID
-     * @param index a value from 0 to n-1, where n is the value
-     * returned by <code>countEquivalentIDs(id)</code>
-     * @return the ID of the index-th zone in the equivalency group
-     * containing 'id', or an empty string if 'id' is not a valid
-     * system ID or 'index' is out of range
-     * @see #countEquivalentIDs
-     * @stable ICU 2.0
-     */
-    static const UnicodeString U_EXPORT2 getEquivalentID(const UnicodeString& id,
-                                               int32_t index);
-
-    /**
-     * Creates a new copy of the default TimeZone for this host. Unless the default time
-     * zone has already been set using adoptDefault() or setDefault(), the default is
-     * determined by querying the system using methods in TPlatformUtilities. If the
-     * system routines fail, or if they specify a TimeZone or TimeZone offset which is not
-     * recognized, the TimeZone indicated by the ID kLastResortID is instantiated
-     * and made the default.
-     *
-     * @return   A default TimeZone. Clients are responsible for deleting the time zone
-     *           object returned.
-     * @stable ICU 2.0
-     */
-    static TimeZone* U_EXPORT2 createDefault(void);
-
-    /**
-     * Sets the default time zone (i.e., what's returned by createDefault()) to be the
-     * specified time zone.  If NULL is specified for the time zone, the default time
-     * zone is set to the default host time zone.  This call adopts the TimeZone object
-     * passed in; the clent is no longer responsible for deleting it.
-     *
-     * @param zone  A pointer to the new TimeZone object to use as the default.
-     * @stable ICU 2.0
-     */
-    static void U_EXPORT2 adoptDefault(TimeZone* zone);
-
-    /**
-     * Same as adoptDefault(), except that the TimeZone object passed in is NOT adopted;
-     * the caller remains responsible for deleting it.
-     *
-     * @param zone  The given timezone.
-     * @system
-     */
-    static void U_EXPORT2 setDefault(const TimeZone& zone);
-
-    /**
-     * Returns the timezone data version currently used by ICU.
-     * @param status Output param to filled in with a success or an error.
-     * @return the version string, such as "2007f"
-     * @stable ICU 4.0
-     */
-    static const char* U_EXPORT2 getTZDataVersion(UErrorCode& status);
-
-    /**
-     * Returns the canonical system timezone ID or the normalized
-     * custom time zone ID for the given time zone ID.
-     * @param id            The input timezone ID to be canonicalized.
-     * @param canonicalID   Receives the canonical system timezone ID
-     *                      or the custom timezone ID in normalized format.
-     * @param status        Recevies the status.  When the given timezone ID
-     *                      is neither a known system time zone ID nor a
-     *                      valid custom timezone ID, U_ILLEGAL_ARGUMENT_ERROR
-     *                      is set.
-     * @return A reference to the result.
-     * @draft ICU 4.0
-     */
-    static UnicodeString& U_EXPORT2 getCanonicalID(const UnicodeString& id,
-        UnicodeString& canonicalID, UErrorCode& status);
-
-    /**
-     * Returns the canonical system timezone ID or the normalized
-     * custom time zone ID for the given time zone ID.
-     * @param id            The input timezone ID to be canonicalized.
-     * @param canonicalID   Receives the canonical system timezone ID
-     *                      or the custom timezone ID in normalized format.
-     * @param isSystemID    Receives if the given ID is a known system
-     *                      timezone ID.
-     * @param status        Recevies the status.  When the given timezone ID
-     *                      is neither a known system time zone ID nor a
-     *                      valid custom timezone ID, U_ILLEGAL_ARGUMENT_ERROR
-     *                      is set.
-     * @return A reference to the result.
-     * @draft ICU 4.0
-     */
-    static UnicodeString& U_EXPORT2 getCanonicalID(const UnicodeString& id,
-        UnicodeString& canonicalID, UBool& isSystemID, UErrorCode& status);
-
-    /**
-     * Returns true if the two TimeZones are equal.  (The TimeZone version only compares
-     * IDs, but subclasses are expected to also compare the fields they add.)
-     *
-     * @param that  The TimeZone object to be compared with.
-     * @return      True if the given TimeZone is equal to this TimeZone; false
-     *              otherwise.
-     * @stable ICU 2.0
-     */
-    virtual UBool operator==(const TimeZone& that) const;
-
-    /**
-     * Returns true if the two TimeZones are NOT equal; that is, if operator==() returns
-     * false.
-     *
-     * @param that  The TimeZone object to be compared with.
-     * @return      True if the given TimeZone is not equal to this TimeZone; false
-     *              otherwise.
-     * @stable ICU 2.0
-     */
-    UBool operator!=(const TimeZone& that) const {return !operator==(that);}
-
-    /**
-     * Returns the TimeZone's adjusted GMT offset (i.e., the number of milliseconds to add
-     * to GMT to get local time in this time zone, taking daylight savings time into
-     * account) as of a particular reference date.  The reference date is used to determine
-     * whether daylight savings time is in effect and needs to be figured into the offset
-     * that is returned (in other words, what is the adjusted GMT offset in this time zone
-     * at this particular date and time?).  For the time zones produced by createTimeZone(),
-     * the reference data is specified according to the Gregorian calendar, and the date
-     * and time fields are local standard time.
-     *
-     * <p>Note: Don't call this method. Instead, call the getOffset(UDate...) overload,
-     * which returns both the raw and the DST offset for a given time. This method
-     * is retained only for backward compatibility.
-     *
-     * @param era        The reference date's era
-     * @param year       The reference date's year
-     * @param month      The reference date's month (0-based; 0 is January)
-     * @param day        The reference date's day-in-month (1-based)
-     * @param dayOfWeek  The reference date's day-of-week (1-based; 1 is Sunday)
-     * @param millis     The reference date's milliseconds in day, local standard time
-     * @param status     Output param to filled in with a success or an error.
-     * @return           The offset in milliseconds to add to GMT to get local time.
-     * @stable ICU 2.0
-     */
-    virtual int32_t getOffset(uint8_t era, int32_t year, int32_t month, int32_t day,
-                              uint8_t dayOfWeek, int32_t millis, UErrorCode& status) const = 0;
-
-    /**
-     * Gets the time zone offset, for current date, modified in case of
-     * daylight savings. This is the offset to add *to* UTC to get local time.
-     *
-     * <p>Note: Don't call this method. Instead, call the getOffset(UDate...) overload,
-     * which returns both the raw and the DST offset for a given time. This method
-     * is retained only for backward compatibility.
-     *
-     * @param era the era of the given date.
-     * @param year the year in the given date.
-     * @param month the month in the given date.
-     * Month is 0-based. e.g., 0 for January.
-     * @param day the day-in-month of the given date.
-     * @param dayOfWeek the day-of-week of the given date.
-     * @param milliseconds the millis in day in <em>standard</em> local time.
-     * @param monthLength the length of the given month in days.
-     * @param status     Output param to filled in with a success or an error.
-     * @return the offset to add *to* GMT to get local time.
-     * @stable ICU 2.0
-     */
-    virtual int32_t getOffset(uint8_t era, int32_t year, int32_t month, int32_t day,
-                           uint8_t dayOfWeek, int32_t milliseconds,
-                           int32_t monthLength, UErrorCode& status) const = 0;
-
-    /**
-     * Returns the time zone raw and GMT offset for the given moment
-     * in time.  Upon return, local-millis = GMT-millis + rawOffset +
-     * dstOffset.  All computations are performed in the proleptic
-     * Gregorian calendar.  The default implementation in the TimeZone
-     * class delegates to the 8-argument getOffset().
-     *
-     * @param date moment in time for which to return offsets, in
-     * units of milliseconds from January 1, 1970 0:00 GMT, either GMT
-     * time or local wall time, depending on `local'.
-     * @param local if true, `date' is local wall time; otherwise it
-     * is in GMT time.
-     * @param rawOffset output parameter to receive the raw offset, that
-     * is, the offset not including DST adjustments
-     * @param dstOffset output parameter to receive the DST offset,
-     * that is, the offset to be added to `rawOffset' to obtain the
-     * total offset between local and GMT time. If DST is not in
-     * effect, this value is zero; otherwise it is a positive value,
-     * typically one hour.
-     * @param ec input-output error code
-     *
-     * @stable ICU 2.8
-     */
-    virtual void getOffset(UDate date, UBool local, int32_t& rawOffset,
-                           int32_t& dstOffset, UErrorCode& ec) const;
-
-    /**
-     * Sets the TimeZone's raw GMT offset (i.e., the number of milliseconds to add
-     * to GMT to get local time, before taking daylight savings time into account).
-     *
-     * @param offsetMillis  The new raw GMT offset for this time zone.
-     * @stable ICU 2.0
-     */
-    virtual void setRawOffset(int32_t offsetMillis) = 0;
-
-    /**
-     * Returns the TimeZone's raw GMT offset (i.e., the number of milliseconds to add
-     * to GMT to get local time, before taking daylight savings time into account).
-     *
-     * @return   The TimeZone's raw GMT offset.
-     * @stable ICU 2.0
-     */
-    virtual int32_t getRawOffset(void) const = 0;
-
-    /**
-     * Fills in "ID" with the TimeZone's ID.
-     *
-     * @param ID  Receives this TimeZone's ID.
-     * @return    A reference to 'ID'
-     * @stable ICU 2.0
-     */
-    UnicodeString& getID(UnicodeString& ID) const;
-
-    /**
-     * Sets the TimeZone's ID to the specified value.  This doesn't affect any other
-     * fields (for example, if you say<
-     * blockquote><pre>
-     * .     TimeZone* foo = TimeZone::createTimeZone("America/New_York");
-     * .     foo.setID("America/Los_Angeles");
-     * </pre>\htmlonly</blockquote>\endhtmlonly
-     * the time zone's GMT offset and daylight-savings rules don't change to those for
-     * Los Angeles.  They're still those for New York.  Only the ID has changed.)
-     *
-     * @param ID  The new timezone ID.
-     * @stable ICU 2.0
-     */
-    void setID(const UnicodeString& ID);
-
-    /**
-     * Enum for use with getDisplayName
-     * @stable ICU 2.4
-     */
-    enum EDisplayType {
-        /**
-         * Selector for short display name
-         * @stable ICU 2.4
-         */
-        SHORT = 1,
-        /**
-         * Selector for long display name
-         * @stable ICU 2.4
-         */
-        LONG
-    };
-
-    /**
-     * Returns a name of this time zone suitable for presentation to the user
-     * in the default locale.
-     * This method returns the long name, not including daylight savings.
-     * If the display name is not available for the locale,
-     * then this method returns a string in the format
-     * <code>GMT[+-]hh:mm</code>.
-     * @param result the human-readable name of this time zone in the default locale.
-     * @return       A reference to 'result'.
-     * @stable ICU 2.0
-     */
-    UnicodeString& getDisplayName(UnicodeString& result) const;
-
-    /**
-     * Returns a name of this time zone suitable for presentation to the user
-     * in the specified locale.
-     * This method returns the long name, not including daylight savings.
-     * If the display name is not available for the locale,
-     * then this method returns a string in the format
-     * <code>GMT[+-]hh:mm</code>.
-     * @param locale the locale in which to supply the display name.
-     * @param result the human-readable name of this time zone in the given locale
-     *               or in the default locale if the given locale is not recognized.
-     * @return       A reference to 'result'.
-     * @stable ICU 2.0
-     */
-    UnicodeString& getDisplayName(const Locale& locale, UnicodeString& result) const;
-
-    /**
-     * Returns a name of this time zone suitable for presentation to the user
-     * in the default locale.
-     * If the display name is not available for the locale,
-     * then this method returns a string in the format
-     * <code>GMT[+-]hh:mm</code>.
-     * @param daylight if true, return the daylight savings name.
-     * @param style either <code>LONG</code> or <code>SHORT</code>
-     * @param result the human-readable name of this time zone in the default locale.
-     * @return       A reference to 'result'.
-     * @stable ICU 2.0
-     */
-    UnicodeString& getDisplayName(UBool daylight, EDisplayType style, UnicodeString& result) const;
-
-    /**
-     * Returns a name of this time zone suitable for presentation to the user
-     * in the specified locale.
-     * If the display name is not available for the locale,
-     * then this method returns a string in the format
-     * <code>GMT[+-]hh:mm</code>.
-     * @param daylight if true, return the daylight savings name.
-     * @param style either <code>LONG</code> or <code>SHORT</code>
-     * @param locale the locale in which to supply the display name.
-     * @param result the human-readable name of this time zone in the given locale
-     *               or in the default locale if the given locale is not recognized.
-     * @return       A refence to 'result'.
-     * @stable ICU 2.0
-     */
-    UnicodeString& getDisplayName(UBool daylight, EDisplayType style, const Locale& locale, UnicodeString& result) const;
-
-    /**
-     * Queries if this time zone uses daylight savings time.
-     * @return true if this time zone uses daylight savings time,
-     * false, otherwise.
-     * @stable ICU 2.0
-     */
-    virtual UBool useDaylightTime(void) const = 0;
-
-    /**
-     * Queries if the given date is in daylight savings time in
-     * this time zone.
-     * This method is wasteful since it creates a new GregorianCalendar and
-     * deletes it each time it is called. This is a deprecated method
-     * and provided only for Java compatibility.
-     *
-     * @param date the given UDate.
-     * @param status Output param filled in with success/error code.
-     * @return true if the given date is in daylight savings time,
-     * false, otherwise.
-     * @deprecated ICU 2.4. Use Calendar::inDaylightTime() instead.
-     */
-    virtual UBool inDaylightTime(UDate date, UErrorCode& status) const = 0;
-
-    /**
-     * Returns true if this zone has the same rule and offset as another zone.
-     * That is, if this zone differs only in ID, if at all.
-     * @param other the <code>TimeZone</code> object to be compared with
-     * @return true if the given zone is the same as this one,
-     * with the possible exception of the ID
-     * @stable ICU 2.0
-     */
-    virtual UBool hasSameRules(const TimeZone& other) const;
-
-    /**
-     * Clones TimeZone objects polymorphically. Clients are responsible for deleting
-     * the TimeZone object cloned.
-     *
-     * @return   A new copy of this TimeZone object.
-     * @stable ICU 2.0
-     */
-    virtual TimeZone* clone(void) const = 0;
-
-    /**
-     * Return the class ID for this class.  This is useful only for
-     * comparing to a return value from getDynamicClassID().
-     * @return The class ID for all objects of this class.
-     * @stable ICU 2.0
-     */
-    static UClassID U_EXPORT2 getStaticClassID(void);
-
-    /**
-     * Returns a unique class ID POLYMORPHICALLY. This method is to
-     * implement a simple version of RTTI, since not all C++ compilers support genuine
-     * RTTI. Polymorphic operator==() and clone() methods call this method.
-     * <P>
-     * Concrete subclasses of TimeZone must use the UOBJECT_DEFINE_RTTI_IMPLEMENTATION
-     *  macro from uobject.h in their implementation to provide correct RTTI information.
-     * @return   The class ID for this object. All objects of a given class have the
-     *           same class ID. Objects of other classes have different class IDs.
-     * @stable ICU 2.0
-     */
-    virtual UClassID getDynamicClassID(void) const = 0;
-    
-    /**
-     * Returns the amount of time to be added to local standard time
-     * to get local wall clock time.
-     * <p>
-     * The default implementation always returns 3600000 milliseconds
-     * (i.e., one hour) if this time zone observes Daylight Saving
-     * Time. Otherwise, 0 (zero) is returned.
-     * <p>
-     * If an underlying TimeZone implementation subclass supports
-     * historical Daylight Saving Time changes, this method returns
-     * the known latest daylight saving value.
-     *
-     * @return the amount of saving time in milliseconds
-     * @stable ICU 3.6
-     */
-    virtual int32_t getDSTSavings() const;
-
-protected:
-
-    /**
-     * Default constructor.  ID is initialized to the empty string.
-     * @stable ICU 2.0
-     */
-    TimeZone();
-
-    /**
-     * Construct a timezone with a given ID.
-     * @param id a system time zone ID
-     * @stable ICU 2.0
-     */
-    TimeZone(const UnicodeString &id);
-
-    /**
-     * Copy constructor.
-     * @param source the object to be copied.
-     * @stable ICU 2.0
-     */
-    TimeZone(const TimeZone& source);
-
-    /**
-     * Default assignment operator.
-     * @param right the object to be copied.
-     * @stable ICU 2.0
-     */
-    TimeZone& operator=(const TimeZone& right);
-
-    /**
-     * Utility function. For internally loading rule data.
-     * @param top Top resource bundle for tz data
-     * @param ruleid ID of rule to load
-     * @param oldbundle Old bundle to reuse or NULL
-     * @param status Status parameter
-     * @return either a new bundle or *oldbundle
-     * @internal
-     */
-    static UResourceBundle* loadRule(const UResourceBundle* top, const UnicodeString& ruleid, UResourceBundle* oldbundle, UErrorCode&status);
-
-private:
-    friend class ZoneMeta;
-
-
-    static TimeZone*        createCustomTimeZone(const UnicodeString&); // Creates a time zone based on the string.
-
-    /**
-     * Resolve a link in Olson tzdata.  When the given id is known and it's not a link,
-     * the id itself is returned.  When the given id is known and it is a link, then
-     * dereferenced zone id is returned.  When the given id is unknown, then it returns
-     * empty string.
-     * @param linkTo Input zone id string
-     * @param linkFrom Receives the dereferenced zone id string
-     * @return The reference to the result (linkFrom)
-     */
-    static UnicodeString& dereferOlsonLink(const UnicodeString& linkTo, UnicodeString& linkFrom);
-
-    /**
-     * Parses the given custom time zone identifier
-     * @param id id A string of the form GMT[+-]hh:mm, GMT[+-]hhmm, or
-     * GMT[+-]hh.
-     * @param sign Receves parsed sign, 1 for positive, -1 for negative.
-     * @param hour Receives parsed hour field
-     * @param minute Receives parsed minute field
-     * @param second Receives parsed second field
-     * @return Returns TRUE when the given custom id is valid.
-     */
-    static UBool parseCustomID(const UnicodeString& id, int32_t& sign, int32_t& hour,
-        int32_t& min, int32_t& sec);
-
-    /**
-     * Parse a custom time zone identifier and return the normalized
-     * custom time zone identifier for the given custom id string.
-     * @param id a string of the form GMT[+-]hh:mm, GMT[+-]hhmm, or
-     * GMT[+-]hh.
-     * @param normalized Receives the normalized custom ID
-     * @param status Receives the status.  When the input ID string is invalid,
-     * U_ILLEGAL_ARGUMENT_ERROR is set.
-     * @return The normalized custom id string.
-    */
-    static UnicodeString& getCustomID(const UnicodeString& id, UnicodeString& normalized,
-        UErrorCode& status);
-
-    /**
-     * Returns the normalized custome timezone ID for the given offset fields.
-     * @param hour offset hours
-     * @param min offset minutes
-     * @param sec offset seconds
-     * @param netative sign of the offset, TRUE for negative offset.
-     * @param id Receves the format result (normalized custom ID)
-     * @return The reference to id
-     */
-    static UnicodeString& formatCustomID(int32_t hour, int32_t min, int32_t sec,
-        UBool negative, UnicodeString& id);
-
-    /**
-     * Responsible for setting up DEFAULT_ZONE.  Uses routines in TPlatformUtilities
-     * (i.e., platform-specific calls) to get the current system time zone.  Failing
-     * that, uses the platform-specific default time zone.  Failing that, uses GMT.
-     */
-    static void             initDefault(void);
-
-    // See source file for documentation
-    /**
-     * Lookup the given name in our system zone table.  If found,
-     * instantiate a new zone of that name and return it.  If not
-     * found, return 0.
-     * @param name tthe given name of a system time zone.
-     * @return the timezone indicated by the 'name'.
-     */
-    static TimeZone*        createSystemTimeZone(const UnicodeString& name);
-
-    UnicodeString           fID;    // this time zone's ID
-};
-
-
-// -------------------------------------
-
-inline UnicodeString&
-TimeZone::getID(UnicodeString& ID) const
-{
-    ID = fID;
-    return ID;
-}
-
-// -------------------------------------
-
-inline void
-TimeZone::setID(const UnicodeString& ID)
-{
-    fID = ID;
-}
-U_NAMESPACE_END
-
-#endif /* #if !UCONFIG_NO_FORMATTING */
-
-#endif //_TIMEZONE
-//eof


[08/57] [abbrv] remove couch_collate

Posted by be...@apache.org.
http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/urename.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/urename.h b/apps/couch_collate/platform/osx/icu/unicode/urename.h
deleted file mode 100644
index 5282958..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/urename.h
+++ /dev/null
@@ -1,1775 +0,0 @@
-/*
-*******************************************************************************
-*   Copyright (C) 2002-2008, International Business Machines
-*   Corporation and others.  All Rights Reserved.
-*******************************************************************************
-*
-*   file name:  urename.h
-*   encoding:   US-ASCII
-*   tab size:   8 (not used)
-*   indentation:4
-*
-*   Created by: Perl script written by Vladimir Weinstein
-*
-*  Contains data for renaming ICU exports.
-*  Gets included by umachine.h
-*
-*  THIS FILE IS MACHINE-GENERATED, DON'T PLAY WITH IT IF YOU DON'T KNOW WHAT
-*  YOU ARE DOING, OTHERWISE VERY BAD THINGS WILL HAPPEN!
-*/
-
-#ifndef URENAME_H
-#define URENAME_H
-
-/* Uncomment the following line to disable renaming on platforms
-   that do not use Autoconf. */
-/* #define U_DISABLE_RENAMING 1 */
-
-#if !U_DISABLE_RENAMING
-
-/* C exports renaming data */
-
-#define T_CString_int64ToString T_CString_int64ToString_4_0
-#define T_CString_integerToString T_CString_integerToString_4_0
-#define T_CString_stricmp T_CString_stricmp_4_0
-#define T_CString_stringToInteger T_CString_stringToInteger_4_0
-#define T_CString_strnicmp T_CString_strnicmp_4_0
-#define T_CString_toLowerCase T_CString_toLowerCase_4_0
-#define T_CString_toUpperCase T_CString_toUpperCase_4_0
-#define UCNV_FROM_U_CALLBACK_ESCAPE UCNV_FROM_U_CALLBACK_ESCAPE_4_0
-#define UCNV_FROM_U_CALLBACK_SKIP UCNV_FROM_U_CALLBACK_SKIP_4_0
-#define UCNV_FROM_U_CALLBACK_STOP UCNV_FROM_U_CALLBACK_STOP_4_0
-#define UCNV_FROM_U_CALLBACK_SUBSTITUTE UCNV_FROM_U_CALLBACK_SUBSTITUTE_4_0
-#define UCNV_TO_U_CALLBACK_ESCAPE UCNV_TO_U_CALLBACK_ESCAPE_4_0
-#define UCNV_TO_U_CALLBACK_SKIP UCNV_TO_U_CALLBACK_SKIP_4_0
-#define UCNV_TO_U_CALLBACK_STOP UCNV_TO_U_CALLBACK_STOP_4_0
-#define UCNV_TO_U_CALLBACK_SUBSTITUTE UCNV_TO_U_CALLBACK_SUBSTITUTE_4_0
-#define UDataMemory_createNewInstance UDataMemory_createNewInstance_4_0
-#define UDataMemory_init UDataMemory_init_4_0
-#define UDataMemory_isLoaded UDataMemory_isLoaded_4_0
-#define UDataMemory_normalizeDataPointer UDataMemory_normalizeDataPointer_4_0
-#define UDataMemory_setData UDataMemory_setData_4_0
-#define UDatamemory_assign UDatamemory_assign_4_0
-#define _ASCIIData _ASCIIData_4_0
-#define _Bocu1Data _Bocu1Data_4_0
-#define _CESU8Data _CESU8Data_4_0
-#define _HZData _HZData_4_0
-#define _IMAPData _IMAPData_4_0
-#define _ISCIIData _ISCIIData_4_0
-#define _ISO2022Data _ISO2022Data_4_0
-#define _LMBCSData1 _LMBCSData1_4_0
-#define _LMBCSData11 _LMBCSData11_4_0
-#define _LMBCSData16 _LMBCSData16_4_0
-#define _LMBCSData17 _LMBCSData17_4_0
-#define _LMBCSData18 _LMBCSData18_4_0
-#define _LMBCSData19 _LMBCSData19_4_0
-#define _LMBCSData2 _LMBCSData2_4_0
-#define _LMBCSData3 _LMBCSData3_4_0
-#define _LMBCSData4 _LMBCSData4_4_0
-#define _LMBCSData5 _LMBCSData5_4_0
-#define _LMBCSData6 _LMBCSData6_4_0
-#define _LMBCSData8 _LMBCSData8_4_0
-#define _Latin1Data _Latin1Data_4_0
-#define _MBCSData _MBCSData_4_0
-#define _SCSUData _SCSUData_4_0
-#define _UTF16BEData _UTF16BEData_4_0
-#define _UTF16Data _UTF16Data_4_0
-#define _UTF16LEData _UTF16LEData_4_0
-#define _UTF32BEData _UTF32BEData_4_0
-#define _UTF32Data _UTF32Data_4_0
-#define _UTF32LEData _UTF32LEData_4_0
-#define _UTF7Data _UTF7Data_4_0
-#define _UTF8Data _UTF8Data_4_0
-#define cmemory_cleanup cmemory_cleanup_4_0
-#define cmemory_inUse cmemory_inUse_4_0
-#define le_close le_close_4_0
-#define le_create le_create_4_0
-#define le_getCharIndices le_getCharIndices_4_0
-#define le_getCharIndicesWithBase le_getCharIndicesWithBase_4_0
-#define le_getGlyphCount le_getGlyphCount_4_0
-#define le_getGlyphPosition le_getGlyphPosition_4_0
-#define le_getGlyphPositions le_getGlyphPositions_4_0
-#define le_getGlyphs le_getGlyphs_4_0
-#define le_layoutChars le_layoutChars_4_0
-#define le_reset le_reset_4_0
-#define locale_getKeywords locale_getKeywords_4_0
-#define locale_get_default locale_get_default_4_0
-#define locale_set_default locale_set_default_4_0
-#define pl_addFontRun pl_addFontRun_4_0
-#define pl_addLocaleRun pl_addLocaleRun_4_0
-#define pl_addValueRun pl_addValueRun_4_0
-#define pl_close pl_close_4_0
-#define pl_closeFontRuns pl_closeFontRuns_4_0
-#define pl_closeLine pl_closeLine_4_0
-#define pl_closeLocaleRuns pl_closeLocaleRuns_4_0
-#define pl_closeValueRuns pl_closeValueRuns_4_0
-#define pl_countLineRuns pl_countLineRuns_4_0
-#define pl_create pl_create_4_0
-#define pl_getAscent pl_getAscent_4_0
-#define pl_getDescent pl_getDescent_4_0
-#define pl_getFontRunCount pl_getFontRunCount_4_0
-#define pl_getFontRunFont pl_getFontRunFont_4_0
-#define pl_getFontRunLastLimit pl_getFontRunLastLimit_4_0
-#define pl_getFontRunLimit pl_getFontRunLimit_4_0
-#define pl_getLeading pl_getLeading_4_0
-#define pl_getLineAscent pl_getLineAscent_4_0
-#define pl_getLineDescent pl_getLineDescent_4_0
-#define pl_getLineLeading pl_getLineLeading_4_0
-#define pl_getLineVisualRun pl_getLineVisualRun_4_0
-#define pl_getLineWidth pl_getLineWidth_4_0
-#define pl_getLocaleRunCount pl_getLocaleRunCount_4_0
-#define pl_getLocaleRunLastLimit pl_getLocaleRunLastLimit_4_0
-#define pl_getLocaleRunLimit pl_getLocaleRunLimit_4_0
-#define pl_getLocaleRunLocale pl_getLocaleRunLocale_4_0
-#define pl_getParagraphLevel pl_getParagraphLevel_4_0
-#define pl_getTextDirection pl_getTextDirection_4_0
-#define pl_getValueRunCount pl_getValueRunCount_4_0
-#define pl_getValueRunLastLimit pl_getValueRunLastLimit_4_0
-#define pl_getValueRunLimit pl_getValueRunLimit_4_0
-#define pl_getValueRunValue pl_getValueRunValue_4_0
-#define pl_getVisualRunAscent pl_getVisualRunAscent_4_0
-#define pl_getVisualRunDescent pl_getVisualRunDescent_4_0
-#define pl_getVisualRunDirection pl_getVisualRunDirection_4_0
-#define pl_getVisualRunFont pl_getVisualRunFont_4_0
-#define pl_getVisualRunGlyphCount pl_getVisualRunGlyphCount_4_0
-#define pl_getVisualRunGlyphToCharMap pl_getVisualRunGlyphToCharMap_4_0
-#define pl_getVisualRunGlyphs pl_getVisualRunGlyphs_4_0
-#define pl_getVisualRunLeading pl_getVisualRunLeading_4_0
-#define pl_getVisualRunPositions pl_getVisualRunPositions_4_0
-#define pl_isComplex pl_isComplex_4_0
-#define pl_nextLine pl_nextLine_4_0
-#define pl_openEmptyFontRuns pl_openEmptyFontRuns_4_0
-#define pl_openEmptyLocaleRuns pl_openEmptyLocaleRuns_4_0
-#define pl_openEmptyValueRuns pl_openEmptyValueRuns_4_0
-#define pl_openFontRuns pl_openFontRuns_4_0
-#define pl_openLocaleRuns pl_openLocaleRuns_4_0
-#define pl_openValueRuns pl_openValueRuns_4_0
-#define pl_reflow pl_reflow_4_0
-#define pl_resetFontRuns pl_resetFontRuns_4_0
-#define pl_resetLocaleRuns pl_resetLocaleRuns_4_0
-#define pl_resetValueRuns pl_resetValueRuns_4_0
-#define res_countArrayItems res_countArrayItems_4_0
-#define res_findResource res_findResource_4_0
-#define res_getAlias res_getAlias_4_0
-#define res_getArrayItem res_getArrayItem_4_0
-#define res_getBinary res_getBinary_4_0
-#define res_getIntVector res_getIntVector_4_0
-#define res_getResource res_getResource_4_0
-#define res_getString res_getString_4_0
-#define res_getTableItemByIndex res_getTableItemByIndex_4_0
-#define res_getTableItemByKey res_getTableItemByKey_4_0
-#define res_load res_load_4_0
-#define res_unload res_unload_4_0
-#define transliterator_cleanup transliterator_cleanup_4_0
-#define triedict_swap triedict_swap_4_0
-#define u_UCharsToChars u_UCharsToChars_4_0
-#define u_austrcpy u_austrcpy_4_0
-#define u_austrncpy u_austrncpy_4_0
-#define u_catclose u_catclose_4_0
-#define u_catgets u_catgets_4_0
-#define u_catopen u_catopen_4_0
-#define u_charAge u_charAge_4_0
-#define u_charDigitValue u_charDigitValue_4_0
-#define u_charDirection u_charDirection_4_0
-#define u_charFromName u_charFromName_4_0
-#define u_charMirror u_charMirror_4_0
-#define u_charName u_charName_4_0
-#define u_charType u_charType_4_0
-#define u_charsToUChars u_charsToUChars_4_0
-#define u_cleanup u_cleanup_4_0
-#define u_countChar32 u_countChar32_4_0
-#define u_digit u_digit_4_0
-#define u_enumCharNames u_enumCharNames_4_0
-#define u_enumCharTypes u_enumCharTypes_4_0
-#define u_errorName u_errorName_4_0
-#define u_fclose u_fclose_4_0
-#define u_feof u_feof_4_0
-#define u_fflush u_fflush_4_0
-#define u_fgetConverter u_fgetConverter_4_0
-#define u_fgetc u_fgetc_4_0
-#define u_fgetcodepage u_fgetcodepage_4_0
-#define u_fgetcx u_fgetcx_4_0
-#define u_fgetfile u_fgetfile_4_0
-#define u_fgetlocale u_fgetlocale_4_0
-#define u_fgets u_fgets_4_0
-#define u_file_read u_file_read_4_0
-#define u_file_write u_file_write_4_0
-#define u_file_write_flush u_file_write_flush_4_0
-#define u_finit u_finit_4_0
-#define u_foldCase u_foldCase_4_0
-#define u_fopen u_fopen_4_0
-#define u_forDigit u_forDigit_4_0
-#define u_formatMessage u_formatMessage_4_0
-#define u_formatMessageWithError u_formatMessageWithError_4_0
-#define u_fprintf u_fprintf_4_0
-#define u_fprintf_u u_fprintf_u_4_0
-#define u_fputc u_fputc_4_0
-#define u_fputs u_fputs_4_0
-#define u_frewind u_frewind_4_0
-#define u_fscanf u_fscanf_4_0
-#define u_fscanf_u u_fscanf_u_4_0
-#define u_fsetcodepage u_fsetcodepage_4_0
-#define u_fsetlocale u_fsetlocale_4_0
-#define u_fsettransliterator u_fsettransliterator_4_0
-#define u_fstropen u_fstropen_4_0
-#define u_fungetc u_fungetc_4_0
-#define u_getCombiningClass u_getCombiningClass_4_0
-#define u_getDataDirectory u_getDataDirectory_4_0
-#define u_getDefaultConverter u_getDefaultConverter_4_0
-#define u_getFC_NFKC_Closure u_getFC_NFKC_Closure_4_0
-#define u_getISOComment u_getISOComment_4_0
-#define u_getIntPropertyMaxValue u_getIntPropertyMaxValue_4_0
-#define u_getIntPropertyMinValue u_getIntPropertyMinValue_4_0
-#define u_getIntPropertyValue u_getIntPropertyValue_4_0
-#define u_getNumericValue u_getNumericValue_4_0
-#define u_getPropertyEnum u_getPropertyEnum_4_0
-#define u_getPropertyName u_getPropertyName_4_0
-#define u_getPropertyValueEnum u_getPropertyValueEnum_4_0
-#define u_getPropertyValueName u_getPropertyValueName_4_0
-#define u_getUnicodeProperties u_getUnicodeProperties_4_0
-#define u_getUnicodeVersion u_getUnicodeVersion_4_0
-#define u_getVersion u_getVersion_4_0
-#define u_growBufferFromStatic u_growBufferFromStatic_4_0
-#define u_hasBinaryProperty u_hasBinaryProperty_4_0
-#define u_init u_init_4_0
-#define u_isIDIgnorable u_isIDIgnorable_4_0
-#define u_isIDPart u_isIDPart_4_0
-#define u_isIDStart u_isIDStart_4_0
-#define u_isISOControl u_isISOControl_4_0
-#define u_isJavaIDPart u_isJavaIDPart_4_0
-#define u_isJavaIDStart u_isJavaIDStart_4_0
-#define u_isJavaSpaceChar u_isJavaSpaceChar_4_0
-#define u_isMirrored u_isMirrored_4_0
-#define u_isUAlphabetic u_isUAlphabetic_4_0
-#define u_isULowercase u_isULowercase_4_0
-#define u_isUUppercase u_isUUppercase_4_0
-#define u_isUWhiteSpace u_isUWhiteSpace_4_0
-#define u_isWhitespace u_isWhitespace_4_0
-#define u_isalnum u_isalnum_4_0
-#define u_isalnumPOSIX u_isalnumPOSIX_4_0
-#define u_isalpha u_isalpha_4_0
-#define u_isbase u_isbase_4_0
-#define u_isblank u_isblank_4_0
-#define u_iscntrl u_iscntrl_4_0
-#define u_isdefined u_isdefined_4_0
-#define u_isdigit u_isdigit_4_0
-#define u_isgraph u_isgraph_4_0
-#define u_isgraphPOSIX u_isgraphPOSIX_4_0
-#define u_islower u_islower_4_0
-#define u_isprint u_isprint_4_0
-#define u_isprintPOSIX u_isprintPOSIX_4_0
-#define u_ispunct u_ispunct_4_0
-#define u_isspace u_isspace_4_0
-#define u_istitle u_istitle_4_0
-#define u_isupper u_isupper_4_0
-#define u_isxdigit u_isxdigit_4_0
-#define u_lengthOfIdenticalLevelRun u_lengthOfIdenticalLevelRun_4_0
-#define u_locbund_close u_locbund_close_4_0
-#define u_locbund_getNumberFormat u_locbund_getNumberFormat_4_0
-#define u_locbund_init u_locbund_init_4_0
-#define u_memcasecmp u_memcasecmp_4_0
-#define u_memchr u_memchr_4_0
-#define u_memchr32 u_memchr32_4_0
-#define u_memcmp u_memcmp_4_0
-#define u_memcmpCodePointOrder u_memcmpCodePointOrder_4_0
-#define u_memcpy u_memcpy_4_0
-#define u_memmove u_memmove_4_0
-#define u_memrchr u_memrchr_4_0
-#define u_memrchr32 u_memrchr32_4_0
-#define u_memset u_memset_4_0
-#define u_parseMessage u_parseMessage_4_0
-#define u_parseMessageWithError u_parseMessageWithError_4_0
-#define u_printf_parse u_printf_parse_4_0
-#define u_releaseDefaultConverter u_releaseDefaultConverter_4_0
-#define u_scanf_parse u_scanf_parse_4_0
-#define u_setAtomicIncDecFunctions u_setAtomicIncDecFunctions_4_0
-#define u_setDataDirectory u_setDataDirectory_4_0
-#define u_setMemoryFunctions u_setMemoryFunctions_4_0
-#define u_setMutexFunctions u_setMutexFunctions_4_0
-#define u_shapeArabic u_shapeArabic_4_0
-#define u_snprintf u_snprintf_4_0
-#define u_snprintf_u u_snprintf_u_4_0
-#define u_sprintf u_sprintf_4_0
-#define u_sprintf_u u_sprintf_u_4_0
-#define u_sscanf u_sscanf_4_0
-#define u_sscanf_u u_sscanf_u_4_0
-#define u_strCaseCompare u_strCaseCompare_4_0
-#define u_strCompare u_strCompare_4_0
-#define u_strCompareIter u_strCompareIter_4_0
-#define u_strFindFirst u_strFindFirst_4_0
-#define u_strFindLast u_strFindLast_4_0
-#define u_strFoldCase u_strFoldCase_4_0
-#define u_strFromPunycode u_strFromPunycode_4_0
-#define u_strFromUTF32 u_strFromUTF32_4_0
-#define u_strFromUTF8 u_strFromUTF8_4_0
-#define u_strFromUTF8Lenient u_strFromUTF8Lenient_4_0
-#define u_strFromUTF8WithSub u_strFromUTF8WithSub_4_0
-#define u_strFromWCS u_strFromWCS_4_0
-#define u_strHasMoreChar32Than u_strHasMoreChar32Than_4_0
-#define u_strToLower u_strToLower_4_0
-#define u_strToPunycode u_strToPunycode_4_0
-#define u_strToTitle u_strToTitle_4_0
-#define u_strToUTF32 u_strToUTF32_4_0
-#define u_strToUTF8 u_strToUTF8_4_0
-#define u_strToUTF8WithSub u_strToUTF8WithSub_4_0
-#define u_strToUpper u_strToUpper_4_0
-#define u_strToWCS u_strToWCS_4_0
-#define u_strcasecmp u_strcasecmp_4_0
-#define u_strcat u_strcat_4_0
-#define u_strchr u_strchr_4_0
-#define u_strchr32 u_strchr32_4_0
-#define u_strcmp u_strcmp_4_0
-#define u_strcmpCodePointOrder u_strcmpCodePointOrder_4_0
-#define u_strcmpFold u_strcmpFold_4_0
-#define u_strcpy u_strcpy_4_0
-#define u_strcspn u_strcspn_4_0
-#define u_strlen u_strlen_4_0
-#define u_strncasecmp u_strncasecmp_4_0
-#define u_strncat u_strncat_4_0
-#define u_strncmp u_strncmp_4_0
-#define u_strncmpCodePointOrder u_strncmpCodePointOrder_4_0
-#define u_strncpy u_strncpy_4_0
-#define u_strpbrk u_strpbrk_4_0
-#define u_strrchr u_strrchr_4_0
-#define u_strrchr32 u_strrchr32_4_0
-#define u_strrstr u_strrstr_4_0
-#define u_strspn u_strspn_4_0
-#define u_strstr u_strstr_4_0
-#define u_strtok_r u_strtok_r_4_0
-#define u_terminateChars u_terminateChars_4_0
-#define u_terminateUChar32s u_terminateUChar32s_4_0
-#define u_terminateUChars u_terminateUChars_4_0
-#define u_terminateWChars u_terminateWChars_4_0
-#define u_tolower u_tolower_4_0
-#define u_totitle u_totitle_4_0
-#define u_toupper u_toupper_4_0
-#define u_uastrcpy u_uastrcpy_4_0
-#define u_uastrncpy u_uastrncpy_4_0
-#define u_unescape u_unescape_4_0
-#define u_unescapeAt u_unescapeAt_4_0
-#define u_versionFromString u_versionFromString_4_0
-#define u_versionToString u_versionToString_4_0
-#define u_vformatMessage u_vformatMessage_4_0
-#define u_vformatMessageWithError u_vformatMessageWithError_4_0
-#define u_vfprintf u_vfprintf_4_0
-#define u_vfprintf_u u_vfprintf_u_4_0
-#define u_vfscanf u_vfscanf_4_0
-#define u_vfscanf_u u_vfscanf_u_4_0
-#define u_vparseMessage u_vparseMessage_4_0
-#define u_vparseMessageWithError u_vparseMessageWithError_4_0
-#define u_vsnprintf u_vsnprintf_4_0
-#define u_vsnprintf_u u_vsnprintf_u_4_0
-#define u_vsprintf u_vsprintf_4_0
-#define u_vsprintf_u u_vsprintf_u_4_0
-#define u_vsscanf u_vsscanf_4_0
-#define u_vsscanf_u u_vsscanf_u_4_0
-#define u_writeDiff u_writeDiff_4_0
-#define u_writeIdenticalLevelRun u_writeIdenticalLevelRun_4_0
-#define u_writeIdenticalLevelRunTwoChars u_writeIdenticalLevelRunTwoChars_4_0
-#define ubidi_addPropertyStarts ubidi_addPropertyStarts_4_0
-#define ubidi_close ubidi_close_4_0
-#define ubidi_closeProps ubidi_closeProps_4_0
-#define ubidi_countParagraphs ubidi_countParagraphs_4_0
-#define ubidi_countRuns ubidi_countRuns_4_0
-#define ubidi_getClass ubidi_getClass_4_0
-#define ubidi_getClassCallback ubidi_getClassCallback_4_0
-#define ubidi_getCustomizedClass ubidi_getCustomizedClass_4_0
-#define ubidi_getDirection ubidi_getDirection_4_0
-#define ubidi_getJoiningGroup ubidi_getJoiningGroup_4_0
-#define ubidi_getJoiningType ubidi_getJoiningType_4_0
-#define ubidi_getLength ubidi_getLength_4_0
-#define ubidi_getLevelAt ubidi_getLevelAt_4_0
-#define ubidi_getLevels ubidi_getLevels_4_0
-#define ubidi_getLogicalIndex ubidi_getLogicalIndex_4_0
-#define ubidi_getLogicalMap ubidi_getLogicalMap_4_0
-#define ubidi_getLogicalRun ubidi_getLogicalRun_4_0
-#define ubidi_getMaxValue ubidi_getMaxValue_4_0
-#define ubidi_getMemory ubidi_getMemory_4_0
-#define ubidi_getMirror ubidi_getMirror_4_0
-#define ubidi_getParaLevel ubidi_getParaLevel_4_0
-#define ubidi_getParagraph ubidi_getParagraph_4_0
-#define ubidi_getParagraphByIndex ubidi_getParagraphByIndex_4_0
-#define ubidi_getProcessedLength ubidi_getProcessedLength_4_0
-#define ubidi_getReorderingMode ubidi_getReorderingMode_4_0
-#define ubidi_getReorderingOptions ubidi_getReorderingOptions_4_0
-#define ubidi_getResultLength ubidi_getResultLength_4_0
-#define ubidi_getRuns ubidi_getRuns_4_0
-#define ubidi_getSingleton ubidi_getSingleton_4_0
-#define ubidi_getText ubidi_getText_4_0
-#define ubidi_getVisualIndex ubidi_getVisualIndex_4_0
-#define ubidi_getVisualMap ubidi_getVisualMap_4_0
-#define ubidi_getVisualRun ubidi_getVisualRun_4_0
-#define ubidi_invertMap ubidi_invertMap_4_0
-#define ubidi_isBidiControl ubidi_isBidiControl_4_0
-#define ubidi_isInverse ubidi_isInverse_4_0
-#define ubidi_isJoinControl ubidi_isJoinControl_4_0
-#define ubidi_isMirrored ubidi_isMirrored_4_0
-#define ubidi_isOrderParagraphsLTR ubidi_isOrderParagraphsLTR_4_0
-#define ubidi_open ubidi_open_4_0
-#define ubidi_openSized ubidi_openSized_4_0
-#define ubidi_orderParagraphsLTR ubidi_orderParagraphsLTR_4_0
-#define ubidi_reorderLogical ubidi_reorderLogical_4_0
-#define ubidi_reorderVisual ubidi_reorderVisual_4_0
-#define ubidi_setClassCallback ubidi_setClassCallback_4_0
-#define ubidi_setInverse ubidi_setInverse_4_0
-#define ubidi_setLine ubidi_setLine_4_0
-#define ubidi_setPara ubidi_setPara_4_0
-#define ubidi_setReorderingMode ubidi_setReorderingMode_4_0
-#define ubidi_setReorderingOptions ubidi_setReorderingOptions_4_0
-#define ubidi_writeReordered ubidi_writeReordered_4_0
-#define ubidi_writeReverse ubidi_writeReverse_4_0
-#define ublock_getCode ublock_getCode_4_0
-#define ubrk_close ubrk_close_4_0
-#define ubrk_countAvailable ubrk_countAvailable_4_0
-#define ubrk_current ubrk_current_4_0
-#define ubrk_first ubrk_first_4_0
-#define ubrk_following ubrk_following_4_0
-#define ubrk_getAvailable ubrk_getAvailable_4_0
-#define ubrk_getLocaleByType ubrk_getLocaleByType_4_0
-#define ubrk_getRuleStatus ubrk_getRuleStatus_4_0
-#define ubrk_getRuleStatusVec ubrk_getRuleStatusVec_4_0
-#define ubrk_isBoundary ubrk_isBoundary_4_0
-#define ubrk_last ubrk_last_4_0
-#define ubrk_next ubrk_next_4_0
-#define ubrk_open ubrk_open_4_0
-#define ubrk_openRules ubrk_openRules_4_0
-#define ubrk_preceding ubrk_preceding_4_0
-#define ubrk_previous ubrk_previous_4_0
-#define ubrk_safeClone ubrk_safeClone_4_0
-#define ubrk_setText ubrk_setText_4_0
-#define ubrk_setUText ubrk_setUText_4_0
-#define ubrk_swap ubrk_swap_4_0
-#define ucal_add ucal_add_4_0
-#define ucal_clear ucal_clear_4_0
-#define ucal_clearField ucal_clearField_4_0
-#define ucal_clone ucal_clone_4_0
-#define ucal_close ucal_close_4_0
-#define ucal_countAvailable ucal_countAvailable_4_0
-#define ucal_equivalentTo ucal_equivalentTo_4_0
-#define ucal_get ucal_get_4_0
-#define ucal_getAttribute ucal_getAttribute_4_0
-#define ucal_getAvailable ucal_getAvailable_4_0
-#define ucal_getCanonicalTimeZoneID ucal_getCanonicalTimeZoneID_4_0
-#define ucal_getDSTSavings ucal_getDSTSavings_4_0
-#define ucal_getDefaultTimeZone ucal_getDefaultTimeZone_4_0
-#define ucal_getGregorianChange ucal_getGregorianChange_4_0
-#define ucal_getLimit ucal_getLimit_4_0
-#define ucal_getLocaleByType ucal_getLocaleByType_4_0
-#define ucal_getMillis ucal_getMillis_4_0
-#define ucal_getNow ucal_getNow_4_0
-#define ucal_getTZDataVersion ucal_getTZDataVersion_4_0
-#define ucal_getTimeZoneDisplayName ucal_getTimeZoneDisplayName_4_0
-#define ucal_inDaylightTime ucal_inDaylightTime_4_0
-#define ucal_isSet ucal_isSet_4_0
-#define ucal_open ucal_open_4_0
-#define ucal_openCountryTimeZones ucal_openCountryTimeZones_4_0
-#define ucal_openTimeZones ucal_openTimeZones_4_0
-#define ucal_roll ucal_roll_4_0
-#define ucal_set ucal_set_4_0
-#define ucal_setAttribute ucal_setAttribute_4_0
-#define ucal_setDate ucal_setDate_4_0
-#define ucal_setDateTime ucal_setDateTime_4_0
-#define ucal_setDefaultTimeZone ucal_setDefaultTimeZone_4_0
-#define ucal_setGregorianChange ucal_setGregorianChange_4_0
-#define ucal_setMillis ucal_setMillis_4_0
-#define ucal_setTimeZone ucal_setTimeZone_4_0
-#define ucase_addCaseClosure ucase_addCaseClosure_4_0
-#define ucase_addPropertyStarts ucase_addPropertyStarts_4_0
-#define ucase_addStringCaseClosure ucase_addStringCaseClosure_4_0
-#define ucase_close ucase_close_4_0
-#define ucase_fold ucase_fold_4_0
-#define ucase_getCaseLocale ucase_getCaseLocale_4_0
-#define ucase_getSingleton ucase_getSingleton_4_0
-#define ucase_getType ucase_getType_4_0
-#define ucase_getTypeOrIgnorable ucase_getTypeOrIgnorable_4_0
-#define ucase_hasBinaryProperty ucase_hasBinaryProperty_4_0
-#define ucase_isCaseSensitive ucase_isCaseSensitive_4_0
-#define ucase_isSoftDotted ucase_isSoftDotted_4_0
-#define ucase_toFullFolding ucase_toFullFolding_4_0
-#define ucase_toFullLower ucase_toFullLower_4_0
-#define ucase_toFullTitle ucase_toFullTitle_4_0
-#define ucase_toFullUpper ucase_toFullUpper_4_0
-#define ucase_tolower ucase_tolower_4_0
-#define ucase_totitle ucase_totitle_4_0
-#define ucase_toupper ucase_toupper_4_0
-#define ucasemap_close ucasemap_close_4_0
-#define ucasemap_getBreakIterator ucasemap_getBreakIterator_4_0
-#define ucasemap_getLocale ucasemap_getLocale_4_0
-#define ucasemap_getOptions ucasemap_getOptions_4_0
-#define ucasemap_open ucasemap_open_4_0
-#define ucasemap_setBreakIterator ucasemap_setBreakIterator_4_0
-#define ucasemap_setLocale ucasemap_setLocale_4_0
-#define ucasemap_setOptions ucasemap_setOptions_4_0
-#define ucasemap_toTitle ucasemap_toTitle_4_0
-#define ucasemap_utf8FoldCase ucasemap_utf8FoldCase_4_0
-#define ucasemap_utf8ToLower ucasemap_utf8ToLower_4_0
-#define ucasemap_utf8ToTitle ucasemap_utf8ToTitle_4_0
-#define ucasemap_utf8ToUpper ucasemap_utf8ToUpper_4_0
-#define uchar_addPropertyStarts uchar_addPropertyStarts_4_0
-#define uchar_getHST uchar_getHST_4_0
-#define uchar_swapNames uchar_swapNames_4_0
-#define ucln_common_registerCleanup ucln_common_registerCleanup_4_0
-#define ucln_i18n_registerCleanup ucln_i18n_registerCleanup_4_0
-#define ucln_io_registerCleanup ucln_io_registerCleanup_4_0
-#define ucln_lib_cleanup ucln_lib_cleanup_4_0
-#define ucln_registerCleanup ucln_registerCleanup_4_0
-#define ucnv_MBCSFromUChar32 ucnv_MBCSFromUChar32_4_0
-#define ucnv_MBCSFromUnicodeWithOffsets ucnv_MBCSFromUnicodeWithOffsets_4_0
-#define ucnv_MBCSGetFilteredUnicodeSetForUnicode ucnv_MBCSGetFilteredUnicodeSetForUnicode_4_0
-#define ucnv_MBCSGetType ucnv_MBCSGetType_4_0
-#define ucnv_MBCSGetUnicodeSetForUnicode ucnv_MBCSGetUnicodeSetForUnicode_4_0
-#define ucnv_MBCSIsLeadByte ucnv_MBCSIsLeadByte_4_0
-#define ucnv_MBCSSimpleGetNextUChar ucnv_MBCSSimpleGetNextUChar_4_0
-#define ucnv_MBCSToUnicodeWithOffsets ucnv_MBCSToUnicodeWithOffsets_4_0
-#define ucnv_bld_countAvailableConverters ucnv_bld_countAvailableConverters_4_0
-#define ucnv_bld_getAvailableConverter ucnv_bld_getAvailableConverter_4_0
-#define ucnv_cbFromUWriteBytes ucnv_cbFromUWriteBytes_4_0
-#define ucnv_cbFromUWriteSub ucnv_cbFromUWriteSub_4_0
-#define ucnv_cbFromUWriteUChars ucnv_cbFromUWriteUChars_4_0
-#define ucnv_cbToUWriteSub ucnv_cbToUWriteSub_4_0
-#define ucnv_cbToUWriteUChars ucnv_cbToUWriteUChars_4_0
-#define ucnv_close ucnv_close_4_0
-#define ucnv_compareNames ucnv_compareNames_4_0
-#define ucnv_convert ucnv_convert_4_0
-#define ucnv_convertEx ucnv_convertEx_4_0
-#define ucnv_countAliases ucnv_countAliases_4_0
-#define ucnv_countAvailable ucnv_countAvailable_4_0
-#define ucnv_countStandards ucnv_countStandards_4_0
-#define ucnv_createAlgorithmicConverter ucnv_createAlgorithmicConverter_4_0
-#define ucnv_createConverter ucnv_createConverter_4_0
-#define ucnv_createConverterFromPackage ucnv_createConverterFromPackage_4_0
-#define ucnv_createConverterFromSharedData ucnv_createConverterFromSharedData_4_0
-#define ucnv_detectUnicodeSignature ucnv_detectUnicodeSignature_4_0
-#define ucnv_extContinueMatchFromU ucnv_extContinueMatchFromU_4_0
-#define ucnv_extContinueMatchToU ucnv_extContinueMatchToU_4_0
-#define ucnv_extGetUnicodeSet ucnv_extGetUnicodeSet_4_0
-#define ucnv_extInitialMatchFromU ucnv_extInitialMatchFromU_4_0
-#define ucnv_extInitialMatchToU ucnv_extInitialMatchToU_4_0
-#define ucnv_extSimpleMatchFromU ucnv_extSimpleMatchFromU_4_0
-#define ucnv_extSimpleMatchToU ucnv_extSimpleMatchToU_4_0
-#define ucnv_fixFileSeparator ucnv_fixFileSeparator_4_0
-#define ucnv_flushCache ucnv_flushCache_4_0
-#define ucnv_fromAlgorithmic ucnv_fromAlgorithmic_4_0
-#define ucnv_fromUChars ucnv_fromUChars_4_0
-#define ucnv_fromUCountPending ucnv_fromUCountPending_4_0
-#define ucnv_fromUWriteBytes ucnv_fromUWriteBytes_4_0
-#define ucnv_fromUnicode ucnv_fromUnicode_4_0
-#define ucnv_fromUnicode_UTF8 ucnv_fromUnicode_UTF8_4_0
-#define ucnv_fromUnicode_UTF8_OFFSETS_LOGIC ucnv_fromUnicode_UTF8_OFFSETS_LOGIC_4_0
-#define ucnv_getAlias ucnv_getAlias_4_0
-#define ucnv_getAliases ucnv_getAliases_4_0
-#define ucnv_getAvailableName ucnv_getAvailableName_4_0
-#define ucnv_getCCSID ucnv_getCCSID_4_0
-#define ucnv_getCanonicalName ucnv_getCanonicalName_4_0
-#define ucnv_getCompleteUnicodeSet ucnv_getCompleteUnicodeSet_4_0
-#define ucnv_getDefaultName ucnv_getDefaultName_4_0
-#define ucnv_getDisplayName ucnv_getDisplayName_4_0
-#define ucnv_getFromUCallBack ucnv_getFromUCallBack_4_0
-#define ucnv_getInvalidChars ucnv_getInvalidChars_4_0
-#define ucnv_getInvalidUChars ucnv_getInvalidUChars_4_0
-#define ucnv_getMaxCharSize ucnv_getMaxCharSize_4_0
-#define ucnv_getMinCharSize ucnv_getMinCharSize_4_0
-#define ucnv_getName ucnv_getName_4_0
-#define ucnv_getNextUChar ucnv_getNextUChar_4_0
-#define ucnv_getNonSurrogateUnicodeSet ucnv_getNonSurrogateUnicodeSet_4_0
-#define ucnv_getPlatform ucnv_getPlatform_4_0
-#define ucnv_getStandard ucnv_getStandard_4_0
-#define ucnv_getStandardName ucnv_getStandardName_4_0
-#define ucnv_getStarters ucnv_getStarters_4_0
-#define ucnv_getSubstChars ucnv_getSubstChars_4_0
-#define ucnv_getToUCallBack ucnv_getToUCallBack_4_0
-#define ucnv_getType ucnv_getType_4_0
-#define ucnv_getUnicodeSet ucnv_getUnicodeSet_4_0
-#define ucnv_incrementRefCount ucnv_incrementRefCount_4_0
-#define ucnv_io_countKnownConverters ucnv_io_countKnownConverters_4_0
-#define ucnv_io_getConverterName ucnv_io_getConverterName_4_0
-#define ucnv_io_stripASCIIForCompare ucnv_io_stripASCIIForCompare_4_0
-#define ucnv_io_stripEBCDICForCompare ucnv_io_stripEBCDICForCompare_4_0
-#define ucnv_isAmbiguous ucnv_isAmbiguous_4_0
-#define ucnv_load ucnv_load_4_0
-#define ucnv_loadSharedData ucnv_loadSharedData_4_0
-#define ucnv_open ucnv_open_4_0
-#define ucnv_openAllNames ucnv_openAllNames_4_0
-#define ucnv_openCCSID ucnv_openCCSID_4_0
-#define ucnv_openPackage ucnv_openPackage_4_0
-#define ucnv_openStandardNames ucnv_openStandardNames_4_0
-#define ucnv_openU ucnv_openU_4_0
-#define ucnv_reset ucnv_reset_4_0
-#define ucnv_resetFromUnicode ucnv_resetFromUnicode_4_0
-#define ucnv_resetToUnicode ucnv_resetToUnicode_4_0
-#define ucnv_safeClone ucnv_safeClone_4_0
-#define ucnv_setDefaultName ucnv_setDefaultName_4_0
-#define ucnv_setFallback ucnv_setFallback_4_0
-#define ucnv_setFromUCallBack ucnv_setFromUCallBack_4_0
-#define ucnv_setSubstChars ucnv_setSubstChars_4_0
-#define ucnv_setSubstString ucnv_setSubstString_4_0
-#define ucnv_setToUCallBack ucnv_setToUCallBack_4_0
-#define ucnv_swap ucnv_swap_4_0
-#define ucnv_swapAliases ucnv_swapAliases_4_0
-#define ucnv_toAlgorithmic ucnv_toAlgorithmic_4_0
-#define ucnv_toUChars ucnv_toUChars_4_0
-#define ucnv_toUCountPending ucnv_toUCountPending_4_0
-#define ucnv_toUWriteCodePoint ucnv_toUWriteCodePoint_4_0
-#define ucnv_toUWriteUChars ucnv_toUWriteUChars_4_0
-#define ucnv_toUnicode ucnv_toUnicode_4_0
-#define ucnv_unload ucnv_unload_4_0
-#define ucnv_unloadSharedDataIfReady ucnv_unloadSharedDataIfReady_4_0
-#define ucnv_usesFallback ucnv_usesFallback_4_0
-#define ucol_allocWeights ucol_allocWeights_4_0
-#define ucol_assembleTailoringTable ucol_assembleTailoringTable_4_0
-#define ucol_calcSortKey ucol_calcSortKey_4_0
-#define ucol_calcSortKeySimpleTertiary ucol_calcSortKeySimpleTertiary_4_0
-#define ucol_cloneBinary ucol_cloneBinary_4_0
-#define ucol_cloneRuleData ucol_cloneRuleData_4_0
-#define ucol_close ucol_close_4_0
-#define ucol_closeElements ucol_closeElements_4_0
-#define ucol_countAvailable ucol_countAvailable_4_0
-#define ucol_createElements ucol_createElements_4_0
-#define ucol_doCE ucol_doCE_4_0
-#define ucol_equal ucol_equal_4_0
-#define ucol_equals ucol_equals_4_0
-#define ucol_forgetUCA ucol_forgetUCA_4_0
-#define ucol_getAttribute ucol_getAttribute_4_0
-#define ucol_getAttributeOrDefault ucol_getAttributeOrDefault_4_0
-#define ucol_getAvailable ucol_getAvailable_4_0
-#define ucol_getBound ucol_getBound_4_0
-#define ucol_getCEStrengthDifference ucol_getCEStrengthDifference_4_0
-#define ucol_getContractions ucol_getContractions_4_0
-#define ucol_getContractionsAndExpansions ucol_getContractionsAndExpansions_4_0
-#define ucol_getDisplayName ucol_getDisplayName_4_0
-#define ucol_getFirstCE ucol_getFirstCE_4_0
-#define ucol_getFunctionalEquivalent ucol_getFunctionalEquivalent_4_0
-#define ucol_getKeywordValues ucol_getKeywordValues_4_0
-#define ucol_getKeywords ucol_getKeywords_4_0
-#define ucol_getLocale ucol_getLocale_4_0
-#define ucol_getLocaleByType ucol_getLocaleByType_4_0
-#define ucol_getMaxExpansion ucol_getMaxExpansion_4_0
-#define ucol_getNextCE ucol_getNextCE_4_0
-#define ucol_getOffset ucol_getOffset_4_0
-#define ucol_getPrevCE ucol_getPrevCE_4_0
-#define ucol_getRules ucol_getRules_4_0
-#define ucol_getRulesEx ucol_getRulesEx_4_0
-#define ucol_getShortDefinitionString ucol_getShortDefinitionString_4_0
-#define ucol_getSortKey ucol_getSortKey_4_0
-#define ucol_getSortKeySize ucol_getSortKeySize_4_0
-#define ucol_getSortKeyWithAllocation ucol_getSortKeyWithAllocation_4_0
-#define ucol_getStrength ucol_getStrength_4_0
-#define ucol_getTailoredSet ucol_getTailoredSet_4_0
-#define ucol_getUCAVersion ucol_getUCAVersion_4_0
-#define ucol_getUnsafeSet ucol_getUnsafeSet_4_0
-#define ucol_getVariableTop ucol_getVariableTop_4_0
-#define ucol_getVersion ucol_getVersion_4_0
-#define ucol_greater ucol_greater_4_0
-#define ucol_greaterOrEqual ucol_greaterOrEqual_4_0
-#define ucol_initBuffers ucol_initBuffers_4_0
-#define ucol_initCollator ucol_initCollator_4_0
-#define ucol_initInverseUCA ucol_initInverseUCA_4_0
-#define ucol_initUCA ucol_initUCA_4_0
-#define ucol_inv_getNextCE ucol_inv_getNextCE_4_0
-#define ucol_inv_getPrevCE ucol_inv_getPrevCE_4_0
-#define ucol_isTailored ucol_isTailored_4_0
-#define ucol_keyHashCode ucol_keyHashCode_4_0
-#define ucol_mergeSortkeys ucol_mergeSortkeys_4_0
-#define ucol_next ucol_next_4_0
-#define ucol_nextProcessed ucol_nextProcessed_4_0
-#define ucol_nextSortKeyPart ucol_nextSortKeyPart_4_0
-#define ucol_nextWeight ucol_nextWeight_4_0
-#define ucol_normalizeShortDefinitionString ucol_normalizeShortDefinitionString_4_0
-#define ucol_open ucol_open_4_0
-#define ucol_openAvailableLocales ucol_openAvailableLocales_4_0
-#define ucol_openBinary ucol_openBinary_4_0
-#define ucol_openElements ucol_openElements_4_0
-#define ucol_openFromShortString ucol_openFromShortString_4_0
-#define ucol_openRules ucol_openRules_4_0
-#define ucol_open_internal ucol_open_internal_4_0
-#define ucol_prepareShortStringOpen ucol_prepareShortStringOpen_4_0
-#define ucol_previous ucol_previous_4_0
-#define ucol_previousProcessed ucol_previousProcessed_4_0
-#define ucol_primaryOrder ucol_primaryOrder_4_0
-#define ucol_prv_getSpecialCE ucol_prv_getSpecialCE_4_0
-#define ucol_prv_getSpecialPrevCE ucol_prv_getSpecialPrevCE_4_0
-#define ucol_reset ucol_reset_4_0
-#define ucol_restoreVariableTop ucol_restoreVariableTop_4_0
-#define ucol_safeClone ucol_safeClone_4_0
-#define ucol_secondaryOrder ucol_secondaryOrder_4_0
-#define ucol_setAttribute ucol_setAttribute_4_0
-#define ucol_setOffset ucol_setOffset_4_0
-#define ucol_setOptionsFromHeader ucol_setOptionsFromHeader_4_0
-#define ucol_setReqValidLocales ucol_setReqValidLocales_4_0
-#define ucol_setStrength ucol_setStrength_4_0
-#define ucol_setText ucol_setText_4_0
-#define ucol_setVariableTop ucol_setVariableTop_4_0
-#define ucol_strcoll ucol_strcoll_4_0
-#define ucol_strcollIter ucol_strcollIter_4_0
-#define ucol_swap ucol_swap_4_0
-#define ucol_swapBinary ucol_swapBinary_4_0
-#define ucol_swapInverseUCA ucol_swapInverseUCA_4_0
-#define ucol_tertiaryOrder ucol_tertiaryOrder_4_0
-#define ucol_tok_assembleTokenList ucol_tok_assembleTokenList_4_0
-#define ucol_tok_closeTokenList ucol_tok_closeTokenList_4_0
-#define ucol_tok_getNextArgument ucol_tok_getNextArgument_4_0
-#define ucol_tok_initTokenList ucol_tok_initTokenList_4_0
-#define ucol_tok_parseNextToken ucol_tok_parseNextToken_4_0
-#define ucol_updateInternalState ucol_updateInternalState_4_0
-#define ucsdet_close ucsdet_close_4_0
-#define ucsdet_detect ucsdet_detect_4_0
-#define ucsdet_detectAll ucsdet_detectAll_4_0
-#define ucsdet_enableInputFilter ucsdet_enableInputFilter_4_0
-#define ucsdet_getAllDetectableCharsets ucsdet_getAllDetectableCharsets_4_0
-#define ucsdet_getConfidence ucsdet_getConfidence_4_0
-#define ucsdet_getLanguage ucsdet_getLanguage_4_0
-#define ucsdet_getName ucsdet_getName_4_0
-#define ucsdet_getUChars ucsdet_getUChars_4_0
-#define ucsdet_isInputFilterEnabled ucsdet_isInputFilterEnabled_4_0
-#define ucsdet_open ucsdet_open_4_0
-#define ucsdet_setDeclaredEncoding ucsdet_setDeclaredEncoding_4_0
-#define ucsdet_setText ucsdet_setText_4_0
-#define ucurr_countCurrencies ucurr_countCurrencies_4_0
-#define ucurr_forLocale ucurr_forLocale_4_0
-#define ucurr_forLocaleAndDate ucurr_forLocaleAndDate_4_0
-#define ucurr_getDefaultFractionDigits ucurr_getDefaultFractionDigits_4_0
-#define ucurr_getName ucurr_getName_4_0
-#define ucurr_getRoundingIncrement ucurr_getRoundingIncrement_4_0
-#define ucurr_openISOCurrencies ucurr_openISOCurrencies_4_0
-#define ucurr_register ucurr_register_4_0
-#define ucurr_unregister ucurr_unregister_4_0
-#define udat_applyPattern udat_applyPattern_4_0
-#define udat_clone udat_clone_4_0
-#define udat_close udat_close_4_0
-#define udat_countAvailable udat_countAvailable_4_0
-#define udat_countSymbols udat_countSymbols_4_0
-#define udat_format udat_format_4_0
-#define udat_get2DigitYearStart udat_get2DigitYearStart_4_0
-#define udat_getAvailable udat_getAvailable_4_0
-#define udat_getCalendar udat_getCalendar_4_0
-#define udat_getLocaleByType udat_getLocaleByType_4_0
-#define udat_getNumberFormat udat_getNumberFormat_4_0
-#define udat_getSymbols udat_getSymbols_4_0
-#define udat_isLenient udat_isLenient_4_0
-#define udat_open udat_open_4_0
-#define udat_parse udat_parse_4_0
-#define udat_parseCalendar udat_parseCalendar_4_0
-#define udat_set2DigitYearStart udat_set2DigitYearStart_4_0
-#define udat_setCalendar udat_setCalendar_4_0
-#define udat_setLenient udat_setLenient_4_0
-#define udat_setNumberFormat udat_setNumberFormat_4_0
-#define udat_setSymbols udat_setSymbols_4_0
-#define udat_toPattern udat_toPattern_4_0
-#define udata_checkCommonData udata_checkCommonData_4_0
-#define udata_close udata_close_4_0
-#define udata_closeSwapper udata_closeSwapper_4_0
-#define udata_getHeaderSize udata_getHeaderSize_4_0
-#define udata_getInfo udata_getInfo_4_0
-#define udata_getInfoSize udata_getInfoSize_4_0
-#define udata_getLength udata_getLength_4_0
-#define udata_getMemory udata_getMemory_4_0
-#define udata_getRawMemory udata_getRawMemory_4_0
-#define udata_open udata_open_4_0
-#define udata_openChoice udata_openChoice_4_0
-#define udata_openSwapper udata_openSwapper_4_0
-#define udata_openSwapperForInputData udata_openSwapperForInputData_4_0
-#define udata_printError udata_printError_4_0
-#define udata_readInt16 udata_readInt16_4_0
-#define udata_readInt32 udata_readInt32_4_0
-#define udata_setAppData udata_setAppData_4_0
-#define udata_setCommonData udata_setCommonData_4_0
-#define udata_setFileAccess udata_setFileAccess_4_0
-#define udata_swapDataHeader udata_swapDataHeader_4_0
-#define udata_swapInvStringBlock udata_swapInvStringBlock_4_0
-#define udatpg_addPattern udatpg_addPattern_4_0
-#define udatpg_clone udatpg_clone_4_0
-#define udatpg_close udatpg_close_4_0
-#define udatpg_getAppendItemFormat udatpg_getAppendItemFormat_4_0
-#define udatpg_getAppendItemName udatpg_getAppendItemName_4_0
-#define udatpg_getBaseSkeleton udatpg_getBaseSkeleton_4_0
-#define udatpg_getBestPattern udatpg_getBestPattern_4_0
-#define udatpg_getDateTimeFormat udatpg_getDateTimeFormat_4_0
-#define udatpg_getDecimal udatpg_getDecimal_4_0
-#define udatpg_getPatternForSkeleton udatpg_getPatternForSkeleton_4_0
-#define udatpg_getSkeleton udatpg_getSkeleton_4_0
-#define udatpg_open udatpg_open_4_0
-#define udatpg_openBaseSkeletons udatpg_openBaseSkeletons_4_0
-#define udatpg_openEmpty udatpg_openEmpty_4_0
-#define udatpg_openSkeletons udatpg_openSkeletons_4_0
-#define udatpg_replaceFieldTypes udatpg_replaceFieldTypes_4_0
-#define udatpg_setAppendItemFormat udatpg_setAppendItemFormat_4_0
-#define udatpg_setAppendItemName udatpg_setAppendItemName_4_0
-#define udatpg_setDateTimeFormat udatpg_setDateTimeFormat_4_0
-#define udatpg_setDecimal udatpg_setDecimal_4_0
-#define uenum_close uenum_close_4_0
-#define uenum_count uenum_count_4_0
-#define uenum_next uenum_next_4_0
-#define uenum_nextDefault uenum_nextDefault_4_0
-#define uenum_openCharStringsEnumeration uenum_openCharStringsEnumeration_4_0
-#define uenum_openStringEnumeration uenum_openStringEnumeration_4_0
-#define uenum_reset uenum_reset_4_0
-#define uenum_unext uenum_unext_4_0
-#define uenum_unextDefault uenum_unextDefault_4_0
-#define ufile_close_translit ufile_close_translit_4_0
-#define ufile_fill_uchar_buffer ufile_fill_uchar_buffer_4_0
-#define ufile_flush_translit ufile_flush_translit_4_0
-#define ufile_getch ufile_getch_4_0
-#define ufile_getch32 ufile_getch32_4_0
-#define ufmt_64tou ufmt_64tou_4_0
-#define ufmt_defaultCPToUnicode ufmt_defaultCPToUnicode_4_0
-#define ufmt_digitvalue ufmt_digitvalue_4_0
-#define ufmt_isdigit ufmt_isdigit_4_0
-#define ufmt_ptou ufmt_ptou_4_0
-#define ufmt_uto64 ufmt_uto64_4_0
-#define ufmt_utop ufmt_utop_4_0
-#define uhash_close uhash_close_4_0
-#define uhash_compareCaselessUnicodeString uhash_compareCaselessUnicodeString_4_0
-#define uhash_compareChars uhash_compareChars_4_0
-#define uhash_compareIChars uhash_compareIChars_4_0
-#define uhash_compareLong uhash_compareLong_4_0
-#define uhash_compareUChars uhash_compareUChars_4_0
-#define uhash_compareUnicodeString uhash_compareUnicodeString_4_0
-#define uhash_count uhash_count_4_0
-#define uhash_deleteHashtable uhash_deleteHashtable_4_0
-#define uhash_deleteUVector uhash_deleteUVector_4_0
-#define uhash_deleteUnicodeString uhash_deleteUnicodeString_4_0
-#define uhash_equals uhash_equals_4_0
-#define uhash_find uhash_find_4_0
-#define uhash_freeBlock uhash_freeBlock_4_0
-#define uhash_get uhash_get_4_0
-#define uhash_geti uhash_geti_4_0
-#define uhash_hashCaselessUnicodeString uhash_hashCaselessUnicodeString_4_0
-#define uhash_hashChars uhash_hashChars_4_0
-#define uhash_hashIChars uhash_hashIChars_4_0
-#define uhash_hashLong uhash_hashLong_4_0
-#define uhash_hashUChars uhash_hashUChars_4_0
-#define uhash_hashUCharsN uhash_hashUCharsN_4_0
-#define uhash_hashUnicodeString uhash_hashUnicodeString_4_0
-#define uhash_iget uhash_iget_4_0
-#define uhash_igeti uhash_igeti_4_0
-#define uhash_init uhash_init_4_0
-#define uhash_iput uhash_iput_4_0
-#define uhash_iputi uhash_iputi_4_0
-#define uhash_iremove uhash_iremove_4_0
-#define uhash_iremovei uhash_iremovei_4_0
-#define uhash_nextElement uhash_nextElement_4_0
-#define uhash_open uhash_open_4_0
-#define uhash_openSize uhash_openSize_4_0
-#define uhash_put uhash_put_4_0
-#define uhash_puti uhash_puti_4_0
-#define uhash_remove uhash_remove_4_0
-#define uhash_removeAll uhash_removeAll_4_0
-#define uhash_removeElement uhash_removeElement_4_0
-#define uhash_removei uhash_removei_4_0
-#define uhash_setKeyComparator uhash_setKeyComparator_4_0
-#define uhash_setKeyDeleter uhash_setKeyDeleter_4_0
-#define uhash_setKeyHasher uhash_setKeyHasher_4_0
-#define uhash_setResizePolicy uhash_setResizePolicy_4_0
-#define uhash_setValueComparator uhash_setValueComparator_4_0
-#define uhash_setValueDeleter uhash_setValueDeleter_4_0
-#define uhst_addPropertyStarts uhst_addPropertyStarts_4_0
-#define uidna_IDNToASCII uidna_IDNToASCII_4_0
-#define uidna_IDNToUnicode uidna_IDNToUnicode_4_0
-#define uidna_compare uidna_compare_4_0
-#define uidna_toASCII uidna_toASCII_4_0
-#define uidna_toUnicode uidna_toUnicode_4_0
-#define uiter_current32 uiter_current32_4_0
-#define uiter_getState uiter_getState_4_0
-#define uiter_next32 uiter_next32_4_0
-#define uiter_previous32 uiter_previous32_4_0
-#define uiter_setCharacterIterator uiter_setCharacterIterator_4_0
-#define uiter_setReplaceable uiter_setReplaceable_4_0
-#define uiter_setState uiter_setState_4_0
-#define uiter_setString uiter_setString_4_0
-#define uiter_setUTF16BE uiter_setUTF16BE_4_0
-#define uiter_setUTF8 uiter_setUTF8_4_0
-#define uloc_acceptLanguage uloc_acceptLanguage_4_0
-#define uloc_acceptLanguageFromHTTP uloc_acceptLanguageFromHTTP_4_0
-#define uloc_addLikelySubtags uloc_addLikelySubtags_4_0
-#define uloc_canonicalize uloc_canonicalize_4_0
-#define uloc_countAvailable uloc_countAvailable_4_0
-#define uloc_getAvailable uloc_getAvailable_4_0
-#define uloc_getBaseName uloc_getBaseName_4_0
-#define uloc_getCharacterOrientation uloc_getCharacterOrientation_4_0
-#define uloc_getCountry uloc_getCountry_4_0
-#define uloc_getDefault uloc_getDefault_4_0
-#define uloc_getDisplayCountry uloc_getDisplayCountry_4_0
-#define uloc_getDisplayKeyword uloc_getDisplayKeyword_4_0
-#define uloc_getDisplayKeywordValue uloc_getDisplayKeywordValue_4_0
-#define uloc_getDisplayLanguage uloc_getDisplayLanguage_4_0
-#define uloc_getDisplayName uloc_getDisplayName_4_0
-#define uloc_getDisplayScript uloc_getDisplayScript_4_0
-#define uloc_getDisplayVariant uloc_getDisplayVariant_4_0
-#define uloc_getISO3Country uloc_getISO3Country_4_0
-#define uloc_getISO3Language uloc_getISO3Language_4_0
-#define uloc_getISOCountries uloc_getISOCountries_4_0
-#define uloc_getISOLanguages uloc_getISOLanguages_4_0
-#define uloc_getKeywordValue uloc_getKeywordValue_4_0
-#define uloc_getLCID uloc_getLCID_4_0
-#define uloc_getLanguage uloc_getLanguage_4_0
-#define uloc_getLineOrientation uloc_getLineOrientation_4_0
-#define uloc_getLocaleForLCID uloc_getLocaleForLCID_4_0
-#define uloc_getName uloc_getName_4_0
-#define uloc_getParent uloc_getParent_4_0
-#define uloc_getScript uloc_getScript_4_0
-#define uloc_getVariant uloc_getVariant_4_0
-#define uloc_minimizeSubtags uloc_minimizeSubtags_4_0
-#define uloc_openKeywordList uloc_openKeywordList_4_0
-#define uloc_openKeywords uloc_openKeywords_4_0
-#define uloc_setDefault uloc_setDefault_4_0
-#define uloc_setKeywordValue uloc_setKeywordValue_4_0
-#define ulocdata_close ulocdata_close_4_0
-#define ulocdata_getDelimiter ulocdata_getDelimiter_4_0
-#define ulocdata_getExemplarSet ulocdata_getExemplarSet_4_0
-#define ulocdata_getMeasurementSystem ulocdata_getMeasurementSystem_4_0
-#define ulocdata_getNoSubstitute ulocdata_getNoSubstitute_4_0
-#define ulocdata_getPaperSize ulocdata_getPaperSize_4_0
-#define ulocdata_open ulocdata_open_4_0
-#define ulocdata_setNoSubstitute ulocdata_setNoSubstitute_4_0
-#define umsg_applyPattern umsg_applyPattern_4_0
-#define umsg_autoQuoteApostrophe umsg_autoQuoteApostrophe_4_0
-#define umsg_clone umsg_clone_4_0
-#define umsg_close umsg_close_4_0
-#define umsg_format umsg_format_4_0
-#define umsg_getLocale umsg_getLocale_4_0
-#define umsg_open umsg_open_4_0
-#define umsg_parse umsg_parse_4_0
-#define umsg_setLocale umsg_setLocale_4_0
-#define umsg_toPattern umsg_toPattern_4_0
-#define umsg_vformat umsg_vformat_4_0
-#define umsg_vparse umsg_vparse_4_0
-#define umtx_atomic_dec umtx_atomic_dec_4_0
-#define umtx_atomic_inc umtx_atomic_inc_4_0
-#define umtx_cleanup umtx_cleanup_4_0
-#define umtx_destroy umtx_destroy_4_0
-#define umtx_init umtx_init_4_0
-#define umtx_lock umtx_lock_4_0
-#define umtx_unlock umtx_unlock_4_0
-#define unorm_addPropertyStarts unorm_addPropertyStarts_4_0
-#define unorm_closeIter unorm_closeIter_4_0
-#define unorm_compare unorm_compare_4_0
-#define unorm_compose unorm_compose_4_0
-#define unorm_concatenate unorm_concatenate_4_0
-#define unorm_decompose unorm_decompose_4_0
-#define unorm_getCanonStartSet unorm_getCanonStartSet_4_0
-#define unorm_getCanonicalDecomposition unorm_getCanonicalDecomposition_4_0
-#define unorm_getDecomposition unorm_getDecomposition_4_0
-#define unorm_getFCD16FromCodePoint unorm_getFCD16FromCodePoint_4_0
-#define unorm_getFCDTrie unorm_getFCDTrie_4_0
-#define unorm_getNX unorm_getNX_4_0
-#define unorm_getQuickCheck unorm_getQuickCheck_4_0
-#define unorm_getUnicodeVersion unorm_getUnicodeVersion_4_0
-#define unorm_haveData unorm_haveData_4_0
-#define unorm_internalIsFullCompositionExclusion unorm_internalIsFullCompositionExclusion_4_0
-#define unorm_internalNormalize unorm_internalNormalize_4_0
-#define unorm_internalNormalizeWithNX unorm_internalNormalizeWithNX_4_0
-#define unorm_internalQuickCheck unorm_internalQuickCheck_4_0
-#define unorm_isCanonSafeStart unorm_isCanonSafeStart_4_0
-#define unorm_isNFSkippable unorm_isNFSkippable_4_0
-#define unorm_isNormalized unorm_isNormalized_4_0
-#define unorm_isNormalizedWithOptions unorm_isNormalizedWithOptions_4_0
-#define unorm_next unorm_next_4_0
-#define unorm_normalize unorm_normalize_4_0
-#define unorm_openIter unorm_openIter_4_0
-#define unorm_previous unorm_previous_4_0
-#define unorm_quickCheck unorm_quickCheck_4_0
-#define unorm_quickCheckWithOptions unorm_quickCheckWithOptions_4_0
-#define unorm_setIter unorm_setIter_4_0
-#define unum_applyPattern unum_applyPattern_4_0
-#define unum_clone unum_clone_4_0
-#define unum_close unum_close_4_0
-#define unum_countAvailable unum_countAvailable_4_0
-#define unum_format unum_format_4_0
-#define unum_formatDouble unum_formatDouble_4_0
-#define unum_formatDoubleCurrency unum_formatDoubleCurrency_4_0
-#define unum_formatInt64 unum_formatInt64_4_0
-#define unum_getAttribute unum_getAttribute_4_0
-#define unum_getAvailable unum_getAvailable_4_0
-#define unum_getDoubleAttribute unum_getDoubleAttribute_4_0
-#define unum_getLocaleByType unum_getLocaleByType_4_0
-#define unum_getSymbol unum_getSymbol_4_0
-#define unum_getTextAttribute unum_getTextAttribute_4_0
-#define unum_open unum_open_4_0
-#define unum_parse unum_parse_4_0
-#define unum_parseDouble unum_parseDouble_4_0
-#define unum_parseDoubleCurrency unum_parseDoubleCurrency_4_0
-#define unum_parseInt64 unum_parseInt64_4_0
-#define unum_setAttribute unum_setAttribute_4_0
-#define unum_setDoubleAttribute unum_setDoubleAttribute_4_0
-#define unum_setSymbol unum_setSymbol_4_0
-#define unum_setTextAttribute unum_setTextAttribute_4_0
-#define unum_toPattern unum_toPattern_4_0
-#define upname_swap upname_swap_4_0
-#define uprops_getSource uprops_getSource_4_0
-#define upropsvec_addPropertyStarts upropsvec_addPropertyStarts_4_0
-#define uprv_asciiFromEbcdic uprv_asciiFromEbcdic_4_0
-#define uprv_asciitolower uprv_asciitolower_4_0
-#define uprv_ceil uprv_ceil_4_0
-#define uprv_cnttab_addContraction uprv_cnttab_addContraction_4_0
-#define uprv_cnttab_changeContraction uprv_cnttab_changeContraction_4_0
-#define uprv_cnttab_changeLastCE uprv_cnttab_changeLastCE_4_0
-#define uprv_cnttab_clone uprv_cnttab_clone_4_0
-#define uprv_cnttab_close uprv_cnttab_close_4_0
-#define uprv_cnttab_constructTable uprv_cnttab_constructTable_4_0
-#define uprv_cnttab_findCE uprv_cnttab_findCE_4_0
-#define uprv_cnttab_findCP uprv_cnttab_findCP_4_0
-#define uprv_cnttab_getCE uprv_cnttab_getCE_4_0
-#define uprv_cnttab_insertContraction uprv_cnttab_insertContraction_4_0
-#define uprv_cnttab_isTailored uprv_cnttab_isTailored_4_0
-#define uprv_cnttab_open uprv_cnttab_open_4_0
-#define uprv_cnttab_setContraction uprv_cnttab_setContraction_4_0
-#define uprv_compareASCIIPropertyNames uprv_compareASCIIPropertyNames_4_0
-#define uprv_compareEBCDICPropertyNames uprv_compareEBCDICPropertyNames_4_0
-#define uprv_compareInvAscii uprv_compareInvAscii_4_0
-#define uprv_compareInvEbcdic uprv_compareInvEbcdic_4_0
-#define uprv_convertToLCID uprv_convertToLCID_4_0
-#define uprv_convertToPosix uprv_convertToPosix_4_0
-#define uprv_copyAscii uprv_copyAscii_4_0
-#define uprv_copyEbcdic uprv_copyEbcdic_4_0
-#define uprv_ebcdicFromAscii uprv_ebcdicFromAscii_4_0
-#define uprv_ebcdictolower uprv_ebcdictolower_4_0
-#define uprv_fabs uprv_fabs_4_0
-#define uprv_floor uprv_floor_4_0
-#define uprv_fmax uprv_fmax_4_0
-#define uprv_fmin uprv_fmin_4_0
-#define uprv_fmod uprv_fmod_4_0
-#define uprv_free uprv_free_4_0
-#define uprv_getCharNameCharacters uprv_getCharNameCharacters_4_0
-#define uprv_getDefaultCodepage uprv_getDefaultCodepage_4_0
-#define uprv_getDefaultLocaleID uprv_getDefaultLocaleID_4_0
-#define uprv_getInfinity uprv_getInfinity_4_0
-#define uprv_getMaxCharNameLength uprv_getMaxCharNameLength_4_0
-#define uprv_getMaxValues uprv_getMaxValues_4_0
-#define uprv_getNaN uprv_getNaN_4_0
-#define uprv_getStaticCurrencyName uprv_getStaticCurrencyName_4_0
-#define uprv_getUTCtime uprv_getUTCtime_4_0
-#define uprv_haveProperties uprv_haveProperties_4_0
-#define uprv_init_collIterate uprv_init_collIterate_4_0
-#define uprv_init_pce uprv_init_pce_4_0
-#define uprv_int32Comparator uprv_int32Comparator_4_0
-#define uprv_isInfinite uprv_isInfinite_4_0
-#define uprv_isInvariantString uprv_isInvariantString_4_0
-#define uprv_isInvariantUString uprv_isInvariantUString_4_0
-#define uprv_isNaN uprv_isNaN_4_0
-#define uprv_isNegativeInfinity uprv_isNegativeInfinity_4_0
-#define uprv_isPositiveInfinity uprv_isPositiveInfinity_4_0
-#define uprv_isRuleWhiteSpace uprv_isRuleWhiteSpace_4_0
-#define uprv_itou uprv_itou_4_0
-#define uprv_log uprv_log_4_0
-#define uprv_malloc uprv_malloc_4_0
-#define uprv_mapFile uprv_mapFile_4_0
-#define uprv_max uprv_max_4_0
-#define uprv_maxMantissa uprv_maxMantissa_4_0
-#define uprv_maximumPtr uprv_maximumPtr_4_0
-#define uprv_min uprv_min_4_0
-#define uprv_modf uprv_modf_4_0
-#define uprv_openRuleWhiteSpaceSet uprv_openRuleWhiteSpaceSet_4_0
-#define uprv_parseCurrency uprv_parseCurrency_4_0
-#define uprv_pathIsAbsolute uprv_pathIsAbsolute_4_0
-#define uprv_pow uprv_pow_4_0
-#define uprv_pow10 uprv_pow10_4_0
-#define uprv_realloc uprv_realloc_4_0
-#define uprv_round uprv_round_4_0
-#define uprv_sortArray uprv_sortArray_4_0
-#define uprv_strCompare uprv_strCompare_4_0
-#define uprv_strdup uprv_strdup_4_0
-#define uprv_strndup uprv_strndup_4_0
-#define uprv_syntaxError uprv_syntaxError_4_0
-#define uprv_timezone uprv_timezone_4_0
-#define uprv_toupper uprv_toupper_4_0
-#define uprv_trunc uprv_trunc_4_0
-#define uprv_tzname uprv_tzname_4_0
-#define uprv_tzset uprv_tzset_4_0
-#define uprv_uca_addAnElement uprv_uca_addAnElement_4_0
-#define uprv_uca_assembleTable uprv_uca_assembleTable_4_0
-#define uprv_uca_canonicalClosure uprv_uca_canonicalClosure_4_0
-#define uprv_uca_closeTempTable uprv_uca_closeTempTable_4_0
-#define uprv_uca_getCodePointFromRaw uprv_uca_getCodePointFromRaw_4_0
-#define uprv_uca_getImplicitFromRaw uprv_uca_getImplicitFromRaw_4_0
-#define uprv_uca_getRawFromCodePoint uprv_uca_getRawFromCodePoint_4_0
-#define uprv_uca_getRawFromImplicit uprv_uca_getRawFromImplicit_4_0
-#define uprv_uca_initImplicitConstants uprv_uca_initImplicitConstants_4_0
-#define uprv_uca_initTempTable uprv_uca_initTempTable_4_0
-#define uprv_uint16Comparator uprv_uint16Comparator_4_0
-#define uprv_uint32Comparator uprv_uint32Comparator_4_0
-#define uprv_unmapFile uprv_unmapFile_4_0
-#define uregex_appendReplacement uregex_appendReplacement_4_0
-#define uregex_appendTail uregex_appendTail_4_0
-#define uregex_clone uregex_clone_4_0
-#define uregex_close uregex_close_4_0
-#define uregex_end uregex_end_4_0
-#define uregex_find uregex_find_4_0
-#define uregex_findNext uregex_findNext_4_0
-#define uregex_flags uregex_flags_4_0
-#define uregex_getMatchCallback uregex_getMatchCallback_4_0
-#define uregex_getStackLimit uregex_getStackLimit_4_0
-#define uregex_getText uregex_getText_4_0
-#define uregex_getTimeLimit uregex_getTimeLimit_4_0
-#define uregex_group uregex_group_4_0
-#define uregex_groupCount uregex_groupCount_4_0
-#define uregex_hasAnchoringBounds uregex_hasAnchoringBounds_4_0
-#define uregex_hasTransparentBounds uregex_hasTransparentBounds_4_0
-#define uregex_hitEnd uregex_hitEnd_4_0
-#define uregex_lookingAt uregex_lookingAt_4_0
-#define uregex_matches uregex_matches_4_0
-#define uregex_open uregex_open_4_0
-#define uregex_openC uregex_openC_4_0
-#define uregex_pattern uregex_pattern_4_0
-#define uregex_regionEnd uregex_regionEnd_4_0
-#define uregex_regionStart uregex_regionStart_4_0
-#define uregex_replaceAll uregex_replaceAll_4_0
-#define uregex_replaceFirst uregex_replaceFirst_4_0
-#define uregex_requireEnd uregex_requireEnd_4_0
-#define uregex_reset uregex_reset_4_0
-#define uregex_setMatchCallback uregex_setMatchCallback_4_0
-#define uregex_setRegion uregex_setRegion_4_0
-#define uregex_setStackLimit uregex_setStackLimit_4_0
-#define uregex_setText uregex_setText_4_0
-#define uregex_setTimeLimit uregex_setTimeLimit_4_0
-#define uregex_split uregex_split_4_0
-#define uregex_start uregex_start_4_0
-#define uregex_useAnchoringBounds uregex_useAnchoringBounds_4_0
-#define uregex_useTransparentBounds uregex_useTransparentBounds_4_0
-#define ures_close ures_close_4_0
-#define ures_copyResb ures_copyResb_4_0
-#define ures_countArrayItems ures_countArrayItems_4_0
-#define ures_findResource ures_findResource_4_0
-#define ures_findSubResource ures_findSubResource_4_0
-#define ures_getBinary ures_getBinary_4_0
-#define ures_getByIndex ures_getByIndex_4_0
-#define ures_getByKey ures_getByKey_4_0
-#define ures_getByKeyWithFallback ures_getByKeyWithFallback_4_0
-#define ures_getFunctionalEquivalent ures_getFunctionalEquivalent_4_0
-#define ures_getInt ures_getInt_4_0
-#define ures_getIntVector ures_getIntVector_4_0
-#define ures_getKey ures_getKey_4_0
-#define ures_getKeywordValues ures_getKeywordValues_4_0
-#define ures_getLocale ures_getLocale_4_0
-#define ures_getLocaleByType ures_getLocaleByType_4_0
-#define ures_getName ures_getName_4_0
-#define ures_getNextResource ures_getNextResource_4_0
-#define ures_getNextString ures_getNextString_4_0
-#define ures_getSize ures_getSize_4_0
-#define ures_getString ures_getString_4_0
-#define ures_getStringByIndex ures_getStringByIndex_4_0
-#define ures_getStringByKey ures_getStringByKey_4_0
-#define ures_getStringByKeyWithFallback ures_getStringByKeyWithFallback_4_0
-#define ures_getType ures_getType_4_0
-#define ures_getUInt ures_getUInt_4_0
-#define ures_getUTF8String ures_getUTF8String_4_0
-#define ures_getUTF8StringByIndex ures_getUTF8StringByIndex_4_0
-#define ures_getUTF8StringByKey ures_getUTF8StringByKey_4_0
-#define ures_getVersion ures_getVersion_4_0
-#define ures_getVersionNumber ures_getVersionNumber_4_0
-#define ures_hasNext ures_hasNext_4_0
-#define ures_initStackObject ures_initStackObject_4_0
-#define ures_open ures_open_4_0
-#define ures_openAvailableLocales ures_openAvailableLocales_4_0
-#define ures_openDirect ures_openDirect_4_0
-#define ures_openFillIn ures_openFillIn_4_0
-#define ures_openU ures_openU_4_0
-#define ures_resetIterator ures_resetIterator_4_0
-#define ures_swap ures_swap_4_0
-#define uscript_closeRun uscript_closeRun_4_0
-#define uscript_getCode uscript_getCode_4_0
-#define uscript_getName uscript_getName_4_0
-#define uscript_getScript uscript_getScript_4_0
-#define uscript_getShortName uscript_getShortName_4_0
-#define uscript_nextRun uscript_nextRun_4_0
-#define uscript_openRun uscript_openRun_4_0
-#define uscript_resetRun uscript_resetRun_4_0
-#define uscript_setRunText uscript_setRunText_4_0
-#define usearch_close usearch_close_4_0
-#define usearch_first usearch_first_4_0
-#define usearch_following usearch_following_4_0
-#define usearch_getAttribute usearch_getAttribute_4_0
-#define usearch_getBreakIterator usearch_getBreakIterator_4_0
-#define usearch_getCollator usearch_getCollator_4_0
-#define usearch_getMatchedLength usearch_getMatchedLength_4_0
-#define usearch_getMatchedStart usearch_getMatchedStart_4_0
-#define usearch_getMatchedText usearch_getMatchedText_4_0
-#define usearch_getOffset usearch_getOffset_4_0
-#define usearch_getPattern usearch_getPattern_4_0
-#define usearch_getText usearch_getText_4_0
-#define usearch_handleNextCanonical usearch_handleNextCanonical_4_0
-#define usearch_handleNextExact usearch_handleNextExact_4_0
-#define usearch_handlePreviousCanonical usearch_handlePreviousCanonical_4_0
-#define usearch_handlePreviousExact usearch_handlePreviousExact_4_0
-#define usearch_last usearch_last_4_0
-#define usearch_next usearch_next_4_0
-#define usearch_open usearch_open_4_0
-#define usearch_openFromCollator usearch_openFromCollator_4_0
-#define usearch_preceding usearch_preceding_4_0
-#define usearch_previous usearch_previous_4_0
-#define usearch_reset usearch_reset_4_0
-#define usearch_search usearch_search_4_0
-#define usearch_searchBackwards usearch_searchBackwards_4_0
-#define usearch_setAttribute usearch_setAttribute_4_0
-#define usearch_setBreakIterator usearch_setBreakIterator_4_0
-#define usearch_setCollator usearch_setCollator_4_0
-#define usearch_setOffset usearch_setOffset_4_0
-#define usearch_setPattern usearch_setPattern_4_0
-#define usearch_setText usearch_setText_4_0
-#define uset_add uset_add_4_0
-#define uset_addAll uset_addAll_4_0
-#define uset_addAllCodePoints uset_addAllCodePoints_4_0
-#define uset_addRange uset_addRange_4_0
-#define uset_addString uset_addString_4_0
-#define uset_applyIntPropertyValue uset_applyIntPropertyValue_4_0
-#define uset_applyPattern uset_applyPattern_4_0
-#define uset_applyPropertyAlias uset_applyPropertyAlias_4_0
-#define uset_charAt uset_charAt_4_0
-#define uset_clear uset_clear_4_0
-#define uset_clone uset_clone_4_0
-#define uset_cloneAsThawed uset_cloneAsThawed_4_0
-#define uset_close uset_close_4_0
-#define uset_compact uset_compact_4_0
-#define uset_complement uset_complement_4_0
-#define uset_complementAll uset_complementAll_4_0
-#define uset_contains uset_contains_4_0
-#define uset_containsAll uset_containsAll_4_0
-#define uset_containsAllCodePoints uset_containsAllCodePoints_4_0
-#define uset_containsNone uset_containsNone_4_0
-#define uset_containsRange uset_containsRange_4_0
-#define uset_containsSome uset_containsSome_4_0
-#define uset_containsString uset_containsString_4_0
-#define uset_equals uset_equals_4_0
-#define uset_freeze uset_freeze_4_0
-#define uset_getItem uset_getItem_4_0
-#define uset_getItemCount uset_getItemCount_4_0
-#define uset_getSerializedRange uset_getSerializedRange_4_0
-#define uset_getSerializedRangeCount uset_getSerializedRangeCount_4_0
-#define uset_getSerializedSet uset_getSerializedSet_4_0
-#define uset_indexOf uset_indexOf_4_0
-#define uset_isEmpty uset_isEmpty_4_0
-#define uset_isFrozen uset_isFrozen_4_0
-#define uset_open uset_open_4_0
-#define uset_openPattern uset_openPattern_4_0
-#define uset_openPatternOptions uset_openPatternOptions_4_0
-#define uset_remove uset_remove_4_0
-#define uset_removeAll uset_removeAll_4_0
-#define uset_removeRange uset_removeRange_4_0
-#define uset_removeString uset_removeString_4_0
-#define uset_resemblesPattern uset_resemblesPattern_4_0
-#define uset_retain uset_retain_4_0
-#define uset_retainAll uset_retainAll_4_0
-#define uset_serialize uset_serialize_4_0
-#define uset_serializedContains uset_serializedContains_4_0
-#define uset_set uset_set_4_0
-#define uset_setSerializedToOne uset_setSerializedToOne_4_0
-#define uset_size uset_size_4_0
-#define uset_span uset_span_4_0
-#define uset_spanBack uset_spanBack_4_0
-#define uset_spanBackUTF8 uset_spanBackUTF8_4_0
-#define uset_spanUTF8 uset_spanUTF8_4_0
-#define uset_toPattern uset_toPattern_4_0
-#define usprep_close usprep_close_4_0
-#define usprep_open usprep_open_4_0
-#define usprep_prepare usprep_prepare_4_0
-#define usprep_swap usprep_swap_4_0
-#define ustr_foldCase ustr_foldCase_4_0
-#define ustr_toLower ustr_toLower_4_0
-#define ustr_toTitle ustr_toTitle_4_0
-#define ustr_toUpper ustr_toUpper_4_0
-#define utext_char32At utext_char32At_4_0
-#define utext_clone utext_clone_4_0
-#define utext_close utext_close_4_0
-#define utext_copy utext_copy_4_0
-#define utext_current32 utext_current32_4_0
-#define utext_equals utext_equals_4_0
-#define utext_extract utext_extract_4_0
-#define utext_freeze utext_freeze_4_0
-#define utext_getNativeIndex utext_getNativeIndex_4_0
-#define utext_getPreviousNativeIndex utext_getPreviousNativeIndex_4_0
-#define utext_hasMetaData utext_hasMetaData_4_0
-#define utext_isLengthExpensive utext_isLengthExpensive_4_0
-#define utext_isWritable utext_isWritable_4_0
-#define utext_moveIndex32 utext_moveIndex32_4_0
-#define utext_nativeLength utext_nativeLength_4_0
-#define utext_next32 utext_next32_4_0
-#define utext_next32From utext_next32From_4_0
-#define utext_openCharacterIterator utext_openCharacterIterator_4_0
-#define utext_openConstUnicodeString utext_openConstUnicodeString_4_0
-#define utext_openReplaceable utext_openReplaceable_4_0
-#define utext_openUChars utext_openUChars_4_0
-#define utext_openUTF8 utext_openUTF8_4_0
-#define utext_openUnicodeString utext_openUnicodeString_4_0
-#define utext_previous32 utext_previous32_4_0
-#define utext_previous32From utext_previous32From_4_0
-#define utext_replace utext_replace_4_0
-#define utext_setNativeIndex utext_setNativeIndex_4_0
-#define utext_setup utext_setup_4_0
-#define utf8_appendCharSafeBody utf8_appendCharSafeBody_4_0
-#define utf8_back1SafeBody utf8_back1SafeBody_4_0
-#define utf8_countTrailBytes utf8_countTrailBytes_4_0
-#define utf8_nextCharSafeBody utf8_nextCharSafeBody_4_0
-#define utf8_prevCharSafeBody utf8_prevCharSafeBody_4_0
-#define utmscale_fromInt64 utmscale_fromInt64_4_0
-#define utmscale_getTimeScaleValue utmscale_getTimeScaleValue_4_0
-#define utmscale_toInt64 utmscale_toInt64_4_0
-#define utrace_cleanup utrace_cleanup_4_0
-#define utrace_data utrace_data_4_0
-#define utrace_entry utrace_entry_4_0
-#define utrace_exit utrace_exit_4_0
-#define utrace_format utrace_format_4_0
-#define utrace_functionName utrace_functionName_4_0
-#define utrace_getFunctions utrace_getFunctions_4_0
-#define utrace_getLevel utrace_getLevel_4_0
-#define utrace_level utrace_level_4_0
-#define utrace_setFunctions utrace_setFunctions_4_0
-#define utrace_setLevel utrace_setLevel_4_0
-#define utrace_vformat utrace_vformat_4_0
-#define utrans_clone utrans_clone_4_0
-#define utrans_close utrans_close_4_0
-#define utrans_countAvailableIDs utrans_countAvailableIDs_4_0
-#define utrans_getAvailableID utrans_getAvailableID_4_0
-#define utrans_getID utrans_getID_4_0
-#define utrans_getUnicodeID utrans_getUnicodeID_4_0
-#define utrans_open utrans_open_4_0
-#define utrans_openIDs utrans_openIDs_4_0
-#define utrans_openInverse utrans_openInverse_4_0
-#define utrans_openU utrans_openU_4_0
-#define utrans_register utrans_register_4_0
-#define utrans_rep_caseContextIterator utrans_rep_caseContextIterator_4_0
-#define utrans_setFilter utrans_setFilter_4_0
-#define utrans_stripRules utrans_stripRules_4_0
-#define utrans_trans utrans_trans_4_0
-#define utrans_transIncremental utrans_transIncremental_4_0
-#define utrans_transIncrementalUChars utrans_transIncrementalUChars_4_0
-#define utrans_transUChars utrans_transUChars_4_0
-#define utrans_unregister utrans_unregister_4_0
-#define utrans_unregisterID utrans_unregisterID_4_0
-#define utrie_clone utrie_clone_4_0
-#define utrie_close utrie_close_4_0
-#define utrie_defaultGetFoldingOffset utrie_defaultGetFoldingOffset_4_0
-#define utrie_enum utrie_enum_4_0
-#define utrie_get32 utrie_get32_4_0
-#define utrie_getData utrie_getData_4_0
-#define utrie_open utrie_open_4_0
-#define utrie_serialize utrie_serialize_4_0
-#define utrie_set32 utrie_set32_4_0
-#define utrie_setRange32 utrie_setRange32_4_0
-#define utrie_swap utrie_swap_4_0
-#define utrie_unserialize utrie_unserialize_4_0
-#define utrie_unserializeDummy utrie_unserializeDummy_4_0
-/* C++ class names renaming defines */
-
-#ifdef XP_CPLUSPLUS
-#if !U_HAVE_NAMESPACE
-
-#define AbsoluteValueSubstitution AbsoluteValueSubstitution_4_0
-#define AlternateSubstitutionSubtable AlternateSubstitutionSubtable_4_0
-#define AnchorTable AnchorTable_4_0
-#define AndConstraint AndConstraint_4_0
-#define AnnualTimeZoneRule AnnualTimeZoneRule_4_0
-#define AnyTransliterator AnyTransliterator_4_0
-#define ArabicOpenTypeLayoutEngine ArabicOpenTypeLayoutEngine_4_0
-#define ArabicShaping ArabicShaping_4_0
-#define BMPSet BMPSet_4_0
-#define BasicCalendarFactory BasicCalendarFactory_4_0
-#define BasicTimeZone BasicTimeZone_4_0
-#define BinarySearchLookupTable BinarySearchLookupTable_4_0
-#define BreakIterator BreakIterator_4_0
-#define BreakTransliterator BreakTransliterator_4_0
-#define BuddhistCalendar BuddhistCalendar_4_0
-#define BuildCompactTrieHorizontalNode BuildCompactTrieHorizontalNode_4_0
-#define BuildCompactTrieNode BuildCompactTrieNode_4_0
-#define BuildCompactTrieVerticalNode BuildCompactTrieVerticalNode_4_0
-#define CEBuffer CEBuffer_4_0
-#define CECalendar CECalendar_4_0
-#define CFactory CFactory_4_0
-#define Calendar Calendar_4_0
-#define CalendarAstronomer CalendarAstronomer_4_0
-#define CalendarCache CalendarCache_4_0
-#define CalendarData CalendarData_4_0
-#define CalendarService CalendarService_4_0
-#define CanonMarkFilter CanonMarkFilter_4_0
-#define CanonShaping CanonShaping_4_0
-#define CanonicalIterator CanonicalIterator_4_0
-#define CaseMapTransliterator CaseMapTransliterator_4_0
-#define ChainingContextualSubstitutionFormat1Subtable ChainingContextualSubstitutionFormat1Subtable_4_0
-#define ChainingContextualSubstitutionFormat2Subtable ChainingContextualSubstitutionFormat2Subtable_4_0
-#define ChainingContextualSubstitutionFormat3Subtable ChainingContextualSubstitutionFormat3Subtable_4_0
-#define ChainingContextualSubstitutionSubtable ChainingContextualSubstitutionSubtable_4_0
-#define CharSubstitutionFilter CharSubstitutionFilter_4_0
-#define CharacterIterator CharacterIterator_4_0
-#define CharacterNode CharacterNode_4_0
-#define CharsetDetector CharsetDetector_4_0
-#define CharsetMatch CharsetMatch_4_0
-#define CharsetRecog_2022 CharsetRecog_2022_4_0
-#define CharsetRecog_2022CN CharsetRecog_2022CN_4_0
-#define CharsetRecog_2022JP CharsetRecog_2022JP_4_0
-#define CharsetRecog_2022KR CharsetRecog_2022KR_4_0
-#define CharsetRecog_8859_1 CharsetRecog_8859_1_4_0
-#define CharsetRecog_8859_1_da CharsetRecog_8859_1_da_4_0
-#define CharsetRecog_8859_1_de CharsetRecog_8859_1_de_4_0
-#define CharsetRecog_8859_1_en CharsetRecog_8859_1_en_4_0
-#define CharsetRecog_8859_1_es CharsetRecog_8859_1_es_4_0
-#define CharsetRecog_8859_1_fr CharsetRecog_8859_1_fr_4_0
-#define CharsetRecog_8859_1_it CharsetRecog_8859_1_it_4_0
-#define CharsetRecog_8859_1_nl CharsetRecog_8859_1_nl_4_0
-#define CharsetRecog_8859_1_no CharsetRecog_8859_1_no_4_0
-#define CharsetRecog_8859_1_pt CharsetRecog_8859_1_pt_4_0
-#define CharsetRecog_8859_1_sv CharsetRecog_8859_1_sv_4_0
-#define CharsetRecog_8859_2 CharsetRecog_8859_2_4_0
-#define CharsetRecog_8859_2_cs CharsetRecog_8859_2_cs_4_0
-#define CharsetRecog_8859_2_hu CharsetRecog_8859_2_hu_4_0
-#define CharsetRecog_8859_2_pl CharsetRecog_8859_2_pl_4_0
-#define CharsetRecog_8859_2_ro CharsetRecog_8859_2_ro_4_0
-#define CharsetRecog_8859_5 CharsetRecog_8859_5_4_0
-#define CharsetRecog_8859_5_ru CharsetRecog_8859_5_ru_4_0
-#define CharsetRecog_8859_6 CharsetRecog_8859_6_4_0
-#define CharsetRecog_8859_6_ar CharsetRecog_8859_6_ar_4_0
-#define CharsetRecog_8859_7 CharsetRecog_8859_7_4_0
-#define CharsetRecog_8859_7_el CharsetRecog_8859_7_el_4_0
-#define CharsetRecog_8859_8 CharsetRecog_8859_8_4_0
-#define CharsetRecog_8859_8_I_he CharsetRecog_8859_8_I_he_4_0
-#define CharsetRecog_8859_8_he CharsetRecog_8859_8_he_4_0
-#define CharsetRecog_8859_9 CharsetRecog_8859_9_4_0
-#define CharsetRecog_8859_9_tr CharsetRecog_8859_9_tr_4_0
-#define CharsetRecog_KOI8_R CharsetRecog_KOI8_R_4_0
-#define CharsetRecog_UTF8 CharsetRecog_UTF8_4_0
-#define CharsetRecog_UTF_16_BE CharsetRecog_UTF_16_BE_4_0
-#define CharsetRecog_UTF_16_LE CharsetRecog_UTF_16_LE_4_0
-#define CharsetRecog_UTF_32 CharsetRecog_UTF_32_4_0
-#define CharsetRecog_UTF_32_BE CharsetRecog_UTF_32_BE_4_0
-#define CharsetRecog_UTF_32_LE CharsetRecog_UTF_32_LE_4_0
-#define CharsetRecog_Unicode CharsetRecog_Unicode_4_0
-#define CharsetRecog_big5 CharsetRecog_big5_4_0
-#define CharsetRecog_euc CharsetRecog_euc_4_0
-#define CharsetRecog_euc_jp CharsetRecog_euc_jp_4_0
-#define CharsetRecog_euc_kr CharsetRecog_euc_kr_4_0
-#define CharsetRecog_gb_18030 CharsetRecog_gb_18030_4_0
-#define CharsetRecog_mbcs CharsetRecog_mbcs_4_0
-#define CharsetRecog_sbcs CharsetRecog_sbcs_4_0
-#define CharsetRecog_sjis CharsetRecog_sjis_4_0
-#define CharsetRecog_windows_1251 CharsetRecog_windows_1251_4_0
-#define CharsetRecog_windows_1256 CharsetRecog_windows_1256_4_0
-#define CharsetRecognizer CharsetRecognizer_4_0
-#define ChineseCalendar ChineseCalendar_4_0
-#define ChoiceFormat ChoiceFormat_4_0
-#define ClassDefFormat1Table ClassDefFormat1Table_4_0
-#define ClassDefFormat2Table ClassDefFormat2Table_4_0
-#define ClassDefinitionTable ClassDefinitionTable_4_0
-#define CollationElementIterator CollationElementIterator_4_0
-#define CollationKey CollationKey_4_0
-#define CollationLocaleListEnumeration CollationLocaleListEnumeration_4_0
-#define Collator Collator_4_0
-#define CollatorFactory CollatorFactory_4_0
-#define CompactTrieDictionary CompactTrieDictionary_4_0
-#define CompactTrieEnumeration CompactTrieEnumeration_4_0
-#define CompoundTransliterator CompoundTransliterator_4_0
-#define ContextualGlyphSubstitutionProcessor ContextualGlyphSubstitutionProcessor_4_0
-#define ContextualSubstitutionBase ContextualSubstitutionBase_4_0
-#define ContextualSubstitutionFormat1Subtable ContextualSubstitutionFormat1Subtable_4_0
-#define ContextualSubstitutionFormat2Subtable ContextualSubstitutionFormat2Subtable_4_0
-#define ContextualSubstitutionFormat3Subtable ContextualSubstitutionFormat3Subtable_4_0
-#define ContextualSubstitutionSubtable ContextualSubstitutionSubtable_4_0
-#define CopticCalendar CopticCalendar_4_0
-#define CoverageFormat1Table CoverageFormat1Table_4_0
-#define CoverageFormat2Table CoverageFormat2Table_4_0
-#define CoverageTable CoverageTable_4_0
-#define CurrencyAmount CurrencyAmount_4_0
-#define CurrencyFormat CurrencyFormat_4_0
-#define CurrencyUnit CurrencyUnit_4_0
-#define CursiveAttachmentSubtable CursiveAttachmentSubtable_4_0
-#define DTRedundantEnumeration DTRedundantEnumeration_4_0
-#define DTSkeletonEnumeration DTSkeletonEnumeration_4_0
-#define DateFormat DateFormat_4_0
-#define DateFormatSymbols DateFormatSymbols_4_0
-#define DateInterval DateInterval_4_0
-#define DateIntervalFormat DateIntervalFormat_4_0
-#define DateIntervalInfo DateIntervalInfo_4_0
-#define DateTimeMatcher DateTimeMatcher_4_0
-#define DateTimePatternGenerator DateTimePatternGenerator_4_0
-#define DateTimeRule DateTimeRule_4_0
-#define DecimalFormat DecimalFormat_4_0
-#define DecimalFormatSymbols DecimalFormatSymbols_4_0
-#define DefaultCalendarFactory DefaultCalendarFactory_4_0
-#define DefaultCharMapper DefaultCharMapper_4_0
-#define DeviceTable DeviceTable_4_0
-#define DictionaryBreakEngine DictionaryBreakEngine_4_0
-#define DigitList DigitList_4_0
-#define DistanceInfo DistanceInfo_4_0
-#define Entry Entry_4_0
-#define EnumToOffset EnumToOffset_4_0
-#define EscapeTransliterator EscapeTransliterator_4_0
-#define EthiopicCalendar EthiopicCalendar_4_0
-#define EventListener EventListener_4_0
-#define ExtensionSubtable ExtensionSubtable_4_0
-#define FeatureListTable FeatureListTable_4_0
-#define FieldPosition FieldPosition_4_0
-#define FontRuns FontRuns_4_0
-#define Format Format_4_0
-#define Format1AnchorTable Format1AnchorTable_4_0
-#define Format2AnchorTable Format2AnchorTable_4_0
-#define Format3AnchorTable Format3AnchorTable_4_0
-#define FormatNameEnumeration FormatNameEnumeration_4_0
-#define FormatParser FormatParser_4_0
-#define Formattable Formattable_4_0
-#define ForwardCharacterIterator ForwardCharacterIterator_4_0
-#define FractionalPartSubstitution FractionalPartSubstitution_4_0
-#define FunctionReplacer FunctionReplacer_4_0
-#define GDEFMarkFilter GDEFMarkFilter_4_0
-#define GXLayoutEngine GXLayoutEngine_4_0
-#define GlyphDefinitionTableHeader GlyphDefinitionTableHeader_4_0
-#define GlyphIterator GlyphIterator_4_0
-#define GlyphLookupTableHeader GlyphLookupTableHeader_4_0
-#define GlyphPositionAdjustments GlyphPositionAdjustments_4_0
-#define GlyphPositioningLookupProcessor GlyphPositioningLookupProcessor_4_0
-#define GlyphPositioningTableHeader GlyphPositioningTableHeader_4_0
-#define GlyphSubstitutionLookupProcessor GlyphSubstitutionLookupProcessor_4_0
-#define GlyphSubstitutionTableHeader GlyphSubstitutionTableHeader_4_0
-#define Grego Grego_4_0
-#define GregorianCalendar GregorianCalendar_4_0
-#define HanOpenTypeLayoutEngine HanOpenTypeLayoutEngine_4_0
-#define HangulOpenTypeLayoutEngine HangulOpenTypeLayoutEngine_4_0
-#define HebrewCalendar HebrewCalendar_4_0
-#define ICUBreakIteratorFactory ICUBreakIteratorFactory_4_0
-#define ICUBreakIteratorService ICUBreakIteratorService_4_0
-#define ICUCollatorFactory ICUCollatorFactory_4_0
-#define ICUCollatorService ICUCollatorService_4_0
-#define ICULanguageBreakFactory ICULanguageBreakFactory_4_0
-#define ICULocaleService ICULocaleService_4_0
-#define ICUNotifier ICUNotifier_4_0
-#define ICUNumberFormatFactory ICUNumberFormatFactory_4_0
-#define ICUNumberFormatService ICUNumberFormatService_4_0
-#define ICUResourceBundleFactory ICUResourceBundleFactory_4_0
-#define ICUService ICUService_4_0
-#define ICUServiceFactory ICUServiceFactory_4_0
-#define ICUServiceKey ICUServiceKey_4_0
-#define ICU_Utility ICU_Utility_4_0
-#define IndianCalendar IndianCalendar_4_0
-#define IndicClassTable IndicClassTable_4_0
-#define IndicOpenTypeLayoutEngine IndicOpenTypeLayoutEngine_4_0
-#define IndicRearrangementProcessor IndicRearrangementProcessor_4_0
-#define IndicReordering IndicReordering_4_0
-#define InitialTimeZoneRule InitialTimeZoneRule_4_0
-#define InputText InputText_4_0
-#define IntegralPartSubstitution IntegralPartSubstitution_4_0
-#define IslamicCalendar IslamicCalendar_4_0
-#define IteratedChar IteratedChar_4_0
-#define JapaneseCalendar JapaneseCalendar_4_0
-#define KernTable KernTable_4_0
-#define KeywordEnumeration KeywordEnumeration_4_0
-#define KhmerClassTable KhmerClassTable_4_0
-#define KhmerOpenTypeLayoutEngine KhmerOpenTypeLayoutEngine_4_0
-#define KhmerReordering KhmerReordering_4_0
-#define LECharMapper LECharMapper_4_0
-#define LEFontInstance LEFontInstance_4_0
-#define LEGlyphFilter LEGlyphFilter_4_0
-#define LEGlyphStorage LEGlyphStorage_4_0
-#define LEInsertionCallback LEInsertionCallback_4_0
-#define LEInsertionList LEInsertionList_4_0
-#define LXUtilities LXUtilities_4_0
-#define LanguageBreakEngine LanguageBreakEngine_4_0
-#define LanguageBreakFactory LanguageBreakFactory_4_0
-#define LayoutEngine LayoutEngine_4_0
-#define LigatureSubstitutionProcessor LigatureSubstitutionProcessor_4_0
-#define LigatureSubstitutionSubtable LigatureSubstitutionSubtable_4_0
-#define LocDataParser LocDataParser_4_0
-#define Locale Locale_4_0
-#define LocaleBased LocaleBased_4_0
-#define LocaleKey LocaleKey_4_0
-#define LocaleKeyFactory LocaleKeyFactory_4_0
-#define LocaleRuns LocaleRuns_4_0
-#define LocaleUtility LocaleUtility_4_0
-#define LocalizationInfo LocalizationInfo_4_0
-#define LookupListTable LookupListTable_4_0
-#define LookupProcessor LookupProcessor_4_0
-#define LookupSubtable LookupSubtable_4_0
-#define LookupTable LookupTable_4_0
-#define LowercaseTransliterator LowercaseTransliterator_4_0
-#define MPreFixups MPreFixups_4_0
-#define MarkArray MarkArray_4_0
-#define MarkToBasePositioningSubtable MarkToBasePositioningSubtable_4_0
-#define MarkToLigaturePositioningSubtable MarkToLigaturePositioningSubtable_4_0
-#define MarkToMarkPositioningSubtable MarkToMarkPositioningSubtable_4_0
-#define Math Math_4_0
-#define Measure Measure_4_0
-#define MeasureFormat MeasureFormat_4_0
-#define MeasureUnit MeasureUnit_4_0
-#define MessageFormat MessageFormat_4_0
-#define MessageFormatAdapter MessageFormatAdapter_4_0
-#define ModulusSubstitution ModulusSubstitution_4_0
-#define MoonRiseSetCoordFunc MoonRiseSetCoordFunc_4_0
-#define MoonTimeAngleFunc MoonTimeAngleFunc_4_0
-#define MorphSubtableHeader MorphSubtableHeader_4_0
-#define MorphTableHeader MorphTableHeader_4_0
-#define MultipleSubstitutionSubtable MultipleSubstitutionSubtable_4_0
-#define MultiplierSubstitution MultiplierSubstitution_4_0
-#define MutableTrieDictionary MutableTrieDictionary_4_0
-#define MutableTrieEnumeration MutableTrieEnumeration_4_0
-#define NFFactory NFFactory_4_0
-#define NFRule NFRule_4_0
-#define NFRuleSet NFRuleSet_4_0
-#define NFSubstitution NFSubstitution_4_0
-#define NGramParser NGramParser_4_0
-#define NameToEnum NameToEnum_4_0
-#define NameUnicodeTransliterator NameUnicodeTransliterator_4_0
-#define NonContextualGlyphSubstitutionProcessor NonContextualGlyphSubstitutionProcessor_4_0
-#define NonContiguousEnumToOffset NonContiguousEnumToOffset_4_0
-#define NormalizationTransliterator NormalizationTransliterator_4_0
-#define Normalizer Normalizer_4_0
-#define NullSubstitution NullSubstitution_4_0
-#define NullTransliterator NullTransliterator_4_0
-#define NumberFormat NumberFormat_4_0
-#define NumberFormatFactory NumberFormatFactory_4_0
-#define NumeratorSubstitution NumeratorSubstitution_4_0
-#define OlsonTimeZone OlsonTimeZone_4_0
-#define OpenTypeLayoutEngine OpenTypeLayoutEngine_4_0
-#define OpenTypeUtilities OpenTypeUtilities_4_0
-#define OrConstraint OrConstraint_4_0
-#define PCEBuffer PCEBuffer_4_0
-#define PairPositioningFormat1Subtable PairPositioningFormat1Subtable_4_0
-#define PairPositioningFormat2Subtable PairPositioningFormat2Subtable_4_0
-#define PairPositioningSubtable PairPositioningSubtable_4_0
-#define ParagraphLayout ParagraphLayout_4_0
-#define ParseData ParseData_4_0
-#define ParsePosition ParsePosition_4_0
-#define PatternMap PatternMap_4_0
-#define PatternMapIterator PatternMapIterator_4_0
-#define PersianCalendar PersianCalendar_4_0
-#define PluralFormat PluralFormat_4_0
-#define PluralKeywordEnumeration PluralKeywordEnumeration_4_0
-#define PluralRules PluralRules_4_0
-#define PropertyAliases PropertyAliases_4_0
-#define PtnElem PtnElem_4_0
-#define PtnSkeleton PtnSkeleton_4_0
-#define Quantifier Quantifier_4_0
-#define RBBIDataWrapper RBBIDataWrapper_4_0
-#define RBBINode RBBINode_4_0
-#define RBBIRuleBuilder RBBIRuleBuilder_4_0
-#define RBBIRuleScanner RBBIRuleScanner_4_0
-#define RBBISetBuilder RBBISetBuilder_4_0
-#define RBBIStateDescriptor RBBIStateDescriptor_4_0
-#define RBBISymbolTable RBBISymbolTable_4_0
-#define RBBISymbolTableEntry RBBISymbolTableEntry_4_0
-#define RBBITableBuilder RBBITableBuilder_4_0
-#define RCEBuffer RCEBuffer_4_0
-#define RangeDescriptor RangeDescriptor_4_0
-#define RegexCImpl RegexCImpl_4_0
-#define RegexCompile RegexCompile_4_0
-#define RegexMatcher RegexMatcher_4_0
-#define RegexPattern RegexPattern_4_0
-#define RegexStaticSets RegexStaticSets_4_0
-#define RelativeDateFormat RelativeDateFormat_4_0
-#define RemoveTransliterator RemoveTransliterator_4_0
-#define Replaceable Replaceable_4_0
-#define ReplaceableGlue ReplaceableGlue_4_0
-#define ResourceBundle ResourceBundle_4_0
-#define RiseSetCoordFunc RiseSetCoordFunc_4_0
-#define RuleBasedBreakIterator RuleBasedBreakIterator_4_0
-#define RuleBasedCollator RuleBasedCollator_4_0
-#define RuleBasedNumberFormat RuleBasedNumberFormat_4_0
-#define RuleBasedTimeZone RuleBasedTimeZone_4_0
-#define RuleBasedTransliterator RuleBasedTransliterator_4_0
-#define RuleChain RuleChain_4_0
-#define RuleCharacterIterator RuleCharacterIterator_4_0
-#define RuleHalf RuleHalf_4_0
-#define RuleParser RuleParser_4_0
-#define RunArray RunArray_4_0
-#define SafeZoneStringFormatPtr SafeZoneStringFormatPtr_4_0
-#define SameValueSubstitution SameValueSubstitution_4_0
-#define ScriptListTable ScriptListTable_4_0
-#define ScriptRunIterator ScriptRunIterator_4_0
-#define ScriptTable ScriptTable_4_0
-#define SearchIterator SearchIterator_4_0
-#define SegmentArrayProcessor SegmentArrayProcessor_4_0
-#define SegmentSingleProcessor SegmentSingleProcessor_4_0
-#define ServiceEnumeration ServiceEnumeration_4_0
-#define ServiceListener ServiceListener_4_0
-#define SimpleArrayProcessor SimpleArrayProcessor_4_0
-#define SimpleDateFormat SimpleDateFormat_4_0
-#define SimpleFactory SimpleFactory_4_0
-#define SimpleLocaleKeyFactory SimpleLocaleKeyFactory_4_0
-#define SimpleNumberFormatFactory SimpleNumberFormatFactory_4_0
-#define SimpleTimeZone SimpleTimeZone_4_0
-#define SinglePositioningFormat1Subtable SinglePositioningFormat1Subtable_4_0
-#define SinglePositioningFormat2Subtable SinglePositioningFormat2Subtable_4_0
-#define SinglePositioningSubtable SinglePositioningSubtable_4_0
-#define SingleSubstitutionFormat1Subtable SingleSubstitutionFormat1Subtable_4_0
-#define SingleSubstitutionFormat2Subtable SingleSubstitutionFormat2Subtable_4_0
-#define SingleSubstitutionSubtable SingleSubstitutionSubtable_4_0
-#define SingleTableProcessor SingleTableProcessor_4_0
-#define Spec Spec_4_0
-#define StateTableProcessor StateTableProcessor_4_0
-#define StringCharacterIterator StringCharacterIterator_4_0
-#define StringEnumeration StringEnumeration_4_0
-#define StringLocalizationInfo StringLocalizationInfo_4_0
-#define StringMatcher StringMatcher_4_0
-#define StringPair StringPair_4_0
-#define StringReplacer StringReplacer_4_0
-#define StringSearch StringSearch_4_0
-#define StyleRuns StyleRuns_4_0
-#define SubstitutionLookup SubstitutionLookup_4_0
-#define SubtableProcessor SubtableProcessor_4_0
-#define SunTimeAngleFunc SunTimeAngleFunc_4_0
-#define SymbolTable SymbolTable_4_0
-#define TZEnumeration TZEnumeration_4_0
-#define TaiwanCalendar TaiwanCalendar_4_0
-#define TernaryNode TernaryNode_4_0
-#define TextTrieMap TextTrieMap_4_0
-#define TextTrieMapSearchResultHandler TextTrieMapSearchResultHandler_4_0
-#define ThaiBreakEngine ThaiBreakEngine_4_0
-#define ThaiLayoutEngine ThaiLayoutEngine_4_0
-#define ThaiShaping ThaiShaping_4_0
-#define TibetanClassTable TibetanClassTable_4_0
-#define TibetanOpenTypeLayoutEngine TibetanOpenTypeLayoutEngine_4_0
-#define TibetanReordering TibetanReordering_4_0
-#define TimeArrayTimeZoneRule TimeArrayTimeZoneRule_4_0
-#define TimeZone TimeZone_4_0
-#define TimeZoneRule TimeZoneRule_4_0
-#define TimeZoneTransition TimeZoneTransition_4_0
-#define TitlecaseTransliterator TitlecaseTransliterator_4_0
-#define TransliterationRule TransliterationRule_4_0
-#define TransliterationRuleData TransliterationRuleData_4_0
-#define TransliterationRuleSet TransliterationRuleSet_4_0
-#define Transliterator Transliterator_4_0
-#define TransliteratorAlias TransliteratorAlias_4_0
-#define TransliteratorIDParser TransliteratorIDParser_4_0
-#define TransliteratorParser TransliteratorParser_4_0
-#define TransliteratorRegistry TransliteratorRegistry_4_0
-#define TrieWordDictionary TrieWordDictionary_4_0
-#define TrimmedArrayProcessor TrimmedArrayProcessor_4_0
-#define UCharCharacterIterator UCharCharacterIterator_4_0
-#define UCollationPCE UCollationPCE_4_0
-#define ULocRuns ULocRuns_4_0
-#define UMemory UMemory_4_0
-#define UObject UObject_4_0
-#define URegularExpression URegularExpression_4_0
-#define UStack UStack_4_0
-#define UStringEnumeration UStringEnumeration_4_0
-#define UVector UVector_4_0
-#define UVector32 UVector32_4_0
-#define UnescapeTransliterator UnescapeTransliterator_4_0
-#define UnhandledEngine UnhandledEngine_4_0
-#define UnicodeArabicOpenTypeLayoutEngine UnicodeArabicOpenTypeLayoutEngine_4_0
-#define UnicodeFilter UnicodeFilter_4_0
-#define UnicodeFunctor UnicodeFunctor_4_0
-#define UnicodeMatcher UnicodeMatcher_4_0
-#define UnicodeNameTransliterator UnicodeNameTransliterator_4_0
-#define UnicodeReplacer UnicodeReplacer_4_0
-#define UnicodeSet UnicodeSet_4_0
-#define UnicodeSetIterator UnicodeSetIterator_4_0
-#define UnicodeSetStringSpan UnicodeSetStringSpan_4_0
-#define UnicodeString UnicodeString_4_0
-#define UppercaseTransliterator UppercaseTransliterator_4_0
-#define VTZReader VTZReader_4_0
-#define VTZWriter VTZWriter_4_0
-#define VTimeZone VTimeZone_4_0
-#define ValueRecord ValueRecord_4_0
-#define ValueRuns ValueRuns_4_0
-#define ZSFCache ZSFCache_4_0
-#define ZSFCacheEntry ZSFCacheEntry_4_0
-#define ZoneMeta ZoneMeta_4_0
-#define ZoneStringFormat ZoneStringFormat_4_0
-#define ZoneStringInfo ZoneStringInfo_4_0
-#define ZoneStringSearchResultHandler ZoneStringSearchResultHandler_4_0
-#define ZoneStrings ZoneStrings_4_0
-#define locale_set_default_internal locale_set_default_internal_4_0
-#define util64_fromDouble util64_fromDouble_4_0
-#define util64_pow util64_pow_4_0
-#define util64_tou util64_tou_4_0
-
-#endif
-#endif
-
-#endif
-
-#endif


[18/57] [abbrv] remove couch_collate

Posted by be...@apache.org.
http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/ucnv.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/ucnv.h b/apps/couch_collate/platform/osx/icu/unicode/ucnv.h
deleted file mode 100644
index bfd7198..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/ucnv.h
+++ /dev/null
@@ -1,1967 +0,0 @@
-/*
-**********************************************************************
-*   Copyright (C) 1999-2008, International Business Machines
-*   Corporation and others.  All Rights Reserved.
-**********************************************************************
- *  ucnv.h:
- *  External APIs for the ICU's codeset conversion library
- *  Bertrand A. Damiba
- *
- * Modification History:
- *
- *   Date        Name        Description
- *   04/04/99    helena      Fixed internal header inclusion.
- *   05/11/00    helena      Added setFallback and usesFallback APIs.
- *   06/29/2000  helena      Major rewrite of the callback APIs.
- *   12/07/2000  srl         Update of documentation
- */
-
-/**
- * \file
- * \brief C API: Character conversion 
- *
- * <h2>Character Conversion C API</h2>
- *
- * <p>This API is used to convert codepage or character encoded data to and
- * from UTF-16. You can open a converter with {@link ucnv_open() }. With that
- * converter, you can get its properties, set options, convert your data and
- * close the converter.</p>
- *
- * <p>Since many software programs recogize different converter names for
- * different types of converters, there are other functions in this API to
- * iterate over the converter aliases. The functions {@link ucnv_getAvailableName() },
- * {@link ucnv_getAlias() } and {@link ucnv_getStandardName() } are some of the
- * more frequently used alias functions to get this information.</p>
- *
- * <p>When a converter encounters an illegal, irregular, invalid or unmappable character
- * its default behavior is to use a substitution character to replace the
- * bad byte sequence. This behavior can be changed by using {@link ucnv_setFromUCallBack() }
- * or {@link ucnv_setToUCallBack() } on the converter. The header ucnv_err.h defines
- * many other callback actions that can be used instead of a character substitution.</p>
- *
- * <p>More information about this API can be found in our 
- * <a href="http://icu-project.org/userguide/conversion.html">User's
- * Guide</a>.</p>
- */
-
-#ifndef UCNV_H
-#define UCNV_H
-
-#include "unicode/ucnv_err.h"
-#include "unicode/uenum.h"
-
-#ifndef __USET_H__
-
-/**
- * USet is the C API type for Unicode sets.
- * It is forward-declared here to avoid including the header file if related
- * conversion APIs are not used.
- * See unicode/uset.h
- *
- * @see ucnv_getUnicodeSet
- * @stable ICU 2.6
- */
-struct USet;
-/** @stable ICU 2.6 */
-typedef struct USet USet;
-
-#endif
-
-#if !UCONFIG_NO_CONVERSION
-
-U_CDECL_BEGIN
-
-/** Maximum length of a converter name including the terminating NULL @stable ICU 2.0 */
-#define UCNV_MAX_CONVERTER_NAME_LENGTH 60
-/** Maximum length of a converter name including path and terminating NULL @stable ICU 2.0 */
-#define UCNV_MAX_FULL_FILE_NAME_LENGTH (600+UCNV_MAX_CONVERTER_NAME_LENGTH)
-
-/** Shift in for EBDCDIC_STATEFUL and iso2022 states @stable ICU 2.0 */
-#define  UCNV_SI 0x0F
-/** Shift out for EBDCDIC_STATEFUL and iso2022 states @stable ICU 2.0 */
-#define  UCNV_SO 0x0E
-
-/**
- * Enum for specifying basic types of converters
- * @see ucnv_getType
- * @stable ICU 2.0
- */
-typedef enum {
-    UCNV_UNSUPPORTED_CONVERTER = -1,
-    UCNV_SBCS = 0,
-    UCNV_DBCS = 1,
-    UCNV_MBCS = 2,
-    UCNV_LATIN_1 = 3,
-    UCNV_UTF8 = 4,
-    UCNV_UTF16_BigEndian = 5,
-    UCNV_UTF16_LittleEndian = 6,
-    UCNV_UTF32_BigEndian = 7,
-    UCNV_UTF32_LittleEndian = 8,
-    UCNV_EBCDIC_STATEFUL = 9,
-    UCNV_ISO_2022 = 10,
-
-    UCNV_LMBCS_1 = 11,
-    UCNV_LMBCS_2, 
-    UCNV_LMBCS_3,
-    UCNV_LMBCS_4,
-    UCNV_LMBCS_5,
-    UCNV_LMBCS_6,
-    UCNV_LMBCS_8,
-    UCNV_LMBCS_11,
-    UCNV_LMBCS_16,
-    UCNV_LMBCS_17,
-    UCNV_LMBCS_18,
-    UCNV_LMBCS_19,
-    UCNV_LMBCS_LAST = UCNV_LMBCS_19,
-    UCNV_HZ,
-    UCNV_SCSU,
-    UCNV_ISCII,
-    UCNV_US_ASCII,
-    UCNV_UTF7,
-    UCNV_BOCU1,
-    UCNV_UTF16,
-    UCNV_UTF32,
-    UCNV_CESU8,
-    UCNV_IMAP_MAILBOX,
-
-    /* Number of converter types for which we have conversion routines. */
-    UCNV_NUMBER_OF_SUPPORTED_CONVERTER_TYPES
-
-} UConverterType;
-
-/**
- * Enum for specifying which platform a converter ID refers to.
- * The use of platform/CCSID is not recommended. See ucnv_openCCSID().
- *
- * @see ucnv_getPlatform
- * @see ucnv_openCCSID
- * @see ucnv_getCCSID
- * @stable ICU 2.0
- */
-typedef enum {
-    UCNV_UNKNOWN = -1,
-    UCNV_IBM = 0
-} UConverterPlatform;
-
-/**
- * Function pointer for error callback in the codepage to unicode direction.
- * Called when an error has occured in conversion to unicode, or on open/close of the callback (see reason).
- * @param context Pointer to the callback's private data
- * @param args Information about the conversion in progress
- * @param codeUnits Points to 'length' bytes of the concerned codepage sequence
- * @param length Size (in bytes) of the concerned codepage sequence
- * @param reason Defines the reason the callback was invoked
- * @param pErrorCode    ICU error code in/out parameter.
- *                      For converter callback functions, set to a conversion error
- *                      before the call, and the callback may reset it to U_ZERO_ERROR.
- * @see ucnv_setToUCallBack
- * @see UConverterToUnicodeArgs
- * @stable ICU 2.0
- */
-typedef void (U_EXPORT2 *UConverterToUCallback) (
-                  const void* context,
-                  UConverterToUnicodeArgs *args,
-                  const char *codeUnits,
-                  int32_t length,
-                  UConverterCallbackReason reason,
-                  UErrorCode *pErrorCode);
-
-/**
- * Function pointer for error callback in the unicode to codepage direction.
- * Called when an error has occured in conversion from unicode, or on open/close of the callback (see reason).
- * @param context Pointer to the callback's private data
- * @param args Information about the conversion in progress
- * @param codeUnits Points to 'length' UChars of the concerned Unicode sequence
- * @param length Size (in bytes) of the concerned codepage sequence
- * @param codePoint Single UChar32 (UTF-32) containing the concerend Unicode codepoint.
- * @param reason Defines the reason the callback was invoked
- * @param pErrorCode    ICU error code in/out parameter.
- *                      For converter callback functions, set to a conversion error
- *                      before the call, and the callback may reset it to U_ZERO_ERROR.
- * @see ucnv_setFromUCallBack
- * @stable ICU 2.0
- */
-typedef void (U_EXPORT2 *UConverterFromUCallback) (
-                    const void* context,
-                    UConverterFromUnicodeArgs *args,
-                    const UChar* codeUnits,
-                    int32_t length,
-                    UChar32 codePoint,
-                    UConverterCallbackReason reason,
-                    UErrorCode *pErrorCode);
-
-U_CDECL_END
-
-/**
- * Character that separates converter names from options and options from each other.
- * @see ucnv_open
- * @stable ICU 2.0
- */
-#define UCNV_OPTION_SEP_CHAR ','
-
-/**
- * String version of UCNV_OPTION_SEP_CHAR. 
- * @see ucnv_open
- * @stable ICU 2.0
- */
-#define UCNV_OPTION_SEP_STRING ","
-
-/**
- * Character that separates a converter option from its value.
- * @see ucnv_open
- * @stable ICU 2.0
- */
-#define UCNV_VALUE_SEP_CHAR '='
-
-/**
- * String version of UCNV_VALUE_SEP_CHAR. 
- * @see ucnv_open
- * @stable ICU 2.0
- */
-#define UCNV_VALUE_SEP_STRING "="
-
-/**
- * Converter option for specifying a locale.
- * For example, ucnv_open("SCSU,locale=ja", &errorCode);
- * See convrtrs.txt.
- *
- * @see ucnv_open
- * @stable ICU 2.0
- */
-#define UCNV_LOCALE_OPTION_STRING ",locale="
-
-/**
- * Converter option for specifying a version selector (0..9) for some converters.
- * For example, ucnv_open("UTF-7,version=1", &errorCode);
- * See convrtrs.txt.
- *
- * @see ucnv_open
- * @stable ICU 2.4
- */
-#define UCNV_VERSION_OPTION_STRING ",version="
-
-/**
- * Converter option for EBCDIC SBCS or mixed-SBCS/DBCS (stateful) codepages.
- * Swaps Unicode mappings for EBCDIC LF and NL codes, as used on
- * S/390 (z/OS) Unix System Services (Open Edition).
- * For example, ucnv_open("ibm-1047,swaplfnl", &errorCode);
- * See convrtrs.txt.
- *
- * @see ucnv_open
- * @stable ICU 2.4
- */
-#define UCNV_SWAP_LFNL_OPTION_STRING ",swaplfnl"
-
-/**
- * Do a fuzzy compare of two converter/alias names.
- * The comparison is case-insensitive, ignores leading zeroes if they are not
- * followed by further digits, and ignores all but letters and digits.
- * Thus the strings "UTF-8", "utf_8", "u*T@f08" and "Utf 8" are exactly equivalent.
- * See section 1.4, Charset Alias Matching in Unicode Technical Standard #22
- * at http://www.unicode.org/reports/tr22/
- *
- * @param name1 a converter name or alias, zero-terminated
- * @param name2 a converter name or alias, zero-terminated
- * @return 0 if the names match, or a negative value if the name1
- * lexically precedes name2, or a positive value if the name1
- * lexically follows name2.
- * @stable ICU 2.0
- */
-U_STABLE int U_EXPORT2
-ucnv_compareNames(const char *name1, const char *name2);
-
-
-/**
- * Creates a UConverter object with the name of a coded character set specified as a C string.
- * The actual name will be resolved with the alias file
- * using a case-insensitive string comparison that ignores
- * leading zeroes and all non-alphanumeric characters.
- * E.g., the names "UTF8", "utf-8", "u*T@f08" and "Utf 8" are all equivalent.
- * (See also ucnv_compareNames().)
- * If <code>NULL</code> is passed for the converter name, it will create one with the
- * getDefaultName return value.
- *
- * <p>A converter name for ICU 1.5 and above may contain options
- * like a locale specification to control the specific behavior of
- * the newly instantiated converter.
- * The meaning of the options depends on the particular converter.
- * If an option is not defined for or recognized by a given converter, then it is ignored.</p>
- *
- * <p>Options are appended to the converter name string, with a
- * <code>UCNV_OPTION_SEP_CHAR</code> between the name and the first option and
- * also between adjacent options.</p>
- *
- * <p>If the alias is ambiguous, then the preferred converter is used
- * and the status is set to U_AMBIGUOUS_ALIAS_WARNING.</p>
- *
- * <p>The conversion behavior and names can vary between platforms. ICU may
- * convert some characters differently from other platforms. Details on this topic
- * are in the <a href="http://icu-project.org/userguide/conversion.html">User's
- * Guide</a>. Aliases starting with a "cp" prefix have no specific meaning
- * other than its an alias starting with the letters "cp". Please do not
- * associate any meaning to these aliases.</p>
- *
- * @param converterName Name of the coded character set table.
- *          This may have options appended to the string.
- *          IANA alias character set names, IBM CCSIDs starting with "ibm-",
- *          Windows codepage numbers starting with "windows-" are frequently
- *          used for this parameter. See ucnv_getAvailableName and
- *          ucnv_getAlias for a complete list that is available.
- *          If this parameter is NULL, the default converter will be used.
- * @param err outgoing error status <TT>U_MEMORY_ALLOCATION_ERROR, U_FILE_ACCESS_ERROR</TT>
- * @return the created Unicode converter object, or <TT>NULL</TT> if an error occured
- * @see ucnv_openU
- * @see ucnv_openCCSID
- * @see ucnv_getAvailableName
- * @see ucnv_getAlias
- * @see ucnv_getDefaultName
- * @see ucnv_close
- * @see ucnv_compareNames
- * @stable ICU 2.0
- */
-U_STABLE UConverter* U_EXPORT2 
-ucnv_open(const char *converterName, UErrorCode *err);
-
-
-/**
- * Creates a Unicode converter with the names specified as unicode string. 
- * The name should be limited to the ASCII-7 alphanumerics range.
- * The actual name will be resolved with the alias file
- * using a case-insensitive string comparison that ignores
- * leading zeroes and all non-alphanumeric characters.
- * E.g., the names "UTF8", "utf-8", "u*T@f08" and "Utf 8" are all equivalent.
- * (See also ucnv_compareNames().)
- * If <TT>NULL</TT> is passed for the converter name, it will create 
- * one with the ucnv_getDefaultName() return value.
- * If the alias is ambiguous, then the preferred converter is used
- * and the status is set to U_AMBIGUOUS_ALIAS_WARNING.
- *
- * <p>See ucnv_open for the complete details</p>
- * @param name Name of the UConverter table in a zero terminated 
- *        Unicode string
- * @param err outgoing error status <TT>U_MEMORY_ALLOCATION_ERROR, 
- *        U_FILE_ACCESS_ERROR</TT>
- * @return the created Unicode converter object, or <TT>NULL</TT> if an 
- *        error occured
- * @see ucnv_open
- * @see ucnv_openCCSID
- * @see ucnv_close
- * @see ucnv_compareNames
- * @stable ICU 2.0
- */
-U_STABLE UConverter* U_EXPORT2 
-ucnv_openU(const UChar *name,
-           UErrorCode *err);
-
-/**
- * Creates a UConverter object from a CCSID number and platform pair.
- * Note that the usefulness of this function is limited to platforms with numeric
- * encoding IDs. Only IBM and Microsoft platforms use numeric (16-bit) identifiers for
- * encodings.
- *
- * In addition, IBM CCSIDs and Unicode conversion tables are not 1:1 related.
- * For many IBM CCSIDs there are multiple (up to six) Unicode conversion tables, and
- * for some Unicode conversion tables there are multiple CCSIDs.
- * Some "alternate" Unicode conversion tables are provided by the
- * IBM CDRA conversion table registry.
- * The most prominent example of a systematic modification of conversion tables that is
- * not provided in the form of conversion table files in the repository is
- * that S/390 Unix System Services swaps the codes for Line Feed and New Line in all
- * EBCDIC codepages, which requires such a swap in the Unicode conversion tables as well.
- *
- * Only IBM default conversion tables are accessible with ucnv_openCCSID().
- * ucnv_getCCSID() will return the same CCSID for all conversion tables that are associated
- * with that CCSID.
- *
- * Currently, the only "platform" supported in the ICU converter API is UCNV_IBM.
- *
- * In summary, the use of CCSIDs and the associated API functions is not recommended.
- *
- * In order to open a converter with the default IBM CDRA Unicode conversion table,
- * you can use this function or use the prefix "ibm-":
- * \code
- *     char name[20];
- *     sprintf(name, "ibm-%hu", ccsid);
- *     cnv=ucnv_open(name, &errorCode);
- * \endcode
- *
- * In order to open a converter with the IBM S/390 Unix System Services variant
- * of a Unicode/EBCDIC conversion table,
- * you can use the prefix "ibm-" together with the option string UCNV_SWAP_LFNL_OPTION_STRING:
- * \code
- *     char name[20];
- *     sprintf(name, "ibm-%hu" UCNV_SWAP_LFNL_OPTION_STRING, ccsid);
- *     cnv=ucnv_open(name, &errorCode);
- * \endcode
- *
- * In order to open a converter from a Microsoft codepage number, use the prefix "cp":
- * \code
- *     char name[20];
- *     sprintf(name, "cp%hu", codepageID);
- *     cnv=ucnv_open(name, &errorCode);
- * \endcode
- *
- * If the alias is ambiguous, then the preferred converter is used
- * and the status is set to U_AMBIGUOUS_ALIAS_WARNING.
- *
- * @param codepage codepage number to create
- * @param platform the platform in which the codepage number exists
- * @param err error status <TT>U_MEMORY_ALLOCATION_ERROR, U_FILE_ACCESS_ERROR</TT>
- * @return the created Unicode converter object, or <TT>NULL</TT> if an error
- *   occured.
- * @see ucnv_open
- * @see ucnv_openU
- * @see ucnv_close
- * @see ucnv_getCCSID
- * @see ucnv_getPlatform
- * @see UConverterPlatform
- * @stable ICU 2.0
- */
-U_STABLE UConverter* U_EXPORT2
-ucnv_openCCSID(int32_t codepage,
-               UConverterPlatform platform,
-               UErrorCode * err);
-
-/**
- * <p>Creates a UConverter object specified from a packageName and a converterName.</p>
- * 
- * <p>The packageName and converterName must point to an ICU udata object, as defined by
- *   <code> udata_open( packageName, "cnv", converterName, err) </code> or equivalent.
- * Typically, packageName will refer to a (.dat) file, or to a package registered with
- * udata_setAppData(). Using a full file or directory pathname for packageName is deprecated.</p>
- * 
- * <p>The name will NOT be looked up in the alias mechanism, nor will the converter be
- * stored in the converter cache or the alias table. The only way to open further converters
- * is call this function multiple times, or use the ucnv_safeClone() function to clone a 
- * 'master' converter.</p>
- *
- * <p>A future version of ICU may add alias table lookups and/or caching
- * to this function.</p>
- * 
- * <p>Example Use:
- *      <code>cnv = ucnv_openPackage("myapp", "myconverter", &err);</code>
- * </p>
- *
- * @param packageName name of the package (equivalent to 'path' in udata_open() call)
- * @param converterName name of the data item to be used, without suffix.
- * @param err outgoing error status <TT>U_MEMORY_ALLOCATION_ERROR, U_FILE_ACCESS_ERROR</TT>
- * @return the created Unicode converter object, or <TT>NULL</TT> if an error occured
- * @see udata_open
- * @see ucnv_open
- * @see ucnv_safeClone
- * @see ucnv_close
- * @stable ICU 2.2
- */
-U_STABLE UConverter* U_EXPORT2 
-ucnv_openPackage(const char *packageName, const char *converterName, UErrorCode *err);
-
-/**
- * Thread safe converter cloning operation.
- * For most efficient operation, pass in a stackBuffer (and a *pBufferSize)
- * with at least U_CNV_SAFECLONE_BUFFERSIZE bytes of space.
- * If the buffer size is sufficient, then the clone will use the stack buffer;
- * otherwise, it will be allocated, and *pBufferSize will indicate
- * the actual size. (This should not occur with U_CNV_SAFECLONE_BUFFERSIZE.)
- *
- * You must ucnv_close() the clone in any case.
- *
- * If *pBufferSize==0, (regardless of whether stackBuffer==NULL or not)
- * then *pBufferSize will be changed to a sufficient size
- * for cloning this converter,
- * without actually cloning the converter ("pure pre-flighting").
- *
- * If *pBufferSize is greater than zero but not large enough for a stack-based
- * clone, then the converter is cloned using newly allocated memory
- * and *pBufferSize is changed to the necessary size.
- *
- * If the converter clone fits into the stack buffer but the stack buffer is not
- * sufficiently aligned for the clone, then the clone will use an
- * adjusted pointer and use an accordingly smaller buffer size.
- *
- * @param cnv converter to be cloned
- * @param stackBuffer user allocated space for the new clone. If NULL new memory will be allocated. 
- *  If buffer is not large enough, new memory will be allocated.
- *  Clients can use the U_CNV_SAFECLONE_BUFFERSIZE. This will probably be enough to avoid memory allocations.
- * @param pBufferSize pointer to size of allocated space. pBufferSize must not be NULL.
- * @param status to indicate whether the operation went on smoothly or there were errors
- *  An informational status value, U_SAFECLONE_ALLOCATED_WARNING,
- *  is used if any allocations were necessary.
- *  However, it is better to check if *pBufferSize grew for checking for
- *  allocations because warning codes can be overridden by subsequent
- *  function calls.
- * @return pointer to the new clone
- * @stable ICU 2.0
- */
-U_STABLE UConverter * U_EXPORT2 
-ucnv_safeClone(const UConverter *cnv, 
-               void             *stackBuffer,
-               int32_t          *pBufferSize, 
-               UErrorCode       *status);
-
-/**
- * \def U_CNV_SAFECLONE_BUFFERSIZE
- * Definition of a buffer size that is designed to be large enough for
- * converters to be cloned with ucnv_safeClone().
- * @stable ICU 2.0
- */
-#define U_CNV_SAFECLONE_BUFFERSIZE  1024
-
-/**
- * Deletes the unicode converter and releases resources associated
- * with just this instance.
- * Does not free up shared converter tables.
- *
- * @param converter the converter object to be deleted
- * @see ucnv_open
- * @see ucnv_openU
- * @see ucnv_openCCSID
- * @stable ICU 2.0
- */
-U_STABLE void  U_EXPORT2
-ucnv_close(UConverter * converter);
-
-/**
- * Fills in the output parameter, subChars, with the substitution characters
- * as multiple bytes.
- * If ucnv_setSubstString() set a Unicode string because the converter is
- * stateful, then subChars will be an empty string.
- *
- * @param converter the Unicode converter
- * @param subChars the subsitution characters
- * @param len on input the capacity of subChars, on output the number 
- * of bytes copied to it
- * @param  err the outgoing error status code.
- * If the substitution character array is too small, an
- * <TT>U_INDEX_OUTOFBOUNDS_ERROR</TT> will be returned.
- * @see ucnv_setSubstString
- * @see ucnv_setSubstChars
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2
-ucnv_getSubstChars(const UConverter *converter,
-                   char *subChars,
-                   int8_t *len,
-                   UErrorCode *err);
-
-/**
- * Sets the substitution chars when converting from unicode to a codepage. The
- * substitution is specified as a string of 1-4 bytes, and may contain
- * <TT>NULL</TT> bytes.
- * The subChars must represent a single character. The caller needs to know the
- * byte sequence of a valid character in the converter's charset.
- * For some converters, for example some ISO 2022 variants, only single-byte
- * substitution characters may be supported.
- * The newer ucnv_setSubstString() function relaxes these limitations.
- *
- * @param converter the Unicode converter
- * @param subChars the substitution character byte sequence we want set
- * @param len the number of bytes in subChars
- * @param err the error status code.  <TT>U_INDEX_OUTOFBOUNDS_ERROR </TT> if
- * len is bigger than the maximum number of bytes allowed in subchars
- * @see ucnv_setSubstString
- * @see ucnv_getSubstChars
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2
-ucnv_setSubstChars(UConverter *converter,
-                   const char *subChars,
-                   int8_t len,
-                   UErrorCode *err);
-
-/**
- * Set a substitution string for converting from Unicode to a charset.
- * The caller need not know the charset byte sequence for each charset.
- *
- * Unlike ucnv_setSubstChars() which is designed to set a charset byte sequence
- * for a single character, this function takes a Unicode string with
- * zero, one or more characters, and immediately verifies that the string can be
- * converted to the charset.
- * If not, or if the result is too long (more than 32 bytes as of ICU 3.6),
- * then the function returns with an error accordingly.
- *
- * Also unlike ucnv_setSubstChars(), this function works for stateful charsets
- * by converting on the fly at the point of substitution rather than setting
- * a fixed byte sequence.
- *
- * @param cnv The UConverter object.
- * @param s The Unicode string.
- * @param length The number of UChars in s, or -1 for a NUL-terminated string.
- * @param err Pointer to a standard ICU error code. Its input value must
- *            pass the U_SUCCESS() test, or else the function returns
- *            immediately. Check for U_FAILURE() on output or use with
- *            function chaining. (See User Guide for details.)
- *
- * @see ucnv_setSubstChars
- * @see ucnv_getSubstChars
- * @stable ICU 3.6
- */
-U_STABLE void U_EXPORT2
-ucnv_setSubstString(UConverter *cnv,
-                    const UChar *s,
-                    int32_t length,
-                    UErrorCode *err);
-
-/**
- * Fills in the output parameter, errBytes, with the error characters from the
- * last failing conversion.
- *
- * @param converter the Unicode converter
- * @param errBytes the codepage bytes which were in error
- * @param len on input the capacity of errBytes, on output the number of
- *  bytes which were copied to it
- * @param err the error status code.
- * If the substitution character array is too small, an
- * <TT>U_INDEX_OUTOFBOUNDS_ERROR</TT> will be returned.
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2
-ucnv_getInvalidChars(const UConverter *converter,
-                     char *errBytes,
-                     int8_t *len,
-                     UErrorCode *err);
-
-/**
- * Fills in the output parameter, errChars, with the error characters from the
- * last failing conversion.
- *
- * @param converter the Unicode converter
- * @param errUChars the UChars which were in error
- * @param len on input the capacity of errUChars, on output the number of 
- *  UChars which were copied to it
- * @param err the error status code.
- * If the substitution character array is too small, an
- * <TT>U_INDEX_OUTOFBOUNDS_ERROR</TT> will be returned.
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2
-ucnv_getInvalidUChars(const UConverter *converter,
-                      UChar *errUChars,
-                      int8_t *len,
-                      UErrorCode *err);
-
-/**
- * Resets the state of a converter to the default state. This is used
- * in the case of an error, to restart a conversion from a known default state.
- * It will also empty the internal output buffers.
- * @param converter the Unicode converter
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2
-ucnv_reset(UConverter *converter);
-
-/**
- * Resets the to-Unicode part of a converter state to the default state.
- * This is used in the case of an error to restart a conversion to
- * Unicode to a known default state. It will also empty the internal
- * output buffers used for the conversion to Unicode codepoints.
- * @param converter the Unicode converter
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2 
-ucnv_resetToUnicode(UConverter *converter);
-
-/**
- * Resets the from-Unicode part of a converter state to the default state.
- * This is used in the case of an error to restart a conversion from
- * Unicode to a known default state. It will also empty the internal output
- * buffers used for the conversion from Unicode codepoints.
- * @param converter the Unicode converter
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2 
-ucnv_resetFromUnicode(UConverter *converter);
-
-/**
- * Returns the maximum number of bytes that are output per UChar in conversion
- * from Unicode using this converter.
- * The returned number can be used with UCNV_GET_MAX_BYTES_FOR_STRING
- * to calculate the size of a target buffer for conversion from Unicode.
- *
- * Note: Before ICU 2.8, this function did not return reliable numbers for
- * some stateful converters (EBCDIC_STATEFUL, ISO-2022) and LMBCS.
- *
- * This number may not be the same as the maximum number of bytes per
- * "conversion unit". In other words, it may not be the intuitively expected
- * number of bytes per character that would be published for a charset,
- * and may not fulfill any other purpose than the allocation of an output
- * buffer of guaranteed sufficient size for a given input length and converter.
- *
- * Examples for special cases that are taken into account:
- * - Supplementary code points may convert to more bytes than BMP code points.
- *   This function returns bytes per UChar (UTF-16 code unit), not per
- *   Unicode code point, for efficient buffer allocation.
- * - State-shifting output (SI/SO, escapes, etc.) from stateful converters.
- * - When m input UChars are converted to n output bytes, then the maximum m/n
- *   is taken into account.
- *
- * The number returned here does not take into account
- * (see UCNV_GET_MAX_BYTES_FOR_STRING):
- * - callbacks which output more than one charset character sequence per call,
- *   like escape callbacks
- * - initial and final non-character bytes that are output by some converters
- *   (automatic BOMs, initial escape sequence, final SI, etc.)
- *
- * Examples for returned values:
- * - SBCS charsets: 1
- * - Shift-JIS: 2
- * - UTF-16: 2 (2 per BMP, 4 per surrogate _pair_, BOM not counted)
- * - UTF-8: 3 (3 per BMP, 4 per surrogate _pair_)
- * - EBCDIC_STATEFUL (EBCDIC mixed SBCS/DBCS): 3 (SO + DBCS)
- * - ISO-2022: 3 (always outputs UTF-8)
- * - ISO-2022-JP: 6 (4-byte escape sequences + DBCS)
- * - ISO-2022-CN: 8 (4-byte designator sequences + 2-byte SS2/SS3 + DBCS)
- *
- * @param converter The Unicode converter.
- * @return The maximum number of bytes per UChar that are output by ucnv_fromUnicode(),
- *         to be used together with UCNV_GET_MAX_BYTES_FOR_STRING for buffer allocation.
- *
- * @see UCNV_GET_MAX_BYTES_FOR_STRING
- * @see ucnv_getMinCharSize
- * @stable ICU 2.0
- */
-U_STABLE int8_t U_EXPORT2
-ucnv_getMaxCharSize(const UConverter *converter);
-
-/**
- * Calculates the size of a buffer for conversion from Unicode to a charset.
- * The calculated size is guaranteed to be sufficient for this conversion.
- *
- * It takes into account initial and final non-character bytes that are output
- * by some converters.
- * It does not take into account callbacks which output more than one charset
- * character sequence per call, like escape callbacks.
- * The default (substitution) callback only outputs one charset character sequence.
- *
- * @param length Number of UChars to be converted.
- * @param maxCharSize Return value from ucnv_getMaxCharSize() for the converter
- *                    that will be used.
- * @return Size of a buffer that will be large enough to hold the output bytes of
- *         converting length UChars with the converter that returned the maxCharSize.
- *
- * @see ucnv_getMaxCharSize
- * @stable ICU 2.8
- */
-#define UCNV_GET_MAX_BYTES_FOR_STRING(length, maxCharSize) \
-     (((int32_t)(length)+10)*(int32_t)(maxCharSize))
-
-/**
- * Returns the minimum byte length for characters in this codepage. 
- * This is usually either 1 or 2.
- * @param converter the Unicode converter
- * @return the minimum number of bytes allowed by this particular converter
- * @see ucnv_getMaxCharSize
- * @stable ICU 2.0
- */
-U_STABLE int8_t U_EXPORT2
-ucnv_getMinCharSize(const UConverter *converter);
-
-/**
- * Returns the display name of the converter passed in based on the Locale 
- * passed in. If the locale contains no display name, the internal ASCII
- * name will be filled in.
- *
- * @param converter the Unicode converter.
- * @param displayLocale is the specific Locale we want to localised for
- * @param displayName user provided buffer to be filled in
- * @param displayNameCapacity size of displayName Buffer
- * @param err error status code
- * @return displayNameLength number of UChar needed in displayName
- * @see ucnv_getName
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2
-ucnv_getDisplayName(const UConverter *converter,
-                    const char *displayLocale,
-                    UChar *displayName,
-                    int32_t displayNameCapacity,
-                    UErrorCode *err);
-
-/**
- * Gets the internal, canonical name of the converter (zero-terminated).
- * The lifetime of the returned string will be that of the converter 
- * passed to this function.
- * @param converter the Unicode converter
- * @param err UErrorCode status
- * @return the internal name of the converter
- * @see ucnv_getDisplayName
- * @stable ICU 2.0
- */
-U_STABLE const char * U_EXPORT2 
-ucnv_getName(const UConverter *converter, UErrorCode *err);
-
-/**
- * Gets a codepage number associated with the converter. This is not guaranteed
- * to be the one used to create the converter. Some converters do not represent
- * platform registered codepages and return zero for the codepage number.
- * The error code fill-in parameter indicates if the codepage number
- * is available.
- * Does not check if the converter is <TT>NULL</TT> or if converter's data
- * table is <TT>NULL</TT>.
- *
- * Important: The use of CCSIDs is not recommended because it is limited
- * to only two platforms in principle and only one (UCNV_IBM) in the current
- * ICU converter API.
- * Also, CCSIDs are insufficient to identify IBM Unicode conversion tables precisely.
- * For more details see ucnv_openCCSID().
- *
- * @param converter the Unicode converter
- * @param err the error status code.
- * @return If any error occurrs, -1 will be returned otherwise, the codepage number
- * will be returned
- * @see ucnv_openCCSID
- * @see ucnv_getPlatform
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2
-ucnv_getCCSID(const UConverter *converter,
-              UErrorCode *err);
-
-/**
- * Gets a codepage platform associated with the converter. Currently, 
- * only <TT>UCNV_IBM</TT> will be returned.
- * Does not test if the converter is <TT>NULL</TT> or if converter's data 
- * table is <TT>NULL</TT>. 
- * @param converter the Unicode converter
- * @param err the error status code.
- * @return The codepage platform
- * @stable ICU 2.0
- */
-U_STABLE UConverterPlatform U_EXPORT2
-ucnv_getPlatform(const UConverter *converter,
-                 UErrorCode *err);
-
-/**
- * Gets the type of the converter
- * e.g. SBCS, MBCS, DBCS, UTF8, UTF16_BE, UTF16_LE, ISO_2022, 
- * EBCDIC_STATEFUL, LATIN_1
- * @param converter a valid, opened converter
- * @return the type of the converter
- * @stable ICU 2.0
- */
-U_STABLE UConverterType U_EXPORT2
-ucnv_getType(const UConverter * converter);
-
-/**
- * Gets the "starter" (lead) bytes for converters of type MBCS.
- * Will fill in an <TT>U_ILLEGAL_ARGUMENT_ERROR</TT> if converter passed in
- * is not MBCS. Fills in an array of type UBool, with the value of the byte 
- * as offset to the array. For example, if (starters[0x20] == TRUE) at return,
- * it means that the byte 0x20 is a starter byte in this converter.
- * Context pointers are always owned by the caller.
- * 
- * @param converter a valid, opened converter of type MBCS
- * @param starters an array of size 256 to be filled in
- * @param err error status, <TT>U_ILLEGAL_ARGUMENT_ERROR</TT> if the 
- * converter is not a type which can return starters.
- * @see ucnv_getType
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2
-ucnv_getStarters(const UConverter* converter, 
-                 UBool starters[256],
-                 UErrorCode* err);
-
-
-/**
- * Selectors for Unicode sets that can be returned by ucnv_getUnicodeSet().
- * @see ucnv_getUnicodeSet
- * @stable ICU 2.6
- */
-typedef enum UConverterUnicodeSet {
-    /** Select the set of roundtrippable Unicode code points. @stable ICU 2.6 */
-    UCNV_ROUNDTRIP_SET,
-    /** Select the set of Unicode code points with roundtrip or fallback mappings. @draft ICU 4.0 */
-    UCNV_ROUNDTRIP_AND_FALLBACK_SET,
-    /** Number of UConverterUnicodeSet selectors. @stable ICU 2.6 */
-    UCNV_SET_COUNT
-} UConverterUnicodeSet;
-
-
-/**
- * Returns the set of Unicode code points that can be converted by an ICU converter.
- *
- * Returns one of several kinds of set:
- *
- * 1. UCNV_ROUNDTRIP_SET
- *
- * The set of all Unicode code points that can be roundtrip-converted
- * (converted without any data loss) with the converter (ucnv_fromUnicode()).
- * This set will not include code points that have fallback mappings
- * or are only the result of reverse fallback mappings.
- * This set will also not include PUA code points with fallbacks, although
- * ucnv_fromUnicode() will always uses those mappings despite ucnv_setFallback().
- * See UTR #22 "Character Mapping Markup Language"
- * at http://www.unicode.org/reports/tr22/
- *
- * This is useful for example for
- * - checking that a string or document can be roundtrip-converted with a converter,
- *   without/before actually performing the conversion
- * - testing if a converter can be used for text for typical text for a certain locale,
- *   by comparing its roundtrip set with the set of ExemplarCharacters from
- *   ICU's locale data or other sources
- *
- * 2. UCNV_ROUNDTRIP_AND_FALLBACK_SET
- *
- * The set of all Unicode code points that can be converted with the converter (ucnv_fromUnicode())
- * when fallbacks are turned on (see ucnv_setFallback()).
- * This set includes all code points with roundtrips and fallbacks (but not reverse fallbacks).
- *
- * In the future, there may be more UConverterUnicodeSet choices to select
- * sets with different properties.
- *
- * @param cnv The converter for which a set is requested.
- * @param setFillIn A valid USet *. It will be cleared by this function before
- *            the converter's specific set is filled into the USet.
- * @param whichSet A UConverterUnicodeSet selector;
- *              currently UCNV_ROUNDTRIP_SET is the only supported value.
- * @param pErrorCode ICU error code in/out parameter.
- *                   Must fulfill U_SUCCESS before the function call.
- *
- * @see UConverterUnicodeSet
- * @see uset_open
- * @see uset_close
- * @stable ICU 2.6
- */
-U_STABLE void U_EXPORT2
-ucnv_getUnicodeSet(const UConverter *cnv,
-                   USet *setFillIn,
-                   UConverterUnicodeSet whichSet,
-                   UErrorCode *pErrorCode);
-
-/**
- * Gets the current calback function used by the converter when an illegal
- *  or invalid codepage sequence is found. 
- * Context pointers are always owned by the caller.
- *
- * @param converter the unicode converter
- * @param action fillin: returns the callback function pointer
- * @param context fillin: returns the callback's private void* context
- * @see ucnv_setToUCallBack
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2
-ucnv_getToUCallBack (const UConverter * converter,
-                     UConverterToUCallback *action,
-                     const void **context);
-
-/**
- * Gets the current callback function used by the converter when illegal 
- * or invalid Unicode sequence is found.
- * Context pointers are always owned by the caller.
- *
- * @param converter the unicode converter
- * @param action fillin: returns the callback function pointer
- * @param context fillin: returns the callback's private void* context
- * @see ucnv_setFromUCallBack
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2
-ucnv_getFromUCallBack (const UConverter * converter,
-                       UConverterFromUCallback *action,
-                       const void **context);
-
-/**
- * Changes the callback function used by the converter when
- * an illegal or invalid sequence is found.
- * Context pointers are always owned by the caller.
- * Predefined actions and contexts can be found in the ucnv_err.h header.
- *
- * @param converter the unicode converter
- * @param newAction the new callback function
- * @param newContext the new toUnicode callback context pointer. This can be NULL.
- * @param oldAction fillin: returns the old callback function pointer. This can be NULL.
- * @param oldContext fillin: returns the old callback's private void* context. This can be NULL.
- * @param err The error code status
- * @see ucnv_getToUCallBack
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2
-ucnv_setToUCallBack (UConverter * converter,
-                     UConverterToUCallback newAction,
-                     const void* newContext,
-                     UConverterToUCallback *oldAction,
-                     const void** oldContext,
-                     UErrorCode * err);
-
-/**
- * Changes the current callback function used by the converter when
- * an illegal or invalid sequence is found.
- * Context pointers are always owned by the caller.
- * Predefined actions and contexts can be found in the ucnv_err.h header.
- *
- * @param converter the unicode converter
- * @param newAction the new callback function
- * @param newContext the new fromUnicode callback context pointer. This can be NULL.
- * @param oldAction fillin: returns the old callback function pointer. This can be NULL.
- * @param oldContext fillin: returns the old callback's private void* context. This can be NULL.
- * @param err The error code status
- * @see ucnv_getFromUCallBack
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2
-ucnv_setFromUCallBack (UConverter * converter,
-                       UConverterFromUCallback newAction,
-                       const void *newContext,
-                       UConverterFromUCallback *oldAction,
-                       const void **oldContext,
-                       UErrorCode * err);
-
-/**
- * Converts an array of unicode characters to an array of codepage
- * characters. This function is optimized for converting a continuous
- * stream of data in buffer-sized chunks, where the entire source and
- * target does not fit in available buffers.
- * 
- * The source pointer is an in/out parameter. It starts out pointing where the 
- * conversion is to begin, and ends up pointing after the last UChar consumed. 
- * 
- * Target similarly starts out pointer at the first available byte in the output
- * buffer, and ends up pointing after the last byte written to the output.
- * 
- * The converter always attempts to consume the entire source buffer, unless 
- * (1.) the target buffer is full, or (2.) a failing error is returned from the
- * current callback function.  When a successful error status has been
- * returned, it means that all of the source buffer has been
- *  consumed. At that point, the caller should reset the source and
- *  sourceLimit pointers to point to the next chunk.
- * 
- * At the end of the stream (flush==TRUE), the input is completely consumed
- * when *source==sourceLimit and no error code is set.
- * The converter object is then automatically reset by this function.
- * (This means that a converter need not be reset explicitly between data
- * streams if it finishes the previous stream without errors.)
- * 
- * This is a <I>stateful</I> conversion. Additionally, even when all source data has
- * been consumed, some data may be in the converters' internal state.
- * Call this function repeatedly, updating the target pointers with
- * the next empty chunk of target in case of a
- * <TT>U_BUFFER_OVERFLOW_ERROR</TT>, and updating the source  pointers
- *  with the next chunk of source when a successful error status is
- * returned, until there are no more chunks of source data.
- * @param converter the Unicode converter
- * @param target I/O parameter. Input : Points to the beginning of the buffer to copy
- *  codepage characters to. Output : points to after the last codepage character copied
- *  to <TT>target</TT>.
- * @param targetLimit the pointer just after last of the <TT>target</TT> buffer
- * @param source I/O parameter, pointer to pointer to the source Unicode character buffer. 
- * @param sourceLimit the pointer just after the last of the source buffer
- * @param offsets if NULL is passed, nothing will happen to it, otherwise it needs to have the same number
- * of allocated cells as <TT>target</TT>. Will fill in offsets from target to source pointer
- * e.g: <TT>offsets[3]</TT> is equal to 6, it means that the <TT>target[3]</TT> was a result of transcoding <TT>source[6]</TT>
- * For output data carried across calls, and other data without a specific source character
- * (such as from escape sequences or callbacks)  -1 will be placed for offsets. 
- * @param flush set to <TT>TRUE</TT> if the current source buffer is the last available
- * chunk of the source, <TT>FALSE</TT> otherwise. Note that if a failing status is returned,
- * this function may have to be called multiple times with flush set to <TT>TRUE</TT> until
- * the source buffer is consumed.
- * @param err the error status.  <TT>U_ILLEGAL_ARGUMENT_ERROR</TT> will be set if the
- * converter is <TT>NULL</TT>.
- * <code>U_BUFFER_OVERFLOW_ERROR</code> will be set if the target is full and there is 
- * still data to be written to the target.
- * @see ucnv_fromUChars
- * @see ucnv_convert
- * @see ucnv_getMinCharSize
- * @see ucnv_setToUCallBack
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2 
-ucnv_fromUnicode (UConverter * converter,
-                  char **target,
-                  const char *targetLimit,
-                  const UChar ** source,
-                  const UChar * sourceLimit,
-                  int32_t* offsets,
-                  UBool flush,
-                  UErrorCode * err);
-
-/**
- * Converts a buffer of codepage bytes into an array of unicode UChars
- * characters. This function is optimized for converting a continuous
- * stream of data in buffer-sized chunks, where the entire source and
- * target does not fit in available buffers.
- * 
- * The source pointer is an in/out parameter. It starts out pointing where the 
- * conversion is to begin, and ends up pointing after the last byte of source consumed. 
- * 
- * Target similarly starts out pointer at the first available UChar in the output
- * buffer, and ends up pointing after the last UChar written to the output. 
- * It does NOT necessarily keep UChar sequences together.
- * 
- * The converter always attempts to consume the entire source buffer, unless 
- * (1.) the target buffer is full, or (2.) a failing error is returned from the
- * current callback function.  When a successful error status has been
- * returned, it means that all of the source buffer has been
- *  consumed. At that point, the caller should reset the source and
- *  sourceLimit pointers to point to the next chunk.
- *
- * At the end of the stream (flush==TRUE), the input is completely consumed
- * when *source==sourceLimit and no error code is set
- * The converter object is then automatically reset by this function.
- * (This means that a converter need not be reset explicitly between data
- * streams if it finishes the previous stream without errors.)
- * 
- * This is a <I>stateful</I> conversion. Additionally, even when all source data has
- * been consumed, some data may be in the converters' internal state.
- * Call this function repeatedly, updating the target pointers with
- * the next empty chunk of target in case of a
- * <TT>U_BUFFER_OVERFLOW_ERROR</TT>, and updating the source  pointers
- *  with the next chunk of source when a successful error status is
- * returned, until there are no more chunks of source data.
- * @param converter the Unicode converter
- * @param target I/O parameter. Input : Points to the beginning of the buffer to copy
- *  UChars into. Output : points to after the last UChar copied.
- * @param targetLimit the pointer just after the end of the <TT>target</TT> buffer
- * @param source I/O parameter, pointer to pointer to the source codepage buffer. 
- * @param sourceLimit the pointer to the byte after the end of the source buffer
- * @param offsets if NULL is passed, nothing will happen to it, otherwise it needs to have the same number
- * of allocated cells as <TT>target</TT>. Will fill in offsets from target to source pointer
- * e.g: <TT>offsets[3]</TT> is equal to 6, it means that the <TT>target[3]</TT> was a result of transcoding <TT>source[6]</TT>
- * For output data carried across calls, and other data without a specific source character
- * (such as from escape sequences or callbacks)  -1 will be placed for offsets. 
- * @param flush set to <TT>TRUE</TT> if the current source buffer is the last available
- * chunk of the source, <TT>FALSE</TT> otherwise. Note that if a failing status is returned,
- * this function may have to be called multiple times with flush set to <TT>TRUE</TT> until
- * the source buffer is consumed.
- * @param err the error status.  <TT>U_ILLEGAL_ARGUMENT_ERROR</TT> will be set if the
- * converter is <TT>NULL</TT>.
- * <code>U_BUFFER_OVERFLOW_ERROR</code> will be set if the target is full and there is 
- * still data to be written to the target. 
- * @see ucnv_fromUChars
- * @see ucnv_convert
- * @see ucnv_getMinCharSize
- * @see ucnv_setFromUCallBack
- * @see ucnv_getNextUChar
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2 
-ucnv_toUnicode(UConverter *converter,
-               UChar **target,
-               const UChar *targetLimit,
-               const char **source,
-               const char *sourceLimit,
-               int32_t *offsets,
-               UBool flush,
-               UErrorCode *err);
-
-/**
- * Convert the Unicode string into a codepage string using an existing UConverter.
- * The output string is NUL-terminated if possible.
- *
- * This function is a more convenient but less powerful version of ucnv_fromUnicode().
- * It is only useful for whole strings, not for streaming conversion.
- *
- * The maximum output buffer capacity required (barring output from callbacks) will be
- * UCNV_GET_MAX_BYTES_FOR_STRING(srcLength, ucnv_getMaxCharSize(cnv)).
- *
- * @param cnv the converter object to be used (ucnv_resetFromUnicode() will be called)
- * @param src the input Unicode string
- * @param srcLength the input string length, or -1 if NUL-terminated
- * @param dest destination string buffer, can be NULL if destCapacity==0
- * @param destCapacity the number of chars available at dest
- * @param pErrorCode normal ICU error code;
- *                  common error codes that may be set by this function include
- *                  U_BUFFER_OVERFLOW_ERROR, U_STRING_NOT_TERMINATED_WARNING,
- *                  U_ILLEGAL_ARGUMENT_ERROR, and conversion errors
- * @return the length of the output string, not counting the terminating NUL;
- *         if the length is greater than destCapacity, then the string will not fit
- *         and a buffer of the indicated length would need to be passed in
- * @see ucnv_fromUnicode
- * @see ucnv_convert
- * @see UCNV_GET_MAX_BYTES_FOR_STRING
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2
-ucnv_fromUChars(UConverter *cnv,
-                char *dest, int32_t destCapacity,
-                const UChar *src, int32_t srcLength,
-                UErrorCode *pErrorCode);
-
-/**
- * Convert the codepage string into a Unicode string using an existing UConverter.
- * The output string is NUL-terminated if possible.
- *
- * This function is a more convenient but less powerful version of ucnv_toUnicode().
- * It is only useful for whole strings, not for streaming conversion.
- *
- * The maximum output buffer capacity required (barring output from callbacks) will be
- * 2*srcLength (each char may be converted into a surrogate pair).
- *
- * @param cnv the converter object to be used (ucnv_resetToUnicode() will be called)
- * @param src the input codepage string
- * @param srcLength the input string length, or -1 if NUL-terminated
- * @param dest destination string buffer, can be NULL if destCapacity==0
- * @param destCapacity the number of UChars available at dest
- * @param pErrorCode normal ICU error code;
- *                  common error codes that may be set by this function include
- *                  U_BUFFER_OVERFLOW_ERROR, U_STRING_NOT_TERMINATED_WARNING,
- *                  U_ILLEGAL_ARGUMENT_ERROR, and conversion errors
- * @return the length of the output string, not counting the terminating NUL;
- *         if the length is greater than destCapacity, then the string will not fit
- *         and a buffer of the indicated length would need to be passed in
- * @see ucnv_toUnicode
- * @see ucnv_convert
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2
-ucnv_toUChars(UConverter *cnv,
-              UChar *dest, int32_t destCapacity,
-              const char *src, int32_t srcLength,
-              UErrorCode *pErrorCode);
-
-/**
- * Convert a codepage buffer into Unicode one character at a time.
- * The input is completely consumed when the U_INDEX_OUTOFBOUNDS_ERROR is set.
- *
- * Advantage compared to ucnv_toUnicode() or ucnv_toUChars():
- * - Faster for small amounts of data, for most converters, e.g.,
- *   US-ASCII, ISO-8859-1, UTF-8/16/32, and most "normal" charsets.
- *   (For complex converters, e.g., SCSU, UTF-7 and ISO 2022 variants,
- *    it uses ucnv_toUnicode() internally.)
- * - Convenient.
- *
- * Limitations compared to ucnv_toUnicode():
- * - Always assumes flush=TRUE.
- *   This makes ucnv_getNextUChar() unsuitable for "streaming" conversion,
- *   that is, for where the input is supplied in multiple buffers,
- *   because ucnv_getNextUChar() will assume the end of the input at the end
- *   of the first buffer.
- * - Does not provide offset output.
- *
- * It is possible to "mix" ucnv_getNextUChar() and ucnv_toUnicode() because
- * ucnv_getNextUChar() uses the current state of the converter
- * (unlike ucnv_toUChars() which always resets first).
- * However, if ucnv_getNextUChar() is called after ucnv_toUnicode()
- * stopped in the middle of a character sequence (with flush=FALSE),
- * then ucnv_getNextUChar() will always use the slower ucnv_toUnicode()
- * internally until the next character boundary.
- * (This is new in ICU 2.6. In earlier releases, ucnv_getNextUChar() had to
- * start at a character boundary.)
- *
- * Instead of using ucnv_getNextUChar(), it is recommended
- * to convert using ucnv_toUnicode() or ucnv_toUChars()
- * and then iterate over the text using U16_NEXT() or a UCharIterator (uiter.h)
- * or a C++ CharacterIterator or similar.
- * This allows streaming conversion and offset output, for example.
- *
- * <p>Handling of surrogate pairs and supplementary-plane code points:<br>
- * There are two different kinds of codepages that provide mappings for surrogate characters:
- * <ul>
- *   <li>Codepages like UTF-8, UTF-32, and GB 18030 provide direct representations for Unicode
- *       code points U+10000-U+10ffff as well as for single surrogates U+d800-U+dfff.
- *       Each valid sequence will result in exactly one returned code point.
- *       If a sequence results in a single surrogate, then that will be returned
- *       by itself, even if a neighboring sequence encodes the matching surrogate.</li>
- *   <li>Codepages like SCSU and LMBCS (and UTF-16) provide direct representations only for BMP code points
- *       including surrogates. Code points in supplementary planes are represented with
- *       two sequences, each encoding a surrogate.
- *       For these codepages, matching pairs of surrogates will be combined into single
- *       code points for returning from this function.
- *       (Note that SCSU is actually a mix of these codepage types.)</li>
- * </ul></p>
- *
- * @param converter an open UConverter
- * @param source the address of a pointer to the codepage buffer, will be
- *  updated to point after the bytes consumed in the conversion call.
- * @param sourceLimit points to the end of the input buffer
- * @param err fills in error status (see ucnv_toUnicode)
- * <code>U_INDEX_OUTOFBOUNDS_ERROR</code> will be set if the input 
- * is empty or does not convert to any output (e.g.: pure state-change 
- * codes SI/SO, escape sequences for ISO 2022,
- * or if the callback did not output anything, ...).
- * This function will not set a <code>U_BUFFER_OVERFLOW_ERROR</code> because
- *  the "buffer" is the return code. However, there might be subsequent output
- *  stored in the converter object
- * that will be returned in following calls to this function.
- * @return a UChar32 resulting from the partial conversion of source
- * @see ucnv_toUnicode
- * @see ucnv_toUChars
- * @see ucnv_convert
- * @stable ICU 2.0
- */
-U_STABLE UChar32 U_EXPORT2
-ucnv_getNextUChar(UConverter * converter,
-                  const char **source,
-                  const char * sourceLimit,
-                  UErrorCode * err);
-
-/**
- * Convert from one external charset to another using two existing UConverters.
- * Internally, two conversions - ucnv_toUnicode() and ucnv_fromUnicode() -
- * are used, "pivoting" through 16-bit Unicode.
- *
- * Important: For streaming conversion (multiple function calls for successive
- * parts of a text stream), the caller must provide a pivot buffer explicitly,
- * and must preserve the pivot buffer and associated pointers from one
- * call to another. (The buffer may be moved if its contents and the relative
- * pointer positions are preserved.)
- *
- * There is a similar function, ucnv_convert(),
- * which has the following limitations:
- * - it takes charset names, not converter objects, so that
- *   - two converters are opened for each call
- *   - only single-string conversion is possible, not streaming operation
- * - it does not provide enough information to find out,
- *   in case of failure, whether the toUnicode or
- *   the fromUnicode conversion failed
- *
- * By contrast, ucnv_convertEx()
- * - takes UConverter parameters instead of charset names
- * - fully exposes the pivot buffer for streaming conversion and complete error handling
- *
- * ucnv_convertEx() also provides further convenience:
- * - an option to reset the converters at the beginning
- *   (if reset==TRUE, see parameters;
- *    also sets *pivotTarget=*pivotSource=pivotStart)
- * - allow NUL-terminated input
- *   (only a single NUL byte, will not work for charsets with multi-byte NULs)
- *   (if sourceLimit==NULL, see parameters)
- * - terminate with a NUL on output
- *   (only a single NUL byte, not useful for charsets with multi-byte NULs),
- *   or set U_STRING_NOT_TERMINATED_WARNING if the output exactly fills
- *   the target buffer
- * - the pivot buffer can be provided internally;
- *   possible only for whole-string conversion, not streaming conversion;
- *   in this case, the caller will not be able to get details about where an
- *   error occurred
- *   (if pivotStart==NULL, see below)
- *
- * The function returns when one of the following is true:
- * - the entire source text has been converted successfully to the target buffer
- * - a target buffer overflow occurred (U_BUFFER_OVERFLOW_ERROR)
- * - a conversion error occurred
- *   (other U_FAILURE(), see description of pErrorCode)
- *
- * Limitation compared to the direct use of
- * ucnv_fromUnicode() and ucnv_toUnicode():
- * ucnv_convertEx() does not provide offset information.
- *
- * Limitation compared to ucnv_fromUChars() and ucnv_toUChars():
- * ucnv_convertEx() does not support preflighting directly.
- *
- * Sample code for converting a single string from
- * one external charset to UTF-8, ignoring the location of errors:
- *
- * \code
- * int32_t
- * myToUTF8(UConverter *cnv,
- *          const char *s, int32_t length,
- *          char *u8, int32_t capacity,
- *          UErrorCode *pErrorCode) {
- *     UConverter *utf8Cnv;
- *     char *target;
- *
- *     if(U_FAILURE(*pErrorCode)) {
- *         return 0;
- *     }
- *
- *     utf8Cnv=myGetCachedUTF8Converter(pErrorCode);
- *     if(U_FAILURE(*pErrorCode)) {
- *         return 0;
- *     }
- *
- *     if(length<0) {
- *         length=strlen(s);
- *     }
- *     target=u8;
- *     ucnv_convertEx(cnv, utf8Cnv,
- *                    &target, u8+capacity,
- *                    &s, s+length,
- *                    NULL, NULL, NULL, NULL,
- *                    TRUE, TRUE,
- *                    pErrorCode);
- * 
- *     myReleaseCachedUTF8Converter(utf8Cnv);
- *
- *     // return the output string length, but without preflighting
- *     return (int32_t)(target-u8);
- * }
- * \endcode
- *
- * @param targetCnv     Output converter, used to convert from the UTF-16 pivot
- *                      to the target using ucnv_fromUnicode().
- * @param sourceCnv     Input converter, used to convert from the source to
- *                      the UTF-16 pivot using ucnv_toUnicode().
- * @param target        I/O parameter, same as for ucnv_fromUChars().
- *                      Input: *target points to the beginning of the target buffer.
- *                      Output: *target points to the first unit after the last char written.
- * @param targetLimit   Pointer to the first unit after the target buffer.
- * @param source        I/O parameter, same as for ucnv_toUChars().
- *                      Input: *source points to the beginning of the source buffer.
- *                      Output: *source points to the first unit after the last char read.
- * @param sourceLimit   Pointer to the first unit after the source buffer.
- * @param pivotStart    Pointer to the UTF-16 pivot buffer. If pivotStart==NULL,
- *                      then an internal buffer is used and the other pivot
- *                      arguments are ignored and can be NULL as well.
- * @param pivotSource   I/O parameter, same as source in ucnv_fromUChars() for
- *                      conversion from the pivot buffer to the target buffer.
- * @param pivotTarget   I/O parameter, same as target in ucnv_toUChars() for
- *                      conversion from the source buffer to the pivot buffer.
- *                      It must be pivotStart<=*pivotSource<=*pivotTarget<=pivotLimit
- *                      and pivotStart<pivotLimit (unless pivotStart==NULL).
- * @param pivotLimit    Pointer to the first unit after the pivot buffer.
- * @param reset         If TRUE, then ucnv_resetToUnicode(sourceCnv) and
- *                      ucnv_resetFromUnicode(targetCnv) are called, and the
- *                      pivot pointers are reset (*pivotTarget=*pivotSource=pivotStart).
- * @param flush         If true, indicates the end of the input.
- *                      Passed directly to ucnv_toUnicode(), and carried over to
- *                      ucnv_fromUnicode() when the source is empty as well.
- * @param pErrorCode    ICU error code in/out parameter.
- *                      Must fulfill U_SUCCESS before the function call.
- *                      U_BUFFER_OVERFLOW_ERROR always refers to the target buffer
- *                      because overflows into the pivot buffer are handled internally.
- *                      Other conversion errors are from the source-to-pivot
- *                      conversion if *pivotSource==pivotStart, otherwise from
- *                      the pivot-to-target conversion.
- *
- * @see ucnv_convert
- * @see ucnv_fromAlgorithmic
- * @see ucnv_toAlgorithmic
- * @see ucnv_fromUnicode
- * @see ucnv_toUnicode
- * @see ucnv_fromUChars
- * @see ucnv_toUChars
- * @stable ICU 2.6
- */
-U_STABLE void U_EXPORT2
-ucnv_convertEx(UConverter *targetCnv, UConverter *sourceCnv,
-               char **target, const char *targetLimit,
-               const char **source, const char *sourceLimit,
-               UChar *pivotStart, UChar **pivotSource,
-               UChar **pivotTarget, const UChar *pivotLimit,
-               UBool reset, UBool flush,
-               UErrorCode *pErrorCode);
-
-/**
- * Convert from one external charset to another.
- * Internally, two converters are opened according to the name arguments,
- * then the text is converted to and from the 16-bit Unicode "pivot"
- * using ucnv_convertEx(), then the converters are closed again.
- *
- * This is a convenience function, not an efficient way to convert a lot of text:
- * ucnv_convert()
- * - takes charset names, not converter objects, so that
- *   - two converters are opened for each call
- *   - only single-string conversion is possible, not streaming operation
- * - does not provide enough information to find out,
- *   in case of failure, whether the toUnicode or
- *   the fromUnicode conversion failed
- * - allows NUL-terminated input
- *   (only a single NUL byte, will not work for charsets with multi-byte NULs)
- *   (if sourceLength==-1, see parameters)
- * - terminate with a NUL on output
- *   (only a single NUL byte, not useful for charsets with multi-byte NULs),
- *   or set U_STRING_NOT_TERMINATED_WARNING if the output exactly fills
- *   the target buffer
- * - a pivot buffer is provided internally
- *
- * The function returns when one of the following is true:
- * - the entire source text has been converted successfully to the target buffer
- *   and either the target buffer is terminated with a single NUL byte
- *   or the error code is set to U_STRING_NOT_TERMINATED_WARNING
- * - a target buffer overflow occurred (U_BUFFER_OVERFLOW_ERROR)
- *   and the full output string length is returned ("preflighting")
- * - a conversion error occurred
- *   (other U_FAILURE(), see description of pErrorCode)
- *
- * @param toConverterName   The name of the converter that is used to convert
- *                          from the UTF-16 pivot buffer to the target.
- * @param fromConverterName The name of the converter that is used to convert
- *                          from the source to the UTF-16 pivot buffer.
- * @param target            Pointer to the output buffer.
- * @param targetCapacity    Capacity of the target, in bytes.
- * @param source            Pointer to the input buffer.
- * @param sourceLength      Length of the input text, in bytes, or -1 for NUL-terminated input.
- * @param pErrorCode        ICU error code in/out parameter.
- *                          Must fulfill U_SUCCESS before the function call.
- * @return Length of the complete output text in bytes, even if it exceeds the targetCapacity
- *         and a U_BUFFER_OVERFLOW_ERROR is set.
- *
- * @see ucnv_convertEx
- * @see ucnv_fromAlgorithmic
- * @see ucnv_toAlgorithmic
- * @see ucnv_fromUnicode
- * @see ucnv_toUnicode
- * @see ucnv_fromUChars
- * @see ucnv_toUChars
- * @see ucnv_getNextUChar
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2
-ucnv_convert(const char *toConverterName,
-             const char *fromConverterName,
-             char *target,
-             int32_t targetCapacity,
-             const char *source,
-             int32_t sourceLength,
-             UErrorCode *pErrorCode);
-
-/**
- * Convert from one external charset to another.
- * Internally, the text is converted to and from the 16-bit Unicode "pivot"
- * using ucnv_convertEx(). ucnv_toAlgorithmic() works exactly like ucnv_convert()
- * except that the two converters need not be looked up and opened completely.
- *
- * The source-to-pivot conversion uses the cnv converter parameter.
- * The pivot-to-target conversion uses a purely algorithmic converter
- * according to the specified type, e.g., UCNV_UTF8 for a UTF-8 converter.
- *
- * Internally, the algorithmic converter is opened and closed for each
- * function call, which is more efficient than using the public ucnv_open()
- * but somewhat less efficient than only resetting an existing converter
- * and using ucnv_convertEx().
- *
- * This function is more convenient than ucnv_convertEx() for single-string
- * conversions, especially when "preflighting" is desired (returning the length
- * of the complete output even if it does not fit into the target buffer;
- * see the User Guide Strings chapter). See ucnv_convert() for details.
- *
- * @param algorithmicType   UConverterType constant identifying the desired target
- *                          charset as a purely algorithmic converter.
- *                          Those are converters for Unicode charsets like
- *                          UTF-8, BOCU-1, SCSU, UTF-7, IMAP-mailbox-name, etc.,
- *                          as well as US-ASCII and ISO-8859-1.
- * @param cnv               The converter that is used to convert
- *                          from the source to the UTF-16 pivot buffer.
- * @param target            Pointer to the output buffer.
- * @param targetCapacity    Capacity of the target, in bytes.
- * @param source            Pointer to the input buffer.
- * @param sourceLength      Length of the input text, in bytes
- * @param pErrorCode        ICU error code in/out parameter.
- *                          Must fulfill U_SUCCESS before the function call.
- * @return Length of the complete output text in bytes, even if it exceeds the targetCapacity
- *         and a U_BUFFER_OVERFLOW_ERROR is set.
- *
- * @see ucnv_fromAlgorithmic
- * @see ucnv_convert
- * @see ucnv_convertEx
- * @see ucnv_fromUnicode
- * @see ucnv_toUnicode
- * @see ucnv_fromUChars
- * @see ucnv_toUChars
- * @stable ICU 2.6
- */
-U_STABLE int32_t U_EXPORT2
-ucnv_toAlgorithmic(UConverterType algorithmicType,
-                   UConverter *cnv,
-                   char *target, int32_t targetCapacity,
-                   const char *source, int32_t sourceLength,
-                   UErrorCode *pErrorCode);
-
-/**
- * Convert from one external charset to another.
- * Internally, the text is converted to and from the 16-bit Unicode "pivot"
- * using ucnv_convertEx(). ucnv_fromAlgorithmic() works exactly like ucnv_convert()
- * except that the two converters need not be looked up and opened completely.
- *
- * The source-to-pivot conversion uses a purely algorithmic converter
- * according to the specified type, e.g., UCNV_UTF8 for a UTF-8 converter.
- * The pivot-to-target conversion uses the cnv converter parameter.
- *
- * Internally, the algorithmic converter is opened and closed for each
- * function call, which is more efficient than using the public ucnv_open()
- * but somewhat less efficient than only resetting an existing converter
- * and using ucnv_convertEx().
- *
- * This function is more convenient than ucnv_convertEx() for single-string
- * conversions, especially when "preflighting" is desired (returning the length
- * of the complete output even if it does not fit into the target buffer;
- * see the User Guide Strings chapter). See ucnv_convert() for details.
- *
- * @param cnv               The converter that is used to convert
- *                          from the UTF-16 pivot buffer to the target.
- * @param algorithmicType   UConverterType constant identifying the desired source
- *                          charset as a purely algorithmic converter.
- *                          Those are converters for Unicode charsets like
- *                          UTF-8, BOCU-1, SCSU, UTF-7, IMAP-mailbox-name, etc.,
- *                          as well as US-ASCII and ISO-8859-1.
- * @param target            Pointer to the output buffer.
- * @param targetCapacity    Capacity of the target, in bytes.
- * @param source            Pointer to the input buffer.
- * @param sourceLength      Length of the input text, in bytes
- * @param pErrorCode        ICU error code in/out parameter.
- *                          Must fulfill U_SUCCESS before the function call.
- * @return Length of the complete output text in bytes, even if it exceeds the targetCapacity
- *         and a U_BUFFER_OVERFLOW_ERROR is set.
- *
- * @see ucnv_fromAlgorithmic
- * @see ucnv_convert
- * @see ucnv_convertEx
- * @see ucnv_fromUnicode
- * @see ucnv_toUnicode
- * @see ucnv_fromUChars
- * @see ucnv_toUChars
- * @stable ICU 2.6
- */
-U_STABLE int32_t U_EXPORT2
-ucnv_fromAlgorithmic(UConverter *cnv,
-                     UConverterType algorithmicType,
-                     char *target, int32_t targetCapacity,
-                     const char *source, int32_t sourceLength,
-                     UErrorCode *pErrorCode);
-
-/**
- * Frees up memory occupied by unused, cached converter shared data.
- *
- * @return the number of cached converters successfully deleted
- * @see ucnv_close
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2
-ucnv_flushCache(void);
-
-/**
- * Returns the number of available converters, as per the alias file.
- *
- * @return the number of available converters
- * @see ucnv_getAvailableName
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2
-ucnv_countAvailable(void);
-
-/**
- * Gets the canonical converter name of the specified converter from a list of
- * all available converters contaied in the alias file. All converters
- * in this list can be opened.
- *
- * @param n the index to a converter available on the system (in the range <TT>[0..ucnv_countAvaiable()]</TT>)
- * @return a pointer a string (library owned), or <TT>NULL</TT> if the index is out of bounds.
- * @see ucnv_countAvailable
- * @stable ICU 2.0
- */
-U_STABLE const char* U_EXPORT2
-ucnv_getAvailableName(int32_t n);
-
-/**
- * Returns a UEnumeration to enumerate all of the canonical converter
- * names, as per the alias file, regardless of the ability to open each
- * converter.
- *
- * @return A UEnumeration object for getting all the recognized canonical
- *   converter names.
- * @see ucnv_getAvailableName
- * @see uenum_close
- * @see uenum_next
- * @stable ICU 2.4
- */
-U_STABLE UEnumeration * U_EXPORT2
-ucnv_openAllNames(UErrorCode *pErrorCode);
-
-/**
- * Gives the number of aliases for a given converter or alias name.
- * If the alias is ambiguous, then the preferred converter is used
- * and the status is set to U_AMBIGUOUS_ALIAS_WARNING.
- * This method only enumerates the listed entries in the alias file.
- * @param alias alias name
- * @param pErrorCode error status
- * @return number of names on alias list for given alias
- * @stable ICU 2.0
- */
-U_STABLE uint16_t U_EXPORT2 
-ucnv_countAliases(const char *alias, UErrorCode *pErrorCode);
-
-/**
- * Gives the name of the alias at given index of alias list.
- * This method only enumerates the listed entries in the alias file.
- * If the alias is ambiguous, then the preferred converter is used
- * and the status is set to U_AMBIGUOUS_ALIAS_WARNING.
- * @param alias alias name
- * @param n index in alias list
- * @param pErrorCode result of operation
- * @return returns the name of the alias at given index
- * @see ucnv_countAliases
- * @stable ICU 2.0
- */
-U_STABLE const char * U_EXPORT2 
-ucnv_getAlias(const char *alias, uint16_t n, UErrorCode *pErrorCode);
-
-/**
- * Fill-up the list of alias names for the given alias.
- * This method only enumerates the listed entries in the alias file.
- * If the alias is ambiguous, then the preferred converter is used
- * and the status is set to U_AMBIGUOUS_ALIAS_WARNING.
- * @param alias alias name
- * @param aliases fill-in list, aliases is a pointer to an array of
- *        <code>ucnv_countAliases()</code> string-pointers
- *        (<code>const char *</code>) that will be filled in.
- *        The strings themselves are owned by the library.
- * @param pErrorCode result of operation
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2 
-ucnv_getAliases(const char *alias, const char **aliases, UErrorCode *pErrorCode);
-
-/**
- * Return a new UEnumeration object for enumerating all the
- * alias names for a given converter that are recognized by a standard.
- * This method only enumerates the listed entries in the alias file.
- * The convrtrs.txt file can be modified to change the results of
- * this function.
- * The first result in this list is the same result given by
- * <code>ucnv_getStandardName</code>, which is the default alias for
- * the specified standard name. The returned object must be closed with
- * <code>uenum_close</code> when you are done with the object.
- *
- * @param convName original converter name
- * @param standard name of the standard governing the names; MIME and IANA
- *      are such standards
- * @param pErrorCode The error code
- * @return A UEnumeration object for getting all aliases that are recognized
- *      by a standard. If any of the parameters are invalid, NULL
- *      is returned.
- * @see ucnv_getStandardName
- * @see uenum_close
- * @see uenum_next
- * @stable ICU 2.2
- */
-U_STABLE UEnumeration * U_EXPORT2
-ucnv_openStandardNames(const char *convName,
-                       const char *standard,
-                       UErrorCode *pErrorCode);
-
-/**
- * Gives the number of standards associated to converter names.
- * @return number of standards
- * @stable ICU 2.0
- */
-U_STABLE uint16_t U_EXPORT2
-ucnv_countStandards(void);
-
-/**
- * Gives the name of the standard at given index of standard list.
- * @param n index in standard list
- * @param pErrorCode result of operation
- * @return returns the name of the standard at given index. Owned by the library.
- * @stable ICU 2.0
- */
-U_STABLE const char * U_EXPORT2
-ucnv_getStandard(uint16_t n, UErrorCode *pErrorCode);
-
-/**
- * Returns a standard name for a given converter name.
- * <p>
- * Example alias table:<br>
- * conv alias1 { STANDARD1 } alias2 { STANDARD1* }
- * <p>
- * Result of ucnv_getStandardName("conv", "STANDARD1") from example
- * alias table:<br>
- * <b>"alias2"</b>
- *
- * @param name original converter name
- * @param standard name of the standard governing the names; MIME and IANA
- *        are such standards
- * @param pErrorCode result of operation
- * @return returns the standard converter name;
- *         if a standard converter name cannot be determined,
- *         then <code>NULL</code> is returned. Owned by the library.
- * @stable ICU 2.0
- */
-U_STABLE const char * U_EXPORT2
-ucnv_getStandardName(const char *name, const char *standard, UErrorCode *pErrorCode);
-
-/**
- * This function will return the internal canonical converter name of the
- * tagged alias. This is the opposite of ucnv_openStandardNames, which
- * returns the tagged alias given the canonical name.
- * <p>
- * Example alias table:<br>
- * conv alias1 { STANDARD1 } alias2 { STANDARD1* }
- * <p>
- * Result of ucnv_getStandardName("alias1", "STANDARD1") from example
- * alias table:<br>
- * <b>"conv"</b>
- *
- * @return returns the canonical converter name;
- *         if a standard or alias name cannot be determined,
- *         then <code>NULL</code> is returned. The returned string is
- *         owned by the library.
- * @see ucnv_getStandardName
- * @stable ICU 2.4
- */
-U_STABLE const char * U_EXPORT2
-ucnv_getCanonicalName(const char *alias, const char *standard, UErrorCode *pErrorCode);
-
-/**
- * Returns the current default converter name. If you want to open
- * a default converter, you do not need to use this function.
- * It is faster if you pass a NULL argument to ucnv_open the
- * default converter.
- *
- * @return returns the current default converter name.
- *         Storage owned by the library
- * @see ucnv_setDefaultName
- * @stable ICU 2.0
- */
-U_STABLE const char * U_EXPORT2
-ucnv_getDefaultName(void);
-
-/**
- * This function is not thread safe. DO NOT call this function when ANY ICU
- * function is being used from more than one thread! This function sets the
- * current default converter name. If this function needs to be called, it
- * should be called during application initialization. Most of the time, the
- * results from ucnv_getDefaultName() or ucnv_open with a NULL string argument
- * is sufficient for your application.
- * @param name the converter name to be the default (must be known by ICU).
- * @see ucnv_getDefaultName
- * @system
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2
-ucnv_setDefaultName(const char *name);
-
-/**
- * Fixes the backslash character mismapping.  For example, in SJIS, the backslash 
- * character in the ASCII portion is also used to represent the yen currency sign.  
- * When mapping from Unicode character 0x005C, it's unclear whether to map the 
- * character back to yen or backslash in SJIS.  This function will take the input
- * buffer and replace all the yen sign characters with backslash.  This is necessary
- * when the user tries to open a file with the input buffer on Windows.
- * This function will test the converter to see whether such mapping is
- * required.  You can sometimes avoid using this function by using the correct version
- * of Shift-JIS.
- *
- * @param cnv The converter representing the target codepage.
- * @param source the input buffer to be fixed
- * @param sourceLen the length of the input buffer
- * @see ucnv_isAmbiguous
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2
-ucnv_fixFileSeparator(const UConverter *cnv, UChar *source, int32_t sourceLen);
-
-/**
- * Determines if the converter contains ambiguous mappings of the same
- * character or not.
- * @param cnv the converter to be tested
- * @return TRUE if the converter contains ambiguous mapping of the same 
- * character, FALSE otherwise.
- * @stable ICU 2.0
- */
-U_STABLE UBool U_EXPORT2
-ucnv_isAmbiguous(const UConverter *cnv);
-
-/**
- * Sets the converter to use fallback mappings or not.
- * Regardless of this flag, the converter will always use
- * fallbacks from Unicode Private Use code points, as well as
- * reverse fallbacks (to Unicode).
- * For details see ".ucm File Format"
- * in the Conversion Data chapter of the ICU User Guide:
- * http://www.icu-project.org/userguide/conversion-data.html#ucmformat
- *
- * @param cnv The converter to set the fallback mapping usage on.
- * @param usesFallback TRUE if the user wants the converter to take advantage of the fallback 
- * mapping, FALSE otherwise.
- * @stable ICU 2.0
- * @see ucnv_usesFallback
- */
-U_STABLE void U_EXPORT2 
-ucnv_setFallback(UConverter *cnv, UBool usesFallback);
-
-/**
- * Determines if the converter uses fallback mappings or not.
- * This flag has restrictions, see ucnv_setFallback().
- *
- * @param cnv The converter to be tested
- * @return TRUE if the converter uses fallback, FALSE otherwise.
- * @stable ICU 2.0
- * @see ucnv_setFallback
- */
-U_STABLE UBool U_EXPORT2 
-ucnv_usesFallback(const UConverter *cnv);
-
-/**
- * Detects Unicode signature byte sequences at the start of the byte stream
- * and returns the charset name of the indicated Unicode charset.
- * NULL is returned when no Unicode signature is recognized.
- * The number of bytes in the signature is output as well.
- *
- * The caller can ucnv_open() a converter using the charset name.
- * The first code unit (UChar) from the start of the stream will be U+FEFF
- * (the Unicode BOM/signature character) and can usually be ignored.
- *
- * For most Unicode charsets it is also possible to ignore the indicated
- * number of initial stream bytes and start converting after them.
- * However, there are stateful Unicode charsets (UTF-7 and BOCU-1) for which
- * this will not work. Therefore, it is best to ignore the first output UChar
- * instead of the input signature bytes.
- * <p>
- * Usage:
- * @code     
- *      UErrorCode err = U_ZERO_ERROR;
- *      char input[] = { '\xEF','\xBB', '\xBF','\x41','\x42','\x43' };
- *      int32_t signatureLength = 0;
- *      char *encoding = ucnv_detectUnicodeSignature(input,sizeof(input),&signatureLength,&err);
- *      UConverter *conv = NULL;
- *      UChar output[100];
- *      UChar *target = output, *out;
- *      char *source = input;
- *      if(encoding!=NULL && U_SUCCESS(err)){
- *          // should signature be discarded ?
- *          conv = ucnv_open(encoding, &err);
- *          // do the conversion
- *          ucnv_toUnicode(conv,
- *                         target, output + sizeof(output)/U_SIZEOF_UCHAR,
- *                         source, input + sizeof(input),
- *                         NULL, TRUE, &err);
- *          out = output;
- *          if (discardSignature){
- *              ++out; // ignore initial U+FEFF
- *          }
- *          while(out != target) {
- *              printf("%04x ", *out++);
- *          }
- *          puts("");
- *      }
- *     
- * @endcode
- *
- * @param source            The source string in which the signature should be detected.
- * @param sourceLength      Length of the input string, or -1 if terminated with a NUL byte.
- * @param signatureLength   A pointer to int32_t to receive the number of bytes that make up the signature 
- *                          of the detected UTF. 0 if not detected.
- *                          Can be a NULL pointer.
- * @param pErrorCode        ICU error code in/out parameter.
- *                          Must fulfill U_SUCCESS before the function call.
- * @return The name of the encoding detected. NULL if encoding is not detected. 
- * @stable ICU 2.4
- */
-U_STABLE const char* U_EXPORT2
-ucnv_detectUnicodeSignature(const char* source,
-                            int32_t sourceLength,
-                            int32_t *signatureLength,
-                            UErrorCode *pErrorCode);
-
-/**
- * Returns the number of UChars held in the converter's internal state 
- * because more input is needed for completing the conversion. This function is 
- * useful for mapping semantics of ICU's converter interface to those of iconv,
- * and this information is not needed for normal conversion.
- * @param cnv       The converter in which the input is held
- * @param status    ICU error code in/out parameter.
- *                  Must fulfill U_SUCCESS before the function call.
- * @return The number of UChars in the state. -1 if an error is encountered.
- * @stable ICU 3.4
- */
-U_STABLE int32_t U_EXPORT2
-ucnv_fromUCountPending(const UConverter* cnv, UErrorCode* status);
-
-/**
- * Returns the number of chars held in the converter's internal state
- * because more input is needed for completing the conversion. This function is 
- * useful for mapping semantics of ICU's converter interface to those of iconv,
- * and this information is not needed for normal conversion.
- * @param cnv       The converter in which the input is held as internal state
- * @param status    ICU error code in/out parameter.
- *                  Must fulfill U_SUCCESS before the function call.
- * @return The number of chars in the state. -1 if an error is encountered.
- * @stable ICU 3.4
- */
-U_STABLE int32_t U_EXPORT2
-ucnv_toUCountPending(const UConverter* cnv, UErrorCode* status);
-
-#endif
-
-#endif
-/*_UCNV*/


[51/57] [abbrv] couchdb commit: updated refs/heads/1994-merge-rcouch-multi-repo to b19d055

Posted by be...@apache.org.
remove couch_index


Project: http://git-wip-us.apache.org/repos/asf/couchdb/repo
Commit: http://git-wip-us.apache.org/repos/asf/couchdb/commit/372b033a
Tree: http://git-wip-us.apache.org/repos/asf/couchdb/tree/372b033a
Diff: http://git-wip-us.apache.org/repos/asf/couchdb/diff/372b033a

Branch: refs/heads/1994-merge-rcouch-multi-repo
Commit: 372b033af8ac8e0f71e918f9e1b34abffe4c1e75
Parents: 75150a1
Author: Benoit Chesneau <bc...@gmail.com>
Authored: Thu Feb 13 16:39:43 2014 +0100
Committer: Benoit Chesneau <bc...@gmail.com>
Committed: Thu Feb 13 16:39:43 2014 +0100

----------------------------------------------------------------------
 apps/couch_index/src/couch_index.app.src       |  19 -
 apps/couch_index/src/couch_index.erl           | 402 --------------------
 apps/couch_index/src/couch_index_api.erl       |  54 ---
 apps/couch_index/src/couch_index_compactor.erl | 113 ------
 apps/couch_index/src/couch_index_event.erl     |  65 ----
 apps/couch_index/src/couch_index_event_sup.erl |  51 ---
 apps/couch_index/src/couch_index_indexer.erl   | 221 -----------
 apps/couch_index/src/couch_index_server.erl    | 221 -----------
 apps/couch_index/src/couch_index_sup.erl       |  34 --
 apps/couch_index/src/couch_index_updater.erl   | 200 ----------
 apps/couch_index/src/couch_index_util.erl      |  77 ----
 11 files changed, 1457 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/couchdb/blob/372b033a/apps/couch_index/src/couch_index.app.src
----------------------------------------------------------------------
diff --git a/apps/couch_index/src/couch_index.app.src b/apps/couch_index/src/couch_index.app.src
deleted file mode 100644
index 921e5d2..0000000
--- a/apps/couch_index/src/couch_index.app.src
+++ /dev/null
@@ -1,19 +0,0 @@
-% Licensed 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.
-
-{application, couch_index, [
-    {description, "CouchDB Secondary Index Manager"},
-    {vsn, "1.3.0"},
-    {modules, []},
-    {registered, [couch_index_server]},
-    {applications, [kernel, stdlib, couch]}
-]}.

http://git-wip-us.apache.org/repos/asf/couchdb/blob/372b033a/apps/couch_index/src/couch_index.erl
----------------------------------------------------------------------
diff --git a/apps/couch_index/src/couch_index.erl b/apps/couch_index/src/couch_index.erl
deleted file mode 100644
index 01483bb..0000000
--- a/apps/couch_index/src/couch_index.erl
+++ /dev/null
@@ -1,402 +0,0 @@
-% Licensed 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.
-
--module(couch_index).
--behaviour(gen_server).
-
-
-%% API
--export([start_link/1, stop/1, get_state/2, get_info/1]).
--export([compact/1, compact/2, get_compactor_pid/1]).
--export([acquire_indexer/1, release_indexer/1]).
--export([config_change/3]).
-
-%% gen_server callbacks
--export([init/1, terminate/2, code_change/3]).
--export([handle_call/3, handle_cast/2, handle_info/2]).
-
--include_lib("couch/include/couch_db.hrl").
-
--record(st, {
-    mod,
-    idx_state,
-    updater,
-    compactor,
-    indexer=nil,
-    waiters=[],
-    commit_delay,
-    committed=true,
-    shutdown=false
-}).
-
-
-start_link({Module, IdxState}) ->
-    proc_lib:start_link(?MODULE, init, [{Module, IdxState}]).
-
-
-stop(Pid) ->
-    gen_server:cast(Pid, stop).
-
-
-get_state(Pid, RequestSeq) ->
-    gen_server:call(Pid, {get_state, RequestSeq}, infinity).
-
-
-get_info(Pid) ->
-    gen_server:call(Pid, get_info).
-
-
-compact(Pid) ->
-    compact(Pid, []).
-
-
-compact(Pid, Options) ->
-    {ok, CPid} = gen_server:call(Pid, compact),
-    case lists:member(monitor, Options) of
-        true -> {ok, erlang:monitor(process, CPid)};
-        false -> ok
-    end.
-
-
-get_compactor_pid(Pid) ->
-    gen_server:call(Pid, get_compactor_pid).
-
-
-acquire_indexer(Pid) ->
-    {ok, IPid} = gen_server:call(Pid, get_indexer_pid),
-    gen_server:call(IPid, {acquire, self()}).
-
-release_indexer(Pid) ->
-    {ok, IPid} = gen_server:call(Pid, get_indexer_pid),
-    gen_server:call(IPid, {release, self()}).
-
-
-config_change("query_server_config", "commit_freq", NewValue) ->
-    ok = gen_server:cast(?MODULE, {config_update, NewValue}).
-
-
-init({Mod, IdxState}) ->
-    ok = couch_config:register(fun ?MODULE:config_change/3),
-    DbName = Mod:get(db_name, IdxState),
-    Resp = couch_util:with_db(DbName, fun(Db) ->
-        case Mod:open(Db, IdxState) of
-            {ok, IdxSt} ->
-                couch_db:monitor(Db),
-                {ok, IdxSt};
-            Error ->
-                Error
-        end
-    end),
-    case Resp of
-        {ok, NewIdxState} ->
-            {ok, UPid} = couch_index_updater:start_link(self(), Mod),
-            {ok, CPid} = couch_index_compactor:start_link(self(), Mod),
-
-            Delay = couch_config:get("query_server_config", "commit_freq", "5"),
-            MsDelay = 1000 * list_to_integer(Delay),
-            State = #st{
-                mod=Mod,
-                idx_state=NewIdxState,
-                updater=UPid,
-                compactor=CPid,
-                commit_delay=MsDelay
-            },
-            Args = [
-                Mod:get(db_name, IdxState),
-                Mod:get(idx_name, IdxState),
-                couch_index_util:hexsig(Mod:get(signature, IdxState))
-            ],
-            ?LOG_INFO("Opening index for db: ~s idx: ~s sig: ~p", Args),
-            proc_lib:init_ack({ok, self()}),
-            gen_server:enter_loop(?MODULE, [], State);
-        Other ->
-            proc_lib:init_ack(Other)
-    end.
-
-
-terminate(Reason, State) ->
-    #st{mod=Mod, idx_state=IdxState}=State,
-    Mod:close(IdxState),
-    send_all(State#st.waiters, Reason),
-    couch_util:shutdown_sync(State#st.updater),
-    couch_util:shutdown_sync(State#st.compactor),
-    Args = [
-        Mod:get(db_name, IdxState),
-        Mod:get(idx_name, IdxState),
-        couch_index_util:hexsig(Mod:get(signature, IdxState)),
-        Reason
-    ],
-    ?LOG_INFO("Closing index for db: ~s idx: ~s sig: ~p~nreason: ~p", Args),
-    ok.
-
-
-handle_call({get_state, ReqSeq}, From, State) ->
-    #st{
-        mod=Mod,
-        idx_state=IdxState,
-        waiters=Waiters
-    } = State,
-    IdxSeq = Mod:get(update_seq, IdxState),
-    case ReqSeq =< IdxSeq of
-        true ->
-            {reply, {ok, IdxState}, State};
-        _ -> % View update required
-            couch_index_updater:run(State#st.updater, IdxState),
-            Waiters2 = [{From, ReqSeq} | Waiters],
-            {noreply, State#st{waiters=Waiters2}, infinity}
-    end;
-handle_call(get_info, _From, State) ->
-    #st{mod=Mod} = State,
-    {ok, Info0} = Mod:get(info, State#st.idx_state),
-    IsUpdating = couch_index_updater:is_running(State#st.updater),
-    IsCompacting = couch_index_compactor:is_running(State#st.compactor),
-    Info = Info0 ++ [
-        {updater_running, IsUpdating},
-        {compact_running, IsCompacting},
-        {waiting_commit, State#st.committed == false},
-        {waiting_clients, length(State#st.waiters)}
-    ],
-    {reply, {ok, Info}, State};
-handle_call(reset, _From, State) ->
-    #st{
-        mod=Mod,
-        idx_state=IdxState
-    } = State,
-    {ok, NewIdxState} = Mod:reset(IdxState),
-    {reply, {ok, NewIdxState}, State#st{idx_state=NewIdxState}};
-handle_call(compact, _From, State) ->
-    Resp = couch_index_compactor:run(State#st.compactor, State#st.idx_state),
-    {reply, Resp, State};
-handle_call(get_compactor_pid, _From, State) ->
-    {reply, {ok, State#st.compactor}, State};
-handle_call({compacted, NewIdxState}, _From, State) ->
-    #st{
-        mod=Mod,
-        idx_state=OldIdxState,
-        updater=Updater,
-        commit_delay=Delay
-    } = State,
-    assert_signature_match(Mod, OldIdxState, NewIdxState),
-    NewSeq = Mod:get(update_seq, NewIdxState),
-    OldSeq = Mod:get(update_seq, OldIdxState),
-    % For indices that require swapping files, we have to make sure we're
-    % up to date with the current index. Otherwise indexes could roll back
-    % (perhaps considerably) to previous points in history.
-    case NewSeq >= OldSeq of
-        true ->
-            {ok, NewIdxState1} = Mod:swap_compacted(OldIdxState, NewIdxState),
-            % Restart the indexer if it's running.
-            case couch_index_updater:is_running(Updater) of
-                true -> ok = couch_index_updater:restart(Updater, NewIdxState1);
-                false -> ok
-            end,
-            case State#st.committed of
-                true -> erlang:send_after(Delay, self(), commit);
-                false -> ok
-            end,
-            {reply, ok, State#st{
-                idx_state=NewIdxState1,
-                committed=false
-            }};
-        _ ->
-            {reply, recompact, State}
-    end;
-handle_call(get_indexer_pid, _From, #st{mod=Mod, idx_state=IdxState}=State) ->
-    Pid = case State#st.indexer of
-        Pid1 when is_pid(Pid1) ->
-            Pid1;
-        _ ->
-            DbName = Mod:get(db_name, IdxState),
-            {ok, IPid} = couch_index_indexer:start_link(self(), DbName),
-            erlang:monitor(process, IPid),
-            IPid
-    end,
-    {reply, {ok, Pid}, State#st{indexer=Pid}}.
-
-
-handle_cast({config_change, NewDelay}, State) ->
-    MsDelay = 1000 * list_to_integer(NewDelay),
-    {noreply, State#st{commit_delay=MsDelay}};
-handle_cast({updated, NewIdxState}, State) ->
-    {noreply, NewState} = handle_cast({new_state, NewIdxState}, State),
-    case NewState#st.shutdown andalso (NewState#st.waiters =:= []) of
-        true ->
-            {stop, normal, NewState};
-        false ->
-            maybe_restart_updater(NewState),
-            {noreply, NewState}
-    end;
-handle_cast({new_state, NewIdxState}, State) ->
-    #st{
-        mod=Mod,
-        idx_state=OldIdxState,
-        commit_delay=Delay
-    } = State,
-    assert_signature_match(Mod, OldIdxState, NewIdxState),
-    CurrSeq = Mod:get(update_seq, NewIdxState),
-
-    DbName = Mod:get(db_name, NewIdxState),
-    DDocId = Mod:get(idx_name, NewIdxState),
-
-    %% notify to event listeners that the index has been
-    %% updated
-    couch_index_event:notify({index_update,
-                              {DbName, DDocId,
-                               Mod}}),
-    Args = [
-        DbName,
-        DDocId,
-        CurrSeq
-    ],
-    ?LOG_DEBUG("Updated index for db: ~s idx: ~s seq: ~B", Args),
-    Rest = send_replies(State#st.waiters, CurrSeq, NewIdxState),
-    case State#st.committed of
-        true -> erlang:send_after(Delay, self(), commit);
-        false -> ok
-    end,
-    {noreply, State#st{
-        idx_state=NewIdxState,
-        waiters=Rest,
-        committed=false
-    }};
-handle_cast({update_error, Error}, State) ->
-    send_all(State#st.waiters, Error),
-    {noreply, State#st{waiters=[]}};
-handle_cast(stop, State) ->
-    {stop, normal, State};
-handle_cast(delete, State) ->
-    #st{mod=Mod, idx_state=IdxState} = State,
-    DbName = Mod:get(db_name, IdxState),
-    DDocId = Mod:get(idx_name, IdxState),
-
-    %% notify about the index deletion
-    couch_index_event:notify({index_delete,
-                              {DbName, DDocId, Mod}}),
-
-    ok = Mod:delete(IdxState),
-
-    {stop, normal, State};
-handle_cast(ddoc_updated, State) ->
-    #st{mod = Mod, idx_state = IdxState, waiters = Waiters} = State,
-    DbName = Mod:get(db_name, IdxState),
-    DDocId = Mod:get(idx_name, IdxState),
-
-    %% notify to event listeners that the index has been
-    %% updated
-    couch_index_event:notify({index_update,
-                              {DbName, DDocId,
-                               Mod}}),
-
-    Shutdown = couch_util:with_db(DbName, fun(Db) ->
-        case couch_db:open_doc(Db, DDocId, [ejson_body]) of
-            {not_found, deleted} ->
-                true;
-            {ok, DDoc} ->
-                {ok, NewIdxState} = Mod:init(Db, DDoc),
-                Mod:get(signature, NewIdxState) =/= Mod:get(signature, IdxState)
-        end
-    end),
-    case Shutdown of
-        true ->
-            case Waiters of
-                [] ->
-                    {stop, normal, State};
-                _ ->
-                    {noreply, State#st{shutdown = true}}
-            end;
-        false ->
-            {noreply, State#st{shutdown = false}}
-    end;
-handle_cast(_Mesg, State) ->
-    {stop, unhandled_cast, State}.
-
-
-handle_info(commit, #st{committed=true}=State) ->
-    {noreply, State};
-handle_info(commit, State) ->
-    #st{mod=Mod, idx_state=IdxState, commit_delay=Delay} = State,
-    DbName = Mod:get(db_name, IdxState),
-    GetCommSeq = fun(Db) -> couch_db:get_committed_update_seq(Db) end,
-    CommittedSeq = couch_util:with_db(DbName, GetCommSeq),
-    case CommittedSeq >= Mod:get(update_seq, IdxState) of
-        true ->
-            % Commit the updates
-            ok = Mod:commit(IdxState),
-            {noreply, State#st{committed=true}};
-        _ ->
-            % We can't commit the header because the database seq that's
-            % fully committed to disk is still behind us. If we committed
-            % now and the database lost those changes our view could be
-            % forever out of sync with the database. But a crash before we
-            % commit these changes, no big deal, we only lose incremental
-            % changes since last committal.
-            erlang:send_after(Delay, self(), commit),
-            {noreply, State}
-    end;
-
-handle_info({'DOWN', _, _, Pid, _}, #st{mod=Mod, idx_state=IdxState,
-                                        indexer=Pid}=State) ->
-    Args = [Mod:get(db_name, IdxState),
-            Mod:get(idx_name, IdxState)],
-    ?LOG_INFO("Background indexer shutdown by monitor notice for db: ~s idx: ~s", Args),
-
-    {noreply, State#st{indexer=nil}};
-
-handle_info({'DOWN', _, _, _Pid, _}, #st{mod=Mod, idx_state=IdxState}=State) ->
-    DbName = Mod:get(db_name, IdxState),
-    DDocId = Mod:get(idx_name, IdxState),
-
-    %% notify to event listeners that the index has been
-    %% updated
-    couch_index_event:notify({index_delete, {DbName, DDocId, Mod}}),
-
-    Args = [DbName, DDocId],
-    ?LOG_INFO("Index shutdown by monitor notice for db: ~s idx: ~s", Args),
-    catch send_all(State#st.waiters, shutdown),
-    {stop, normal, State#st{waiters=[]}}.
-
-
-code_change(_OldVsn, State, _Extra) ->
-    {ok, State}.
-
-
-maybe_restart_updater(#st{waiters=[]}) ->
-    ok;
-maybe_restart_updater(#st{mod=Mod, idx_state=IdxState}=State) ->
-    couch_util:with_db(Mod:get(db_name, IdxState), fun(Db) ->
-        UpdateSeq = couch_db:get_update_seq(Db),
-        CommittedSeq = couch_db:get_committed_update_seq(Db),
-        CanUpdate = UpdateSeq > CommittedSeq,
-        UOpts = Mod:get(update_options, IdxState),
-        case CanUpdate and lists:member(committed_only, UOpts) of
-            true -> couch_db:ensure_full_commit(Db);
-            false -> ok
-        end
-    end),
-    couch_index_updater:run(State#st.updater, IdxState).
-
-
-send_all(Waiters, Reply) ->
-    [gen_server:reply(From, Reply) || {From, _} <- Waiters].
-
-
-send_replies(Waiters, UpdateSeq, IdxState) ->
-    Pred = fun({_, S}) -> S =< UpdateSeq end,
-    {ToSend, Remaining} = lists:partition(Pred, Waiters),
-    [gen_server:reply(From, {ok, IdxState}) || {From, _} <- ToSend],
-    Remaining.
-
-assert_signature_match(Mod, OldIdxState, NewIdxState) ->
-    case {Mod:get(signature, OldIdxState), Mod:get(signature, NewIdxState)} of
-        {Sig, Sig} -> ok;
-        _ -> erlang:error(signature_mismatch)
-    end.

http://git-wip-us.apache.org/repos/asf/couchdb/blob/372b033a/apps/couch_index/src/couch_index_api.erl
----------------------------------------------------------------------
diff --git a/apps/couch_index/src/couch_index_api.erl b/apps/couch_index/src/couch_index_api.erl
deleted file mode 100644
index 9d3a67c..0000000
--- a/apps/couch_index/src/couch_index_api.erl
+++ /dev/null
@@ -1,54 +0,0 @@
-% Licensed 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.
-
--module(couch_index_api).
-
-get(Field, State) ->
-    ok.
-
-init(Db, Ddoc) ->
-    ok.
-
-open(Db, State) ->
-    ok.
-
-close(State) ->
-    ok.
-
-delete(State) ->
-    ok.
-
-reset(State) ->
-    ok.
-
-
-start_update(State, PurgedState, NumChanges) ->
-    {ok, State}.
-
-purge(Db, PurgeSeq, PurgedIdRevs, State) ->
-    ok.
-
-process_doc(Doc, Seq, State) ->
-    ok.
-
-finish_update(State) ->
-    {ok, State}.
-
-commit(State) ->
-    ok.
-
-
-compact(Parent, State, Opts) ->
-    ok.
-
-swap_compacted(OldState, NewState) ->
-    ok.

http://git-wip-us.apache.org/repos/asf/couchdb/blob/372b033a/apps/couch_index/src/couch_index_compactor.erl
----------------------------------------------------------------------
diff --git a/apps/couch_index/src/couch_index_compactor.erl b/apps/couch_index/src/couch_index_compactor.erl
deleted file mode 100644
index 6e9fb2e..0000000
--- a/apps/couch_index/src/couch_index_compactor.erl
+++ /dev/null
@@ -1,113 +0,0 @@
-% Licensed 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.
-
--module(couch_index_compactor).
--behaviour(gen_server).
-
-
-%% API
--export([start_link/2, run/2, cancel/1, is_running/1]).
-
-%% gen_server callbacks
--export([init/1, terminate/2, code_change/3]).
--export([handle_call/3, handle_cast/2, handle_info/2]).
-
-
--include_lib("couch/include/couch_db.hrl").
-
--record(st, {
-    idx,
-    mod,
-    pid
-}).
-
-
-start_link(Index, Module) ->
-    gen_server:start_link(?MODULE, {Index, Module}, []).
-
-
-run(Pid, IdxState) ->
-    gen_server:call(Pid, {compact, IdxState}).
-
-
-cancel(Pid) ->
-    gen_server:call(Pid, cancel).
-
-
-is_running(Pid) ->
-    gen_server:call(Pid, is_running).
-
-
-init({Index, Module}) ->
-    process_flag(trap_exit, true),
-    {ok, #st{idx=Index, mod=Module}}.
-
-
-terminate(_Reason, State) ->
-    couch_util:shutdown_sync(State#st.pid),
-    ok.
-
-
-handle_call({compact, _}, _From, #st{pid=Pid}=State) when is_pid(Pid) ->
-    {reply, {ok, Pid}, State};
-handle_call({compact, IdxState}, _From, #st{idx=Idx}=State) ->
-    Pid = spawn_link(fun() -> compact(Idx, State#st.mod, IdxState) end),
-    {reply, {ok, Pid}, State#st{pid=Pid}};
-handle_call(cancel, _From, #st{pid=undefined}=State) ->
-    {reply, ok, State};
-handle_call(cancel, _From, #st{pid=Pid}=State) ->
-    unlink(Pid),
-    exit(Pid, kill),
-    {reply, ok, State#st{pid=undefined}};
-handle_call(is_running, _From, #st{pid=Pid}=State) when is_pid(Pid) ->
-    {reply, true, State};
-handle_call(is_running, _From, State) ->
-    {reply, false, State}.
-
-
-handle_cast(_Mesg, State) ->
-    {stop, unknown_cast, State}.
-
-
-handle_info({'EXIT', Pid, normal}, #st{pid=Pid}=State) ->
-    {noreply, State#st{pid=undefined}};
-handle_info({'EXIT', _Pid, normal}, State) ->
-    {noreply, State};
-handle_info({'EXIT', Pid, _Reason}, #st{idx=Pid}=State) ->
-    {stop, normal, State};
-handle_info(_Mesg, State) ->
-    {stop, unknown_info, State}.
-
-
-code_change(_OldVsn, State, _Extra) ->
-    {ok, State}.
-
-
-compact(Parent, Mod, IdxState) ->
-    compact(Parent, Mod, IdxState, []).
-
-compact(Idx, Mod, IdxState, Opts) ->
-    DbName = Mod:get(db_name, IdxState),
-    Args = [DbName, Mod:get(idx_name, IdxState)],
-    ?LOG_INFO("Compaction started for db: ~s idx: ~s", Args),
-    {ok, NewIdxState} = couch_util:with_db(DbName, fun(Db) ->
-        Mod:compact(Db, IdxState, Opts)
-    end),
-    ok = Mod:commit(NewIdxState),
-    case gen_server:call(Idx, {compacted, NewIdxState}) of
-        recompact ->
-            ?LOG_INFO("Compaction restarting for db: ~s idx: ~s", Args),
-            compact(Idx, Mod, NewIdxState, [recompact]);
-        _ ->
-            ?LOG_INFO("Compaction finished for db: ~s idx: ~s", Args),
-            ok
-    end.

http://git-wip-us.apache.org/repos/asf/couchdb/blob/372b033a/apps/couch_index/src/couch_index_event.erl
----------------------------------------------------------------------
diff --git a/apps/couch_index/src/couch_index_event.erl b/apps/couch_index/src/couch_index_event.erl
deleted file mode 100644
index 0cd0a6b..0000000
--- a/apps/couch_index/src/couch_index_event.erl
+++ /dev/null
@@ -1,65 +0,0 @@
-% Licensed 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.
-
--module(couch_index_event).
--behaviour(gen_event).
-
--export([start_link/1]).
--export([notify/1]).
--export([stop/1]).
-
-%% gen_event callbacks
--export([init/1, handle_event/2, handle_call/2, handle_info/2,
-         terminate/2, code_change/3]).
-
-start_link(Consumer) ->
-    HandlerId = {?MODULE, make_ref()},
-    couch_index_event_sup:start_link(couch_index_events, HandlerId,
-                                     Consumer).
-
-notify(Event) ->
-    gen_event:notify(couch_index_events, Event).
-
-stop(Pid) ->
-    couch_index_event_sup:stop(Pid).
-
-
-init(Consumer) ->
-    process_flag(trap_exit, true),
-    {ok, Consumer}.
-
-handle_event(Event, Consumer) ->
-    dispatch_event(Event, Consumer).
-
-handle_call(_Req, Consumer) ->
-    {reply, ok, Consumer}.
-
-handle_info({'EXIT', _, _}, _Consumer) ->
-    remove_handler;
-handle_info(_Info, Consumer)->
-    {ok, Consumer}.
-
-code_change(_OldVsn, Consumer, _Extra) ->
-    {ok, Consumer}.
-
-terminate(_Reason, _consumer) ->
-    ok.
-
-dispatch_event(Event, Fun) when is_function(Fun) ->
-    Fun(Event),
-    {ok, Fun};
-dispatch_event(Event, {Fun, Acc}) when is_function(Fun) ->
-    Acc2 = Fun(Event, Acc),
-    {ok, {Fun, Acc2}};
-dispatch_event(Event, Pid) when is_pid(Pid) ->
-    Pid ! Event,
-    {ok, Pid}.

http://git-wip-us.apache.org/repos/asf/couchdb/blob/372b033a/apps/couch_index/src/couch_index_event_sup.erl
----------------------------------------------------------------------
diff --git a/apps/couch_index/src/couch_index_event_sup.erl b/apps/couch_index/src/couch_index_event_sup.erl
deleted file mode 100644
index 68cba43..0000000
--- a/apps/couch_index/src/couch_index_event_sup.erl
+++ /dev/null
@@ -1,51 +0,0 @@
-% Licensed 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.
-
--module(couch_index_event_sup).
-
--export([start_link/3]).
--export([stop/1]).
-
-%% internal gen_server callbacks
--export([init/1, terminate/2, handle_call/3, handle_cast/2,
-         handle_info/2,code_change/3]).
-
-start_link(EventMgr, EventHandler, Args) ->
-    gen_server:start_link(?MODULE, {EventMgr, EventHandler, Args}, []).
-
-stop(Pid) ->
-    gen_server:cast(Pid, stop).
-
-init({EventMgr, EventHandler, Args}) ->
-    case gen_event:add_sup_handler(EventMgr, EventHandler, Args) of
-    ok ->
-        {ok, {EventMgr, EventHandler}};
-    {stop, Error} ->
-        {stop, Error}
-    end.
-
-handle_call(_Whatever, _From, State) ->
-    {ok, State}.
-
-handle_cast(stop, State) ->
-    {stop, normal, State}.
-
-handle_info({gen_event_EXIT, _Handler, Reason}, State) ->
-    {stop, Reason, State}.
-
-code_change(_OldVsn, State, _Extra) ->
-    {ok, State}.
-
-terminate(_Reason, _State) ->
-    ok.
-
-

http://git-wip-us.apache.org/repos/asf/couchdb/blob/372b033a/apps/couch_index/src/couch_index_indexer.erl
----------------------------------------------------------------------
diff --git a/apps/couch_index/src/couch_index_indexer.erl b/apps/couch_index/src/couch_index_indexer.erl
deleted file mode 100644
index 727c8dd..0000000
--- a/apps/couch_index/src/couch_index_indexer.erl
+++ /dev/null
@@ -1,221 +0,0 @@
-% Licensed 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.
-
--module(couch_index_indexer).
-
--export([start_link/2]).
-
--export([init/1, handle_call/3, handle_cast/2, handle_info/2,
-         terminate/2, code_change/3]).
-
--record(state, {index,
-                dbname,
-                threshold,
-                refresh_interval,
-                db_updates=0,
-                tref=nil,
-                notifier=nil,
-                locks}).
-
-
-start_link(Index, DbName) ->
-    gen_server:start_link(?MODULE, {Index, DbName}, []).
-
-init({Index, DbName}) ->
-    process_flag(trap_exit, true),
-    %% register to config events
-    Self = self(),
-    ok  = couch_config:register(fun
-                ("couch_index", "threshold") ->
-                    gen_server:cast(Self, config_threshold);
-                ("couch_index", "refresh_interval") ->
-                    gen_server:cast(Self, config_refresh)
-            end),
-
-    %% get defaults
-    Threshold = get_db_threshold(),
-    Refresh = get_refresh_interval(),
-
-    %% delay background index indexing
-    self() ! start_indexing,
-    {ok, #state{index=Index,
-                dbname=DbName,
-                threshold=Threshold,
-                refresh_interval=Refresh,
-                locks=dict:new()}}.
-
-handle_call({acquire, Pid}, _From, #state{locks=Locks}=State) ->
-    NLocks = case dict:find(Pid, Locks) of
-        error ->
-            dict:store(Pid, {erlang:monitor(process, Pid), 1}, Locks);
-        {ok, {MRef, Refc}} ->
-             dict:store(Pid, {MRef, Refc+1}, Locks)
-    end,
-    {reply, ok, State#state{locks=NLocks}};
-
-handle_call({release, Pid}, _From, #state{locks=Locks}=State) ->
-     NLocks = case dict:find(Pid, Locks) of
-        {ok, {MRef, 1}} ->
-            erlang:demonitor(MRef, [flush]),
-            dict:erase(Pid, Locks);
-        {ok, {MRef, Refc}} ->
-            dict:store(Pid, {MRef, Refc-1}, Locks);
-        error ->
-            Locks
-    end,
-
-    NState = State#state{locks=NLocks},
-
-    case should_close() of
-        true -> {stop, normal, ok, NState};
-        false -> {reply, ok, NState}
-    end;
-
-handle_call(stop, _From, State) ->
-    {stop, normal, ok, State}.
-
-
-handle_cast(config_threshold, State) ->
-    Threshold = get_db_threshold(),
-    {noreply, State#state{threshold=Threshold}};
-handle_cast(config_refresh, #state{tref=TRef}=State) ->
-    R = get_refresh_interval(),
-    %% stop the old timee
-    if TRef /= nil ->
-            erlang:cancel_timer(TRef);
-        true -> ok
-    end,
-    %% start the new timer
-    NTRef = erlang:start_timer(R, self(), refresh_index),
-    {noreply, State#state{refresh_interval=R, tref=NTRef}};
-
-handle_cast(updated, #state{index=Index, dbname=DbName,
-                            threshold=Threshold,
-                            db_updates=Updates}=State) ->
-    NUpdates = Updates + 1,
-
-    %% we only update if the number of updates is greater than the
-    %% threshold.
-    case NUpdates =:= Threshold of
-        true ->
-            refresh_index(DbName, Index),
-            {noreply, State#state{db_updates=0}};
-        false ->
-             {noreply, State#state{db_updates=NUpdates}}
-
-    end;
-
-handle_cast(_Msg, State) ->
-    {noreply, State}.
-
-handle_info(start_indexing, #state{dbname=DbName,
-                                   refresh_interval=R}=State) ->
-    %% start the db notifier to watch db update events
-    {ok, NotifierPid} = start_db_notifier(DbName),
-
-    %% start the timer
-    TRef = erlang:start_timer(R, self(), refresh_index),
-
-    {noreply, State#state{tref=TRef, notifier=NotifierPid}};
-
-handle_info({timeout, TRef, refresh_index}, #state{index=Index,
-                                                   dbname=DbName,
-                                                   tref=TRef,
-                                                   db_updates=N}=State) ->
-    %% only refresh the index if an update happened
-    case N > 0 of
-        true ->
-            refresh_index(DbName, Index);
-        false ->
-            ok
-    end,
-    {noreply, #state{db_updates=0}=State};
-
-handle_info({'DOWN', MRef, _, Pid, _}, #state{locks=Locks}=State) ->
-    NLocks = case dict:find(Pid, Locks) of
-        {ok, {MRef, _}} ->
-            dict:erase(Pid, Locks);
-        error ->
-            Locks
-    end,
-
-    NState = State#state{locks=NLocks},
-
-    case should_close() of
-        true -> {stop, normal, NState};
-        false -> {noreply, NState}
-    end;
-
-handle_info({'EXIT', Pid, _Reason}, #state{notifier=Pid}=State) ->
-    %% db notifier exited
-    {stop, normal, State#state{notifier=nil}}.
-
-code_change(_OldVsn, State, _Extra) ->
-    {ok, State}.
-
-terminate(_Reason, #state{tref=TRef, notifier=Pid}) ->
-    if TRef /= nil ->
-            erlang:cancel_timer(TRef);
-        true -> ok
-    end,
-
-    case is_pid(Pid) of
-        true -> couch_util:shutdown_sync(Pid);
-        _ -> ok
-    end,
-    ok.
-
-%% refresh the index to trigger updates.
-refresh_index(Db, Index) ->
-    UpdateSeq = couch_util:with_db(Db, fun(WDb) ->
-                    couch_db:get_update_seq(WDb)
-            end),
-
-    case catch couch_index:get_state(Index, UpdateSeq) of
-        {ok, _} -> ok;
-        Error -> {error, Error}
-    end.
-
-%% if none has acquired us, we could stop the server.
-should_close() ->
-    case process_info(self(), monitors) of
-        {monitors, []} ->   true;
-        _ ->                false
-    end.
-
-
-%% number of max updates before refreshing the index. We don't
-%% update the index on each db update. Instead we are waiting for a
-%% minimum. If the minimum is not acchieved, the update will happen
-%% in the next interval.
-get_db_threshold() ->
-    list_to_integer(
-            couch_config:get("couch_index", "threshold", "200")
-    ).
-
-%% refresh interval in ms, the interval in which the index will be
-%% updated
-get_refresh_interval() ->
-    list_to_integer(
-            couch_config:get("couch_index", "refresh_interval", "1000")
-    ).
-
-%% db notifier
-start_db_notifier(DbName) ->
-    Self = self(),
-
-    couch_db_update_notifier:start_link(fun
-            ({updated, Name}) when Name =:= DbName ->
-                gen_server:cast(Self, updated);
-            (_) ->
-                ok
-        end).

http://git-wip-us.apache.org/repos/asf/couchdb/blob/372b033a/apps/couch_index/src/couch_index_server.erl
----------------------------------------------------------------------
diff --git a/apps/couch_index/src/couch_index_server.erl b/apps/couch_index/src/couch_index_server.erl
deleted file mode 100644
index 2c6ebc9..0000000
--- a/apps/couch_index/src/couch_index_server.erl
+++ /dev/null
@@ -1,221 +0,0 @@
-% Licensed 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.
-
--module(couch_index_server).
--behaviour(gen_server).
-
--export([start_link/0, get_index/4, get_index/3, get_index/2]).
--export([acquire_indexer/3, release_indexer/3]).
--export([config_change/2, update_notify/1]).
-
--export([init/1, terminate/2, code_change/3]).
--export([handle_call/3, handle_cast/2, handle_info/2]).
-
--include_lib("couch/include/couch_db.hrl").
-
--define(BY_SIG, couchdb_indexes_by_sig).
--define(BY_PID, couchdb_indexes_by_pid).
--define(BY_DB, couchdb_indexes_by_db).
-
-
--record(st, {root_dir,
-             notifier_pid}).
-
-start_link() ->
-    gen_server:start_link({local, ?MODULE}, ?MODULE, [], []).
-
-
-get_index(Module, DbName, DDoc) ->
-    get_index(Module, DbName, DDoc, nil).
-
-
-get_index(Module, DbName, DDoc, Fun) when is_binary(DbName) ->
-    couch_util:with_db(DbName, fun(Db) ->
-        get_index(Module, Db, DDoc, Fun)
-    end);
-get_index(Module, Db, DDoc, Fun) when is_binary(DDoc) ->
-    case couch_db:open_doc(Db, DDoc, [ejson_body]) of
-        {ok, Doc} -> get_index(Module, Db, Doc, Fun);
-        Error -> Error
-    end;
-get_index(Module, Db, DDoc, Fun) when is_function(Fun, 1) ->
-    {ok, InitState} = Module:init(Db, DDoc),
-    {ok, FunResp} = Fun(InitState),
-    {ok, Pid} = get_index(Module, InitState),
-    {ok, Pid, FunResp};
-get_index(Module, Db, DDoc, _Fun) ->
-    {ok, InitState} = Module:init(Db, DDoc),
-    get_index(Module, InitState).
-
-
-get_index(Module, IdxState) ->
-    DbName = Module:get(db_name, IdxState),
-    Sig = Module:get(signature, IdxState),
-    case ets:lookup(?BY_SIG, {DbName, Sig}) of
-        [{_, Pid}] when is_pid(Pid) ->
-            {ok, Pid};
-        _ ->
-            Args = {Module, IdxState, DbName, Sig},
-            gen_server:call(?MODULE, {get_index, Args}, infinity)
-    end.
-
-acquire_indexer(Module, DbName, DDoc) ->
-    case get_index(Module, DbName, DDoc) of
-        {ok, Pid} ->
-            couch_index:acquire_indexer(Pid);
-        Error ->
-            Error
-    end.
-
-release_indexer(Module, DbName, DDoc) ->
-    case get_index(Module, DbName, DDoc) of
-        {ok, Pid} ->
-            couch_index:release_indexer(Pid);
-        Error ->
-            Error
-    end.
-
-
-
-init([]) ->
-    process_flag(trap_exit, true),
-    couch_config:register(fun ?MODULE:config_change/2),
-    ets:new(?BY_SIG, [protected, set, named_table]),
-    ets:new(?BY_PID, [private, set, named_table]),
-    ets:new(?BY_DB, [protected, bag, named_table]),
-
-    {ok, NotifierPid} = couch_db_update_notifier:start_link(
-            fun ?MODULE:update_notify/1),
-    RootDir = couch_index_util:root_dir(),
-    couch_file:init_delete_dir(RootDir),
-    {ok, #st{root_dir=RootDir,
-             notifier_pid=NotifierPid}}.
-
-
-terminate(_Reason, _State) ->
-    Pids = [Pid || {Pid, _} <- ets:tab2list(?BY_PID)],
-    lists:map(fun couch_util:shutdown_sync/1, Pids),
-    ok.
-
-
-handle_call({get_index, {_Mod, _IdxState, DbName, Sig}=Args}, From, State) ->
-    case ets:lookup(?BY_SIG, {DbName, Sig}) of
-        [] ->
-            spawn_link(fun() -> new_index(Args) end),
-            ets:insert(?BY_SIG, {{DbName, Sig}, [From]}),
-            {noreply, State};
-        [{_, Waiters}] when is_list(Waiters) ->
-            ets:insert(?BY_SIG, {{DbName, Sig}, [From | Waiters]}),
-            {noreply, State};
-        [{_, Pid}] when is_pid(Pid) ->
-            {reply, {ok, Pid}, State}
-    end;
-handle_call({async_open, {DbName, DDocId, Sig}, {ok, Pid}}, _From, State) ->
-    [{_, Waiters}] = ets:lookup(?BY_SIG, {DbName, Sig}),
-    [gen_server:reply(From, {ok, Pid}) || From <- Waiters],
-    link(Pid),
-    add_to_ets(DbName, Sig, DDocId, Pid),
-    {reply, ok, State};
-handle_call({async_error, {DbName, _DDocId, Sig}, Error}, _From, State) ->
-    [{_, Waiters}] = ets:lookup(?BY_SIG, {DbName, Sig}),
-    [gen_server:reply(From, Error) || From <- Waiters],
-    ets:delete(?BY_SIG, {DbName, Sig}),
-    {reply, ok, State};
-handle_call({reset_indexes, DbName}, _From, State) ->
-    reset_indexes(DbName, State#st.root_dir),
-    {reply, ok, State}.
-
-
-handle_cast({reset_indexes, DbName}, State) ->
-    reset_indexes(DbName, State#st.root_dir),
-    {noreply, State}.
-
-handle_info({'EXIT', Pid, Reason}, Server) ->
-    case ets:lookup(?BY_PID, Pid) of
-        [{Pid, {DbName, Sig}}] ->
-            [{DbName, {DDocId, Sig}}] =
-                ets:match_object(?BY_DB, {DbName, {'$1', Sig}}),
-            rem_from_ets(DbName, Sig, DDocId, Pid);
-        [] when Reason /= normal ->
-            exit(Reason);
-        _Else ->
-            ok
-    end,
-    {noreply, Server}.
-
-
-code_change(_OldVsn, State, _Extra) ->
-    {ok, State}.
-
-
-new_index({Mod, IdxState, DbName, Sig}) ->
-    DDocId = Mod:get(idx_name, IdxState),
-    case couch_index:start_link({Mod, IdxState}) of
-        {ok, Pid} ->
-            ok = gen_server:call(
-                ?MODULE, {async_open, {DbName, DDocId, Sig}, {ok, Pid}}),
-            unlink(Pid);
-        Error ->
-            ok = gen_server:call(
-                ?MODULE, {async_error, {DbName, DDocId, Sig}, Error})
-    end.
-
-
-reset_indexes(DbName, Root) ->
-    % shutdown all the updaters and clear the files, the db got changed
-    Fun = fun({_, {DDocId, Sig}}) ->
-        [{_, Pid}] = ets:lookup(?BY_SIG, {DbName, Sig}),
-        MRef = erlang:monitor(process, Pid),
-        gen_server:cast(Pid, delete),
-        receive {'DOWN', MRef, _, _, _} -> ok end,
-        rem_from_ets(DbName, Sig, DDocId, Pid)
-    end,
-    lists:foreach(Fun, ets:lookup(?BY_DB, DbName)),
-    Path = couch_index_util:index_dir("", DbName),
-    couch_file:nuke_dir(Root, Path).
-
-
-add_to_ets(DbName, Sig, DDocId, Pid) ->
-    ets:insert(?BY_SIG, {{DbName, Sig}, Pid}),
-    ets:insert(?BY_PID, {Pid, {DbName, Sig}}),
-    ets:insert(?BY_DB, {DbName, {DDocId, Sig}}).
-
-
-rem_from_ets(DbName, Sig, DDocId, Pid) ->
-    ets:delete(?BY_SIG, {DbName, Sig}),
-    ets:delete(?BY_PID, Pid),
-    ets:delete_object(?BY_DB, {DbName, {DDocId, Sig}}).
-
-
-config_change("couchdb", "view_index_dir") ->
-    exit(whereis(?MODULE), config_change);
-config_change("couchdb", "index_dir") ->
-    exit(whereis(?MODULE), config_change).
-
-
-update_notify({deleted, DbName}) ->
-    gen_server:cast(?MODULE, {reset_indexes, DbName});
-update_notify({created, DbName}) ->
-    gen_server:cast(?MODULE, {reset_indexes, DbName});
-update_notify({ddoc_updated, {DbName, DDocId}}) ->
-    lists:foreach(
-        fun({_DbName, {_DDocId, Sig}}) ->
-            case ets:lookup(?BY_SIG, {DbName, Sig}) of
-                [{_, IndexPid}] ->
-                    (catch gen_server:cast(IndexPid, ddoc_updated));
-                [] ->
-                    ok
-            end
-        end,
-        ets:match_object(?BY_DB, {DbName, {DDocId, '$1'}}));
-update_notify(_) ->
-    ok.

http://git-wip-us.apache.org/repos/asf/couchdb/blob/372b033a/apps/couch_index/src/couch_index_sup.erl
----------------------------------------------------------------------
diff --git a/apps/couch_index/src/couch_index_sup.erl b/apps/couch_index/src/couch_index_sup.erl
deleted file mode 100644
index 8e69016..0000000
--- a/apps/couch_index/src/couch_index_sup.erl
+++ /dev/null
@@ -1,34 +0,0 @@
-% Licensed 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.
-
--module(couch_index_sup).
--behaviour(supervisor).
-
--export([start_link/0]).
--export([init/1]).
-
-
-%% Helper macro for declaring children of supervisor
--define(CHILD(I), {I, {I, start_link, []}, permanent, 5000, worker, [I]}).
-
-start_link() ->
-    supervisor:start_link({local, ?MODULE}, ?MODULE, []).
-
-
-init([]) ->
-    Server = ?CHILD(couch_index_server),
-
-    EventSup = {couch_index_events,
-                {gen_event, start_link, [{local, couch_index_events}]},
-                permanent, brutal_kill, worker, dynamic},
-
-    {ok, {{one_for_one, 10, 3600}, [Server, EventSup]}}.

http://git-wip-us.apache.org/repos/asf/couchdb/blob/372b033a/apps/couch_index/src/couch_index_updater.erl
----------------------------------------------------------------------
diff --git a/apps/couch_index/src/couch_index_updater.erl b/apps/couch_index/src/couch_index_updater.erl
deleted file mode 100644
index 9f54a56..0000000
--- a/apps/couch_index/src/couch_index_updater.erl
+++ /dev/null
@@ -1,200 +0,0 @@
-% Licensed 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.
-
--module(couch_index_updater).
--behaviour(gen_server).
-
-
-%% API
--export([start_link/2, run/2, is_running/1, update/2, restart/2]).
-
-%% gen_server callbacks
--export([init/1, terminate/2, code_change/3]).
--export([handle_call/3, handle_cast/2, handle_info/2]).
-
--include_lib("couch/include/couch_db.hrl").
-
--record(st, {
-    idx,
-    mod,
-    pid=nil
-}).
-
-
-start_link(Index, Module) ->
-    gen_server:start_link(?MODULE, {Index, Module}, []).
-
-
-run(Pid, IdxState) ->
-    gen_server:call(Pid, {update, IdxState}).
-
-
-is_running(Pid) ->
-    gen_server:call(Pid, is_running).
-
-
-update(Mod, State) ->
-    update(nil, Mod, State).
-
-
-restart(Pid, IdxState) ->
-    gen_server:call(Pid, {restart, IdxState}).
-
-
-init({Index, Module}) ->
-    process_flag(trap_exit, true),
-    {ok, #st{idx=Index, mod=Module}}.
-
-
-terminate(_Reason, State) ->
-    couch_util:shutdown_sync(State#st.pid),
-    ok.
-
-
-handle_call({update, _IdxState}, _From, #st{pid=Pid}=State) when is_pid(Pid) ->
-    {reply, ok, State};
-handle_call({update, IdxState}, _From, #st{idx=Idx, mod=Mod}=State) ->
-    Args = [Mod:get(db_name, IdxState), Mod:get(idx_name, IdxState)],
-    ?LOG_INFO("Starting index update for db: ~s idx: ~s", Args),
-    Pid = spawn_link(fun() -> update(Idx, Mod, IdxState) end),
-    {reply, ok, State#st{pid=Pid}};
-handle_call({restart, IdxState}, _From, #st{idx=Idx, mod=Mod}=State) ->
-    Args = [Mod:get(db_name, IdxState), Mod:get(idx_name, IdxState)],
-    ?LOG_INFO("Restarting index update for db: ~s idx: ~s", Args),
-    case is_pid(State#st.pid) of
-        true -> couch_util:shutdown_sync(State#st.pid);
-        _ -> ok
-    end,
-    Pid = spawn_link(fun() -> update(Idx, State#st.mod, IdxState) end),
-    {reply, ok, State#st{pid=Pid}};
-handle_call(is_running, _From, #st{pid=Pid}=State) when is_pid(Pid) ->
-    {reply, true, State};
-handle_call(is_running, _From, State) ->
-    {reply, false, State}.
-
-
-handle_cast(_Mesg, State) ->
-    {stop, unknown_cast, State}.
-
-
-handle_info({'EXIT', _, {updated, Pid, IdxState}}, #st{pid=Pid}=State) ->
-    Mod = State#st.mod,
-    Args = [Mod:get(db_name, IdxState), Mod:get(idx_name, IdxState)],
-    ?LOG_INFO("Index update finished for db: ~s idx: ~s", Args),
-    ok = gen_server:cast(State#st.idx, {updated, IdxState}),
-    {noreply, State#st{pid=undefined}};
-handle_info({'EXIT', _, {reset, Pid}}, #st{idx=Idx, pid=Pid}=State) ->
-    {ok, NewIdxState} = gen_server:call(State#st.idx, reset),
-    Pid2 = spawn_link(fun() -> update(Idx, State#st.mod, NewIdxState) end),
-    {noreply, State#st{pid=Pid2}};
-handle_info({'EXIT', Pid, normal}, #st{pid=Pid}=State) ->
-    {noreply, State#st{pid=undefined}};
-handle_info({'EXIT', Pid, {{nocatch, Error}, _Trace}}, State) ->
-    handle_info({'EXIT', Pid, Error}, State);
-handle_info({'EXIT', Pid, Error}, #st{pid=Pid}=State) ->
-    ok = gen_server:cast(State#st.idx, {update_error, Error}),
-    {noreply, State#st{pid=undefined}};
-handle_info({'EXIT', Pid, _Reason}, #st{idx=Pid}=State) ->
-    {stop, normal, State};
-handle_info({'EXIT', _Pid, normal}, State) ->
-    {noreply, State};
-handle_info(_Mesg, State) ->
-    {stop, unknown_info, State}.
-
-
-code_change(_OldVsn, State, _Extra) ->
-    {ok, State}.
-
-
-update(Idx, Mod, IdxState) ->
-    DbName = Mod:get(db_name, IdxState),
-    CurrSeq = Mod:get(update_seq, IdxState),
-    UpdateOpts = Mod:get(update_options, IdxState),
-    CommittedOnly = lists:member(committed_only, UpdateOpts),
-    IncludeDesign = lists:member(include_design, UpdateOpts),
-    DocOpts = case lists:member(local_seq, UpdateOpts) of
-        true -> [conflicts, deleted_conflicts, local_seq];
-        _ -> [conflicts, deleted_conflicts]
-    end,
-
-    couch_util:with_db(DbName, fun(Db) ->
-        DbUpdateSeq = couch_db:get_update_seq(Db),
-        DbCommittedSeq = couch_db:get_committed_update_seq(Db),
-
-        PurgedIdxState = case purge_index(Db, Mod, IdxState) of
-            {ok, IdxState0} -> IdxState0;
-            reset -> exit({reset, self()})
-        end,
-
-        NumChanges = couch_db:count_changes_since(Db, CurrSeq),
-
-        LoadDoc = fun(DocInfo) ->
-            #doc_info{
-                id=DocId,
-                high_seq=Seq,
-                revs=[#rev_info{deleted=Deleted} | _]
-            } = DocInfo,
-
-            case {IncludeDesign, DocId} of
-                {false, <<"_design/", _/binary>>} ->
-                    {nil, Seq};
-                _ when Deleted ->
-                    {#doc{id=DocId, deleted=true}, Seq};
-                _ ->
-                    {ok, Doc} = couch_db:open_doc_int(Db, DocInfo, DocOpts),
-                    {Doc, Seq}
-            end
-        end,
-
-        Proc = fun(DocInfo, _, {IdxStateAcc, _}) ->
-            HighSeq = DocInfo#doc_info.high_seq,
-            case CommittedOnly and (HighSeq > DbCommittedSeq) of
-                true ->
-                    {stop, {IdxStateAcc, false}};
-                false ->
-                    {Doc, Seq} = LoadDoc(DocInfo),
-                    {ok, NewSt} = Mod:process_doc(Doc, Seq, IdxStateAcc),
-                    {ok, {NewSt, true}}
-            end
-        end,
-
-        {ok, InitIdxState} = Mod:start_update(Idx, PurgedIdxState, NumChanges),
-        Acc0 = {InitIdxState, true},
-        {ok, _, Acc} = couch_db:enum_docs_since(Db, CurrSeq, Proc, Acc0, []),
-        {ProcIdxSt, SendLast} = Acc,
-
-        % If we didn't bail due to hitting the last committed seq we need
-        % to send our last update_seq through.
-        {ok, LastIdxSt} = case SendLast of
-            true ->
-                Mod:process_doc(nil, DbUpdateSeq, ProcIdxSt);
-            _ ->
-                {ok, ProcIdxSt}
-        end,
-
-        {ok, FinalIdxState} = Mod:finish_update(LastIdxSt),
-        exit({updated, self(), FinalIdxState})
-    end).
-
-
-purge_index(Db, Mod, IdxState) ->
-    DbPurgeSeq = couch_db:get_purge_seq(Db),
-    IdxPurgeSeq = Mod:get(purge_seq, IdxState),
-    if
-        DbPurgeSeq == IdxPurgeSeq ->
-            {ok, IdxState};
-        DbPurgeSeq == IdxPurgeSeq + 1 ->
-            {ok, PurgedIdRevs} = couch_db:get_last_purged(Db),
-            Mod:purge(Db, DbPurgeSeq, PurgedIdRevs, IdxState);
-        true ->
-            reset
-    end.

http://git-wip-us.apache.org/repos/asf/couchdb/blob/372b033a/apps/couch_index/src/couch_index_util.erl
----------------------------------------------------------------------
diff --git a/apps/couch_index/src/couch_index_util.erl b/apps/couch_index/src/couch_index_util.erl
deleted file mode 100644
index c833920..0000000
--- a/apps/couch_index/src/couch_index_util.erl
+++ /dev/null
@@ -1,77 +0,0 @@
-% Licensed 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.
-
--module(couch_index_util).
-
--export([root_dir/0, index_dir/2, index_file/3]).
--export([load_doc/3, sort_lib/1, hexsig/1]).
-
--include_lib("couch/include/couch_db.hrl").
-
-root_dir() ->
-  couch_config:get("couchdb", "view_index_dir").
-
-
-index_dir(Module, DbName) when is_binary(DbName) ->
-    DbDir = "." ++ binary_to_list(DbName) ++ "_design",
-    filename:join([root_dir(), DbDir, Module]);
-index_dir(Module, #db{}=Db) ->
-    index_dir(Module, couch_db:name(Db)).
-
-
-index_file(Module, DbName, FileName) ->
-    filename:join(index_dir(Module, DbName), FileName).
-
-
-load_doc(Db, #doc_info{}=DI, Opts) ->
-    Deleted = lists:member(deleted, Opts),
-    case (catch couch_db:open_doc(Db, DI, Opts)) of
-        {ok, #doc{deleted=false}=Doc} -> Doc;
-        {ok, #doc{deleted=true}=Doc} when Deleted -> Doc;
-        _Else -> null
-    end;
-load_doc(Db, {DocId, Rev}, Opts) ->
-    case (catch load_doc(Db, DocId, Rev, Opts)) of
-        #doc{deleted=false} = Doc -> Doc;
-        _ -> null
-    end.
-
-
-load_doc(Db, DocId, Rev, Options) ->
-    case Rev of
-        nil -> % open most recent rev
-            case (catch couch_db:open_doc(Db, DocId, Options)) of
-                {ok, Doc} -> Doc;
-                _Error -> null
-            end;
-        _ -> % open a specific rev (deletions come back as stubs)
-            case (catch couch_db:open_doc_revs(Db, DocId, [Rev], Options)) of
-                {ok, [{ok, Doc}]} -> Doc;
-                {ok, [{{not_found, missing}, Rev}]} -> null;
-                {ok, [_Else]} -> null
-            end
-    end.
-
-
-sort_lib({Lib}) ->
-    sort_lib(Lib, []).
-sort_lib([], LAcc) ->
-    lists:keysort(1, LAcc);
-sort_lib([{LName, {LObj}}|Rest], LAcc) ->
-    LSorted = sort_lib(LObj, []), % descend into nested object
-    sort_lib(Rest, [{LName, LSorted}|LAcc]);
-sort_lib([{LName, LCode}|Rest], LAcc) ->
-    sort_lib(Rest, [{LName, LCode}|LAcc]).
-
-
-hexsig(Sig) ->
-    couch_util:to_hex(binary_to_list(Sig)).


[42/57] [abbrv] couchdb commit: updated refs/heads/1994-merge-rcouch-multi-repo to b19d055

Posted by be...@apache.org.
remove couch_collate


Project: http://git-wip-us.apache.org/repos/asf/couchdb/repo
Commit: http://git-wip-us.apache.org/repos/asf/couchdb/commit/81332b78
Tree: http://git-wip-us.apache.org/repos/asf/couchdb/tree/81332b78
Diff: http://git-wip-us.apache.org/repos/asf/couchdb/diff/81332b78

Branch: refs/heads/1994-merge-rcouch-multi-repo
Commit: 81332b78ab2152af555c7d7d78ec8e878c07fc3a
Parents: d95b902
Author: Benoit Chesneau <bc...@gmail.com>
Authored: Thu Feb 13 16:33:36 2014 +0100
Committer: Benoit Chesneau <bc...@gmail.com>
Committed: Thu Feb 13 16:33:36 2014 +0100

----------------------------------------------------------------------
 apps/couch_collate/build_icu.sh                 |  191 -
 apps/couch_collate/c_src/couch_collate.c        |  281 --
 .../patches/icu/common-uloc_c.patch             |   26 -
 .../icu/layout_LookupProcessor_cpp.patch        |   13 -
 .../icu/source_config_Makefile_inc_in.patch     |   12 -
 .../patches/icu/source_icudefs_mk_in.patch      |   19 -
 .../platform/osx/icu/unicode/basictz.h          |  210 -
 .../platform/osx/icu/unicode/brkiter.h          |  557 ---
 .../platform/osx/icu/unicode/calendar.h         | 2170 ---------
 .../platform/osx/icu/unicode/caniter.h          |  201 -
 .../platform/osx/icu/unicode/chariter.h         |  716 ---
 .../platform/osx/icu/unicode/choicfmt.h         |  746 ---
 .../platform/osx/icu/unicode/coleitr.h          |  400 --
 .../platform/osx/icu/unicode/coll.h             | 1035 -----
 .../platform/osx/icu/unicode/curramt.h          |  130 -
 .../platform/osx/icu/unicode/currunit.h         |  117 -
 .../platform/osx/icu/unicode/datefmt.h          |  700 ---
 .../platform/osx/icu/unicode/dbbi.h             |   41 -
 .../platform/osx/icu/unicode/dcfmtsym.h         |  370 --
 .../platform/osx/icu/unicode/decimfmt.h         | 1901 --------
 .../platform/osx/icu/unicode/docmain.h          |  202 -
 .../platform/osx/icu/unicode/dtfmtsym.h         |  721 ---
 .../platform/osx/icu/unicode/dtintrv.h          |  159 -
 .../platform/osx/icu/unicode/dtitvfmt.h         |  949 ----
 .../platform/osx/icu/unicode/dtitvinf.h         |  528 ---
 .../platform/osx/icu/unicode/dtptngen.h         |  423 --
 .../platform/osx/icu/unicode/dtrule.h           |  250 --
 .../platform/osx/icu/unicode/fieldpos.h         |  291 --
 .../platform/osx/icu/unicode/fmtable.h          |  591 ---
 .../platform/osx/icu/unicode/format.h           |  296 --
 .../platform/osx/icu/unicode/gregocal.h         |  823 ----
 .../platform/osx/icu/unicode/locid.h            |  765 ----
 .../platform/osx/icu/unicode/measfmt.h          |   77 -
 .../platform/osx/icu/unicode/measunit.h         |   71 -
 .../platform/osx/icu/unicode/measure.h          |  137 -
 .../platform/osx/icu/unicode/msgfmt.h           |  940 ----
 .../platform/osx/icu/unicode/normlzr.h          |  823 ----
 .../platform/osx/icu/unicode/numfmt.h           |  886 ----
 .../platform/osx/icu/unicode/parseerr.h         |   92 -
 .../platform/osx/icu/unicode/parsepos.h         |  230 -
 .../platform/osx/icu/unicode/platform.h         |  316 --
 .../platform/osx/icu/unicode/plurfmt.h          |  541 ---
 .../platform/osx/icu/unicode/plurrule.h         |  291 --
 .../platform/osx/icu/unicode/ppalmos.h          |  273 --
 .../platform/osx/icu/unicode/putil.h            |  184 -
 .../platform/osx/icu/unicode/pwin32.h           |  311 --
 .../platform/osx/icu/unicode/rbbi.h             |  722 ---
 .../platform/osx/icu/unicode/rbnf.h             | 1049 -----
 .../platform/osx/icu/unicode/rbtz.h             |  361 --
 .../platform/osx/icu/unicode/regex.h            | 1232 -----
 .../platform/osx/icu/unicode/rep.h              |  259 --
 .../platform/osx/icu/unicode/resbund.h          |  485 --
 .../platform/osx/icu/unicode/schriter.h         |  187 -
 .../platform/osx/icu/unicode/search.h           |  569 ---
 .../platform/osx/icu/unicode/simpletz.h         |  927 ----
 .../platform/osx/icu/unicode/smpdtfmt.h         |  975 ----
 .../platform/osx/icu/unicode/sortkey.h          |  324 --
 .../platform/osx/icu/unicode/strenum.h          |  271 --
 .../platform/osx/icu/unicode/stsearch.h         |  518 ---
 .../platform/osx/icu/unicode/symtable.h         |  112 -
 .../platform/osx/icu/unicode/tblcoll.h          |  926 ----
 .../platform/osx/icu/unicode/timezone.h         |  803 ----
 .../platform/osx/icu/unicode/translit.h         | 1323 ------
 .../platform/osx/icu/unicode/tzrule.h           |  828 ----
 .../platform/osx/icu/unicode/tztrans.h          |  195 -
 .../platform/osx/icu/unicode/ubidi.h            | 2013 ---------
 .../platform/osx/icu/unicode/ubrk.h             |  482 --
 .../platform/osx/icu/unicode/ucal.h             | 1161 -----
 .../platform/osx/icu/unicode/ucasemap.h         |  391 --
 .../platform/osx/icu/unicode/ucat.h             |  158 -
 .../platform/osx/icu/unicode/uchar.h            | 3062 -------------
 .../platform/osx/icu/unicode/uchriter.h         |  381 --
 .../platform/osx/icu/unicode/uclean.h           |  267 --
 .../platform/osx/icu/unicode/ucnv.h             | 1967 --------
 .../platform/osx/icu/unicode/ucnv_cb.h          |  162 -
 .../platform/osx/icu/unicode/ucnv_err.h         |  463 --
 .../platform/osx/icu/unicode/ucol.h             | 1132 -----
 .../platform/osx/icu/unicode/ucoleitr.h         |  315 --
 .../platform/osx/icu/unicode/uconfig.h          |  228 -
 .../platform/osx/icu/unicode/ucsdet.h           |  349 --
 .../platform/osx/icu/unicode/ucurr.h            |  270 --
 .../platform/osx/icu/unicode/udat.h             |  962 ----
 .../platform/osx/icu/unicode/udata.h            |  389 --
 .../platform/osx/icu/unicode/udatpg.h           |  471 --
 .../platform/osx/icu/unicode/udeprctd.h         |   50 -
 .../platform/osx/icu/unicode/udraft.h           |  166 -
 .../platform/osx/icu/unicode/uenum.h            |  134 -
 .../platform/osx/icu/unicode/uidna.h            |  312 --
 .../platform/osx/icu/unicode/uintrnal.h         |  180 -
 .../platform/osx/icu/unicode/uiter.h            |  707 ---
 .../platform/osx/icu/unicode/uloc.h             | 1046 -----
 .../platform/osx/icu/unicode/ulocdata.h         |  192 -
 .../platform/osx/icu/unicode/umachine.h         |  338 --
 .../platform/osx/icu/unicode/umisc.h            |   60 -
 .../platform/osx/icu/unicode/umsg.h             |  647 ---
 .../platform/osx/icu/unicode/unifilt.h          |  127 -
 .../platform/osx/icu/unicode/unifunct.h         |  125 -
 .../platform/osx/icu/unicode/unimatch.h         |  163 -
 .../platform/osx/icu/unicode/unirepl.h          |   97 -
 .../platform/osx/icu/unicode/uniset.h           | 1566 -------
 .../platform/osx/icu/unicode/unistr.h           | 4230 ------------------
 .../platform/osx/icu/unicode/unorm.h            |  576 ---
 .../platform/osx/icu/unicode/unum.h             |  869 ----
 .../platform/osx/icu/unicode/uobject.h          |  308 --
 .../platform/osx/icu/unicode/uobslete.h         |   32 -
 .../platform/osx/icu/unicode/urbtok.h           |  126 -
 .../platform/osx/icu/unicode/uregex.h           |  989 ----
 .../platform/osx/icu/unicode/urename.h          | 1775 --------
 .../platform/osx/icu/unicode/urep.h             |  155 -
 .../platform/osx/icu/unicode/ures.h             |  871 ----
 .../platform/osx/icu/unicode/uscript.h          |  254 --
 .../platform/osx/icu/unicode/usearch.h          |  766 ----
 .../platform/osx/icu/unicode/uset.h             | 1052 -----
 .../platform/osx/icu/unicode/usetiter.h         |  318 --
 .../platform/osx/icu/unicode/ushape.h           |  263 --
 .../platform/osx/icu/unicode/usprep.h           |  156 -
 .../platform/osx/icu/unicode/ustring.h          | 1479 ------
 .../platform/osx/icu/unicode/usystem.h          |   46 -
 .../platform/osx/icu/unicode/utext.h            | 1562 -------
 .../platform/osx/icu/unicode/utf.h              |  227 -
 .../platform/osx/icu/unicode/utf16.h            |  605 ---
 .../platform/osx/icu/unicode/utf32.h            |   23 -
 .../platform/osx/icu/unicode/utf8.h             |  652 ---
 .../platform/osx/icu/unicode/utf_old.h          | 1171 -----
 .../platform/osx/icu/unicode/utmscale.h         |  481 --
 .../platform/osx/icu/unicode/utrace.h           |  358 --
 .../platform/osx/icu/unicode/utrans.h           |  583 ---
 .../platform/osx/icu/unicode/utypes.h           |  801 ----
 .../platform/osx/icu/unicode/uversion.h         |  275 --
 .../platform/osx/icu/unicode/vtzone.h           |  443 --
 apps/couch_collate/rebar.config                 |    9 -
 apps/couch_collate/rebar.config.script          |   90 -
 apps/couch_collate/src/couch_collate.app.src    |   13 -
 apps/couch_collate/src/couch_collate.erl        |   62 -
 134 files changed, 75225 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/build_icu.sh
----------------------------------------------------------------------
diff --git a/apps/couch_collate/build_icu.sh b/apps/couch_collate/build_icu.sh
deleted file mode 100755
index 167e73d..0000000
--- a/apps/couch_collate/build_icu.sh
+++ /dev/null
@@ -1,191 +0,0 @@
-#!/bin/sh
-
-CORE_TOP=`pwd`
-export CORE_TOP
-
-CURLBIN=`which curl`
-if ! test -n "CURLBIN"; then
-    display_error "Error: curl is required. Add it to 'PATH'"
-    exit 1
-fi
-
-GUNZIP=`which gunzip`
-UNZIP=`which unzip`
-TAR=`which tar`
-GNUMAKE=`which gmake 2>/dev/null || which make`
-PATCHES=$CORE_TOP/patches
-STATICLIBS=$CORE_TOP/.libs
-DISTDIR=$CORE_TOP/.dists
-
-# icu sources
-ICU_VER=4.4.2
-ICU_DISTNAME=icu4c-4_4_2-src.tgz
-ICU_SITE=http://dl.refuge.io
-ICUDIR=$STATICLIBS/icu
-
-
-[ "$MACHINE" ] || MACHINE=`(uname -m) 2>/dev/null` || MACHINE="unknown"
-[ "$RELEASE" ] || RELEASE=`(uname -r) 2>/dev/null` || RELEASE="unknown"
-[ "$SYSTEM" ] || SYSTEM=`(uname -s) 2>/dev/null`  || SYSTEM="unknown"
-[ "$BUILD" ] || VERSION=`(uname -v) 2>/dev/null` || VERSION="unknown"
-
-
-CFLAGS="-g -O2 -Wall"
-LDFLAGS="-lstdc++"
-ARCH=
-ISA64=
-GNUMAKE=make
-CC=gcc
-CXX=g++
-PATCH=patch
-case "$SYSTEM" in
-    Linux)
-        ARCH=`arch 2>/dev/null`
-        ;;
-    FreeBSD|OpenBSD|NetBSD)
-        ARCH=`(uname -p) 2>/dev/null`
-        GNUMAKE=gmake
-        ;;
-    Darwin)
-        ARCH=`(uname -p) 2>/dev/null`
-        ISA64=`(sysctl -n hw.optional.x86_64) 2>/dev/null`
-        ;;
-    Solaris)
-        ARCH=`(uname -p) 2>/dev/null`
-        GNUMAKE=gmake
-        PATCH=gpatch
-        ;;
-    *)
-        ARCH="unknown"
-        ;;
-esac
-
-
-# TODO: add mirror & signature validation support
-fetch()
-{
-    TARGET=$DISTDIR/$1
-    if ! test -f $TARGET; then
-        echo "==> Fetch $1 to $TARGET"
-        $CURLBIN --progress-bar -L $2/$1 -o $TARGET
-    fi
-}
-
-build_icu()
-{
-    fetch $ICU_DISTNAME $ICU_SITE
-
-    mkdir -p $ICUDIR
-
-    echo "==> icu (compile)"
-
-    rm -rf $STATICLIBS/icu*
-
-    cd $STATICLIBS
-    $GUNZIP -c $DISTDIR/$ICU_DISTNAME | $TAR xf -
-
-    # apply patches
-    cd $STATICLIBS/icu
-    for P in $PATCHES/icu/*.patch; do \
-        (patch -p0 -i $P || echo "skipping patch"); \
-    done
-
-    cd $ICUDIR/source
-
-    CFLAGS="-g -Wall -fPIC -Os"
-
-    env CC="gcc" CXX="g++" CPPFLAGS="" LDFLAGS="-fPIC" \
-	CFLAGS="$CFLAGS" CXXFLAGS="$CFLAGS" \
-        ./configure --disable-debug \
-		    --enable-static \
-		    --disable-shared \
-		    --disable-icuio \
-		    --disable-layout \
-		    --disable-extras \
-		    --disable-tests \
-		    --disable-samples \
-		    --prefix=$STATICLIBS/icu && \
-        $GNUMAKE && $GNUMAKE install
-}
-
-do_setup()
-{
-    echo "==> build icu"
-    mkdir -p $DISTDIR
-    mkdir -p $STATICLIBS
-}
-
-do_builddeps()
-{
-    if [ ! -f $STATICLIBS/icu/lib/libicui18n.a ]; then
-        build_icu
-    fi
-}
-
-
-clean()
-{
-    rm -rf $STATICLIBS
-    rm -rf $DISTDIR
-}
-
-
-
-usage()
-{
-    cat << EOF
-Usage: $basename [command] [OPTIONS]
-
-The $basename command compile Mozilla Spidermonkey and ICU statically
-for couch_core.
-
-Commands:
-
-    all:        build couch_core static libs
-    clean:      clean static libs
-    -?:         display usage
-
-Report bugs at <https://github.com/refuge/couch_core>.
-EOF
-}
-
-
-if [ ! "x$COUCHDB_STATIC" = "x1" ]; then
-    exit 0
-fi
-
-if [ ! "x$USE_STATIC_ICU" = "x1" ]; then
-    exit 0
-fi
-
-if [ "x$1" = "x" ]; then
-    do_setup
-    do_builddeps
-	exit 0
-fi
-
-case "$1" in
-    all)
-        shift 1
-        do_setup
-        do_builddeps
-        ;;
-    clean)
-        shift 1
-        clean
-        ;;
-    help|--help|-h|-?)
-        usage
-        exit 0
-        ;;
-    *)
-        echo $basename: ERROR Unknown command $arg 1>&2
-        echo 1>&2
-        usage 1>&2
-        echo "### $basename: Exitting." 1>&2
-        exit 1;
-        ;;
-esac
-
-
-exit 0

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/c_src/couch_collate.c
----------------------------------------------------------------------
diff --git a/apps/couch_collate/c_src/couch_collate.c b/apps/couch_collate/c_src/couch_collate.c
deleted file mode 100644
index c5453d2..0000000
--- a/apps/couch_collate/c_src/couch_collate.c
+++ /dev/null
@@ -1,281 +0,0 @@
-/*
-
-Licensed 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.
-
-*/
-
-#ifdef DARWIN
-#define U_HIDE_DRAFT_API 1
-#define U_DISABLE_RENAMING 1
-#endif
-
-#include "erl_nif.h"
-#include "unicode/ucol.h"
-#include "unicode/ucasemap.h"
-#include <stdio.h>
-#include <assert.h>
-
-static ERL_NIF_TERM ATOM_TRUE;
-static ERL_NIF_TERM ATOM_FALSE;
-static ERL_NIF_TERM ATOM_NULL;
-
-typedef struct {
-    ErlNifEnv* env;
-    int error;
-    UCollator* coll;
-} ctx_t;
-
-typedef struct {
-    UCollator** collators;
-    int collStackTop;
-    int numCollators;
-    ErlNifMutex* collMutex;
-} priv_data_t;
-
-static ERL_NIF_TERM collate_nif(ErlNifEnv*, int, const ERL_NIF_TERM []);
-static int collate_binary(priv_data_t*, ctx_t*, ERL_NIF_TERM, ERL_NIF_TERM, ERL_NIF_TERM);
-static int on_load(ErlNifEnv*, void**, ERL_NIF_TERM);
-static void on_unload(ErlNifEnv*, void*);
-static __inline void reserve_coll(priv_data_t*, ctx_t*);
-static __inline void release_coll(priv_data_t*, ctx_t*);
-int on_reload(ErlNifEnv*, void**, ERL_NIF_TERM);
-int on_upgrade(ErlNifEnv*, void**, void**, ERL_NIF_TERM);
-
-void
-reserve_coll(priv_data_t* pData, ctx_t *ctx)
-{
-    if (ctx->coll == NULL) {
-        enif_mutex_lock(pData->collMutex);
-        assert(pData->collStackTop < pData->numCollators);
-        ctx->coll = pData->collators[pData->collStackTop];
-        pData->collStackTop += 1;
-        enif_mutex_unlock(pData->collMutex);
-    }
-}
-
-
-void
-release_coll(priv_data_t* pData, ctx_t *ctx)
-{
-    if (ctx->coll != NULL) {
-        enif_mutex_lock(pData->collMutex);
-        pData->collStackTop -= 1;
-        assert(pData->collStackTop >= 0);
-        enif_mutex_unlock(pData->collMutex);
-    }
-}
-
-/* ------------------------------------------------------------------------- */
-
-static ERL_NIF_TERM
-collate_nif(ErlNifEnv* env, int argc, const ERL_NIF_TERM argv[]) {
-    ERL_NIF_TERM term_a          = argv[0];
-    ERL_NIF_TERM term_b          = argv[1];
-    ERL_NIF_TERM term_has_nocase = argv[2];
-
-    ctx_t ctx;
-    int result;
-    priv_data_t* pData;
-
-    ctx.env = env;
-    ctx.error = 0;
-    ctx.coll = NULL;
-
-    pData = (priv_data_t*) enif_priv_data(env);
-
-    result = collate_binary(pData, &ctx, term_a, term_b, term_has_nocase);
-    release_coll(pData, &ctx);
-
-    return enif_make_int(env, result);
-}
-
-int
-collate_binary(priv_data_t* pData, ctx_t* ctx, ERL_NIF_TERM term_a, ERL_NIF_TERM term_b, ERL_NIF_TERM term_has_nocase)
-{
-    ErlNifBinary binA, binB;
-    int has_nocase, response;
-
-    if(!enif_get_int(ctx->env, term_has_nocase, &has_nocase)) {
-        ctx->error = 1;
-        return 0;
-    }
-    if(!enif_inspect_binary(ctx->env, term_a, &binA)) {
-        ctx->error = 1;
-        return 0;
-    }
-    if(!enif_inspect_binary(ctx->env, term_b, &binB)) {
-        ctx->error = 1;
-        return 0;
-    }
-
-    switch(has_nocase) {
-    case 0: /* COLLATE */
-    case 1: /* COLLATE_NO_CASE: */
-        {
-        UErrorCode status = U_ZERO_ERROR;
-        UCharIterator iterA;
-        UCharIterator iterB;
-
-        uiter_setUTF8(&iterA, (const char *) binA.data, (uint32_t) binA.size);
-        uiter_setUTF8(&iterB, (const char *) binB.data, (uint32_t) binB.size);
-
-        /* grab a collator */
-        reserve_coll(pData, ctx);
-
-        if (has_nocase == 1) /* switching this collator to case insensitive */
-          ucol_setAttribute(ctx->coll, UCOL_STRENGTH, UCOL_PRIMARY, &status);
-
-        /* by default, it will collate case sensitive */
-        response = ucol_strcollIter(ctx->coll, &iterA, &iterB, &status);
-
-        if (has_nocase == 1) /* puting back this collator to case sensitive */
-          ucol_setAttribute(ctx->coll, UCOL_STRENGTH, UCOL_DEFAULT, &status);
-
-        break;
-        }
-
-    default:
-        response = -1;
-    }
-
-    return response;
-}
-
-/* ------------------------------------------------------------------------- */
-
-int
-on_load(ErlNifEnv* env, void** priv_data, ERL_NIF_TERM info)
-{
-    UErrorCode status = U_ZERO_ERROR;
-    priv_data_t* pData = (priv_data_t*)enif_alloc(sizeof(priv_data_t));
-    int i, j;
-
-    /* Initialize the structure */
-    pData->collators = NULL;
-    pData->collStackTop = 0;
-    pData->numCollators = 0;
-    pData->collMutex = NULL;
-
-    if (!enif_get_int(env, info, &(pData->numCollators) )) {
-        enif_free((char*)pData);
-        return 1;
-    }
-
-    if (pData->numCollators < 1) {
-        enif_free((char*)pData);
-        return 2;
-    }
-
-    pData->collMutex = enif_mutex_create((char *)"coll_mutex");
-
-    if (pData->collMutex == NULL) {
-        enif_free((char*)pData);
-        return 3;
-    }
-
-    pData->collators = enif_alloc(sizeof(UCollator*) * pData->numCollators);
-
-    if (pData->collators == NULL) {
-        enif_mutex_destroy(pData->collMutex);
-        enif_free((char*)pData);
-        return 4;
-    }
-
-    for (i = 0; i < pData->numCollators; i++) {
-        pData->collators[i] = ucol_open("", &status);
-
-        if (U_FAILURE(status)) {
-            for (j = 0; j < i; j++) {
-                ucol_close(pData->collators[j]);
-            }
-
-            enif_free(pData->collators);
-            enif_mutex_destroy(pData->collMutex);
-
-            enif_free((char*)pData);
-
-            return 5;
-        }
-    }
-
-    ATOM_TRUE = enif_make_atom(env, "true");
-    ATOM_FALSE = enif_make_atom(env, "false");
-    ATOM_NULL = enif_make_atom(env, "null");
-
-    *priv_data = pData;
-
-    return 0;
-}
-
-
-void
-on_unload(ErlNifEnv* env, void* priv_data)
-{
-    priv_data_t* pData = (priv_data_t*)priv_data;
-    if (pData->collators != NULL) {
-        int i;
-
-        for (i = 0; i < pData->numCollators; i++) {
-            ucol_close(pData->collators[i]);
-        }
-
-        enif_free(pData->collators);
-    }
-
-    if (pData->collMutex != NULL) {
-        enif_mutex_destroy(pData->collMutex);
-    }
-
-    enif_free((char*)pData);
-}
-
-int
-on_reload(ErlNifEnv* env, void** priv_data, ERL_NIF_TERM info)
-{
-    return 0;
-}
-
-int
-on_upgrade(ErlNifEnv* env, void** priv_data, void** old_data, ERL_NIF_TERM info)
-{
-    if (*old_data != NULL) {
-        priv_data_t* pData = (priv_data_t*)old_data;
-
-        if (pData->collators != NULL) {
-            int i;
-
-            for (i = 0; i < pData->numCollators; i++) {
-                ucol_close(pData->collators[i]);
-            }
-
-            enif_free(pData->collators);
-        }
-
-        if (pData->collMutex != NULL) {
-            enif_mutex_destroy(pData->collMutex);
-        }
-
-        enif_free((char*)pData);
-    }
-
-    return on_load(env, priv_data, info);
-}
-
-/* ------------------------------------------------------------------------- */
-
-static ErlNifFunc
-nif_funcs[] =
-{
-    {"collate_nif", 3, collate_nif}
-};
-
-ERL_NIF_INIT(couch_collate, nif_funcs, &on_load, &on_reload, &on_upgrade, &on_unload)

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/patches/icu/common-uloc_c.patch
----------------------------------------------------------------------
diff --git a/apps/couch_collate/patches/icu/common-uloc_c.patch b/apps/couch_collate/patches/icu/common-uloc_c.patch
deleted file mode 100644
index fe60732..0000000
--- a/apps/couch_collate/patches/icu/common-uloc_c.patch
+++ /dev/null
@@ -1,26 +0,0 @@
-$FreeBSD: ports/devel/icu/files/patch-common-uloc.c,v 1.1 2011/12/23 14:54:18 crees Exp $
-
-From http://bugs.icu-project.org/trac/ticket/8984
-
-Submitted by: Andrei Lavreniyuk <an...@gmail.com> (thanks!)
-
---- icu/source/common/uloc.c
-+++ icu/source/common/uloc.c
-@@ -1797,7 +1797,7 @@
-                 int32_t variantLen = _deleteVariant(variant, uprv_min(variantSize, (nameCapacity-len)), variantToCompare, n);
-                 len -= variantLen;
-                 if (variantLen > 0) {
--                    if (name[len-1] == '_') { /* delete trailing '_' */
-+                    if (len > 0 && name[len-1] == '_') { /* delete trailing '_' */
-                         --len;
-                     }
-                     addKeyword = VARIANT_MAP[j].keyword;
-@@ -1805,7 +1805,7 @@
-                     break;
-                 }
-             }
--            if (name[len-1] == '_') { /* delete trailing '_' */
-+            if (len > 0 && len <= nameCapacity && name[len-1] == '_') { /* delete trailing '_' */
-                 --len;
-             }
-         }

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/patches/icu/layout_LookupProcessor_cpp.patch
----------------------------------------------------------------------
diff --git a/apps/couch_collate/patches/icu/layout_LookupProcessor_cpp.patch b/apps/couch_collate/patches/icu/layout_LookupProcessor_cpp.patch
deleted file mode 100644
index 304d266..0000000
--- a/apps/couch_collate/patches/icu/layout_LookupProcessor_cpp.patch
+++ /dev/null
@@ -1,13 +0,0 @@
---- icu/source/layout/LookupProcessor.cpp
-+++ icu/source/layout/LookupProcessor.cpp
-@@ -201,7 +201,9 @@
- 
-     if (requiredFeatureIndex != 0xFFFF) {
-         requiredFeatureTable = featureListTable->getFeatureTable(requiredFeatureIndex, &requiredFeatureTag);
--        featureReferences += SWAPW(featureTable->lookupCount);
-+	if (requiredFeatureTable) {
-+	        featureReferences += SWAPW(requiredFeatureTable->lookupCount);
-+	}
-     }
- 
-     lookupOrderArray = LE_NEW_ARRAY(le_uint16, featureReferences);

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/patches/icu/source_config_Makefile_inc_in.patch
----------------------------------------------------------------------
diff --git a/apps/couch_collate/patches/icu/source_config_Makefile_inc_in.patch b/apps/couch_collate/patches/icu/source_config_Makefile_inc_in.patch
deleted file mode 100644
index 89d428e..0000000
--- a/apps/couch_collate/patches/icu/source_config_Makefile_inc_in.patch
+++ /dev/null
@@ -1,12 +0,0 @@
---- icu/source/config/Makefile.inc.in.orig	2011-04-07 17:41:15.000000000 +0200
-+++ icu/source/config/Makefile.inc.in	2011-04-07 17:41:40.000000000 +0200
-@@ -44,8 +44,7 @@
- LIBICU = lib$(ICUPREFIX)
- 
- # Static library prefix and file extension
--STATIC_PREFIX = s
--LIBSICU = lib$(STATIC_PREFIX)$(ICUPREFIX)
-+LIBSICU = lib$(ICUPREFIX)
- A = a
- 
- # Suffix at the end of libraries. Usually empty.

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/patches/icu/source_icudefs_mk_in.patch
----------------------------------------------------------------------
diff --git a/apps/couch_collate/patches/icu/source_icudefs_mk_in.patch b/apps/couch_collate/patches/icu/source_icudefs_mk_in.patch
deleted file mode 100644
index a1add5e..0000000
--- a/apps/couch_collate/patches/icu/source_icudefs_mk_in.patch
+++ /dev/null
@@ -1,19 +0,0 @@
---- icu/source/icudefs.mk.in.orig	2011-04-07 17:15:44.000000000 +0200
-+++ icu/source/icudefs.mk.in	2011-04-07 17:15:56.000000000 +0200
-@@ -189,14 +189,13 @@
- 
- ## If we can't use the shared libraries, use the static libraries
- ifneq ($(ENABLE_SHARED),YES)
--STATIC_PREFIX_WHEN_USED = s
-+STATIC_PREFIX_WHEN_USED =
- else
- STATIC_PREFIX_WHEN_USED = 
- endif
- 
- # Static library prefix and file extension
--STATIC_PREFIX = s
--LIBSICU = $(LIBPREFIX)$(STATIC_PREFIX)$(ICUPREFIX)
-+LIBSICU = $(LIBPREFIX)$(ICUPREFIX)
- A = a
- SOBJ = $(SO)
- 

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/basictz.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/basictz.h b/apps/couch_collate/platform/osx/icu/unicode/basictz.h
deleted file mode 100644
index c616a3e..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/basictz.h
+++ /dev/null
@@ -1,210 +0,0 @@
-/*
-*******************************************************************************
-* Copyright (C) 2007-2008, International Business Machines Corporation and         *
-* others. All Rights Reserved.                                                *
-*******************************************************************************
-*/
-#ifndef BASICTZ_H
-#define BASICTZ_H
-
-/**
- * \file 
- * \brief C++ API: ICU TimeZone base class
- */
-
-#include "unicode/utypes.h"
-
-#if !UCONFIG_NO_FORMATTING
-
-#include "unicode/timezone.h"
-#include "unicode/tzrule.h"
-#include "unicode/tztrans.h"
-
-U_NAMESPACE_BEGIN
-
-// forward declarations
-class UVector;
-
-/**
- * <code>BasicTimeZone</code> is an abstract class extending <code>TimeZone</code>.
- * This class provides some additional methods to access time zone transitions and rules.
- * All ICU <code>TimeZone</code> concrete subclasses extend this class.
- * @stable ICU 4.0
- */
-class U_I18N_API BasicTimeZone: public TimeZone {
-public:
-    /**
-     * Destructor.
-     * @stable ICU 4.0
-     */
-    virtual ~BasicTimeZone();
-
-    /**
-     * Gets the first time zone transition after the base time.
-     * @param base      The base time.
-     * @param inclusive Whether the base time is inclusive or not.
-     * @param result    Receives the first transition after the base time.
-     * @return  TRUE if the transition is found.
-     * @stable ICU 4.0
-     */
-    virtual UBool getNextTransition(UDate base, UBool inclusive, TimeZoneTransition& result) /*const*/ = 0;
-
-    /**
-     * Gets the most recent time zone transition before the base time.
-     * @param base      The base time.
-     * @param inclusive Whether the base time is inclusive or not.
-     * @param result    Receives the most recent transition before the base time.
-     * @return  TRUE if the transition is found.
-     * @stable ICU 4.0
-     */
-    virtual UBool getPreviousTransition(UDate base, UBool inclusive, TimeZoneTransition& result) /*const*/ = 0;
-
-    /**
-     * Checks if the time zone has equivalent transitions in the time range.
-     * This method returns true when all of transition times, from/to standard
-     * offsets and DST savings used by this time zone match the other in the
-     * time range.
-     * @param tz    The <code>BasicTimeZone</code> object to be compared with.
-     * @param start The start time of the evaluated time range (inclusive)
-     * @param end   The end time of the evaluated time range (inclusive)
-     * @param ignoreDstAmount
-     *              When true, any transitions with only daylight saving amount
-     *              changes will be ignored, except either of them is zero.
-     *              For example, a transition from rawoffset 3:00/dstsavings 1:00
-     *              to rawoffset 2:00/dstsavings 2:00 is excluded from the comparison,
-     *              but a transtion from rawoffset 2:00/dstsavings 1:00 to
-     *              rawoffset 3:00/dstsavings 0:00 is included.
-     * @param ec    Output param to filled in with a success or an error.
-     * @return      true if the other time zone has the equivalent transitions in the
-     *              time range.
-     * @stable ICU 4.0
-     */
-    virtual UBool hasEquivalentTransitions(/*const*/ BasicTimeZone& tz, UDate start, UDate end,
-        UBool ignoreDstAmount, UErrorCode& ec) /*const*/;
-
-    /**
-     * Returns the number of <code>TimeZoneRule</code>s which represents time transitions,
-     * for this time zone, that is, all <code>TimeZoneRule</code>s for this time zone except
-     * <code>InitialTimeZoneRule</code>.  The return value range is 0 or any positive value.
-     * @param status    Receives error status code.
-     * @return The number of <code>TimeZoneRule</code>s representing time transitions.
-     * @stable ICU 4.0
-     */
-    virtual int32_t countTransitionRules(UErrorCode& status) /*const*/ = 0;
-
-    /**
-     * Gets the <code>InitialTimeZoneRule</code> and the set of <code>TimeZoneRule</code>
-     * which represent time transitions for this time zone.  On successful return,
-     * the argument initial points to non-NULL <code>InitialTimeZoneRule</code> and
-     * the array trsrules is filled with 0 or multiple <code>TimeZoneRule</code>
-     * instances up to the size specified by trscount.  The results are referencing the
-     * rule instance held by this time zone instance.  Therefore, after this time zone
-     * is destructed, they are no longer available.
-     * @param initial       Receives the initial timezone rule
-     * @param trsrules      Receives the timezone transition rules
-     * @param trscount      On input, specify the size of the array 'transitions' receiving
-     *                      the timezone transition rules.  On output, actual number of
-     *                      rules filled in the array will be set.
-     * @param status        Receives error status code.
-     * @stable ICU 4.0
-     */
-    virtual void getTimeZoneRules(const InitialTimeZoneRule*& initial,
-        const TimeZoneRule* trsrules[], int32_t& trscount, UErrorCode& status) /*const*/ = 0;
-
-    /**
-     * Gets the set of time zone rules valid at the specified time.  Some known external time zone
-     * implementations are not capable to handle historic time zone rule changes.  Also some
-     * implementations can only handle certain type of rule definitions.
-     * If this time zone does not use any daylight saving time within about 1 year from the specified
-     * time, only the <code>InitialTimeZone</code> is returned.  Otherwise, the rule for standard
-     * time and daylight saving time transitions are returned in addition to the
-     * <code>InitialTimeZoneRule</code>.  The standard and daylight saving time transition rules are
-     * represented by <code>AnnualTimeZoneRule</code> with <code>DateTimeRule::DOW</code> for its date
-     * rule and <code>DateTimeRule::WALL_TIME</code> for its time rule.  Because daylight saving time
-     * rule is changing time to time in many time zones and also mapping a transition time rule to
-     * different type is lossy transformation, the set of rules returned by this method may be valid
-     * for short period of time.
-     * The time zone rule objects returned by this method is owned by the caller, so the caller is
-     * responsible for deleting them after use.
-     * @param date      The date used for extracting time zone rules.
-     * @param initial   Receives the <code>InitialTimeZone</code>, always not NULL.
-     * @param std       Receives the <code>AnnualTimeZoneRule</code> for standard time transitions.
-     *                  When this time time zone does not observe daylight saving times around the
-     *                  specified date, NULL is set.
-     * @param dst       Receives the <code>AnnualTimeZoneRule</code> for daylight saving time
-     *                  transitions.  When this time zone does not observer daylight saving times
-     *                  around the specified date, NULL is set.
-     * @param status    Receives error status code.
-     * @stable ICU 4.0
-     */
-    virtual void getSimpleRulesNear(UDate date, InitialTimeZoneRule*& initial,
-        AnnualTimeZoneRule*& std, AnnualTimeZoneRule*& dst, UErrorCode& status) /*const*/;
-
-
-    /**
-     * The time type option bit flags used by getOffsetFromLocal
-     * @internal
-     */
-    enum {
-        kStandard = 0x01,
-        kDaylight = 0x03,
-        kFormer = 0x04,
-        kLatter = 0x0C
-    };
-
-    /**
-     * Get time zone offsets from local wall time.
-     * @internal
-     */
-    virtual void getOffsetFromLocal(UDate date, int32_t nonExistingTimeOpt, int32_t duplicatedTimeOpt,
-        int32_t& rawOffset, int32_t& dstOffset, UErrorCode& status) /*const*/;
-
-protected:
-
-    /**
-     * The time type option bit masks used by getOffsetFromLocal
-     * @internal
-     */
-    enum {
-        kStdDstMask = kDaylight,
-        kFormerLatterMask = kLatter
-    };
-
-    /**
-     * Default constructor.
-     * @stable ICU 4.0
-     */
-    BasicTimeZone();
-
-    /**
-     * Construct a timezone with a given ID.
-     * @param id a system time zone ID
-     * @stable ICU 4.0
-     */
-    BasicTimeZone(const UnicodeString &id);
-
-    /**
-     * Copy constructor.
-     * @param source the object to be copied.
-     * @stable ICU 4.0
-     */
-    BasicTimeZone(const BasicTimeZone& source);
-
-    /**
-     * Gets the set of TimeZoneRule instances applicable to the specified time and after.
-     * @param start     The start date used for extracting time zone rules
-     * @param initial   Receives the InitialTimeZone, always not NULL
-     * @param transitionRules   Receives the transition rules, could be NULL
-     * @param status    Receives error status code
-     */
-    void getTimeZoneRulesAfter(UDate start, InitialTimeZoneRule*& initial, UVector*& transitionRules,
-        UErrorCode& status) /*const*/;
-};
-
-U_NAMESPACE_END
-
-#endif /* #if !UCONFIG_NO_FORMATTING */
-
-#endif // BASICTZ_H
-
-//eof

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/brkiter.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/brkiter.h b/apps/couch_collate/platform/osx/icu/unicode/brkiter.h
deleted file mode 100644
index 7df5f14..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/brkiter.h
+++ /dev/null
@@ -1,557 +0,0 @@
-/*
-********************************************************************************
-*   Copyright (C) 1997-2007, International Business Machines
-*   Corporation and others.  All Rights Reserved.
-********************************************************************************
-*
-* File brkiter.h
-*
-* Modification History:
-*
-*   Date        Name        Description
-*   02/18/97    aliu        Added typedef for TextCount.  Made DONE const.
-*   05/07/97    aliu        Fixed DLL declaration.
-*   07/09/97    jfitz       Renamed BreakIterator and interface synced with JDK
-*   08/11/98    helena      Sync-up JDK1.2.
-*   01/13/2000  helena      Added UErrorCode parameter to createXXXInstance methods.
-********************************************************************************
-*/
-
-#ifndef BRKITER_H
-#define BRKITER_H
-
-#include "unicode/utypes.h"
-
-/**
- * \file
- * \brief C++ API: Break Iterator.
- */
-
-#if UCONFIG_NO_BREAK_ITERATION
-
-U_NAMESPACE_BEGIN
-
-/*
- * Allow the declaration of APIs with pointers to BreakIterator
- * even when break iteration is removed from the build.
- */
-class BreakIterator;
-
-U_NAMESPACE_END
-
-#else
-
-#include "unicode/uobject.h"
-#include "unicode/unistr.h"
-#include "unicode/chariter.h"
-#include "unicode/locid.h"
-#include "unicode/ubrk.h"
-#include "unicode/strenum.h"
-#include "unicode/utext.h"
-#include "unicode/umisc.h"
-
-U_NAMESPACE_BEGIN
-
-/**
- * The BreakIterator class implements methods for finding the location
- * of boundaries in text. BreakIterator is an abstract base class.
- * Instances of BreakIterator maintain a current position and scan over
- * text returning the index of characters where boundaries occur.
- * <p>
- * Line boundary analysis determines where a text string can be broken
- * when line-wrapping. The mechanism correctly handles punctuation and
- * hyphenated words.
- * <p>
- * Sentence boundary analysis allows selection with correct
- * interpretation of periods within numbers and abbreviations, and
- * trailing punctuation marks such as quotation marks and parentheses.
- * <p>
- * Word boundary analysis is used by search and replace functions, as
- * well as within text editing applications that allow the user to
- * select words with a double click. Word selection provides correct
- * interpretation of punctuation marks within and following
- * words. Characters that are not part of a word, such as symbols or
- * punctuation marks, have word-breaks on both sides.
- * <p>
- * Character boundary analysis allows users to interact with
- * characters as they expect to, for example, when moving the cursor
- * through a text string. Character boundary analysis provides correct
- * navigation of through character strings, regardless of how the
- * character is stored.  For example, an accented character might be
- * stored as a base character and a diacritical mark. What users
- * consider to be a character can differ between languages.
- * <p>
- * The text boundary positions are found according to the rules
- * described in Unicode Standard Annex #29, Text Boundaries, and
- * Unicode Standard Annex #14, Line Breaking Properties.  These
- * are available at http://www.unicode.org/reports/tr14/ and
- * http://www.unicode.org/reports/tr29/.
- * <p>
- * In addition to the C++ API defined in this header file, a
- * plain C API with equivalent functionality is defined in the
- * file ubrk.h
- * <p>
- * Code snippits illustrating the use of the Break Iterator APIs
- * are available in the ICU User Guide,
- * http://icu-project.org/userguide/boundaryAnalysis.html
- * and in the sample program icu/source/samples/break/break.cpp"
- *
- */
-class U_COMMON_API BreakIterator : public UObject {
-public:
-    /**
-     *  destructor
-     *  @stable ICU 2.0
-     */
-    virtual ~BreakIterator();
-
-    /**
-     * Return true if another object is semantically equal to this
-     * one. The other object should be an instance of the same subclass of
-     * BreakIterator. Objects of different subclasses are considered
-     * unequal.
-     * <P>
-     * Return true if this BreakIterator is at the same position in the
-     * same text, and is the same class and type (word, line, etc.) of
-     * BreakIterator, as the argument.  Text is considered the same if
-     * it contains the same characters, it need not be the same
-     * object, and styles are not considered.
-     * @stable ICU 2.0
-     */
-    virtual UBool operator==(const BreakIterator&) const = 0;
-
-    /**
-     * Returns the complement of the result of operator==
-     * @param rhs The BreakIterator to be compared for inequality
-     * @return the complement of the result of operator==
-     * @stable ICU 2.0
-     */
-    UBool operator!=(const BreakIterator& rhs) const { return !operator==(rhs); }
-
-    /**
-     * Return a polymorphic copy of this object.  This is an abstract
-     * method which subclasses implement.
-     * @stable ICU 2.0
-     */
-    virtual BreakIterator* clone(void) const = 0;
-
-    /**
-     * Return a polymorphic class ID for this object. Different subclasses
-     * will return distinct unequal values.
-     * @stable ICU 2.0
-     */
-    virtual UClassID getDynamicClassID(void) const = 0;
-
-    /**
-     * Return a CharacterIterator over the text being analyzed.
-     * @stable ICU 2.0
-     */
-    virtual CharacterIterator& getText(void) const = 0;
-
-
-    /**
-      *  Get a UText for the text being analyzed.
-      *  The returned UText is a shallow clone of the UText used internally
-      *  by the break iterator implementation.  It can safely be used to
-      *  access the text without impacting any break iterator operations,
-      *  but the underlying text itself must not be altered.
-      *
-      * @param fillIn A UText to be filled in.  If NULL, a new UText will be
-      *           allocated to hold the result.
-      * @param status receives any error codes.
-      * @return   The current UText for this break iterator.  If an input
-      *           UText was provided, it will always be returned.
-      * @stable ICU 3.4
-      */
-     virtual UText *getUText(UText *fillIn, UErrorCode &status) const = 0;
-
-    /**
-     * Change the text over which this operates. The text boundary is
-     * reset to the start.
-     * @param text The UnicodeString used to change the text.
-     * @stable ICU 2.0
-     */
-    virtual void  setText(const UnicodeString &text) = 0;
-
-    /**
-     * Reset the break iterator to operate over the text represented by
-     * the UText.  The iterator position is reset to the start.
-     *
-     * This function makes a shallow clone of the supplied UText.  This means
-     * that the caller is free to immediately close or otherwise reuse the
-     * Utext that was passed as a parameter, but that the underlying text itself
-     * must not be altered while being referenced by the break iterator.
-     *
-     * @param text The UText used to change the text.
-     * @param status receives any error codes.
-     * @stable ICU 3.4
-     */
-    virtual void  setText(UText *text, UErrorCode &status) = 0;
-
-    /**
-     * Change the text over which this operates. The text boundary is
-     * reset to the start.
-     * Note that setText(UText *) provides similar functionality to this function,
-     * and is more efficient.
-     * @param it The CharacterIterator used to change the text.
-     * @stable ICU 2.0
-     */
-    virtual void  adoptText(CharacterIterator* it) = 0;
-
-    enum {
-        /**
-         * DONE is returned by previous() and next() after all valid
-         * boundaries have been returned.
-         * @stable ICU 2.0
-         */
-        DONE = (int32_t)-1
-    };
-
-    /**
-     * Return the index of the first character in the text being scanned.
-     * @stable ICU 2.0
-     */
-    virtual int32_t first(void) = 0;
-
-    /**
-     * Return the index immediately BEYOND the last character in the text being scanned.
-     * @stable ICU 2.0
-     */
-    virtual int32_t last(void) = 0;
-
-    /**
-     * Return the boundary preceding the current boundary.
-     * @return The character index of the previous text boundary or DONE if all
-     * boundaries have been returned.
-     * @stable ICU 2.0
-     */
-    virtual int32_t previous(void) = 0;
-
-    /**
-     * Return the boundary following the current boundary.
-     * @return The character index of the next text boundary or DONE if all
-     * boundaries have been returned.
-     * @stable ICU 2.0
-     */
-    virtual int32_t next(void) = 0;
-
-    /**
-     * Return character index of the current interator position within the text.
-     * @return The boundary most recently returned.
-     * @stable ICU 2.0
-     */
-    virtual int32_t current(void) const = 0;
-
-    /**
-     * Return the first boundary following the specified offset.
-     * The value returned is always greater than the offset or
-     * the value BreakIterator.DONE
-     * @param offset the offset to begin scanning.
-     * @return The first boundary after the specified offset.
-     * @stable ICU 2.0
-     */
-    virtual int32_t following(int32_t offset) = 0;
-
-    /**
-     * Return the first boundary preceding the specified offset.
-     * The value returned is always smaller than the offset or
-     * the value BreakIterator.DONE
-     * @param offset the offset to begin scanning.
-     * @return The first boundary before the specified offset.
-     * @stable ICU 2.0
-     */
-    virtual int32_t preceding(int32_t offset) = 0;
-
-    /**
-     * Return true if the specfied position is a boundary position.
-     * As a side effect, the current position of the iterator is set
-     * to the first boundary position at or following the specified offset.
-     * @param offset the offset to check.
-     * @return True if "offset" is a boundary position.
-     * @stable ICU 2.0
-     */
-    virtual UBool isBoundary(int32_t offset) = 0;
-
-    /**
-     * Return the nth boundary from the current boundary
-     * @param n which boundary to return.  A value of 0
-     * does nothing.  Negative values move to previous boundaries
-     * and positive values move to later boundaries.
-     * @return The index of the nth boundary from the current position, or
-     * DONE if there are fewer than |n| boundaries in the specfied direction.
-     * @stable ICU 2.0
-     */
-    virtual int32_t next(int32_t n) = 0;
-
-    /**
-     * Create BreakIterator for word-breaks using the given locale.
-     * Returns an instance of a BreakIterator implementing word breaks.
-     * WordBreak is useful for word selection (ex. double click)
-     * @param where the locale.
-     * @param status the error code
-     * @return A BreakIterator for word-breaks.  The UErrorCode& status
-     * parameter is used to return status information to the user.
-     * To check whether the construction succeeded or not, you should check
-     * the value of U_SUCCESS(err).  If you wish more detailed information, you
-     * can check for informational error results which still indicate success.
-     * U_USING_FALLBACK_WARNING indicates that a fall back locale was used.  For
-     * example, 'de_CH' was requested, but nothing was found there, so 'de' was
-     * used.  U_USING_DEFAULT_WARNING indicates that the default locale data was
-     * used; neither the requested locale nor any of its fall back locales
-     * could be found.
-     * The caller owns the returned object and is responsible for deleting it.
-     * @stable ICU 2.0
-     */
-    static BreakIterator* U_EXPORT2
-    createWordInstance(const Locale& where, UErrorCode& status);
-
-    /**
-     * Create BreakIterator for line-breaks using specified locale.
-     * Returns an instance of a BreakIterator implementing line breaks. Line
-     * breaks are logically possible line breaks, actual line breaks are
-     * usually determined based on display width.
-     * LineBreak is useful for word wrapping text.
-     * @param where the locale.
-     * @param status The error code.
-     * @return A BreakIterator for line-breaks.  The UErrorCode& status
-     * parameter is used to return status information to the user.
-     * To check whether the construction succeeded or not, you should check
-     * the value of U_SUCCESS(err).  If you wish more detailed information, you
-     * can check for informational error results which still indicate success.
-     * U_USING_FALLBACK_WARNING indicates that a fall back locale was used.  For
-     * example, 'de_CH' was requested, but nothing was found there, so 'de' was
-     * used.  U_USING_DEFAULT_WARNING indicates that the default locale data was
-     * used; neither the requested locale nor any of its fall back locales
-     * could be found.
-     * The caller owns the returned object and is responsible for deleting it.
-     * @stable ICU 2.0
-     */
-    static BreakIterator* U_EXPORT2
-    createLineInstance(const Locale& where, UErrorCode& status);
-
-    /**
-     * Create BreakIterator for character-breaks using specified locale
-     * Returns an instance of a BreakIterator implementing character breaks.
-     * Character breaks are boundaries of combining character sequences.
-     * @param where the locale.
-     * @param status The error code.
-     * @return A BreakIterator for character-breaks.  The UErrorCode& status
-     * parameter is used to return status information to the user.
-     * To check whether the construction succeeded or not, you should check
-     * the value of U_SUCCESS(err).  If you wish more detailed information, you
-     * can check for informational error results which still indicate success.
-     * U_USING_FALLBACK_WARNING indicates that a fall back locale was used.  For
-     * example, 'de_CH' was requested, but nothing was found there, so 'de' was
-     * used.  U_USING_DEFAULT_WARNING indicates that the default locale data was
-     * used; neither the requested locale nor any of its fall back locales
-     * could be found.
-     * The caller owns the returned object and is responsible for deleting it.
-     * @stable ICU 2.0
-     */
-    static BreakIterator* U_EXPORT2
-    createCharacterInstance(const Locale& where, UErrorCode& status);
-
-    /**
-     * Create BreakIterator for sentence-breaks using specified locale
-     * Returns an instance of a BreakIterator implementing sentence breaks.
-     * @param where the locale.
-     * @param status The error code.
-     * @return A BreakIterator for sentence-breaks.  The UErrorCode& status
-     * parameter is used to return status information to the user.
-     * To check whether the construction succeeded or not, you should check
-     * the value of U_SUCCESS(err).  If you wish more detailed information, you
-     * can check for informational error results which still indicate success.
-     * U_USING_FALLBACK_WARNING indicates that a fall back locale was used.  For
-     * example, 'de_CH' was requested, but nothing was found there, so 'de' was
-     * used.  U_USING_DEFAULT_WARNING indicates that the default locale data was
-     * used; neither the requested locale nor any of its fall back locales
-     * could be found.
-     * The caller owns the returned object and is responsible for deleting it.
-     * @stable ICU 2.0
-     */
-    static BreakIterator* U_EXPORT2
-    createSentenceInstance(const Locale& where, UErrorCode& status);
-
-    /**
-     * Create BreakIterator for title-casing breaks using the specified locale
-     * Returns an instance of a BreakIterator implementing title breaks.
-     * The iterator returned locates title boundaries as described for
-     * Unicode 3.2 only. For Unicode 4.0 and above title boundary iteration,
-     * please use Word Boundary iterator.{@link #createWordInstance }
-     *
-     * @param where the locale.
-     * @param status The error code.
-     * @return A BreakIterator for title-breaks.  The UErrorCode& status
-     * parameter is used to return status information to the user.
-     * To check whether the construction succeeded or not, you should check
-     * the value of U_SUCCESS(err).  If you wish more detailed information, you
-     * can check for informational error results which still indicate success.
-     * U_USING_FALLBACK_WARNING indicates that a fall back locale was used.  For
-     * example, 'de_CH' was requested, but nothing was found there, so 'de' was
-     * used.  U_USING_DEFAULT_WARNING indicates that the default locale data was
-     * used; neither the requested locale nor any of its fall back locales
-     * could be found.
-     * The caller owns the returned object and is responsible for deleting it.
-     * @stable ICU 2.1
-     */
-    static BreakIterator* U_EXPORT2
-    createTitleInstance(const Locale& where, UErrorCode& status);
-
-    /**
-     * Get the set of Locales for which TextBoundaries are installed.
-     * <p><b>Note:</b> this will not return locales added through the register
-     * call. To see the registered locales too, use the getAvailableLocales
-     * function that returns a StringEnumeration object </p>
-     * @param count the output parameter of number of elements in the locale list
-     * @return available locales
-     * @stable ICU 2.0
-     */
-    static const Locale* U_EXPORT2 getAvailableLocales(int32_t& count);
-
-    /**
-     * Get name of the object for the desired Locale, in the desired langauge.
-     * @param objectLocale must be from getAvailableLocales.
-     * @param displayLocale specifies the desired locale for output.
-     * @param name the fill-in parameter of the return value
-     * Uses best match.
-     * @return user-displayable name
-     * @stable ICU 2.0
-     */
-    static UnicodeString& U_EXPORT2 getDisplayName(const Locale& objectLocale,
-                                         const Locale& displayLocale,
-                                         UnicodeString& name);
-
-    /**
-     * Get name of the object for the desired Locale, in the langauge of the
-     * default locale.
-     * @param objectLocale must be from getMatchingLocales
-     * @param name the fill-in parameter of the return value
-     * @return user-displayable name
-     * @stable ICU 2.0
-     */
-    static UnicodeString& U_EXPORT2 getDisplayName(const Locale& objectLocale,
-                                         UnicodeString& name);
-
-    /**
-     * Thread safe client-buffer-based cloning operation
-     *    Do NOT call delete on a safeclone, since 'new' is not used to create it.
-     * @param stackBuffer user allocated space for the new clone. If NULL new memory will be allocated.
-     * If buffer is not large enough, new memory will be allocated.
-     * @param BufferSize reference to size of allocated space.
-     * If BufferSize == 0, a sufficient size for use in cloning will
-     * be returned ('pre-flighting')
-     * If BufferSize is not enough for a stack-based safe clone,
-     * new memory will be allocated.
-     * @param status to indicate whether the operation went on smoothly or there were errors
-     *  An informational status value, U_SAFECLONE_ALLOCATED_ERROR, is used if any allocations were
-     *  necessary.
-     * @return pointer to the new clone
-     *
-     * @stable ICU 2.0
-     */
-    virtual BreakIterator *  createBufferClone(void *stackBuffer,
-                                               int32_t &BufferSize,
-                                               UErrorCode &status) = 0;
-
-    /**
-     *   Determine whether the BreakIterator was created in user memory by
-     *   createBufferClone(), and thus should not be deleted.  Such objects
-     *   must be closed by an explicit call to the destructor (not delete).
-     *  @stable ICU 2.0
-     */
-    inline UBool isBufferClone(void);
-
-#if !UCONFIG_NO_SERVICE
-    /**
-     * Register a new break iterator of the indicated kind, to use in the given locale.
-     * The break iterator will be adopted.  Clones of the iterator will be returned
-     * if a request for a break iterator of the given kind matches or falls back to
-     * this locale.
-     * @param toAdopt the BreakIterator instance to be adopted
-     * @param locale the Locale for which this instance is to be registered
-     * @param kind the type of iterator for which this instance is to be registered
-     * @param status the in/out status code, no special meanings are assigned
-     * @return a registry key that can be used to unregister this instance
-     * @stable ICU 2.4
-     */
-    static URegistryKey U_EXPORT2 registerInstance(BreakIterator* toAdopt,
-                                        const Locale& locale,
-                                        UBreakIteratorType kind,
-                                        UErrorCode& status);
-
-    /**
-     * Unregister a previously-registered BreakIterator using the key returned from the
-     * register call.  Key becomes invalid after a successful call and should not be used again.
-     * The BreakIterator corresponding to the key will be deleted.
-     * @param key the registry key returned by a previous call to registerInstance
-     * @param status the in/out status code, no special meanings are assigned
-     * @return TRUE if the iterator for the key was successfully unregistered
-     * @stable ICU 2.4
-     */
-    static UBool U_EXPORT2 unregister(URegistryKey key, UErrorCode& status);
-
-    /**
-     * Return a StringEnumeration over the locales available at the time of the call,
-     * including registered locales.
-     * @return a StringEnumeration over the locales available at the time of the call
-     * @stable ICU 2.4
-     */
-    static StringEnumeration* U_EXPORT2 getAvailableLocales(void);
-#endif
-
-    /**
-     * Returns the locale for this break iterator. Two flavors are available: valid and
-     * actual locale.
-     * @stable ICU 2.8
-     */
-    Locale getLocale(ULocDataLocaleType type, UErrorCode& status) const;
-
-    /** Get the locale for this break iterator object. You can choose between valid and actual locale.
-     *  @param type type of the locale we're looking for (valid or actual)
-     *  @param status error code for the operation
-     *  @return the locale
-     *  @internal
-     */
-    const char *getLocaleID(ULocDataLocaleType type, UErrorCode& status) const;
-
- private:
-    static BreakIterator* buildInstance(const Locale& loc, const char *type, int32_t kind, UErrorCode& status);
-    static BreakIterator* createInstance(const Locale& loc, int32_t kind, UErrorCode& status);
-    static BreakIterator* makeInstance(const Locale& loc, int32_t kind, UErrorCode& status);
-
-    friend class ICUBreakIteratorFactory;
-    friend class ICUBreakIteratorService;
-
-protected:
-    /** @internal */
-    BreakIterator();
-    /** @internal */
-    UBool fBufferClone;
-    /** @internal */
-    BreakIterator (const BreakIterator &other) : UObject(other), fBufferClone(FALSE) {}
-
-private:
-
-    /** @internal */
-    char actualLocale[ULOC_FULLNAME_CAPACITY];
-    char validLocale[ULOC_FULLNAME_CAPACITY];
-
-    /**
-     * The assignment operator has no real implementation.
-     * It's provided to make the compiler happy. Do not call.
-     */
-    BreakIterator& operator=(const BreakIterator&);
-};
-
-inline UBool BreakIterator::isBufferClone()
-{
-    return fBufferClone;
-}
-
-U_NAMESPACE_END
-
-#endif /* #if !UCONFIG_NO_BREAK_ITERATION */
-
-#endif // _BRKITER
-//eof
-


[55/57] [abbrv] couchdb commit: updated refs/heads/1994-merge-rcouch-multi-repo to b19d055

Posted by be...@apache.org.
small update


Project: http://git-wip-us.apache.org/repos/asf/couchdb/repo
Commit: http://git-wip-us.apache.org/repos/asf/couchdb/commit/cb4817b4
Tree: http://git-wip-us.apache.org/repos/asf/couchdb/tree/cb4817b4
Diff: http://git-wip-us.apache.org/repos/asf/couchdb/diff/cb4817b4

Branch: refs/heads/1994-merge-rcouch-multi-repo
Commit: cb4817b40498bff9bf95fdeb1a8e631ecf587ec6
Parents: c085543
Author: Benoit Chesneau <bc...@gmail.com>
Authored: Thu Feb 13 18:08:08 2014 +0100
Committer: Benoit Chesneau <bc...@gmail.com>
Committed: Thu Feb 13 18:08:08 2014 +0100

----------------------------------------------------------------------
 rebar.config | 73 ++++++++++++++++++++++++++++++++++++++++---------------
 1 file changed, 54 insertions(+), 19 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/couchdb/blob/cb4817b4/rebar.config
----------------------------------------------------------------------
diff --git a/rebar.config b/rebar.config
index 81f7e48..232b6ff 100644
--- a/rebar.config
+++ b/rebar.config
@@ -14,42 +14,77 @@
                          {tag, "1.3.8"}}},
 
     %% erlang oauth module
-    {oauth, ".*", {git, "git://github.com/refuge/erlang-oauth.git", {branch,
-        "master"}}},
+    {oauth, ".*",
+     {git, "http://git-wip-us.apache.org/repos/asf/couchdb-oauth.git",
+      {branch, "import"}}},
 
     %% ibrowse module , http client
-    {ibrowse, ".*", {git, "git://github.com/refuge/ibrowse.git",
-                     {branch, "master"}}},
+    {ibrowse, ".*",
+     {git, "http://git-wip-us.apache.org/repos/asf/couchdb-ibrowse.git",
+      {branch, "import"}}},
 
     %% mochiweb module, http framework
-    {mochiweb, ".*", {git,"git://github.com/refuge/mochiweb.git",
-                        {branch, "master"}}},
+    {mochiweb, ".*",
+     {git,"http://git-wip-us.apache.org/repos/asf/couchdb-mochiweb.git",
+      {branch, "import-upstream"}}},
 
     %% snappy module, used for compression
-    {snappy, ".*", {git, "git://github.com/refuge/snappy-erlang.git",
-                   {branch, "refuge"}}},
+    {snappy, ".*",
+     {git, "http://git-wip-us.apache.org/repos/asf/couchdb-snappy.git",
+      {branch, "import"}}},
 
     %% json module, encode/decode module
-    {jiffy, ".*", {git, "git://github.com/refuge/jiffy.git", "master"}},
+    {jiffy, ".*",
+        {git, "http://git-wip-us.apache.org/repos/asf/couchdb-jiffy.git",
+         {branch, "import"}},
 
     %% lager logging module
-    {lager, ".*", {git, "git://github.com/refuge/lager.git", "master"}}
+    {lager, ".*",
+     {git, "http://git-wip-us.apache.org/repos/asf/couchdb-lager.git",
+      {branch, "master"}}},
+
+
+     %% apps
+     {couch_collate, ".*",
+      {git,"http://git-wip-us.apache.org/repos/asf/couchdb-couch-collate.git",
+       {branch, "1994-merge-rcouch"}}},
+
+     {couch, ".*",
+      {git, "http://git-wip-us.apache.org/repos/asf/couchdb-couch.git",
+       {branch, "1994-merge-rcouch"}}},
+
+    {couch_httpd, ".*",
+      {git, "http://git-wip-us.apache.org/repos/asf/couchdb-couch-httpd.git",
+       {branch, "1994-merge-rcouch"}}},
+
+    {couch_index, ".*",
+      {git, "http://git-wip-us.apache.org/repos/asf/couchdb-couch-index.git",
+       {branch, "1994-merge-rcouch"}}},
+
+    {couch_mrview, ".*",
+      {git, "http://git-wip-us.apache.org/repos/asf/couchdb-couch-mrview.git",
+       {branch, "1994-merge-rcouch"}}},
+
+    {couch_replicator, ".*",
+      {git, "http://git-wip-us.apache.org/repos/asf/couchdb-couch-replicator.git",
+       {branch, "1994-merge-rcouch"}}},
+
+     {couch_plugins, ".*",
+      {git, "http://git-wip-us.apache.org/repos/asf/couchdb-couch-plugins.git",
+       {branch, "import"}}},
+
+     {couch_dbupdates, ".*",
+      {git, "http://git-wip-us.apache.org/repos/asf/couchdb-couch-dbupdates.git",
+       {branch, "import"}}}
+
 ]}.
 
 
 {deps_dir, ["deps"]}.
 
-{libs_dir, ["apps", "deps/"]}.
+{libs_dir, ["deps/"]}.
 
 {sub_dirs, [
-    "apps/couch_collate",
-    "apps/couch",
-    "apps/couch_httpd",
-    "apps/couch_index",
-    "apps/couch_mrview",
-    "apps/couch_replicator",
-    "apps/couch_plugins",
-    "apps/couch_dbupdates",
     "support/couch_rel",
     "rel"
 ]}.


[32/57] [abbrv] remove couch_collate

Posted by be...@apache.org.
http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/numfmt.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/numfmt.h b/apps/couch_collate/platform/osx/icu/unicode/numfmt.h
deleted file mode 100644
index 6deab8f..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/numfmt.h
+++ /dev/null
@@ -1,886 +0,0 @@
-/*
-********************************************************************************
-* Copyright (C) 1997-2009, International Business Machines Corporation and others.
-* All Rights Reserved.
-********************************************************************************
-*
-* File NUMFMT.H
-*
-* Modification History:
-*
-*   Date        Name        Description
-*   02/19/97    aliu        Converted from java.
-*   03/18/97    clhuang     Updated per C++ implementation.
-*   04/17/97    aliu        Changed DigitCount to int per code review.
-*    07/20/98    stephen        JDK 1.2 sync up. Added scientific support.
-*                            Changed naming conventions to match C++ guidelines
-*                            Derecated Java style constants (eg, INTEGER_FIELD)
-********************************************************************************
-*/
-
-#ifndef NUMFMT_H
-#define NUMFMT_H
-
-
-#include "unicode/utypes.h"
-
-/**
- * \file 
- * \brief C++ API: Abstract base class for all number formats.
- */
- 
-#if !UCONFIG_NO_FORMATTING
-
-#include "unicode/unistr.h"
-#include "unicode/format.h"
-#include "unicode/unum.h" // UNumberFormatStyle
-#include "unicode/locid.h"
-
-U_NAMESPACE_BEGIN
-
-#if !UCONFIG_NO_SERVICE
-class NumberFormatFactory;
-class StringEnumeration;
-#endif
-
-/**
- *
- * Abstract base class for all number formats.  Provides interface for
- * formatting and parsing a number.  Also provides methods for
- * determining which locales have number formats, and what their names
- * are.
- * <P>
- * NumberFormat helps you to format and parse numbers for any locale.
- * Your code can be completely independent of the locale conventions
- * for decimal points, thousands-separators, or even the particular
- * decimal digits used, or whether the number format is even decimal.
- * <P>
- * To format a number for the current Locale, use one of the static
- * factory methods:
- * <pre>
- * \code
- *    double myNumber = 7.0;
- *    UnicodeString myString;
- *    UErrorCode success = U_ZERO_ERROR;
- *    NumberFormat* nf = NumberFormat::createInstance(success)
- *    nf->format(myNumber, myString);
- *    cout << " Example 1: " << myString << endl;
- * \endcode
- * </pre>
- * If you are formatting multiple numbers, it is more efficient to get
- * the format and use it multiple times so that the system doesn't
- * have to fetch the information about the local language and country
- * conventions multiple times.
- * <pre>
- * \code
- *     UnicodeString myString;
- *     UErrorCode success = U_ZERO_ERROR;
- *     nf = NumberFormat::createInstance( success );
- *     int32_t a[] = { 123, 3333, -1234567 };
- *     const int32_t a_len = sizeof(a) / sizeof(a[0]);
- *     myString.remove();
- *     for (int32_t i = 0; i < a_len; i++) {
- *         nf->format(a[i], myString);
- *         myString += " ; ";
- *     }
- *     cout << " Example 2: " << myString << endl;
- * \endcode
- * </pre>
- * To format a number for a different Locale, specify it in the
- * call to createInstance().
- * <pre>
- * \code
- *     nf = NumberFormat::createInstance( Locale::FRENCH, success );
- * \endcode
- * </pre>
- * You can use a NumberFormat to parse also.
- * <pre>
- * \code
- *    UErrorCode success;
- *    Formattable result(-999);  // initialized with error code
- *    nf->parse(myString, result, success);
- * \endcode
- * </pre>
- * Use createInstance to get the normal number format for that country.
- * There are other static factory methods available.  Use getCurrency
- * to get the currency number format for that country.  Use getPercent
- * to get a format for displaying percentages. With this format, a
- * fraction from 0.53 is displayed as 53%.
- * <P>
- * You can also control the display of numbers with such methods as
- * getMinimumFractionDigits.  If you want even more control over the
- * format or parsing, or want to give your users more control, you can
- * try casting the NumberFormat you get from the factory methods to a
- * DecimalNumberFormat. This will work for the vast majority of
- * countries; just remember to put it in a try block in case you
- * encounter an unusual one.
- * <P>
- * You can also use forms of the parse and format methods with
- * ParsePosition and FieldPosition to allow you to:
- * <ul type=round>
- *   <li>(a) progressively parse through pieces of a string.
- *   <li>(b) align the decimal point and other areas.
- * </ul>
- * For example, you can align numbers in two ways.
- * <P>
- * If you are using a monospaced font with spacing for alignment, you
- * can pass the FieldPosition in your format call, with field =
- * INTEGER_FIELD. On output, getEndIndex will be set to the offset
- * between the last character of the integer and the decimal. Add
- * (desiredSpaceCount - getEndIndex) spaces at the front of the
- * string.
- * <P>
- * If you are using proportional fonts, instead of padding with
- * spaces, measure the width of the string in pixels from the start to
- * getEndIndex.  Then move the pen by (desiredPixelWidth -
- * widthToAlignmentPoint) before drawing the text.  It also works
- * where there is no decimal, but possibly additional characters at
- * the end, e.g. with parentheses in negative numbers: "(12)" for -12.
- * <p>
- * <em>User subclasses are not supported.</em> While clients may write
- * subclasses, such code will not necessarily work and will not be
- * guaranteed to work stably from release to release.
- *
- * @stable ICU 2.0
- */
-class U_I18N_API NumberFormat : public Format {
-public:
-
-    /**
-     * Alignment Field constants used to construct a FieldPosition object.
-     * Signifies that the position of the integer part or fraction part of
-     * a formatted number should be returned.
-     *
-     * @see FieldPosition
-     * @stable ICU 2.0
-     */
-    enum EAlignmentFields {
-        kIntegerField,
-        kFractionField,
-
-
-    /**
-     * These constants are provided for backwards compatibility only.
-     * Please use the C++ style constants defined above.
-     * @stable ICU 2.0
-     */
-        INTEGER_FIELD        = kIntegerField,
-        FRACTION_FIELD        = kFractionField
-    };
-
-    /**
-     * Destructor.
-     * @stable ICU 2.0
-     */
-    virtual ~NumberFormat();
-
-    /**
-     * Return true if the given Format objects are semantically equal.
-     * Objects of different subclasses are considered unequal.
-     * @return    true if the given Format objects are semantically equal.
-     * @stable ICU 2.0
-     */
-    virtual UBool operator==(const Format& other) const;
-
-    /**
-     * Format an object to produce a string.  This method handles
-     * Formattable objects with numeric types. If the Formattable
-     * object type is not a numeric type, then it returns a failing
-     * UErrorCode.
-     *
-     * @param obj       The object to format.
-     * @param appendTo  Output parameter to receive result.
-     *                  Result is appended to existing contents.
-     * @param pos       On input: an alignment field, if desired.
-     *                  On output: the offsets of the alignment field.
-     * @param status    Output param filled with success/failure status.
-     * @return          Reference to 'appendTo' parameter.
-     * @stable ICU 2.0
-     */
-    virtual UnicodeString& format(const Formattable& obj,
-                                  UnicodeString& appendTo,
-                                  FieldPosition& pos,
-                                  UErrorCode& status) const;
-
-    /**
-     * Parse a string to produce an object.  This methods handles
-     * parsing of numeric strings into Formattable objects with numeric
-     * types.
-     * <P>
-     * Before calling, set parse_pos.index to the offset you want to
-     * start parsing at in the source. After calling, parse_pos.index
-     * indicates the position after the successfully parsed text.  If
-     * an error occurs, parse_pos.index is unchanged.
-     * <P>
-     * When parsing, leading whitespace is discarded (with successful
-     * parse), while trailing whitespace is left as is.
-     * <P>
-     * See Format::parseObject() for more.
-     *
-     * @param source    The string to be parsed into an object.
-     * @param result    Formattable to be set to the parse result.
-     *                  If parse fails, return contents are undefined.
-     * @param parse_pos The position to start parsing at. Upon return
-     *                  this param is set to the position after the
-     *                  last character successfully parsed. If the
-     *                  source is not parsed successfully, this param
-     *                  will remain unchanged.
-     * @return          A newly created Formattable* object, or NULL
-     *                  on failure.  The caller owns this and should
-     *                  delete it when done.
-     * @stable ICU 2.0
-     */
-    virtual void parseObject(const UnicodeString& source,
-                             Formattable& result,
-                             ParsePosition& parse_pos) const;
-
-    /**
-     * Format a double number. These methods call the NumberFormat
-     * pure virtual format() methods with the default FieldPosition.
-     *
-     * @param number    The value to be formatted.
-     * @param appendTo  Output parameter to receive result.
-     *                  Result is appended to existing contents.
-     * @return          Reference to 'appendTo' parameter.
-     * @stable ICU 2.0
-     */
-    UnicodeString& format(  double number,
-                            UnicodeString& appendTo) const;
-
-    /**
-     * Format a long number. These methods call the NumberFormat
-     * pure virtual format() methods with the default FieldPosition.
-     *
-     * @param number    The value to be formatted.
-     * @param appendTo  Output parameter to receive result.
-     *                  Result is appended to existing contents.
-     * @return          Reference to 'appendTo' parameter.
-     * @stable ICU 2.0
-     */
-    UnicodeString& format(  int32_t number,
-                            UnicodeString& appendTo) const;
-
-    /**
-     * Format an int64 number. These methods call the NumberFormat
-     * pure virtual format() methods with the default FieldPosition.
-     *
-     * @param number    The value to be formatted.
-     * @param appendTo  Output parameter to receive result.
-     *                  Result is appended to existing contents.
-     * @return          Reference to 'appendTo' parameter.
-     * @stable ICU 2.8
-     */
-    UnicodeString& format(  int64_t number,
-                            UnicodeString& appendTo) const;
-
-    /**
-     * Format a double number. Concrete subclasses must implement
-     * these pure virtual methods.
-     *
-     * @param number    The value to be formatted.
-     * @param appendTo  Output parameter to receive result.
-     *                  Result is appended to existing contents.
-     * @param pos       On input: an alignment field, if desired.
-     *                  On output: the offsets of the alignment field.
-     * @return          Reference to 'appendTo' parameter.
-     * @stable ICU 2.0
-     */
-    virtual UnicodeString& format(double number,
-                                  UnicodeString& appendTo,
-                                  FieldPosition& pos) const = 0;
-    /**
-     * Format a long number. Concrete subclasses must implement
-     * these pure virtual methods.
-     *
-     * @param number    The value to be formatted.
-     * @param appendTo  Output parameter to receive result.
-     *                  Result is appended to existing contents.
-     * @param pos       On input: an alignment field, if desired.
-     *                  On output: the offsets of the alignment field.
-     * @return          Reference to 'appendTo' parameter.
-     * @stable ICU 2.0
-    */
-    virtual UnicodeString& format(int32_t number,
-                                  UnicodeString& appendTo,
-                                  FieldPosition& pos) const = 0;
-
-    /**
-     * Format an int64 number. (Not abstract to retain compatibility
-     * with earlier releases, however subclasses should override this
-     * method as it just delegates to format(int32_t number...);
-     *
-     * @param number    The value to be formatted.
-     * @param appendTo  Output parameter to receive result.
-     *                  Result is appended to existing contents.
-     * @param pos       On input: an alignment field, if desired.
-     *                  On output: the offsets of the alignment field.
-     * @return          Reference to 'appendTo' parameter.
-     * @stable ICU 2.8
-    */
-    virtual UnicodeString& format(int64_t number,
-                                  UnicodeString& appendTo,
-                                  FieldPosition& pos) const;
-    /**
-     * Redeclared Format method.
-     * @param obj       The object to be formatted.
-     * @param appendTo  Output parameter to receive result.
-     *                  Result is appended to existing contents.
-     * @param status    Output parameter set to a failure error code
-     *                  when a failure occurs.
-     * @return          Reference to 'appendTo' parameter.
-     * @stable ICU 2.0
-     */
-    UnicodeString& format(const Formattable& obj,
-                          UnicodeString& appendTo,
-                          UErrorCode& status) const;
-
-   /**
-    * Return a long if possible (e.g. within range LONG_MAX,
-    * LONG_MAX], and with no decimals), otherwise a double.  If
-    * IntegerOnly is set, will stop at a decimal point (or equivalent;
-    * e.g. for rational numbers "1 2/3", will stop after the 1).
-    * <P>
-    * If no object can be parsed, index is unchanged, and NULL is
-    * returned.
-    * <P>
-    * This is a pure virtual which concrete subclasses must implement.
-    *
-    * @param text           The text to be parsed.
-    * @param result         Formattable to be set to the parse result.
-    *                       If parse fails, return contents are undefined.
-    * @param parsePosition  The position to start parsing at on input.
-    *                       On output, moved to after the last successfully
-    *                       parse character. On parse failure, does not change.
-    * @return               A Formattable object of numeric type.  The caller
-    *                       owns this an must delete it.  NULL on failure.
-    * @stable ICU 2.0
-    */
-    virtual void parse(const UnicodeString& text,
-                       Formattable& result,
-                       ParsePosition& parsePosition) const = 0;
-
-    /**
-     * Parse a string as a numeric value, and return a Formattable
-     * numeric object. This method parses integers only if IntegerOnly
-     * is set.
-     *
-     * @param text          The text to be parsed.
-     * @param result        Formattable to be set to the parse result.
-     *                      If parse fails, return contents are undefined.
-     * @param status        Output parameter set to a failure error code
-     *                      when a failure occurs.
-     * @return              A Formattable object of numeric type.  The caller
-     *                      owns this an must delete it.  NULL on failure.
-     * @see                 NumberFormat::isParseIntegerOnly
-     * @stable ICU 2.0
-     */
-    virtual void parse( const UnicodeString& text,
-                        Formattable& result,
-                        UErrorCode& status) const;
-
-    /**
-     * Parses text from the given string as a currency amount.  Unlike
-     * the parse() method, this method will attempt to parse a generic
-     * currency name, searching for a match of this object's locale's
-     * currency display names, or for a 3-letter ISO currency code.
-     * This method will fail if this format is not a currency format,
-     * that is, if it does not contain the currency pattern symbol
-     * (U+00A4) in its prefix or suffix.
-     *
-     * @param text the string to parse
-     * @param result output parameter to receive result. This will have
-     * its currency set to the parsed ISO currency code.
-     * @param pos input-output position; on input, the position within
-     * text to match; must have 0 <= pos.getIndex() < text.length();
-     * on output, the position after the last matched character. If
-     * the parse fails, the position in unchanged upon output.
-     * @return a reference to result
-     * @internal
-     */
-    virtual Formattable& parseCurrency(const UnicodeString& text,
-                                       Formattable& result,
-                                       ParsePosition& pos) const;
-
-    /**
-     * Return true if this format will parse numbers as integers
-     * only.  For example in the English locale, with ParseIntegerOnly
-     * true, the string "1234." would be parsed as the integer value
-     * 1234 and parsing would stop at the "." character.  Of course,
-     * the exact format accepted by the parse operation is locale
-     * dependant and determined by sub-classes of NumberFormat.
-     * @return    true if this format will parse numbers as integers
-     *            only.
-     * @stable ICU 2.0
-     */
-    UBool isParseIntegerOnly(void) const;
-
-    /**
-     * Sets whether or not numbers should be parsed as integers only.
-     * @param value    set True, this format will parse numbers as integers
-     *                 only.
-     * @see isParseIntegerOnly
-     * @stable ICU 2.0
-     */
-    virtual void setParseIntegerOnly(UBool value);
-	
-    /**
-     * Return whether or not strict parsing is in effect.
-     *
-     * @return <code>TRUE</code> if strict parsing is in effect,
-     *         <code>FALSE</code> otherwise.
-     *  @internal
-     */
-    UBool isParseStrict(void) const;
-	
-    /**
-     * Set whether or not strict parsing should be used.
-     *
-     * @param value <code>TRUE</code> if strict parsing should be used,
-     *              <code>FALSE</code> otherwise.
-     *  @internal
-     */
-    virtual void setParseStrict(UBool value);
-	
-    /**
-     * Returns the default number format for the current default
-     * locale.  The default format is one of the styles provided by
-     * the other factory methods: getNumberInstance,
-     * getCurrencyInstance or getPercentInstance.  Exactly which one
-     * is locale dependant.
-     * @stable ICU 2.0
-     */
-    static NumberFormat* U_EXPORT2 createInstance(UErrorCode&);
-
-    /**
-     * Returns the default number format for the specified locale.
-     * The default format is one of the styles provided by the other
-     * factory methods: getNumberInstance, getCurrencyInstance or
-     * getPercentInstance.  Exactly which one is locale dependant.
-     * @param inLocale    the given locale.
-     * @stable ICU 2.0
-     */
-    static NumberFormat* U_EXPORT2 createInstance(const Locale& inLocale,
-                                        UErrorCode&);
-
-    /**
-     * Returns a currency format for the current default locale.
-     * @stable ICU 2.0
-     */
-    static NumberFormat* U_EXPORT2 createCurrencyInstance(UErrorCode&);
-
-    /**
-     * Returns a currency format for the specified locale.
-     * @param inLocale    the given locale.
-     * @stable ICU 2.0
-     */
-    static NumberFormat* U_EXPORT2 createCurrencyInstance(const Locale& inLocale,
-                                                UErrorCode&);
-
-    /**
-     * Returns a percentage format for the current default locale.
-     * @stable ICU 2.0
-     */
-    static NumberFormat* U_EXPORT2 createPercentInstance(UErrorCode&);
-
-    /**
-     * Returns a percentage format for the specified locale.
-     * @param inLocale    the given locale.
-     * @stable ICU 2.0
-     */
-    static NumberFormat* U_EXPORT2 createPercentInstance(const Locale& inLocale,
-                                               UErrorCode&);
-
-    /**
-     * Returns a scientific format for the current default locale.
-     * @stable ICU 2.0
-     */
-    static NumberFormat* U_EXPORT2 createScientificInstance(UErrorCode&);
-
-    /**
-     * Returns a scientific format for the specified locale.
-     * @param inLocale    the given locale.
-     * @stable ICU 2.0
-     */
-    static NumberFormat* U_EXPORT2 createScientificInstance(const Locale& inLocale,
-                                                UErrorCode&);
-
-    /**
-     * Get the set of Locales for which NumberFormats are installed.
-     * @param count    Output param to receive the size of the locales
-     * @stable ICU 2.0
-     */
-    static const Locale* U_EXPORT2 getAvailableLocales(int32_t& count);
-
-#if !UCONFIG_NO_SERVICE
-    /**
-     * Register a new NumberFormatFactory.  The factory will be adopted.
-     * @param toAdopt the NumberFormatFactory instance to be adopted
-     * @param status the in/out status code, no special meanings are assigned
-     * @return a registry key that can be used to unregister this factory
-     * @stable ICU 2.6
-     */
-    static URegistryKey U_EXPORT2 registerFactory(NumberFormatFactory* toAdopt, UErrorCode& status);
-
-    /**
-     * Unregister a previously-registered NumberFormatFactory using the key returned from the
-     * register call.  Key becomes invalid after a successful call and should not be used again.
-     * The NumberFormatFactory corresponding to the key will be deleted.
-     * @param key the registry key returned by a previous call to registerFactory
-     * @param status the in/out status code, no special meanings are assigned
-     * @return TRUE if the factory for the key was successfully unregistered
-     * @stable ICU 2.6
-     */
-    static UBool U_EXPORT2 unregister(URegistryKey key, UErrorCode& status);
-
-    /**
-     * Return a StringEnumeration over the locales available at the time of the call,
-     * including registered locales.
-     * @return a StringEnumeration over the locales available at the time of the call
-     * @stable ICU 2.6
-     */
-    static StringEnumeration* U_EXPORT2 getAvailableLocales(void);
-#endif /* UCONFIG_NO_SERVICE */
-
-    /**
-     * Returns true if grouping is used in this format. For example,
-     * in the English locale, with grouping on, the number 1234567
-     * might be formatted as "1,234,567". The grouping separator as
-     * well as the size of each group is locale dependant and is
-     * determined by sub-classes of NumberFormat.
-     * @see setGroupingUsed
-     * @stable ICU 2.0
-     */
-    UBool isGroupingUsed(void) const;
-
-    /**
-     * Set whether or not grouping will be used in this format.
-     * @param newValue    True, grouping will be used in this format.
-     * @see getGroupingUsed
-     * @stable ICU 2.0
-     */
-    virtual void setGroupingUsed(UBool newValue);
-
-    /**
-     * Returns the maximum number of digits allowed in the integer portion of a
-     * number.
-     * @return     the maximum number of digits allowed in the integer portion of a
-     *             number.
-     * @see setMaximumIntegerDigits
-     * @stable ICU 2.0
-     */
-    int32_t getMaximumIntegerDigits(void) const;
-
-    /**
-     * Sets the maximum number of digits allowed in the integer portion of a
-     * number. maximumIntegerDigits must be >= minimumIntegerDigits.  If the
-     * new value for maximumIntegerDigits is less than the current value
-     * of minimumIntegerDigits, then minimumIntegerDigits will also be set to
-     * the new value.
-     *
-     * @param newValue    the new value for the maximum number of digits
-     *                    allowed in the integer portion of a number.
-     * @see getMaximumIntegerDigits
-     * @stable ICU 2.0
-     */
-    virtual void setMaximumIntegerDigits(int32_t newValue);
-
-    /**
-     * Returns the minimum number of digits allowed in the integer portion of a
-     * number.
-     * @return    the minimum number of digits allowed in the integer portion of a
-     *            number.
-     * @see setMinimumIntegerDigits
-     * @stable ICU 2.0
-     */
-    int32_t getMinimumIntegerDigits(void) const;
-
-    /**
-     * Sets the minimum number of digits allowed in the integer portion of a
-     * number. minimumIntegerDigits must be &lt;= maximumIntegerDigits.  If the
-     * new value for minimumIntegerDigits exceeds the current value
-     * of maximumIntegerDigits, then maximumIntegerDigits will also be set to
-     * the new value.
-     * @param newValue    the new value to be set.
-     * @see getMinimumIntegerDigits
-     * @stable ICU 2.0
-     */
-    virtual void setMinimumIntegerDigits(int32_t newValue);
-
-    /**
-     * Returns the maximum number of digits allowed in the fraction portion of a
-     * number.
-     * @return    the maximum number of digits allowed in the fraction portion of a
-     *            number.
-     * @see setMaximumFractionDigits
-     * @stable ICU 2.0
-     */
-    int32_t getMaximumFractionDigits(void) const;
-
-    /**
-     * Sets the maximum number of digits allowed in the fraction portion of a
-     * number. maximumFractionDigits must be >= minimumFractionDigits.  If the
-     * new value for maximumFractionDigits is less than the current value
-     * of minimumFractionDigits, then minimumFractionDigits will also be set to
-     * the new value.
-     * @param newValue    the new value to be set.
-     * @see getMaximumFractionDigits
-     * @stable ICU 2.0
-     */
-    virtual void setMaximumFractionDigits(int32_t newValue);
-
-    /**
-     * Returns the minimum number of digits allowed in the fraction portion of a
-     * number.
-     * @return    the minimum number of digits allowed in the fraction portion of a
-     *            number.
-     * @see setMinimumFractionDigits
-     * @stable ICU 2.0
-     */
-    int32_t getMinimumFractionDigits(void) const;
-
-    /**
-     * Sets the minimum number of digits allowed in the fraction portion of a
-     * number. minimumFractionDigits must be &lt;= maximumFractionDigits.   If the
-     * new value for minimumFractionDigits exceeds the current value
-     * of maximumFractionDigits, then maximumIntegerDigits will also be set to
-     * the new value
-     * @param newValue    the new value to be set.
-     * @see getMinimumFractionDigits
-     * @stable ICU 2.0
-     */
-    virtual void setMinimumFractionDigits(int32_t newValue);
-
-    /**
-     * Sets the currency used to display currency
-     * amounts.  This takes effect immediately, if this format is a
-     * currency format.  If this format is not a currency format, then
-     * the currency is used if and when this object becomes a
-     * currency format.
-     * @param theCurrency a 3-letter ISO code indicating new currency
-     * to use.  It need not be null-terminated.  May be the empty
-     * string or NULL to indicate no currency.
-     * @param ec input-output error code
-     * @stable ICU 3.0
-     */
-    virtual void setCurrency(const UChar* theCurrency, UErrorCode& ec);
-
-    /**
-     * Gets the currency used to display currency
-     * amounts.  This may be an empty string for some subclasses.
-     * @return a 3-letter null-terminated ISO code indicating
-     * the currency in use, or a pointer to the empty string.
-     * @stable ICU 2.6
-     */
-    const UChar* getCurrency() const;
-
-public:
-
-    /**
-     * Return the class ID for this class.  This is useful for
-     * comparing to a return value from getDynamicClassID(). Note that,
-     * because NumberFormat is an abstract base class, no fully constructed object
-     * will have the class ID returned by NumberFormat::getStaticClassID().
-     * @return The class ID for all objects of this class.
-     * @stable ICU 2.0
-     */
-    static UClassID U_EXPORT2 getStaticClassID(void);
-
-    /**
-     * Returns a unique class ID POLYMORPHICALLY.  Pure virtual override.
-     * This method is to implement a simple version of RTTI, since not all
-     * C++ compilers support genuine RTTI.  Polymorphic operator==() and
-     * clone() methods call this method.
-     * <P>
-     * @return The class ID for this object. All objects of a
-     * given class have the same class ID.  Objects of
-     * other classes have different class IDs.
-     * @stable ICU 2.0
-     */
-    virtual UClassID getDynamicClassID(void) const = 0;
-
-protected:
-
-    /**
-     * Default constructor for subclass use only.
-     * @stable ICU 2.0
-     */
-    NumberFormat();
-
-    /**
-     * Copy constructor.
-     * @stable ICU 2.0
-     */
-    NumberFormat(const NumberFormat&);
-
-    /**
-     * Assignment operator.
-     * @stable ICU 2.0
-     */
-    NumberFormat& operator=(const NumberFormat&);
-
-    /**
-     * Returns the currency in effect for this formatter.  Subclasses
-     * should override this method as needed.  Unlike getCurrency(),
-     * this method should never return "".
-     * @result output parameter for null-terminated result, which must
-     * have a capacity of at least 4
-     * @internal
-     */
-    virtual void getEffectiveCurrency(UChar* result, UErrorCode& ec) const;
-
-private:
-
-    enum EStyles {
-        kNumberStyle,
-        kCurrencyStyle,
-        kPercentStyle,
-        kScientificStyle,
-        kStyleCount // ALWAYS LAST ENUM: number of styles
-    };
-
-    /**
-     * Creates the specified decimal format style of the desired locale.
-     * Hook for service registration, uses makeInstance directly if no services
-     * registered.
-     * @param desiredLocale    the given locale.
-     * @param choice           the given style.
-     * @param success          Output param filled with success/failure status.
-     * @return                 A new NumberFormat instance.
-     */
-    static NumberFormat* U_EXPORT2 createInstance(const Locale& desiredLocale, EStyles choice, UErrorCode& success);
-
-    /**
-     * Creates the specified decimal format style of the desired locale.
-     * @param desiredLocale    the given locale.
-     * @param choice           the given style.
-     * @param success          Output param filled with success/failure status.
-     * @return                 A new NumberFormat instance.
-     */
-    static NumberFormat* makeInstance(const Locale& desiredLocale, EStyles choice, UErrorCode& success);
-
-    UBool      fGroupingUsed;
-    int32_t    fMaxIntegerDigits;
-    int32_t    fMinIntegerDigits;
-    int32_t    fMaxFractionDigits;
-    int32_t    fMinFractionDigits;
-    UBool      fParseIntegerOnly;
-    UBool      fParseStrict;
-
-    // ISO currency code
-    UChar      fCurrency[4];
-
-    friend class ICUNumberFormatFactory; // access to makeInstance, EStyles
-    friend class ICUNumberFormatService;
-};
-
-#if !UCONFIG_NO_SERVICE
-/**
- * A NumberFormatFactory is used to register new number formats.  The factory
- * should be able to create any of the predefined formats for each locale it
- * supports.  When registered, the locales it supports extend or override the
- * locale already supported by ICU.
- *
- * @stable ICU 2.6
- */
-class U_I18N_API NumberFormatFactory : public UObject {
-public:
-
-    /**
-     * Destructor
-     * @stable ICU 3.0
-     */
-    virtual ~NumberFormatFactory();
-
-    /**
-     * Return true if this factory will be visible.  Default is true.
-     * If not visible, the locales supported by this factory will not
-     * be listed by getAvailableLocales.
-     * @stable ICU 2.6
-     */
-    virtual UBool visible(void) const = 0;
-
-    /**
-     * Return the locale names directly supported by this factory.  The number of names
-     * is returned in count;
-     * @stable ICU 2.6
-     */
-    virtual const UnicodeString * getSupportedIDs(int32_t &count, UErrorCode& status) const = 0;
-
-    /**
-     * Return a number format of the appropriate type.  If the locale
-     * is not supported, return null.  If the locale is supported, but
-     * the type is not provided by this service, return null.  Otherwise
-     * return an appropriate instance of NumberFormat.
-     * @stable ICU 2.6
-     */
-    virtual NumberFormat* createFormat(const Locale& loc, UNumberFormatStyle formatType) = 0;
-};
-
-/**
- * A NumberFormatFactory that supports a single locale.  It can be visible or invisible.
- * @stable ICU 2.6
- */
-class U_I18N_API SimpleNumberFormatFactory : public NumberFormatFactory {
-protected:
-    /**
-     * True if the locale supported by this factory is visible.
-     * @stable ICU 2.6
-     */
-    const UBool _visible;
-
-    /**
-     * The locale supported by this factory, as a UnicodeString.
-     * @stable ICU 2.6
-     */
-    UnicodeString _id;
-
-public:
-    /**
-     * @stable ICU 2.6
-     */
-    SimpleNumberFormatFactory(const Locale& locale, UBool visible = TRUE);
-
-    /**
-     * @stable ICU 3.0
-     */
-    virtual ~SimpleNumberFormatFactory();
-
-    /**
-     * @stable ICU 2.6
-     */
-    virtual UBool visible(void) const;
-
-    /**
-     * @stable ICU 2.6
-     */
-    virtual const UnicodeString * getSupportedIDs(int32_t &count, UErrorCode& status) const;
-};
-#endif /* #if !UCONFIG_NO_SERVICE */
-
-// -------------------------------------
-
-inline UBool
-NumberFormat::isParseIntegerOnly() const
-{
-    return fParseIntegerOnly;
-}
-
-inline UBool
-NumberFormat::isParseStrict() const
-{
-	return fParseStrict;
-}
-
-inline UnicodeString&
-NumberFormat::format(const Formattable& obj,
-                     UnicodeString& appendTo,
-                     UErrorCode& status) const {
-    return Format::format(obj, appendTo, status);
-}
-
-U_NAMESPACE_END
-
-#endif /* #if !UCONFIG_NO_FORMATTING */
-
-#endif // _NUMFMT
-//eof

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/parseerr.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/parseerr.h b/apps/couch_collate/platform/osx/icu/unicode/parseerr.h
deleted file mode 100644
index 44ff008..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/parseerr.h
+++ /dev/null
@@ -1,92 +0,0 @@
-/*
-**********************************************************************
-*   Copyright (C) 1999-2005, International Business Machines
-*   Corporation and others.  All Rights Reserved.
-**********************************************************************
-*   Date        Name        Description
-*   03/14/00    aliu        Creation.
-*   06/27/00    aliu        Change from C++ class to C struct
-**********************************************************************
-*/
-#ifndef PARSEERR_H
-#define PARSEERR_H
-
-#include "unicode/utypes.h"
-
-
-/**
- * \file
- * \brief C API: Parse Error Information
- */
-/**
- * The capacity of the context strings in UParseError.
- * @stable ICU 2.0
- */ 
-enum { U_PARSE_CONTEXT_LEN = 16 };
-
-/**
- * A UParseError struct is used to returned detailed information about
- * parsing errors.  It is used by ICU parsing engines that parse long
- * rules, patterns, or programs, where the text being parsed is long
- * enough that more information than a UErrorCode is needed to
- * localize the error.
- *
- * <p>The line, offset, and context fields are optional; parsing
- * engines may choose not to use to use them.
- *
- * <p>The preContext and postContext strings include some part of the
- * context surrounding the error.  If the source text is "let for=7"
- * and "for" is the error (e.g., because it is a reserved word), then
- * some examples of what a parser might produce are the following:
- *
- * <pre>
- * preContext   postContext
- * ""           ""            The parser does not support context
- * "let "       "=7"          Pre- and post-context only
- * "let "       "for=7"       Pre- and post-context and error text
- * ""           "for"         Error text only
- * </pre>
- *
- * <p>Examples of engines which use UParseError (or may use it in the
- * future) are Transliterator, RuleBasedBreakIterator, and
- * RegexPattern.
- * 
- * @stable ICU 2.0
- */
-typedef struct UParseError {
-
-    /**
-     * The line on which the error occured.  If the parser uses this
-     * field, it sets it to the line number of the source text line on
-     * which the error appears, which will be be a value >= 1.  If the
-     * parse does not support line numbers, the value will be <= 0.
-     * @stable ICU 2.0
-     */
-    int32_t        line;
-
-    /**
-     * The character offset to the error.  If the line field is >= 1,
-     * then this is the offset from the start of the line.  Otherwise,
-     * this is the offset from the start of the text.  If the parser
-     * does not support this field, it will have a value < 0.
-     * @stable ICU 2.0
-     */
-    int32_t        offset;
-
-    /**
-     * Textual context before the error.  Null-terminated.  The empty
-     * string if not supported by parser.
-     * @stable ICU 2.0   
-     */
-    UChar          preContext[U_PARSE_CONTEXT_LEN];
-
-    /**
-     * The error itself and/or textual context after the error.
-     * Null-terminated.  The empty string if not supported by parser.
-     * @stable ICU 2.0   
-     */
-    UChar          postContext[U_PARSE_CONTEXT_LEN];
-
-} UParseError;
-
-#endif

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/parsepos.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/parsepos.h b/apps/couch_collate/platform/osx/icu/unicode/parsepos.h
deleted file mode 100644
index cdf49e0..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/parsepos.h
+++ /dev/null
@@ -1,230 +0,0 @@
-/*
-* Copyright (C) 1997-2005, International Business Machines Corporation and others. All Rights Reserved.
-*******************************************************************************
-*
-* File PARSEPOS.H
-*
-* Modification History:
-*
-*   Date        Name        Description
-*   07/09/97    helena      Converted from java.
-*   07/17/98    stephen     Added errorIndex support.
-*   05/11/99    stephen     Cleaned up.
-*******************************************************************************
-*/
-
-#ifndef PARSEPOS_H
-#define PARSEPOS_H
-
-#include "unicode/utypes.h"
-#include "unicode/uobject.h"
-
- 
-U_NAMESPACE_BEGIN
-
-/**
- * \file
- * \brief C++ API: Canonical Iterator
- */
-/** 
- * <code>ParsePosition</code> is a simple class used by <code>Format</code>
- * and its subclasses to keep track of the current position during parsing.
- * The <code>parseObject</code> method in the various <code>Format</code>
- * classes requires a <code>ParsePosition</code> object as an argument.
- *
- * <p>
- * By design, as you parse through a string with different formats,
- * you can use the same <code>ParsePosition</code>, since the index parameter
- * records the current position.
- *
- * The ParsePosition class is not suitable for subclassing.
- *
- * @version     1.3 10/30/97
- * @author      Mark Davis, Helena Shih
- * @see         java.text.Format
- */
-
-class U_COMMON_API ParsePosition : public UObject {
-public:
-    /**
-     * Default constructor, the index starts with 0 as default.
-     * @stable ICU 2.0
-     */
-    ParsePosition()
-        : UObject(),
-        index(0),
-        errorIndex(-1)
-      {}
-
-    /**
-     * Create a new ParsePosition with the given initial index.
-     * @param newIndex the new text offset.
-     * @stable ICU 2.0
-     */
-    ParsePosition(int32_t newIndex)
-        : UObject(),
-        index(newIndex),
-        errorIndex(-1)
-      {}
-
-    /**
-     * Copy constructor
-     * @param copy the object to be copied from.
-     * @stable ICU 2.0
-     */
-    ParsePosition(const ParsePosition& copy)
-        : UObject(copy),
-        index(copy.index),
-        errorIndex(copy.errorIndex)
-      {}
-
-    /**
-     * Destructor
-     * @stable ICU 2.0
-     */
-    virtual ~ParsePosition();
-
-    /**
-     * Assignment operator
-     * @stable ICU 2.0
-     */
-    ParsePosition&      operator=(const ParsePosition& copy);
-
-    /**
-     * Equality operator.
-     * @return TRUE if the two parse positions are equal, FALSE otherwise.
-     * @stable ICU 2.0
-     */
-    UBool              operator==(const ParsePosition& that) const;
-
-    /**
-     * Equality operator.
-     * @return TRUE if the two parse positions are not equal, FALSE otherwise.
-     * @stable ICU 2.0
-     */
-    UBool              operator!=(const ParsePosition& that) const;
-
-    /**
-     * Clone this object.
-     * Clones can be used concurrently in multiple threads.
-     * If an error occurs, then NULL is returned.
-     * The caller must delete the clone.
-     *
-     * @return a clone of this object
-     *
-     * @see getDynamicClassID
-     * @stable ICU 2.8
-     */
-    ParsePosition *clone() const;
-
-    /**
-     * Retrieve the current parse position.  On input to a parse method, this
-     * is the index of the character at which parsing will begin; on output, it
-     * is the index of the character following the last character parsed.
-     * @return the current index.
-     * @stable ICU 2.0
-     */
-    int32_t getIndex(void) const;
-
-    /**
-     * Set the current parse position.
-     * @param index the new index.
-     * @stable ICU 2.0
-     */
-    void setIndex(int32_t index);
-
-    /**
-     * Set the index at which a parse error occurred.  Formatters
-     * should set this before returning an error code from their
-     * parseObject method.  The default value is -1 if this is not
-     * set.
-     * @stable ICU 2.0
-     */
-    void setErrorIndex(int32_t ei);
-
-    /**
-     * Retrieve the index at which an error occurred, or -1 if the
-     * error index has not been set.
-     * @stable ICU 2.0
-     */
-    int32_t getErrorIndex(void) const;
-
-    /**
-     * ICU "poor man's RTTI", returns a UClassID for this class.
-     *
-     * @stable ICU 2.2
-     */
-    static UClassID U_EXPORT2 getStaticClassID();
-
-    /**
-     * ICU "poor man's RTTI", returns a UClassID for the actual class.
-     *
-     * @stable ICU 2.2
-     */
-    virtual UClassID getDynamicClassID() const;
-
-private:
-    /**
-     * Input: the place you start parsing.
-     * <br>Output: position where the parse stopped.
-     * This is designed to be used serially,
-     * with each call setting index up for the next one.
-     */
-    int32_t index;
-
-    /**
-     * The index at which a parse error occurred.
-     */
-    int32_t errorIndex;
-
-};
-
-inline ParsePosition&
-ParsePosition::operator=(const ParsePosition& copy)
-{
-  index = copy.index;
-  errorIndex = copy.errorIndex;
-  return *this;
-}
-
-inline UBool
-ParsePosition::operator==(const ParsePosition& copy) const
-{
-  if(index != copy.index || errorIndex != copy.errorIndex)
-  return FALSE;
-  else
-  return TRUE;
-}
-
-inline UBool
-ParsePosition::operator!=(const ParsePosition& copy) const
-{
-  return !operator==(copy);
-}
-
-inline int32_t
-ParsePosition::getIndex() const
-{
-  return index;
-}
-
-inline void
-ParsePosition::setIndex(int32_t offset)
-{
-  this->index = offset;
-}
-
-inline int32_t
-ParsePosition::getErrorIndex() const
-{
-  return errorIndex;
-}
-
-inline void
-ParsePosition::setErrorIndex(int32_t ei)
-{
-  this->errorIndex = ei;
-}
-U_NAMESPACE_END
-
-#endif

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/platform.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/platform.h b/apps/couch_collate/platform/osx/icu/unicode/platform.h
deleted file mode 100644
index 15ccbf5..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/platform.h
+++ /dev/null
@@ -1,316 +0,0 @@
-/*
-******************************************************************************
-*
-*   Copyright (C) 1997-2007, International Business Machines
-*   Corporation and others.  All Rights Reserved.
-*
-******************************************************************************
-*
-*  FILE NAME : platform.h
-*
-*   Date        Name        Description
-*   05/13/98    nos         Creation (content moved here from ptypes.h).
-*   03/02/99    stephen     Added AS400 support.
-*   03/30/99    stephen     Added Linux support.
-*   04/13/99    stephen     Reworked for autoconf.
-******************************************************************************
-*/
-
-/**
- * \file 
- * \brief Basic types for the platform 
- */
-
-/* Define the platform we're on. */
-#ifndef U_DARWIN
-#define U_DARWIN
-#endif
-
-/* Define whether inttypes.h is available */
-#ifndef U_HAVE_INTTYPES_H
-#define U_HAVE_INTTYPES_H 1
-#endif
-
-/*
- * Define what support for C++ streams is available.
- *     If U_IOSTREAM_SOURCE is set to 199711, then <iostream> is available
- * (1997711 is the date the ISO/IEC C++ FDIS was published), and then
- * one should qualify streams using the std namespace in ICU header
- * files.
- *     If U_IOSTREAM_SOURCE is set to 198506, then <iostream.h> is
- * available instead (198506 is the date when Stroustrup published
- * "An Extensible I/O Facility for C++" at the summer USENIX conference).
- *     If U_IOSTREAM_SOURCE is 0, then C++ streams are not available and
- * support for them will be silently suppressed in ICU.
- *
- */
-
-#ifndef U_IOSTREAM_SOURCE
-#define U_IOSTREAM_SOURCE 199711
-#endif
-
-/* Determines whether specific types are available */
-#ifndef U_HAVE_INT8_T
-#define U_HAVE_INT8_T 1
-#endif
-
-#ifndef U_HAVE_UINT8_T
-#define U_HAVE_UINT8_T 1
-#endif
-
-#ifndef U_HAVE_INT16_T
-#define U_HAVE_INT16_T 1
-#endif
-
-#ifndef U_HAVE_UINT16_T
-#define U_HAVE_UINT16_T 1
-#endif
-
-#ifndef U_HAVE_INT32_T
-#define U_HAVE_INT32_T 1
-#endif
-
-#ifndef U_HAVE_UINT32_T
-#define U_HAVE_UINT32_T 1
-#endif
-
-#ifndef U_HAVE_INT64_T
-#define U_HAVE_INT64_T 1
-#endif
-
-#ifndef U_HAVE_UINT64_T
-#define U_HAVE_UINT64_T 1
-#endif
-
-/*===========================================================================*/
-/* Generic data types                                                        */
-/*===========================================================================*/
-
-#include <sys/types.h>
-
-/* If your platform does not have the <inttypes.h> header, you may
-   need to edit the typedefs below. */
-#if U_HAVE_INTTYPES_H
-
-/* autoconf 2.13 sometimes can't properly find the data types in <inttypes.h> */
-/* os/390 needs <inttypes.h>, but it doesn't have int8_t, and it sometimes */
-/* doesn't have uint8_t depending on the OS version. */
-/* So we have this work around. */
-#ifdef OS390
-/* The features header is needed to get (u)int64_t sometimes. */
-#include <features.h>
-#if ! U_HAVE_INT8_T
-typedef signed char int8_t;
-#endif
-#if !defined(__uint8_t)
-#define __uint8_t 1
-typedef unsigned char uint8_t;
-#endif
-#endif /* OS390 */
-
-#include <inttypes.h>
-
-#else /* U_HAVE_INTTYPES_H */
-
-#if ! U_HAVE_INT8_T
-typedef signed char int8_t;
-#endif
-
-#if ! U_HAVE_UINT8_T
-typedef unsigned char uint8_t;
-#endif
-
-#if ! U_HAVE_INT16_T
-typedef signed short int16_t;
-#endif
-
-#if ! U_HAVE_UINT16_T
-typedef unsigned short uint16_t;
-#endif
-
-#if ! U_HAVE_INT32_T
-typedef signed int int32_t;
-#endif
-
-#if ! U_HAVE_UINT32_T
-typedef unsigned int uint32_t;
-#endif
-
-#if ! U_HAVE_INT64_T
-    typedef signed long long int64_t;
-/* else we may not have a 64-bit type */
-#endif
-
-#if ! U_HAVE_UINT64_T
-    typedef unsigned long long uint64_t;
-/* else we may not have a 64-bit type */
-#endif
-
-#endif
-
-/*===========================================================================*/
-/* Compiler and environment features                                         */
-/*===========================================================================*/
-
-/* Define whether namespace is supported */
-#ifndef U_HAVE_NAMESPACE
-#define U_HAVE_NAMESPACE 1
-#endif
-
-/* Determines the endianness of the platform
-   It's done this way in case multiple architectures are being built at once.
-   For example, Darwin supports fat binaries, which can be both PPC and x86 based. */
-#if defined(BYTE_ORDER) && defined(BIG_ENDIAN)
-#define U_IS_BIG_ENDIAN (BYTE_ORDER == BIG_ENDIAN)
-#else
-#define U_IS_BIG_ENDIAN 0
-#endif
-
-/* 1 or 0 to enable or disable threads.  If undefined, default is: enable threads. */
-#define ICU_USE_THREADS 1
-
-/* On strong memory model CPUs (e.g. x86 CPUs), we use a safe & quick double check lock. */
-#if defined(__GNUC__) && (defined(__i386__) || defined(__x86_64__))
-#define UMTX_STRONG_MEMORY_MODEL 1
-#endif
-
-#ifndef U_DEBUG
-#define U_DEBUG 0
-#endif
-
-#ifndef U_RELEASE
-#define U_RELEASE 1
-#endif
-
-/* Determine whether to disable renaming or not. This overrides the
-   setting in umachine.h which is for all platforms. */
-#ifndef U_DISABLE_RENAMING
-#define U_DISABLE_RENAMING 1
-#endif
-
-/* Determine whether to override new and delete. */
-#ifndef U_OVERRIDE_CXX_ALLOCATION
-#define U_OVERRIDE_CXX_ALLOCATION 1
-#endif
-/* Determine whether to override placement new and delete for STL. */
-#ifndef U_HAVE_PLACEMENT_NEW
-#define U_HAVE_PLACEMENT_NEW 1
-#endif
-
-/* Determine whether to enable tracing. */
-#ifndef U_ENABLE_TRACING
-#define U_ENABLE_TRACING 0
-#endif
-
-/* Do we allow ICU users to use the draft APIs by default? */
-#ifndef U_DEFAULT_SHOW_DRAFT
-#define U_DEFAULT_SHOW_DRAFT 1
-#endif
-
-/* Define the library suffix in a C syntax. */
-#define U_HAVE_LIB_SUFFIX 0
-#define U_LIB_SUFFIX_C_NAME 
-#define U_LIB_SUFFIX_C_NAME_STRING ""
-
-/*===========================================================================*/
-/* Character data types                                                      */
-/*===========================================================================*/
-
-#if ((defined(OS390) && (!defined(__CHARSET_LIB) || !__CHARSET_LIB))) || defined(OS400)
-#   define U_CHARSET_FAMILY 1
-#endif
-
-/*===========================================================================*/
-/* Information about wchar support                                           */
-/*===========================================================================*/
-
-#define U_HAVE_WCHAR_H      1
-#define U_SIZEOF_WCHAR_T    4
-
-#define U_HAVE_WCSCPY       1
-
-/**
- * \def U_DECLARE_UTF16
- * Do not use this macro. Use the UNICODE_STRING or U_STRING_DECL macros
- * instead.
- * @internal
- */
-#if 1 || defined(U_CHECK_UTF16_STRING)
-#if (defined(__xlC__) && defined(__IBM_UTF_LITERAL) && U_SIZEOF_WCHAR_T != 2) \
-    || (defined(__HP_aCC) && __HP_aCC >= 035000) \
-    || (defined(__HP_cc) && __HP_cc >= 111106)
-#define U_DECLARE_UTF16(string) u ## string
-#elif (defined(__SUNPRO_CC) && __SUNPRO_CC >= 0x550)
-/* || (defined(__SUNPRO_C) && __SUNPRO_C >= 0x580) */
-/* Sun's C compiler has issues with this notation, and it's unreliable. */
-#define U_DECLARE_UTF16(string) U ## string
-#elif U_SIZEOF_WCHAR_T == 2 \
-    && (U_CHARSET_FAMILY == 0 || ((defined(OS390) || defined(OS400)) && defined(__UCS2__)))
-#define U_DECLARE_UTF16(string) L ## string
-#endif
-#endif
-
-/*===========================================================================*/
-/* Information about POSIX support                                           */
-/*===========================================================================*/
-
-#define U_HAVE_NL_LANGINFO_CODESET  1
-#define U_NL_LANGINFO_CODESET       CODESET
-
-#if 1
-#define U_TZSET         tzset
-#endif
-#if 1
-#define U_TIMEZONE      timezone
-#endif
-#if 1
-#define U_TZNAME        tzname
-#endif
-
-#define U_HAVE_MMAP     1
-#define U_HAVE_POPEN    1
-
-/*===========================================================================*/
-/* Symbol import-export control                                              */
-/*===========================================================================*/
-
-#if 1
-#define U_EXPORT __attribute__((visibility("default")))
-#elif (defined(__SUNPRO_CC) && __SUNPRO_CC >= 0x550) \
-   || (defined(__SUNPRO_C) && __SUNPRO_C >= 0x550) 
-#define U_EXPORT __global
-/*#elif defined(__HP_aCC) || defined(__HP_cc)
-#define U_EXPORT __declspec(dllexport)*/
-#else
-#define U_EXPORT
-#endif
-
-/* U_CALLCONV is releated to U_EXPORT2 */
-#define U_EXPORT2
-
-/* cygwin needs to export/import data */
-#ifdef U_CYGWIN
-#define U_IMPORT __declspec(dllimport)
-#else
-#define U_IMPORT 
-#endif
-
-/*===========================================================================*/
-/* Code alignment and C function inlining                                    */
-/*===========================================================================*/
-
-#ifndef U_INLINE
-#   ifdef __cplusplus
-#       define U_INLINE inline
-#   else
-#       define U_INLINE inline
-#   endif
-#endif
-
-#define U_ALIGN_CODE(n) 
-
-/*===========================================================================*/
-/* Programs used by ICU code                                                 */
-/*===========================================================================*/
-
-#define U_MAKE  "/usr/bin/gnumake"

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/plurfmt.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/plurfmt.h b/apps/couch_collate/platform/osx/icu/unicode/plurfmt.h
deleted file mode 100644
index 445db39..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/plurfmt.h
+++ /dev/null
@@ -1,541 +0,0 @@
-/*
-*******************************************************************************
-* Copyright (C) 2007-2008, International Business Machines Corporation and
-* others. All Rights Reserved.
-*******************************************************************************
-*
-
-* File PLURFMT.H
-*
-* Modification History:*
-*   Date        Name        Description
-*
-********************************************************************************
-*/
-
-#ifndef PLURFMT
-#define PLURFMT
-
-#include "unicode/utypes.h"
-
-/**
- * \file
- * \brief C++ API: PluralFormat object
- */
-
-#if !UCONFIG_NO_FORMATTING
-
-#include "unicode/numfmt.h"
-#include "unicode/plurrule.h"
-
-U_NAMESPACE_BEGIN
-
-class Hashtable;
-
-/**
- * <p>
- * <code>PluralFormat</code> supports the creation of internationalized
- * messages with plural inflection. It is based on <i>plural
- * selection</i>, i.e. the caller specifies messages for each
- * plural case that can appear in the users language and the
- * <code>PluralFormat</code> selects the appropriate message based on
- * the number.
- * </p>
- * <h4>The Problem of Plural Forms in Internationalized Messages</h4>
- * <p>
- * Different languages have different ways to inflect
- * plurals. Creating internationalized messages that include plural
- * forms is only feasible when the framework is able to handle plural
- * forms of <i>all</i> languages correctly. <code>ChoiceFormat</code>
- * doesn't handle this well, because it attaches a number interval to
- * each message and selects the message whose interval contains a
- * given number. This can only handle a finite number of
- * intervals. But in some languages, like Polish, one plural case
- * applies to infinitely many intervals (e.g., paucal applies to
- * numbers ending with 2, 3, or 4 except those ending with 12, 13, or
- * 14). Thus <code>ChoiceFormat</code> is not adequate.
- * </p><p>
- * <code>PluralFormat</code> deals with this by breaking the problem
- * into two parts:
- * <ul>
- * <li>It uses <code>PluralRules</code> that can define more complex
- *     conditions for a plural case than just a single interval. These plural
- *     rules define both what plural cases exist in a language, and to
- *     which numbers these cases apply.
- * <li>It provides predefined plural rules for many locales. Thus, the programmer
- *     need not worry about the plural cases of a language. On the flip side,
- *     the localizer does not have to specify the plural cases; he can simply
- *     use the predefined keywords. The whole plural formatting of messages can
- *     be done using localized patterns from resource bundles.
- * </ul>
- * </p>
- * <h4>Usage of <code>PluralFormat</code></h4>
- * <p>
- * This discussion assumes that you use <code>PluralFormat</code> with
- * a predefined set of plural rules. You can create one using one of
- * the constructors that takes a <code>locale</code> object. To
- * specify the message pattern, you can either pass it to the
- * constructor or set it explicitly using the
- * <code>applyPattern()</code> method. The <code>format()</code>
- * method takes a number object and selects the message of the
- * matching plural case. This message will be returned.
- * </p>
- * <h5>Patterns and Their Interpretation</h5>
- * <p>
- * The pattern text defines the message output for each plural case of the
- * used locale. The pattern is a sequence of
- * <code><i>caseKeyword</i>{<i>message</i>}</code> clauses, separated by white
- * space characters. Each clause assigns the message <code><i>message</i></code>
- * to the plural case identified by <code><i>caseKeyword</i></code>.
- * </p><p>
- * You always have to define a message text for the default plural case
- * "<code>other</code>" which is contained in every rule set. If the plural
- * rules of the <code>PluralFormat</code> object do not contain a plural case
- * identified by <code><i>caseKeyword</i></code>, U_DEFAULT_KEYWORD_MISSING
- * will be set to status.
- * If you do not specify a message text for a particular plural case, the
- * message text of the plural case "<code>other</code>" gets assigned to this
- * plural case. If you specify more than one message for the same plural case,
- * U_DUPLICATE_KEYWORD will be set to status.
- * <br/>
- * Spaces between <code><i>caseKeyword</i></code> and
- * <code><i>message</i></code>  will be ignored; spaces within
- * <code><i>message</i></code> will be preserved.
- * </p><p>
- * The message text for a particular plural case may contain other message
- * format patterns. <code>PluralFormat</code> preserves these so that you
- * can use the strings produced by <code>PluralFormat</code> with other
- * formatters. If you are using <code>PluralFormat</code> inside a
- * <code>MessageFormat</code> pattern, <code>MessageFormat</code> will
- * automatically evaluate the resulting format pattern.<br/>
- * Thus, curly braces (<code>{</code>, <code>}</code>) are <i>only</i> allowed
- * in message texts to define a nested format pattern.<br/>
- * The pound sign (<code>#</code>) will be interpreted as the number placeholder
- * in the message text, if it is not contained in curly braces (to preserve
- * <code>NumberFormat</code> patterns). <code>PluralFormat</code> will
- * replace each of those pound signs by the number passed to the
- * <code>format()</code> method. It will be formatted using a
- * <code>NumberFormat</code> for the <code>PluralFormat</code>'s locale. If you
- * need special number formatting, you have to explicitly specify a
- * <code>NumberFormat</code> for the <code>PluralFormat</code> to use.
- * </p>
- * Example
- * <pre>
- * UErrorCode status = U_ZERO_ERROR;
- * MessageFormat* msgFmt = new MessageFormat(UnicodeString("{0, plural,
- *   one{{0, number, C''est #,##0.0#  fichier}} other {Ce sont # fichiers}} dans la liste."),
- *   Locale("fr"), status);
- * if (U_FAILURE(status)) {
- *     return;
- * }
- * Formattable args1[] = {(int32_t)0};
- * Formattable args2[] = {(int32_t)3};
- * FieldPosition ignore(FieldPosition::DONT_CARE);
- * UnicodeString result;
- * msgFmt->format(args1, 1, result, ignore, status);
- * cout << result << endl;
- * result.remove();
- * msgFmt->format(args2, 1, result, ignore, status);
- * cout << result << endl;
- * </pre>
- * Produces the output:<br/>
- * <code>C'est 0,0 fichier dans la liste.</code><br/>
- * <code>Ce sont 3 fichiers dans la liste."</code>
- * <p>
- * <strong>Note:</strong><br/>
- *   Currently <code>PluralFormat</code>
- *   does not make use of quotes like <code>MessageFormat</code>.
- *   If you use plural format strings with <code>MessageFormat</code> and want
- *   to use a quote sign "<code>'</code>", you have to write "<code>''</code>".
- *   <code>MessageFormat</code> unquotes this pattern and  passes the unquoted
- *   pattern to <code>PluralFormat</code>. It's a bit trickier if you use
- *   nested formats that do quoting. In the example above, we wanted to insert
- *   "<code>'</code>" in the number format pattern. Since
- *   <code>NumberFormat</code> supports quotes, we had to insert
- *   "<code>''</code>". But since <code>MessageFormat</code> unquotes the
- *   pattern before it gets passed to <code>PluralFormat</code>, we have to
- *   double these quotes, i.e. write "<code>''''</code>".
- * </p>
- * <h4>Defining Custom Plural Rules</h4>
- * <p>If you need to use <code>PluralFormat</code> with custom rules, you can
- * create a <code>PluralRules</code> object and pass it to
- * <code>PluralFormat</code>'s constructor. If you also specify a locale in this
- * constructor, this locale will be used to format the number in the message
- * texts.
- * </p><p>
- * For more information about <code>PluralRules</code>, see
- * {@link PluralRules}.
- * </p>
- *
- * ported from Java
- * @draft ICU 4.0
- */
-
-class U_I18N_API PluralFormat : public Format {
-public:
-
-    /**
-     * Creates a new <code>PluralFormat</code> for the default locale.
-     * This locale will be used to get the set of plural rules and for standard
-     * number formatting.
-     * @param status  output param set to success/failure code on exit, which
-     *                must not indicate a failure before the function call.
-     * @draft ICU 4.0
-     */
-    PluralFormat(UErrorCode& status);
-
-    /**
-     * Creates a new <code>PluralFormat</code> for a given locale.
-     * @param locale the <code>PluralFormat</code> will be configured with
-     *               rules for this locale. This locale will also be used for
-     *               standard number formatting.
-     * @param status output param set to success/failure code on exit, which
-     *               must not indicate a failure before the function call.
-     * @draft ICU 4.0
-     */
-    PluralFormat(const Locale& locale, UErrorCode& status);
-
-    /**
-     * Creates a new <code>PluralFormat</code> for a given set of rules.
-     * The standard number formatting will be done using the default locale.
-     * @param rules   defines the behavior of the <code>PluralFormat</code>
-     *                object.
-     * @param status  output param set to success/failure code on exit, which
-     *                must not indicate a failure before the function call.
-     * @draft ICU 4.0
-     */
-    PluralFormat(const PluralRules& rules, UErrorCode& status);
-
-    /**
-     * Creates a new <code>PluralFormat</code> for a given set of rules.
-     * The standard number formatting will be done using the given locale.
-     * @param locale  the default number formatting will be done using this
-     *                locale.
-     * @param rules   defines the behavior of the <code>PluralFormat</code>
-     *                object.
-     * @param status  output param set to success/failure code on exit, which
-     *                must not indicate a failure before the function call.
-     * @draft ICU 4.0
-     */
-    PluralFormat(const Locale& locale, const PluralRules& rules, UErrorCode& status);
-
-    /**
-     * Creates a new <code>PluralFormat</code> for a given pattern string.
-     * The default locale will be used to get the set of plural rules and for
-     * standard number formatting.
-     * @param  pattern the pattern for this <code>PluralFormat</code>.
-     *                 errors are returned to status if the pattern is invalid.
-     * @param status   output param set to success/failure code on exit, which
-     *                 must not indicate a failure before the function call.
-     * @draft ICU 4.0
-     */
-    PluralFormat(const UnicodeString& pattern, UErrorCode& status);
-
-    /**
-     * Creates a new <code>PluralFormat</code> for a given pattern string and
-     * locale.
-     * The locale will be used to get the set of plural rules and for
-     * standard number formatting.
-     * @param locale   the <code>PluralFormat</code> will be configured with
-     *                 rules for this locale. This locale will also be used for
-     *                 standard number formatting.
-     * @param pattern  the pattern for this <code>PluralFormat</code>.
-     *                 errors are returned to status if the pattern is invalid.
-     * @param status   output param set to success/failure code on exit, which
-     *                 must not indicate a failure before the function call.
-     * @draft ICU 4.0
-     */
-    PluralFormat(const Locale& locale, const UnicodeString& pattern, UErrorCode& status);
-
-    /**
-     * Creates a new <code>PluralFormat</code> for a given set of rules, a
-     * pattern and a locale.
-     * @param rules    defines the behavior of the <code>PluralFormat</code>
-     *                 object.
-     * @param pattern  the pattern for this <code>PluralFormat</code>.
-     *                 errors are returned to status if the pattern is invalid.
-     * @param status   output param set to success/failure code on exit, which
-     *                 must not indicate a failure before the function call.
-     * @draft ICU 4.0
-     */
-    PluralFormat(const PluralRules& rules,
-                 const UnicodeString& pattern,
-                 UErrorCode& status);
-
-    /**
-     * Creates a new <code>PluralFormat</code> for a given set of rules, a
-     * pattern and a locale.
-     * @param locale  the <code>PluralFormat</code> will be configured with
-     *                rules for this locale. This locale will also be used for
-     *                standard number formatting.
-     * @param rules   defines the behavior of the <code>PluralFormat</code>
-     *                object.
-     * @param pattern the pattern for this <code>PluralFormat</code>.
-     *                errors are returned to status if the pattern is invalid.
-     * @param status  output param set to success/failure code on exit, which
-     *                must not indicate a failure before the function call.
-     * @draft ICU 4.0
-     */
-    PluralFormat(const Locale& locale,
-                 const PluralRules& rules,
-                 const UnicodeString& pattern,
-                 UErrorCode& status);
-
-    /**
-      * copy constructor.
-      * @draft ICU 4.0
-      */
-    PluralFormat(const PluralFormat& other);
-
-    /**
-     * Destructor.
-     * @draft ICU 4.0
-     */
-    virtual ~PluralFormat();
-
-    /**
-     * Sets the pattern used by this plural format.
-     * The method parses the pattern and creates a map of format strings
-     * for the plural rules.
-     * Patterns and their interpretation are specified in the class description.
-     *
-     * @param pattern the pattern for this plural format
-     *                errors are returned to status if the pattern is invalid.
-     * @param status  output param set to success/failure code on exit, which
-     *                must not indicate a failure before the function call.
-     * @draft ICU 4.0
-     */
-    void applyPattern(const UnicodeString& pattern, UErrorCode& status);
-
-    /**
-     * Formats a plural message for a given number.
-     *
-     * @param number  a number for which the plural message should be formatted
-     *                for. If no pattern has been applied to this
-     *                <code>PluralFormat</code> object yet, the formatted number
-     *                will be returned.
-     * @param status  output param set to success/failure code on exit, which
-     *                must not indicate a failure before the function call.
-     * @return        the string containing the formatted plural message.
-     * @draft ICU 4.0
-     */
-    UnicodeString format(int32_t number, UErrorCode& status) const;   
-    
-    /**
-     * Formats a plural message for a given number.
-     *
-     * @param number  a number for which the plural message should be formatted
-     *                for. If no pattern has been applied to this
-     *                <code>PluralFormat</code> object yet, the formatted number
-     *                will be returned.
-     * @param status  output param set to success/failure code on exit, which
-     *                must not indicate a failure before the function call.
-     * @return        the string containing the formatted plural message.
-     * @draft ICU 4.0
-     */
-    UnicodeString format(double number, UErrorCode& status) const;
-
-    /**
-     * Formats a plural message for a given number.
-     *
-     * @param number   a number for which the plural message should be formatted
-     *                 for. If no pattern has been applied to this
-     *                 <code>PluralFormat</code> object yet, the formatted number
-     *                 will be returned.
-     * @param appendTo output parameter to receive result.
-     *                 result is appended to existing contents.
-     * @param pos      On input: an alignment field, if desired.
-     *                 On output: the offsets of the alignment field.
-     * @param status   output param set to success/failure code on exit, which
-     *                 must not indicate a failure before the function call.
-     * @return         the string containing the formatted plural message.
-     * @draft ICU 4.0
-     */
-    UnicodeString& format(int32_t number,
-                          UnicodeString& appendTo,
-                          FieldPosition& pos,
-                          UErrorCode& status) const;
-    
-    /**
-     * Formats a plural message for a given number.
-     *
-     * @param number   a number for which the plural message should be formatted
-     *                 for. If no pattern has been applied to this
-     *                 <code>PluralFormat</code> object yet, the formatted number
-     *                 will be returned.
-     * @param appendTo output parameter to receive result.
-     *                 result is appended to existing contents.
-     * @param pos      On input: an alignment field, if desired.
-     *                 On output: the offsets of the alignment field.
-     * @param status   output param set to success/failure code on exit, which
-     *                 must not indicate a failure before the function call.
-     * @return         the string containing the formatted plural message.
-     * @draft ICU 4.0
-     */
-    UnicodeString& format(double number,
-                          UnicodeString& appendTo,
-                          FieldPosition& pos,
-                          UErrorCode& status) const;
-
-    /**
-     * Sets the locale used by this <code>PluraFormat</code> object.
-     * Note: Calling this method resets this <code>PluraFormat</code> object,
-     *     i.e., a pattern that was applied previously will be removed,
-     *     and the NumberFormat is set to the default number format for
-     *     the locale.  The resulting format behaves the same as one
-     *     constructed from {@link #PluralFormat(locale)}.
-     * @param locale  the <code>locale</code> to use to configure the formatter.
-     * @param status  output param set to success/failure code on exit, which
-     *                must not indicate a failure before the function call.
-     * @draft ICU 4.0
-     */
-    void setLocale(const Locale& locale, UErrorCode& status);
-
-    /**
-      * Sets the number format used by this formatter.  You only need to
-      * call this if you want a different number format than the default
-      * formatter for the locale.
-      * @param format  the number format to use.
-      * @param status  output param set to success/failure code on exit, which
-      *                must not indicate a failure before the function call.
-      * @draft ICU 4.0
-      */
-    void setNumberFormat(const NumberFormat* format, UErrorCode& status);
-
-    /**
-       * Assignment operator
-       *
-       * @param other    the PluralFormat object to copy from.
-       * @draft ICU 4.0
-       */
-    PluralFormat& operator=(const PluralFormat& other);
-
-    /**
-      * Return true if another object is semantically equal to this one.
-      *
-      * @param other    the PluralFormat object to be compared with.
-      * @return         true if other is semantically equal to this.
-      * @draft ICU 4.0
-      */
-    virtual UBool operator==(const Format& other) const;
-
-    /**
-     * Return true if another object is semantically unequal to this one.
-     *
-     * @param other    the PluralFormat object to be compared with.
-     * @return         true if other is semantically unequal to this.
-     * @draft ICU 4.0
-     */
-    virtual UBool operator!=(const Format& other) const;
-
-    /**
-     * Clones this Format object polymorphically.  The caller owns the
-     * result and should delete it when done.
-     * @draft ICU 4.0
-     */
-    virtual Format* clone(void) const;
-
-    /**
-    * Redeclared Format method.
-    *
-    * @param obj       The object to be formatted into a string.
-    * @param appendTo  output parameter to receive result.
-    *                  Result is appended to existing contents.
-    * @param pos       On input: an alignment field, if desired.
-    *                  On output: the offsets of the alignment field.
-    * @param status    output param filled with success/failure status.
-    * @return          Reference to 'appendTo' parameter.
-    * @draft ICU 4.0
-    */
-   UnicodeString& format(const Formattable& obj,
-                         UnicodeString& appendTo,
-                         FieldPosition& pos,
-                         UErrorCode& status) const;
-
-   /**
-    * Returns the pattern from applyPattern() or constructor().
-    *
-    * @param  appendTo  output parameter to receive result.
-     *                  Result is appended to existing contents.
-    * @return the UnicodeString with inserted pattern.
-    * @draft ICU 4.0
-    */
-   UnicodeString& toPattern(UnicodeString& appendTo);
-
-   /**
-    * This method is not yet supported by <code>PluralFormat</code>.
-    * <P>
-    * Before calling, set parse_pos.index to the offset you want to start
-    * parsing at in the source. After calling, parse_pos.index is the end of
-    * the text you parsed. If error occurs, index is unchanged.
-    * <P>
-    * When parsing, leading whitespace is discarded (with a successful parse),
-    * while trailing whitespace is left as is.
-    * <P>
-    * See Format::parseObject() for more.
-    *
-    * @param source    The string to be parsed into an object.
-    * @param result    Formattable to be set to the parse result.
-    *                  If parse fails, return contents are undefined.
-    * @param parse_pos The position to start parsing at. Upon return
-    *                  this param is set to the position after the
-    *                  last character successfully parsed. If the
-    *                  source is not parsed successfully, this param
-    *                  will remain unchanged.
-    * @draft ICU 4.0
-    */
-   virtual void parseObject(const UnicodeString& source,
-                            Formattable& result,
-                            ParsePosition& parse_pos) const;
-
-    /**
-     * ICU "poor man's RTTI", returns a UClassID for this class.
-     *
-     * @draft ICU 4.0
-     *
-     */
-    static UClassID U_EXPORT2 getStaticClassID(void);
-
-    /**
-     * ICU "poor man's RTTI", returns a UClassID for the actual class.
-     *
-     * @draft ICU 4.0
-     */
-     virtual UClassID getDynamicClassID() const;
-
-private:
-    typedef enum fmtToken {
-        none,
-        tLetter,
-        tNumber,
-        tSpace,
-        tNumberSign,
-        tLeftBrace,
-        tRightBrace
-    }fmtToken;
-
-    Locale  locale;
-    PluralRules* pluralRules;
-    UnicodeString pattern;
-    Hashtable  *fParsedValuesHash;
-    NumberFormat*  numberFormat;
-    NumberFormat*  replacedNumberFormat;
-
-    PluralFormat();   // default constructor not implemented
-    void init(const PluralRules* rules, const Locale& curlocale, UErrorCode& status);
-    UBool inRange(UChar ch, fmtToken& type);
-    UBool checkSufficientDefinition();
-    void parsingFailure();
-    UnicodeString insertFormattedNumber(double number,
-                                        UnicodeString& message,
-                                        UnicodeString& appendTo,
-                                        FieldPosition& pos) const;
-    void copyHashtable(Hashtable *other, UErrorCode& status);
-};
-
-U_NAMESPACE_END
-
-#endif /* #if !UCONFIG_NO_FORMATTING */
-
-#endif // _PLURFMT
-//eof

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/plurrule.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/plurrule.h b/apps/couch_collate/platform/osx/icu/unicode/plurrule.h
deleted file mode 100644
index 7c3fedb..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/plurrule.h
+++ /dev/null
@@ -1,291 +0,0 @@
-/*
-*******************************************************************************
-* Copyright (C) 2008, International Business Machines Corporation and
-* others. All Rights Reserved.
-*******************************************************************************
-*
-*
-* File PLURRULE.H
-*
-* Modification History:*
-*   Date        Name        Description
-*
-********************************************************************************
-*/
-
-#ifndef PLURRULE
-#define PLURRULE
-
-#include "unicode/utypes.h"
-
-/**
- * \file
- * \brief C++ API: PluralRules object
- */
-
-#if !UCONFIG_NO_FORMATTING
-
-#include "unicode/format.h"
-
-U_NAMESPACE_BEGIN
-
-class Hashtable;
-class RuleChain;
-class RuleParser;
-
-/**
- * Defines rules for mapping positive long values onto a small set of
- * keywords. Rules are constructed from a text description, consisting
- * of a series of keywords and conditions.  The {@link #select} method
- * examines each condition in order and returns the keyword for the
- * first condition that matches the number.  If none match,
- * default rule(other) is returned.
- *
- * Examples:<pre>
- *   "one: n is 1; few: n in 2..4"</pre>
- *  This defines two rules, for 'one' and 'few'.  The condition for
- *  'one' is "n is 1" which means that the number must be equal to
- *  1 for this condition to pass.  The condition for 'few' is
- *  "n in 2..4" which means that the number must be between 2 and
- *  4 inclusive for this condition to pass.  All other numbers
- *  are assigned the keyword "other" by the default rule.
- *  </p><pre>
- *    "zero: n is 0; one: n is 1; zero: n mod 100 in 1..19"</pre>
- *  This illustrates that the same keyword can be defined multiple times.
- *  Each rule is examined in order, and the first keyword whose condition
- *  passes is the one returned.  Also notes that a modulus is applied
- *  to n in the last rule.  Thus its condition holds for 119, 219, 319...
- *  </p><pre>
- *    "one: n is 1; few: n mod 10 in 2..4 and n mod 100 not in 12..14"</pre>
- *  This illustrates conjunction and negation.  The condition for 'few'
- *  has two parts, both of which must be met: "n mod 10 in 2..4" and
- *  "n mod 100 not in 12..14".  The first part applies a modulus to n
- *  before the test as in the previous example.  The second part applies
- *  a different modulus and also uses negation, thus it matches all
- *  numbers _not_ in 12, 13, 14, 112, 113, 114, 212, 213, 214...
- *  </p>
- *  <p>
- * Syntax:<pre>
- * rules         = rule (';' rule)*
- * rule          = keyword ':' condition
- * keyword       = <identifier>
- * condition     = and_condition ('or' and_condition)*
- * and_condition = relation ('and' relation)*
- * relation      = is_relation | in_relation | within_relation | 'n' <EOL>
- * is_relation   = expr 'is' ('not')? value
- * in_relation   = expr ('not')? 'in' range
- * within_relation = expr ('not')? 'within' range
- * expr          = 'n' ('mod' value)?
- * value         = digit+
- * digit         = 0|1|2|3|4|5|6|7|8|9
- * range         = value'..'value
- * </pre></p>
- * <p>
- *  The difference between 'in' and 'within' is that 'in' only includes
- *  integers in the specified range, while 'within' includes all values.</p>
- *  <p>
- *  Keywords
- *  could be defined by users or from ICU locale data. There are 6
- *  predefined values in ICU - 'zero', 'one', 'two', 'few', 'many' and
- *  'other'. Callers need to check the value of keyword returned by
- *  {@link #select} method.
- *  </p>
- *
- * Examples:<pre>
- * UnicodeString keyword = pl->select(number);
- * if (keyword== UnicodeString("one") {
- *     ...
- * }
- * else if ( ... )
- * </pre>
- */
-class U_I18N_API PluralRules : public UObject {
-public:
-
-    /**
-     * Constructor.
-     * @param status  Output param set to success/failure code on exit, which
-     *                must not indicate a failure before the function call.
-     *
-     * @draft ICU 4.0
-     */
-    PluralRules(UErrorCode& status);
-
-    /**
-     * Copy constructor.
-     * @draft ICU 4.0
-     */
-    PluralRules(const PluralRules& other);
-
-    /**
-     * Destructor.
-     * @draft ICU 4.0
-     */
-    virtual ~PluralRules();
-
-    /**
-     * Clone
-     * @draft ICU 4.0
-     */
-    PluralRules* clone() const;
-
-    /**
-      * Assignment operator.
-      * @draft ICU 4.0
-      */
-    PluralRules& operator=(const PluralRules&);
-
-    /**
-     * Creates a PluralRules from a description if it is parsable, otherwise
-     * returns null.
-     *
-     * @param description rule description
-     * @param status      Output param set to success/failure code on exit, which
-     *                    must not indicate a failure before the function call.
-     * @return            new PluralRules pointer. NULL if there is an error.
-     * @draft ICU 4.0
-     */
-    static PluralRules* U_EXPORT2 createRules(const UnicodeString& description,
-                                              UErrorCode& status);
-
-    /**
-     * The default rules that accept any number.
-     *
-     * @param status  Output param set to success/failure code on exit, which
-     *                must not indicate a failure before the function call.
-     * @return        new PluralRules pointer. NULL if there is an error.
-     * @draft ICU 4.0
-     */
-    static PluralRules* U_EXPORT2 createDefaultRules(UErrorCode& status);
-
-    /**
-     * Provides access to the predefined <code>PluralRules</code> for a given
-     * locale.
-     *
-     * @param locale  The locale for which a <code>PluralRules</code> object is
-     *                returned.
-     * @param status  Output param set to success/failure code on exit, which
-     *                must not indicate a failure before the function call.
-     * @return        The predefined <code>PluralRules</code> object pointer for
-     *                this locale. If there's no predefined rules for this locale,
-     *                the rules for the closest parent in the locale hierarchy
-     *                that has one will  be returned.  The final fallback always
-     *                returns the default 'other' rules.
-     * @draft ICU 4.0
-     */
-    static PluralRules* U_EXPORT2 forLocale(const Locale& locale, UErrorCode& status);
-    
-    /**
-     * Given a number, returns the keyword of the first rule that applies to
-     * the number.  This function can be used with isKeyword* functions to
-     * determine the keyword for default plural rules.
-     *
-     * @param number  The number for which the rule has to be determined.
-     * @return        The keyword of the selected rule.
-     * @draft ICU 4.0
-     */
-    UnicodeString select(int32_t number) const;
-    
-    /**
-     * Given a number, returns the keyword of the first rule that applies to
-     * the number.  This function can be used with isKeyword* functions to
-     * determine the keyword for default plural rules.
-     *
-     * @param number  The number for which the rule has to be determined.
-     * @return        The keyword of the selected rule.
-     * @draft ICU 4.0
-     */
-    UnicodeString select(double number) const;
-
-    /**
-     * Returns a list of all rule keywords used in this <code>PluralRules</code>
-     * object.  The rule 'other' is always present by default.
-     *
-     * @param status Output param set to success/failure code on exit, which
-     *               must not indicate a failure before the function call.
-     * @return       StringEnumeration with the keywords.
-     *               The caller must delete the object.
-     * @draft ICU 4.0
-     */
-    StringEnumeration* getKeywords(UErrorCode& status) const;
-
-    /**
-     * Returns TRUE if the given keyword is defined in this
-     * <code>PluralRules</code> object.
-     *
-     * @param keyword  the input keyword.
-     * @return         TRUE if the input keyword is defined.
-     *                 Otherwise, return FALSE.
-     * @draft ICU 4.0
-     */
-    UBool isKeyword(const UnicodeString& keyword) const;
-
-
-    /**
-     * Returns keyword for default plural form.
-     *
-     * @return         keyword for default plural form.
-     * @internal 4.0
-     * @draft ICU 4.0
-     */
-    UnicodeString getKeywordOther() const;
-
-    /**
-     * Compares the equality of two PluralRules objects.
-     *
-     * @param other The other PluralRules object to be compared with.
-     * @return      True if the given PluralRules is the same as this
-     *              PluralRules; false otherwise.
-     * @draft ICU 4.0
-     */
-    virtual UBool operator==(const PluralRules& other) const;
-
-    /**
-     * Compares the inequality of two PluralRules objects.
-     *
-     * @param other The PluralRules object to be compared with.
-     * @return      True if the given PluralRules is not the same as this
-     *              PluralRules; false otherwise.
-     * @draft ICU 4.0
-     */
-    UBool operator!=(const PluralRules& other) const  {return !operator==(other);}
-
-
-    /**
-     * ICU "poor man's RTTI", returns a UClassID for this class.
-     *
-     * @draft ICU 4.0
-     *
-    */
-    static UClassID U_EXPORT2 getStaticClassID(void);
-
-    /**
-     * ICU "poor man's RTTI", returns a UClassID for the actual class.
-     *
-     * @draft ICU 4.0
-     */
-    virtual UClassID getDynamicClassID() const;
-
-
-private:
-    Hashtable       *fLocaleStringsHash;
-    UnicodeString   mLocaleName;
-    RuleChain       *mRules;
-    RuleParser      *mParser;
-
-    PluralRules();   // default constructor not implemented
-    int32_t getRepeatLimit() const;
-    void parseDescription(UnicodeString& ruleData, RuleChain& rules, UErrorCode &status);
-    void getNextLocale(const UnicodeString& localeData, int32_t* curIndex, UnicodeString& localeName);
-    void addRules(RuleChain& rules);
-    int32_t getNumberValue(const UnicodeString& token) const;
-    UnicodeString getRuleFromResource(const Locale& locale, UErrorCode& status);
-
-};
-
-U_NAMESPACE_END
-
-#endif /* #if !UCONFIG_NO_FORMATTING */
-
-#endif // _PLURRULE
-//eof


[36/57] [abbrv] remove couch_collate

Posted by be...@apache.org.
http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/dtfmtsym.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/dtfmtsym.h b/apps/couch_collate/platform/osx/icu/unicode/dtfmtsym.h
deleted file mode 100644
index a4b08bc..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/dtfmtsym.h
+++ /dev/null
@@ -1,721 +0,0 @@
-/*  
-********************************************************************************
-*   Copyright (C) 1997-2008, International Business Machines
-*   Corporation and others.  All Rights Reserved.
-********************************************************************************
-*
-* File DTFMTSYM.H
-*
-* Modification History:
-*
-*   Date        Name        Description
-*   02/19/97    aliu        Converted from java.
-*    07/21/98    stephen        Added getZoneIndex()
-*                            Changed to match C++ conventions
-********************************************************************************
-*/
-     
-#ifndef DTFMTSYM_H
-#define DTFMTSYM_H
- 
-#include "unicode/utypes.h"
-
-#if !UCONFIG_NO_FORMATTING
-
-#include "unicode/calendar.h"
-#include "unicode/uobject.h"
-#include "unicode/locid.h"
-#include "unicode/ures.h"
-
-/**
- * \file 
- * \brief C++ API: Symbols for formatting dates.
- */
-
-U_NAMESPACE_BEGIN
-
-/* forward declaration */
-class SimpleDateFormat;
-class Hashtable;
-class ZoneStringFormat;
-class SafeZoneStringFormatPtr;
-
-/**
- * DateFormatSymbols is a public class for encapsulating localizable date-time
- * formatting data -- including timezone data. DateFormatSymbols is used by
- * DateFormat and SimpleDateFormat.
- * <P>
- * Rather than first creating a DateFormatSymbols to get a date-time formatter
- * by using a SimpleDateFormat constructor, clients are encouraged to create a
- * date-time formatter using the getTimeInstance(), getDateInstance(), or
- * getDateTimeInstance() method in DateFormat. Each of these methods can return a
- * date/time formatter initialized with a default format pattern along with the
- * date-time formatting data for a given or default locale. After a formatter is
- * created, clients may modify the format pattern using the setPattern function
- * as so desired. For more information on using these formatter factory
- * functions, see DateFormat.
- * <P>
- * If clients decide to create a date-time formatter with a particular format
- * pattern and locale, they can do so with new SimpleDateFormat(aPattern,
- * new DateFormatSymbols(aLocale)).  This will load the appropriate date-time
- * formatting data from the locale.
- * <P>
- * DateFormatSymbols objects are clonable. When clients obtain a
- * DateFormatSymbols object, they can feel free to modify the date-time
- * formatting data as necessary. For instance, clients can
- * replace the localized date-time format pattern characters with the ones that
- * they feel easy to remember. Or they can change the representative cities
- * originally picked by default to using their favorite ones.
- * <P>
- * DateFormatSymbols are not expected to be subclassed. Data for a calendar is
- * loaded out of resource bundles.  The 'type' parameter indicates the type of
- * calendar, for example, "gregorian" or "japanese".  If the type is not gregorian
- * (or NULL, or an empty string) then the type is appended to the resource name,
- * for example,  'Eras_japanese' instead of 'Eras'.   If the resource 'Eras_japanese' did
- * not exist (even in root), then this class will fall back to just 'Eras', that is,
- * Gregorian data.  Therefore, the calendar implementor MUST ensure that the root
- * locale at least contains any resources that are to be particularized for the
- * calendar type.
- */
-class U_I18N_API DateFormatSymbols : public UObject {
-public:
-    /**
-     * Construct a DateFormatSymbols object by loading format data from
-     * resources for the default locale, in the default calendar (Gregorian).
-     * <P>
-     * NOTE: This constructor will never fail; if it cannot get resource
-     * data for the default locale, it will return a last-resort object
-     * based on hard-coded strings.
-     *
-     * @param status    Status code.  Failure
-     *                  results if the resources for the default cannot be
-     *                  found or cannot be loaded
-     * @stable ICU 2.0
-     */
-    DateFormatSymbols(UErrorCode& status);
-
-    /**
-     * Construct a DateFormatSymbols object by loading format data from
-     * resources for the given locale, in the default calendar (Gregorian).
-     *
-     * @param locale    Locale to load format data from.
-     * @param status    Status code.  Failure
-     *                  results if the resources for the locale cannot be
-     *                  found or cannot be loaded
-     * @stable ICU 2.0
-     */
-    DateFormatSymbols(const Locale& locale,
-                      UErrorCode& status);
-
-    /**
-     * Construct a DateFormatSymbols object by loading format data from
-     * resources for the default locale, in the default calendar (Gregorian).
-     * <P>
-     * NOTE: This constructor will never fail; if it cannot get resource
-     * data for the default locale, it will return a last-resort object
-     * based on hard-coded strings.
-     *
-     * @param type      Type of calendar (as returned by Calendar::getType). 
-     *                  Will be used to access the correct set of strings.
-     *                  (NULL or empty string defaults to "gregorian".)
-     * @param status    Status code.  Failure
-     *                  results if the resources for the default cannot be
-     *                  found or cannot be loaded
-     * @internal
-     */
-    DateFormatSymbols(const char *type, UErrorCode& status);
-
-    /**
-     * Construct a DateFormatSymbols object by loading format data from
-     * resources for the given locale, in the default calendar (Gregorian).
-     *
-     * @param locale    Locale to load format data from.
-     * @param type      Type of calendar (as returned by Calendar::getType). 
-     *                  Will be used to access the correct set of strings.
-     *                  (NULL or empty string defaults to "gregorian".)
-     * @param status    Status code.  Failure
-     *                  results if the resources for the locale cannot be
-     *                  found or cannot be loaded
-     * @internal
-     */
-    DateFormatSymbols(const Locale& locale,
-                      const char *type,
-                      UErrorCode& status);
-
-    /**
-     * Copy constructor.
-     * @stable ICU 2.0
-     */
-    DateFormatSymbols(const DateFormatSymbols&);
-
-    /**
-     * Assignment operator.
-     * @stable ICU 2.0
-     */
-    DateFormatSymbols& operator=(const DateFormatSymbols&);
-
-    /**
-     * Destructor. This is nonvirtual because this class is not designed to be
-     * subclassed.
-     * @stable ICU 2.0
-     */
-    virtual ~DateFormatSymbols();
-
-    /**
-     * Return true if another object is semantically equal to this one.
-     *
-     * @param other    the DateFormatSymbols object to be compared with.
-     * @return         true if other is semantically equal to this.
-     * @stable ICU 2.0
-     */
-    UBool operator==(const DateFormatSymbols& other) const;
-
-    /**
-     * Return true if another object is semantically unequal to this one.
-     *
-     * @param other    the DateFormatSymbols object to be compared with.
-     * @return         true if other is semantically unequal to this.
-     * @stable ICU 2.0
-     */
-    UBool operator!=(const DateFormatSymbols& other) const { return !operator==(other); }
-
-    /**
-     * Gets abbreviated era strings. For example: "AD" and "BC".
-     *
-     * @param count    Filled in with length of the array.
-     * @return         the era strings.
-     * @stable ICU 2.0
-     */
-    const UnicodeString* getEras(int32_t& count) const;
-
-    /**
-     * Sets abbreviated era strings. For example: "AD" and "BC".
-     * @param eras  Array of era strings (DateFormatSymbols retains ownership.)
-     * @param count Filled in with length of the array.
-     * @stable ICU 2.0
-     */
-    void setEras(const UnicodeString* eras, int32_t count);
-
-    /**
-     * Gets era name strings. For example: "Anno Domini" and "Before Christ".
-     *
-     * @param count    Filled in with length of the array.
-     * @return         the era name strings.
-     * @stable ICU 3.4
-     */
-    const UnicodeString* getEraNames(int32_t& count) const;
-
-    /**
-     * Sets era name strings. For example: "Anno Domini" and "Before Christ".
-     * @param eraNames  Array of era name strings (DateFormatSymbols retains ownership.)
-     * @param count Filled in with length of the array.
-     * @stable ICU 3.6
-     */
-    void setEraNames(const UnicodeString* eraNames, int32_t count);
-
-    /**
-     * Gets narrow era strings. For example: A" and "D".
-     *
-     * @param count    Filled in with length of the array.
-     * @return         the narrow era strings.
-     * @draft ICU 4.2
-     */
-    const UnicodeString* getNarrowEras(int32_t& count) const;
-
-    /**
-     * Sets narrow era strings. For example: "A" and "B".
-     * @param narrowEras  Array of narrow era strings (DateFormatSymbols retains ownership.)
-     * @param count Filled in with length of the array.
-     * @draft ICU 4.2
-     */
-    void setNarrowEras(const UnicodeString* narrowEras, int32_t count);
-
-    /**
-     * Gets month strings. For example: "January", "February", etc.
-     * @param count Filled in with length of the array.
-     * @return the month strings. (DateFormatSymbols retains ownership.)
-     * @stable ICU 2.0
-     */
-    const UnicodeString* getMonths(int32_t& count) const;
-
-    /**
-     * Sets month strings. For example: "January", "February", etc.
-     *
-     * @param months    the new month strings. (not adopted; caller retains ownership)
-     * @param count     Filled in with length of the array.
-     * @stable ICU 2.0
-     */
-    void setMonths(const UnicodeString* months, int32_t count);
-
-    /**
-     * Gets short month strings. For example: "Jan", "Feb", etc.
-     *
-     * @param count Filled in with length of the array.
-     * @return the short month strings. (DateFormatSymbols retains ownership.)
-     * @stable ICU 2.0
-     */
-    const UnicodeString* getShortMonths(int32_t& count) const;
-
-    /**
-     * Sets short month strings. For example: "Jan", "Feb", etc.
-     * @param count        Filled in with length of the array.
-     * @param shortMonths  the new short month strings. (not adopted; caller retains ownership)
-     * @stable ICU 2.0
-     */
-    void setShortMonths(const UnicodeString* shortMonths, int32_t count);
-
-    /**
-     * Selector for date formatting context
-     * @stable ICU 3.6
-     */
-    enum DtContextType {
-         FORMAT,
-         STANDALONE,
-         DT_CONTEXT_COUNT
-    };
-
-    /**
-     * Selector for date formatting width
-     * @stable ICU 3.6
-     */
-    enum DtWidthType {
-         ABBREVIATED,
-         WIDE,
-         NARROW,
-         DT_WIDTH_COUNT
-    };
-
-    /**
-     * Gets month strings by width and context. For example: "January", "February", etc.
-     * @param count Filled in with length of the array.
-     * @param context The formatting context, either FORMAT or STANDALONE
-     * @param width   The width of returned strings, either WIDE, ABBREVIATED, or NARROW.
-     * @return the month strings. (DateFormatSymbols retains ownership.)
-     * @stable ICU 3.4
-     */
-    const UnicodeString* getMonths(int32_t& count, DtContextType context, DtWidthType width) const;
-
-    /**
-     * Sets month strings by width and context. For example: "January", "February", etc.
-     *
-     * @param months  The new month strings. (not adopted; caller retains ownership)
-     * @param count   Filled in with length of the array.
-     * @param context The formatting context, either FORMAT or STANDALONE
-     * @param width   The width of returned strings, either WIDE, ABBREVIATED, or NARROW.
-     * @stable ICU 3.6
-     */
-    void setMonths(const UnicodeString* months, int32_t count, DtContextType context, DtWidthType width);
-
-    /**
-     * Gets weekday strings. For example: "Sunday", "Monday", etc.
-     * @param count        Filled in with length of the array.
-     * @return the weekday strings. (DateFormatSymbols retains ownership.)
-     * @stable ICU 2.0
-     */
-    const UnicodeString* getWeekdays(int32_t& count) const;
-
-
-    /**
-     * Sets weekday strings. For example: "Sunday", "Monday", etc.
-     * @param weekdays     the new weekday strings. (not adopted; caller retains ownership)
-     * @param count        Filled in with length of the array.
-     * @stable ICU 2.0
-     */
-    void setWeekdays(const UnicodeString* weekdays, int32_t count);
-
-    /**
-     * Gets short weekday strings. For example: "Sun", "Mon", etc.
-     * @param count        Filled in with length of the array.
-     * @return             the short weekday strings. (DateFormatSymbols retains ownership.)
-     * @stable ICU 2.0
-     */
-    const UnicodeString* getShortWeekdays(int32_t& count) const;
-
-    /**
-     * Sets short weekday strings. For example: "Sun", "Mon", etc.
-     * @param shortWeekdays  the new short weekday strings. (not adopted; caller retains ownership)
-     * @param count          Filled in with length of the array.
-     * @stable ICU 2.0
-     */
-    void setShortWeekdays(const UnicodeString* shortWeekdays, int32_t count);
-
-    /**
-     * Gets weekday strings by width and context. For example: "Sunday", "Monday", etc.
-     * @param count   Filled in with length of the array.
-     * @param context The formatting context, either FORMAT or STANDALONE
-     * @param width   The width of returned strings, either WIDE, ABBREVIATED, or NARROW
-     * @return the month strings. (DateFormatSymbols retains ownership.)
-     * @stable ICU 3.4
-     */
-    const UnicodeString* getWeekdays(int32_t& count, DtContextType context, DtWidthType width) const;
-
-    /**
-     * Sets weekday strings by width and context. For example: "Sunday", "Monday", etc.
-     * @param weekdays  The new weekday strings. (not adopted; caller retains ownership)
-     * @param count     Filled in with length of the array.
-     * @param context   The formatting context, either FORMAT or STANDALONE
-     * @param width     The width of returned strings, either WIDE, ABBREVIATED, or NARROW
-     * @stable ICU 3.6
-     */
-    void setWeekdays(const UnicodeString* weekdays, int32_t count, DtContextType context, DtWidthType width);
-
-    /**
-     * Gets quarter strings by width and context. For example: "1st Quarter", "2nd Quarter", etc.
-     * @param count Filled in with length of the array.
-     * @param context The formatting context, either FORMAT or STANDALONE
-     * @param width   The width of returned strings, either WIDE or ABBREVIATED. There
-     *                are no NARROW quarters.
-     * @return the quarter strings. (DateFormatSymbols retains ownership.)
-     * @stable ICU 3.6
-     */
-    const UnicodeString* getQuarters(int32_t& count, DtContextType context, DtWidthType width) const;
-
-    /**
-     * Sets quarter strings by width and context. For example: "1st Quarter", "2nd Quarter", etc.
-     *
-     * @param quarters  The new quarter strings. (not adopted; caller retains ownership)
-     * @param count   Filled in with length of the array.
-     * @param context The formatting context, either FORMAT or STANDALONE
-     * @param width   The width of returned strings, either WIDE or ABBREVIATED. There
-     *                are no NARROW quarters.
-     * @stable ICU 3.6
-     */
-    void setQuarters(const UnicodeString* quarters, int32_t count, DtContextType context, DtWidthType width);
-
-    /**
-     * Gets AM/PM strings. For example: "AM" and "PM".
-     * @param count        Filled in with length of the array.
-     * @return             the weekday strings. (DateFormatSymbols retains ownership.)
-     * @stable ICU 2.0
-     */
-    const UnicodeString* getAmPmStrings(int32_t& count) const;
-
-    /**
-     * Sets ampm strings. For example: "AM" and "PM".
-     * @param ampms        the new ampm strings. (not adopted; caller retains ownership)
-     * @param count        Filled in with length of the array.
-     * @stable ICU 2.0
-     */
-    void setAmPmStrings(const UnicodeString* ampms, int32_t count);
-
-    /**
-     * Gets timezone strings. These strings are stored in a 2-dimensional array.
-     * @param rowCount      Output param to receive number of rows.
-     * @param columnCount   Output param to receive number of columns.
-     * @return              The timezone strings as a 2-d array. (DateFormatSymbols retains ownership.)
-     * @deprecated ICU 3.6
-     */
-    const UnicodeString** getZoneStrings(int32_t& rowCount, int32_t& columnCount) const;
-
-    /**
-     * Sets timezone strings. These strings are stored in a 2-dimensional array.
-     * @param strings       The timezone strings as a 2-d array to be copied. (not adopted; caller retains ownership)
-     * @param rowCount      The number of rows (count of first index).
-     * @param columnCount   The number of columns (count of second index).
-     * @stable ICU 2.0
-     */
-    void setZoneStrings(const UnicodeString* const* strings, int32_t rowCount, int32_t columnCount);
-
-    /**
-     * Get the non-localized date-time pattern characters.
-     * @return    the non-localized date-time pattern characters
-     * @stable ICU 2.0
-     */
-    static const UChar * U_EXPORT2 getPatternUChars(void);
-
-    /**
-     * Gets localized date-time pattern characters. For example: 'u', 't', etc.
-     * <p>
-     * Note: ICU no longer provides localized date-time pattern characters for a locale
-     * starting ICU 3.8.  This method returns the non-localized date-time pattern
-     * characters unless user defined localized data is set by setLocalPatternChars.
-     * @param result    Output param which will receive the localized date-time pattern characters.
-     * @return          A reference to 'result'.
-     * @stable ICU 2.0
-     */
-    UnicodeString& getLocalPatternChars(UnicodeString& result) const;
-
-    /**
-     * Sets localized date-time pattern characters. For example: 'u', 't', etc.
-     * @param newLocalPatternChars the new localized date-time
-     * pattern characters.
-     * @stable ICU 2.0
-     */
-    void setLocalPatternChars(const UnicodeString& newLocalPatternChars);
-
-    /**
-     * Returns the locale for this object. Two flavors are available:
-     * valid and actual locale.
-     * @stable ICU 2.8
-     */
-    Locale getLocale(ULocDataLocaleType type, UErrorCode& status) const;
-
-    /**
-     * ICU "poor man's RTTI", returns a UClassID for the actual class.
-     *
-     * @stable ICU 2.2
-     */
-    virtual UClassID getDynamicClassID() const;
-
-    /**
-     * ICU "poor man's RTTI", returns a UClassID for this class.
-     *
-     * @stable ICU 2.2
-     */
-    static UClassID U_EXPORT2 getStaticClassID();
-
-private:
-
-    friend class SimpleDateFormat;
-    friend class DateFormatSymbolsSingleSetter; // see udat.cpp
-
-    /**
-     * Abbreviated era strings. For example: "AD" and "BC".
-     */
-    UnicodeString*  fEras;
-    int32_t         fErasCount;
-
-    /**
-     * Era name strings. For example: "Anno Domini" and "Before Christ".
-     */
-    UnicodeString*  fEraNames;
-    int32_t         fEraNamesCount;
-
-    /**
-     * Narrow era strings. For example: "A" and "B".
-     */
-    UnicodeString*  fNarrowEras;
-    int32_t         fNarrowErasCount;
-
-    /**
-     * Month strings. For example: "January", "February", etc.
-     */
-    UnicodeString*  fMonths;
-    int32_t         fMonthsCount;
-
-    /**
-     * Short month strings. For example: "Jan", "Feb", etc.
-     */
-    UnicodeString*  fShortMonths;
-    int32_t         fShortMonthsCount;
-
-    /**
-     * Narrow month strings. For example: "J", "F", etc.
-     */
-    UnicodeString*  fNarrowMonths;
-    int32_t         fNarrowMonthsCount;
-
-    /**
-     * Standalone Month strings. For example: "January", "February", etc.
-     */
-    UnicodeString*  fStandaloneMonths;
-    int32_t         fStandaloneMonthsCount;
-
-    /**
-     * Standalone Short month strings. For example: "Jan", "Feb", etc.
-     */
-    UnicodeString*  fStandaloneShortMonths;
-    int32_t         fStandaloneShortMonthsCount;
-
-    /**
-     * Standalone Narrow month strings. For example: "J", "F", etc.
-     */
-    UnicodeString*  fStandaloneNarrowMonths;
-    int32_t         fStandaloneNarrowMonthsCount;
-
-    /**
-     * Weekday strings. For example: "Sunday", "Monday", etc.
-     */
-    UnicodeString*  fWeekdays;
-    int32_t         fWeekdaysCount;
-
-    /**
-     * Short weekday strings. For example: "Sun", "Mon", etc.
-     */
-    UnicodeString*  fShortWeekdays;
-    int32_t         fShortWeekdaysCount;
-
-    /**
-     * Narrow weekday strings. For example: "Sun", "Mon", etc.
-     */
-    UnicodeString*  fNarrowWeekdays;
-    int32_t         fNarrowWeekdaysCount;
-
-    /**
-     * Standalone Weekday strings. For example: "Sunday", "Monday", etc.
-     */
-    UnicodeString*  fStandaloneWeekdays;
-    int32_t         fStandaloneWeekdaysCount;
-
-    /**
-     * Standalone Short weekday strings. For example: "Sun", "Mon", etc.
-     */
-    UnicodeString*  fStandaloneShortWeekdays;
-    int32_t         fStandaloneShortWeekdaysCount;
-
-    /**
-     * Standalone Narrow weekday strings. For example: "Sun", "Mon", etc.
-     */
-    UnicodeString*  fStandaloneNarrowWeekdays;
-    int32_t         fStandaloneNarrowWeekdaysCount;
-
-    /**
-     * Ampm strings. For example: "AM" and "PM".
-     */
-    UnicodeString*  fAmPms;
-    int32_t         fAmPmsCount;
-
-    /**
-     * Quarter strings. For example: "1st quarter", "2nd quarter", etc.
-     */
-    UnicodeString  *fQuarters;
-    int32_t         fQuartersCount;
-
-    /**
-     * Short quarters. For example: "Q1", "Q2", etc.
-     */
-    UnicodeString  *fShortQuarters;
-    int32_t         fShortQuartersCount;
-
-    /**
-     * Standalone quarter strings. For example: "1st quarter", "2nd quarter", etc.
-     */
-    UnicodeString  *fStandaloneQuarters;
-    int32_t         fStandaloneQuartersCount;
-
-    /**
-     * Standalone short quarter strings. For example: "Q1", "Q2", etc.
-     */
-    UnicodeString  *fStandaloneShortQuarters;
-    int32_t         fStandaloneShortQuartersCount;
-
-    /**
-     * The format data of all the timezones in this locale.
-     */
-    UnicodeString   **fZoneStrings;         // Zone string array set by setZoneStrings
-    UnicodeString   **fLocaleZoneStrings;   // Zone string array created by the locale
-    int32_t         fZoneStringsRowCount;
-    int32_t         fZoneStringsColCount;
-
-    const ZoneStringFormat  *fZoneStringFormat;
-    ZoneStringFormat        *fZSFLocal;         // Local ZoneStringFormat instance
-    SafeZoneStringFormatPtr *fZSFCachePtr;      // Cached ZoneStringFormat
-    Locale                  fZSFLocale;         // Locale used for getting ZoneStringFormat
-
-    /**
-     * Pattern string used for localized time zone GMT format.  For example, "GMT{0}"
-     */
-    UnicodeString   fGmtFormat;
-
-    /**
-     * Pattern strings used for formatting zone offset in a localized time zone GMT string.
-     */
-    UnicodeString  *fGmtHourFormats;
-    int32_t         fGmtHourFormatsCount; 
-
-    enum GMTHourType {
-        GMT_NEGATIVE_HMS = 0,
-        GMT_NEGATIVE_HM,
-        GMT_POSITIVE_HMS,
-        GMT_POSITIVE_HM,
-        GMT_HOUR_COUNT
-    };
-
-    /**
-     * Localized date-time pattern characters. For example: use 'u' as 'y'.
-     */
-    UnicodeString   fLocalPatternChars;
-
-private:
-    /** valid/actual locale information 
-     *  these are always ICU locales, so the length should not be a problem
-     */
-    char validLocale[ULOC_FULLNAME_CAPACITY];
-    char actualLocale[ULOC_FULLNAME_CAPACITY];
-
-    DateFormatSymbols(); // default constructor not implemented
-
-    /**
-     * Called by the constructors to actually load data from the resources
-     *
-     * @param locale               The locale to get symbols for.
-     * @param type                 Calendar Type (as from Calendar::getType())
-     * @param status               Input/output parameter, set to success or
-     *                             failure code upon return.
-     * @param useLastResortData    determine if use last resort data
-     */
-    void initializeData(const Locale&, const char *type, UErrorCode& status, UBool useLastResortData = FALSE);
-
-    /**
-     * Copy or alias an array in another object, as appropriate.
-     *
-     * @param dstArray    the copy destination array.
-     * @param dstCount    fill in with the lenth of 'dstArray'.
-     * @param srcArray    the source array to be copied.
-     * @param srcCount    the length of items to be copied from the 'srcArray'.
-     */
-    static void assignArray(UnicodeString*& dstArray,
-                            int32_t& dstCount,
-                            const UnicodeString* srcArray,
-                            int32_t srcCount);
-
-    /**
-     * Return true if the given arrays' contents are equal, or if the arrays are
-     * identical (pointers are equal).
-     *
-     * @param array1   one array to be compared with.
-     * @param array2   another array to be compared with.
-     * @param count    the length of items to be copied.
-     * @return         true if the given arrays' contents are equal, or if the arrays are
-     *                 identical (pointers are equal).
-     */
-    static UBool arrayCompare(const UnicodeString* array1,
-                             const UnicodeString* array2,
-                             int32_t count);
-
-    /**
-     * Create a copy, in fZoneStrings, of the given zone strings array. The
-     * member variables fZoneStringsRowCount and fZoneStringsColCount should be
-     * set already by the caller.
-     */
-    void createZoneStrings(const UnicodeString *const * otherStrings);
-
-    /**
-     * Delete all the storage owned by this object.
-     */
-    void dispose(void);
-
-    /**
-     * Copy all of the other's data to this.
-     * @param other the object to be copied.
-     */
-    void copyData(const DateFormatSymbols& other);
-
-
-    /**
-     * Returns a ZoneStringFormat, used only by SimpleDateFormat for now.
-     */
-    const ZoneStringFormat* getZoneStringFormat(void) const;
-
-    /**
-     * Create a ZoneStringFormat by locale if not yet availble
-     */
-    void initZoneStringFormat(void);
-
-    /**
-     * Create zone strings array by locale if not yet available
-     */
-    void initZoneStringsArray(void);
-
-    /**
-     * Delete just the zone strings.
-     */
-    void disposeZoneStrings(void);
-};
-
-U_NAMESPACE_END
-
-#endif /* #if !UCONFIG_NO_FORMATTING */
-
-#endif // _DTFMTSYM
-//eof

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/dtintrv.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/dtintrv.h b/apps/couch_collate/platform/osx/icu/unicode/dtintrv.h
deleted file mode 100644
index b55dcd4..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/dtintrv.h
+++ /dev/null
@@ -1,159 +0,0 @@
-/*
-*******************************************************************************
-* Copyright (C) 2008, International Business Machines Corporation and
-* others. All Rights Reserved.
-*******************************************************************************
-*
-* File DTINTRV.H 
-*
-*******************************************************************************
-*/
-
-#ifndef __DTINTRV_H__
-#define __DTINTRV_H__
-
-#include "unicode/utypes.h"
-#include "unicode/uobject.h"
-
-/**
- * \file
- * \brief C++ API: Date Interval data type
- */
-
-
-U_NAMESPACE_BEGIN
-
-
-/**
- * This class represents a date interval.
- * It is a pair of UDate representing from UDate 1 to UDate 2.
- * @draft ICU 4.0
-**/
-class U_COMMON_API DateInterval : public UObject {
-public:
-
-    /** 
-     * Construct a DateInterval given a from date and a to date.
-     * @param fromDate  The from date in date interval.
-     * @param toDate    The to date in date interval.
-     * @draft ICU 4.0
-     */
-    DateInterval(UDate fromDate, UDate toDate);
-
-    /**
-     * destructor
-     * @draft ICU 4.0
-     */
-    virtual ~DateInterval();
- 
-    /** 
-     * Get the from date.
-     * @return  the from date in dateInterval.
-     * @draft ICU 4.0
-     */
-    UDate getFromDate() const;
-
-    /** 
-     * Get the to date.
-     * @return  the to date in dateInterval.
-     * @draft ICU 4.0
-     */
-    UDate getToDate() const;
-
-
-    /**
-     * Return the class ID for this class. This is useful only for comparing to
-     * a return value from getDynamicClassID(). For example:
-     * <pre>
-     * .   Base* polymorphic_pointer = createPolymorphicObject();
-     * .   if (polymorphic_pointer->getDynamicClassID() ==
-     * .       erived::getStaticClassID()) ...
-     * </pre>
-     * @return          The class ID for all objects of this class.
-     * @draft ICU 4.0
-     */
-    static UClassID U_EXPORT2 getStaticClassID(void);
-
-    /**
-     * Returns a unique class ID POLYMORPHICALLY. Pure virtual override. This
-     * method is to implement a simple version of RTTI, since not all C++
-     * compilers support genuine RTTI. Polymorphic operator==() and clone()
-     * methods call this method.
-     *
-     * @return          The class ID for this object. All objects of a
-     *                  given class have the same class ID.  Objects of
-     *                  other classes have different class IDs.
-     * @draft ICU 4.0
-     */
-    virtual UClassID getDynamicClassID(void) const;
-
-    
-    /**
-     * Copy constructor.
-     * @draft ICU 4.0
-     */
-    DateInterval(const DateInterval& other);
-
-    /**
-     * Default assignment operator
-     * @draft ICU 4.0
-     */
-    DateInterval& operator=(const DateInterval&);
-
-    /**
-     * Equality operator.
-     * @return TRUE if the two DateIntervals are the same
-     * @draft ICU 4.0
-     */
-    virtual UBool operator==(const DateInterval& other) const;
-
-    /**
-     * Non-equality operator
-     * @return TRUE if the two DateIntervals are not the same
-     * @draft ICU 4.0
-     */
-    UBool operator!=(const DateInterval& other) const;
-
-
-    /**
-     * clone this object. 
-     * The caller owns the result and should delete it when done.
-     * @return a cloned DateInterval
-     * @draft ICU 4.0
-     */
-     virtual DateInterval* clone() const;
-
-private:
-    /** 
-     * Default constructor, not implemented.
-     * @draft ICU 4.0
-     */
-    DateInterval();
-
-    UDate fromDate;
-    UDate toDate;
-
-} ;// end class DateInterval
-
-
-inline UDate 
-DateInterval::getFromDate() const { 
-    return fromDate; 
-}
-
-
-inline UDate 
-DateInterval::getToDate() const { 
-    return toDate; 
-}
-
-
-inline UBool 
-DateInterval::operator!=(const DateInterval& other) const { 
-    return ( !operator==(other) );
-}
-
-
-U_NAMESPACE_END
-
-#endif

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/dtitvfmt.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/dtitvfmt.h b/apps/couch_collate/platform/osx/icu/unicode/dtitvfmt.h
deleted file mode 100644
index 2384437..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/dtitvfmt.h
+++ /dev/null
@@ -1,949 +0,0 @@
-/********************************************************************************
-* Copyright (C) 2008, International Business Machines Corporation and others. All Rights Reserved.
-*******************************************************************************
-*
-* File DTITVFMT.H
-*
-*******************************************************************************
-*/
-
-#ifndef __DTITVFMT_H__
-#define __DTITVFMT_H__
-
-
-#include "unicode/utypes.h"
-
-/**
- * \file 
- * \brief C++ API: Format and parse date interval in a language-independent manner.
- */
- 
-#if !UCONFIG_NO_FORMATTING
-
-#include "unicode/ucal.h"
-#include "unicode/smpdtfmt.h"
-#include "unicode/dtintrv.h"
-#include "unicode/dtitvinf.h"
-
-U_NAMESPACE_BEGIN
-
-
-
-/**
- * DateIntervalFormat is a class for formatting and parsing date 
- * intervals in a language-independent manner. 
- * Date interval formatting is supported in Gregorian calendar only.
- * And only formatting is supported. Parsing is not supported.
- *
- * <P>
- * Date interval means from one date to another date,
- * for example, from "Jan 11, 2008" to "Jan 18, 2008".
- * We introduced class DateInterval to represent it.
- * DateInterval is a pair of UDate, which is 
- * the standard milliseconds since 24:00 GMT, Jan 1, 1970.
- *
- * <P>
- * DateIntervalFormat formats a DateInterval into
- * text as compactly as possible. 
- * For example, the date interval format from "Jan 11, 2008" to "Jan 18,. 2008"
- * is "Jan 11-18, 2008" for English.
- * And it parses text into DateInterval, 
- * although initially, parsing is not supported. 
- *
- * <P>
- * There is no structural information in date time patterns. 
- * For any punctuations and string literals inside a date time pattern, 
- * we do not know whether it is just a separator, or a prefix, or a suffix. 
- * Without such information, so, it is difficult to generate a sub-pattern 
- * (or super-pattern) by algorithm.
- * So, formatting a DateInterval is pattern-driven. It is very
- * similar to formatting in SimpleDateFormat.
- * We introduce class DateIntervalInfo to save date interval 
- * patterns, similar to date time pattern in SimpleDateFormat.
- *
- * <P>
- * Logically, the interval patterns are mappings
- * from (skeleton, the_largest_different_calendar_field)
- * to (date_interval_pattern).
- *
- * <P>
- * A skeleton 
- * <ol>
- * <li>
- * only keeps the field pattern letter and ignores all other parts 
- * in a pattern, such as space, punctuations, and string literals.
- * </li>
- * <li>
- * hides the order of fields. 
- * </li>
- * <li>
- * might hide a field's pattern letter length.
- * </li>
- * </ol>
- *
- * For those non-digit calendar fields, the pattern letter length is 
- * important, such as MMM, MMMM, and MMMMM; EEE and EEEE, 
- * and the field's pattern letter length is honored.
- *    
- * For the digit calendar fields,  such as M or MM, d or dd, yy or yyyy, 
- * the field pattern length is ignored and the best match, which is defined 
- * in date time patterns, will be returned without honor the field pattern
- * letter length in skeleton.
- *
- * <P>
- * The calendar fields we support for interval formatting are:
- * year, month, date, day-of-week, am-pm, hour, hour-of-day, and minute.
- * Those calendar fields can be defined in the following order:
- * year >  month > date > hour (in day) >  minute 
- *  
- * The largest different calendar fields between 2 calendars is the
- * first different calendar field in above order.
- *
- * For example: the largest different calendar fields between "Jan 10, 2007" 
- * and "Feb 20, 2008" is year.
- *
- * <P>
- * For other calendar fields, the compact interval formatting is not
- * supported. And the interval format will be fall back to fall-back
- * patterns, which is mostly "{date0} - {date1}".
- *   
- * <P>
- * There is a set of pre-defined static skeleton strings.
- * There are pre-defined interval patterns for those pre-defined skeletons
- * in locales' resource files.
- * For example, for a skeleton UDAT_YEAR_ABBR_MONTH_DAY, which is  "yMMMd",
- * in  en_US, if the largest different calendar field between date1 and date2 
- * is "year", the date interval pattern  is "MMM d, yyyy - MMM d, yyyy", 
- * such as "Jan 10, 2007 - Jan 10, 2008".
- * If the largest different calendar field between date1 and date2 is "month",
- * the date interval pattern is "MMM d - MMM d, yyyy",
- * such as "Jan 10 - Feb 10, 2007".
- * If the largest different calendar field between date1 and date2 is "day",
- * the date interval pattern is ""MMM d-d, yyyy", such as "Jan 10-20, 2007".
- *
- * For date skeleton, the interval patterns when year, or month, or date is 
- * different are defined in resource files.
- * For time skeleton, the interval patterns when am/pm, or hour, or minute is
- * different are defined in resource files.
- *
- * <P>
- * If a skeleton is not found in a locale's DateIntervalInfo, which means
- * the interval patterns for the skeleton is not defined in resource file,
- * the interval pattern will falls back to the interval "fallback" pattern 
- * defined in resource file.
- * If the interval "fallback" pattern is not defined, the default fall-back
- * is "{date0} - {data1}".
- *
- * <P>
- * For the combination of date and time, 
- * The rule to generate interval patterns are:
- * <ol>
- * <li>
- *    when the year, month, or day differs, falls back to fall-back
- *    interval pattern, which mostly is the concatenate the two original 
- *    expressions with a separator between, 
- *    For example, interval pattern from "Jan 10, 2007 10:10 am" 
- *    to "Jan 11, 2007 10:10am" is 
- *    "Jan 10, 2007 10:10 am - Jan 11, 2007 10:10am" 
- * </li>
- * <li>
- *    otherwise, present the date followed by the range expression 
- *    for the time.
- *    For example, interval pattern from "Jan 10, 2007 10:10 am" 
- *    to "Jan 10, 2007 11:10am" is "Jan 10, 2007 10:10 am - 11:10am" 
- * </li>
- * </ol>
- *
- *
- * <P>
- * If two dates are the same, the interval pattern is the single date pattern.
- * For example, interval pattern from "Jan 10, 2007" to "Jan 10, 2007" is 
- * "Jan 10, 2007".
- *
- * Or if the presenting fields between 2 dates have the exact same values,
- * the interval pattern is the  single date pattern. 
- * For example, if user only requests year and month,
- * the interval pattern from "Jan 10, 2007" to "Jan 20, 2007" is "Jan 2007".
- *
- * <P>
- * DateIntervalFormat needs the following information for correct 
- * formatting: time zone, calendar type, pattern, date format symbols, 
- * and date interval patterns.
- * It can be instantiated in 2 ways:
- * <ol>
- * <li>
- *    create an instance using default or given locale plus given skeleton.
- *    Users are encouraged to created date interval formatter this way and 
- *    to use the pre-defined skeleton macros, such as
- *    UDAT_YEAR_NUM_MONTH, which consists the calendar fields and
- *    the format style. 
- * </li>
- * <li>
- *    create an instance using default or given locale plus given skeleton
- *    plus a given DateIntervalInfo.
- *    This factory method is for powerful users who want to provide their own 
- *    interval patterns. 
- *    Locale provides the timezone, calendar, and format symbols information.
- *    Local plus skeleton provides full pattern information.
- *    DateIntervalInfo provides the date interval patterns.
- * </li>
- * </ol>
- *
- * <P>
- * For the calendar field pattern letter, such as G, y, M, d, a, h, H, m, s etc.
- * DateIntervalFormat uses the same syntax as that of
- * DateTime format.
- * 
- * <P>
- * Code Sample: general usage
- * <pre>
- * \code
- *   // the date interval object which the DateIntervalFormat formats on
- *   // and parses into
- *   DateInterval*  dtInterval = new DateInterval(1000*3600*24, 1000*3600*24*2);
- *   UErrorCode status = U_ZERO_ERROR;
- *   DateIntervalFormat* dtIntervalFmt = DateIntervalFormat::createInstance(
- *                           UDAT_YEAR_MONTH_DAY, 
- *                           Locale("en", "GB", ""), status);
- *   UnicodeUnicodeString dateIntervalString;
- *   FieldPosition pos = 0;
- *   // formatting
- *   dtIntervalFmt->format(dtInterval, dateIntervalUnicodeString, pos, status);
- *   delete dtIntervalFmt;
- * \endcode
- * </pre>
- */
-
-class U_I18N_API DateIntervalFormat : public Format {
-public:
-
-    /**
-     * Construct a DateIntervalFormat from skeleton and  the default locale.
-     *
-     * This is a convenient override of 
-     * createInstance(const UnicodeString& skeleton, const Locale& locale,
-     *                UErrorCode&)  
-     * with the value of locale as default locale.
-     *
-     * @param skeleton  the skeleton on which interval format based.
-     * @param status    output param set to success/failure code on exit
-     * @return          a date time interval formatter which the caller owns.
-     * @draft ICU 4.0
-     */
-    static DateIntervalFormat* U_EXPORT2 createInstance(
-                                               const UnicodeString& skeleton,
-                                               UErrorCode& status);
-
-    /**
-     * Construct a DateIntervalFormat from skeleton and a given locale.
-     * <P>
-     * In this factory method, 
-     * the date interval pattern information is load from resource files.
-     * Users are encouraged to created date interval formatter this way and 
-     * to use the pre-defined skeleton macros.
-     *
-     * <P>
-     * There are pre-defined skeletons (defined in udate.h) having predefined 
-     * interval patterns in resource files.
-     * Users are encouraged to use those macros.
-     * For example: 
-     * DateIntervalFormat::createInstance(UDAT_MONTH_DAY, status) 
-     *
-     * The given Locale provides the interval patterns.
-     * For example, for en_GB, if skeleton is UDAT_YEAR_ABBR_MONTH_WEEKDAY_DAY,
-     * which is "yMMMEEEd",
-     * the interval patterns defined in resource file to above skeleton are:
-     * "EEE, d MMM, yyyy - EEE, d MMM, yyyy" for year differs,
-     * "EEE, d MMM - EEE, d MMM, yyyy" for month differs,
-     * "EEE, d - EEE, d MMM, yyyy" for day differs,
-     * @param skeleton  the skeleton on which interval format based.
-     * @param locale    the given locale
-     * @param status    output param set to success/failure code on exit
-     * @return          a date time interval formatter which the caller owns.
-     * @draft ICU 4.0
-     */
-
-    static DateIntervalFormat* U_EXPORT2 createInstance(
-                                               const UnicodeString& skeleton,
-                                               const Locale& locale,
-                                               UErrorCode& status);
-
-    /**
-     * Construct a DateIntervalFormat from skeleton
-     *  DateIntervalInfo, and default locale.
-     *
-     * This is a convenient override of
-     * createInstance(const UnicodeString& skeleton, const Locale& locale, 
-     *                const DateIntervalInfo& dtitvinf, UErrorCode&)
-     * with the locale value as default locale.
-     *
-     * @param skeleton  the skeleton on which interval format based.
-     * @param dtitvinf  the DateIntervalInfo object. 
-     * @param status    output param set to success/failure code on exit
-     * @return          a date time interval formatter which the caller owns.
-     * @draft ICU 4.0
-     */
-    static DateIntervalFormat* U_EXPORT2 createInstance(
-                                              const UnicodeString& skeleton,
-                                              const DateIntervalInfo& dtitvinf,
-                                              UErrorCode& status);
-
-    /**
-     * Construct a DateIntervalFormat from skeleton
-     * a DateIntervalInfo, and the given locale.
-     *
-     * <P>
-     * In this factory method, user provides its own date interval pattern
-     * information, instead of using those pre-defined data in resource file. 
-     * This factory method is for powerful users who want to provide their own 
-     * interval patterns. 
-     * <P>
-     * There are pre-defined skeletons (defined in udate.h) having predefined 
-     * interval patterns in resource files.
-     * Users are encouraged to use those macros.
-     * For example: 
-     * DateIntervalFormat::createInstance(UDAT_MONTH_DAY, status) 
-     *
-     * The DateIntervalInfo provides the interval patterns.
-     * and the DateIntervalInfo ownership remains to the caller. 
-     *
-     * User are encouraged to set default interval pattern in DateIntervalInfo
-     * as well, if they want to set other interval patterns ( instead of
-     * reading the interval patterns from resource files).
-     * When the corresponding interval pattern for a largest calendar different
-     * field is not found ( if user not set it ), interval format fallback to
-     * the default interval pattern.
-     * If user does not provide default interval pattern, it fallback to
-     * "{date0} - {date1}" 
-     *
-     * @param skeleton  the skeleton on which interval format based.
-     * @param locale    the given locale
-     * @param dtitvinf  the DateIntervalInfo object.
-     * @param status    output param set to success/failure code on exit
-     * @return          a date time interval formatter which the caller owns.
-     * @draft ICU 4.0
-     */
-    static DateIntervalFormat* U_EXPORT2 createInstance(
-                                              const UnicodeString& skeleton,
-                                              const Locale& locale,
-                                              const DateIntervalInfo& dtitvinf,
-                                              UErrorCode& status);
-
-    /**
-     * Destructor.
-     * @draft ICU 4.0
-     */
-    virtual ~DateIntervalFormat();
-
-    /**
-     * Clone this Format object polymorphically. The caller owns the result and
-     * should delete it when done.
-     * @return    A copy of the object.
-     * @draft ICU 4.0
-     */
-    virtual Format* clone(void) const;
-
-    /**
-     * Return true if the given Format objects are semantically equal. Objects
-     * of different subclasses are considered unequal.
-     * @param other    the object to be compared with.
-     * @return         true if the given Format objects are semantically equal.
-     * @draft ICU 4.0
-     */
-    virtual UBool operator==(const Format& other) const;
-
-    /**
-     * Return true if the given Format objects are not semantically equal. 
-     * Objects of different subclasses are considered unequal.
-     * @param other the object to be compared with.
-     * @return      true if the given Format objects are not semantically equal.
-     * @draft ICU 4.0
-     */
-    UBool operator!=(const Format& other) const;
-
-    /**
-     * Format an object to produce a string. This method handles Formattable
-     * objects with a DateInterval type. 
-     * If a the Formattable object type is not a DateInterval,
-     * then it returns a failing UErrorCode.
-     *
-     * @param obj               The object to format. 
-     *                          Must be a DateInterval.
-     * @param appendTo          Output parameter to receive result.
-     *                          Result is appended to existing contents.
-     * @param fieldPosition     On input: an alignment field, if desired.
-     *                          On output: the offsets of the alignment field.
-     * @param status            Output param filled with success/failure status.
-     * @return                  Reference to 'appendTo' parameter.
-     * @draft ICU 4.0
-     */
-    virtual UnicodeString& format(const Formattable& obj,
-                                  UnicodeString& appendTo,
-                                  FieldPosition& fieldPosition,
-                                  UErrorCode& status) const ;
-                                    
-                                    
-
-    /**
-     * Format a DateInterval to produce a string. 
-     *
-     * @param dtInterval        DateInterval to be formatted.
-     * @param appendTo          Output parameter to receive result.
-     *                          Result is appended to existing contents.
-     * @param fieldPosition     On input: an alignment field, if desired.
-     *                          On output: the offsets of the alignment field.
-     * @param status            Output param filled with success/failure status.
-     * @return                  Reference to 'appendTo' parameter.
-     * @draft ICU 4.0
-     */
-    UnicodeString& format(const DateInterval* dtInterval,
-                          UnicodeString& appendTo,
-                          FieldPosition& fieldPosition,
-                          UErrorCode& status) const ;
-                                    
-                                    
-    /**
-     * Format 2 Calendars to produce a string. 
-     *
-     * Note: "fromCalendar" and "toCalendar" are not const,
-     * since calendar is not const in  SimpleDateFormat::format(Calendar&),
-     *
-     * @param fromCalendar      calendar set to the from date in date interval
-     *                          to be formatted into date interval string
-     * @param toCalendar        calendar set to the to date in date interval
-     *                          to be formatted into date interval string
-     * @param appendTo          Output parameter to receive result.
-     *                          Result is appended to existing contents.
-     * @param fieldPosition     On input: an alignment field, if desired.
-     *                          On output: the offsets of the alignment field.
-     * @param status            Output param filled with success/failure status.
-     *                          Caller needs to make sure it is SUCCESS
-     *                          at the function entrance
-     * @return                  Reference to 'appendTo' parameter.
-     * @draft ICU 4.0
-     */
-    UnicodeString& format(Calendar& fromCalendar,
-                          Calendar& toCalendar,
-                          UnicodeString& appendTo,
-                          FieldPosition& fieldPosition,
-                          UErrorCode& status) const ;
-
-    /**
-     * Date interval parsing is not supported. Please do not use.
-     * <P>
-     * This method should handle parsing of
-     * date time interval strings into Formattable objects with 
-     * DateInterval type, which is a pair of UDate.
-     * <P>
-     * Before calling, set parse_pos.index to the offset you want to start
-     * parsing at in the source. After calling, parse_pos.index is the end of
-     * the text you parsed. If error occurs, index is unchanged.
-     * <P>
-     * When parsing, leading whitespace is discarded (with a successful parse),
-     * while trailing whitespace is left as is.
-     * <P>
-     * See Format::parseObject() for more.
-     *
-     * @param source    The string to be parsed into an object.
-     * @param result    Formattable to be set to the parse result.
-     *                  If parse fails, return contents are undefined.
-     * @param parse_pos The position to start parsing at. Since no parsing
-     *                  is supported, upon return this param is unchanged.
-     * @return          A newly created Formattable* object, or NULL
-     *                  on failure.  The caller owns this and should
-     *                  delete it when done.
-     * @internal ICU 4.0
-     */
-    virtual void parseObject(const UnicodeString& source,
-                             Formattable& result,
-                             ParsePosition& parse_pos) const;
-
-
-    /**
-     * Gets the date time interval patterns.
-     * @return the date time interval patterns associated with
-     * this date interval formatter.
-     * @draft ICU 4.0
-     */
-    const DateIntervalInfo* getDateIntervalInfo(void) const;
-
-
-    /**
-     * Set the date time interval patterns. 
-     * @param newIntervalPatterns   the given interval patterns to copy.
-     * @param status          output param set to success/failure code on exit
-     * @draft ICU 4.0
-     */
-    void setDateIntervalInfo(const DateIntervalInfo& newIntervalPatterns,
-                             UErrorCode& status);
-
-
-    /**
-     * Gets the date formatter
-     * @return the date formatter associated with this date interval formatter.
-     * @draft ICU 4.0
-     */
-    const DateFormat* getDateFormat(void) const;
-
-    /**
-     * Return the class ID for this class. This is useful only for comparing to
-     * a return value from getDynamicClassID(). For example:
-     * <pre>
-     * .   Base* polymorphic_pointer = createPolymorphicObject();
-     * .   if (polymorphic_pointer->getDynamicClassID() ==
-     * .       erived::getStaticClassID()) ...
-     * </pre>
-     * @return          The class ID for all objects of this class.
-     * @draft ICU 4.0
-     */
-    static UClassID U_EXPORT2 getStaticClassID(void);
-
-    /**
-     * Returns a unique class ID POLYMORPHICALLY. Pure virtual override. This
-     * method is to implement a simple version of RTTI, since not all C++
-     * compilers support genuine RTTI. Polymorphic operator==() and clone()
-     * methods call this method.
-     *
-     * @return          The class ID for this object. All objects of a
-     *                  given class have the same class ID.  Objects of
-     *                  other classes have different class IDs.
-     * @draft ICU 4.0
-     */
-    virtual UClassID getDynamicClassID(void) const;
-
-protected:
-
-    /**
-     * Copy constructor.
-     * @draft ICU 4.0
-     */
-    DateIntervalFormat(const DateIntervalFormat&);
-
-    /**
-     * Assignment operator.
-     * @draft ICU 4.0
-     */
-    DateIntervalFormat& operator=(const DateIntervalFormat&);
-
-private:
-
-    /*
-     * This is for ICU internal use only. Please do not use.
-     * Save the interval pattern information.
-     * Interval pattern consists of 2 single date patterns and the separator.
-     * For example, interval pattern "MMM d - MMM d, yyyy" consists
-     * a single date pattern "MMM d", another single date pattern "MMM d, yyyy",
-     * and a separator "-".
-     * The pattern is divided into 2 parts. For above example,
-     * the first part is "MMM d - ", and the second part is "MMM d, yyyy".
-     * Also, the first date appears in an interval pattern could be 
-     * the earlier date or the later date.
-     * And such information is saved in the interval pattern as well.
-     * @internal ICU 4.0
-     */
-    struct PatternInfo {
-        UnicodeString firstPart;
-        UnicodeString secondPart;
-        /**
-         * Whether the first date in interval pattern is later date or not.
-         * Fallback format set the default ordering.
-         * And for a particular interval pattern, the order can be 
-         * overriden by prefixing the interval pattern with "latestFirst:" or 
-         * "earliestFirst:"
-         * For example, given 2 date, Jan 10, 2007 to Feb 10, 2007.
-         * if the fallback format is "{0} - {1}", 
-         * and the pattern is "d MMM - d MMM yyyy", the interval format is
-         * "10 Jan - 10 Feb, 2007".
-         * If the pattern is "latestFirst:d MMM - d MMM yyyy", 
-         * the interval format is "10 Feb - 10 Jan, 2007"
-         */
-        UBool         laterDateFirst;
-    };
-
-   
-    /**
-     * default constructor 
-     * @internal ICU 4.0
-     */
-    DateIntervalFormat();
-
-    /**
-     * Construct a DateIntervalFormat from DateFormat,
-     * a DateIntervalInfo, and skeleton.
-     * DateFormat provides the timezone, calendar,
-     * full pattern, and date format symbols information.
-     * It should be a SimpleDateFormat object which 
-     * has a pattern in it.
-     * the DateIntervalInfo provides the interval patterns.
-     *
-     * Note: the DateIntervalFormat takes ownership of both 
-     * DateFormat and DateIntervalInfo objects. 
-     * Caller should not delete them.
-     *
-     * @param dtfmt     the SimpleDateFormat object to be adopted.
-     * @param dtitvinf  the DateIntervalInfo object to be adopted.
-     * @param skeleton  the skeleton of the date formatter
-     * @param status    output param set to success/failure code on exit
-     * @internal ICU 4.0
-     */
-    DateIntervalFormat(DateFormat* dtfmt, DateIntervalInfo* dtItvInfo,
-                       const UnicodeString* skeleton, UErrorCode& status);
-
-    
-    /**
-     * Construct a DateIntervalFormat from DateFormat
-     * and a DateIntervalInfo.
-     *
-     * It is a wrapper of the constructor.
-     *
-     * @param dtfmt     the DateFormat object to be adopted.
-     * @param dtitvinf  the DateIntervalInfo object to be adopted.
-     * @param skeleton  the skeleton of this formatter.
-     * @param status    Output param set to success/failure code.
-     * @return          a date time interval formatter which the caller owns.
-     * @internal ICU 4.0
-     */
-    static DateIntervalFormat* U_EXPORT2 create(DateFormat* dtfmt,
-                                                DateIntervalInfo* dtitvinf,
-                                                const UnicodeString* skeleton,
-                                                UErrorCode& status);
-
-
-    /**
-     *  Below are for generating interval patterns locale to the formatter 
-     */
-
-
-    /**
-     * Format 2 Calendars using fall-back interval pattern
-     *
-     * The full pattern used in this fall-back format is the
-     * full pattern of the date formatter.
-     *
-     * @param fromCalendar      calendar set to the from date in date interval
-     *                          to be formatted into date interval string
-     * @param toCalendar        calendar set to the to date in date interval
-     *                          to be formatted into date interval string
-     * @param appendTo          Output parameter to receive result.
-     *                          Result is appended to existing contents.
-     * @param pos               On input: an alignment field, if desired.
-     *                          On output: the offsets of the alignment field.
-     * @param status            output param set to success/failure code on exit
-     * @return                  Reference to 'appendTo' parameter.
-     * @internal ICU 4.0
-     */
-    UnicodeString& fallbackFormat(Calendar& fromCalendar,
-                                  Calendar& toCalendar,
-                                  UnicodeString& appendTo,
-                                  FieldPosition& pos,
-                                  UErrorCode& status) const;
-
-
-
-    /** 
-     * Initialize interval patterns locale to this formatter
-     * 
-     * This code is a bit complicated since 
-     * 1. the interval patterns saved in resource bundle files are interval
-     *    patterns based on date or time only.
-     *    It does not have interval patterns based on both date and time.
-     *    Interval patterns on both date and time are algorithm generated.
-     *
-     *    For example, it has interval patterns on skeleton "dMy" and "hm",
-     *    but it does not have interval patterns on skeleton "dMyhm".
-     *    
-     *    The rule to generate interval patterns for both date and time skeleton are
-     *    1) when the year, month, or day differs, concatenate the two original 
-     *    expressions with a separator between, 
-     *    For example, interval pattern from "Jan 10, 2007 10:10 am" 
-     *    to "Jan 11, 2007 10:10am" is 
-     *    "Jan 10, 2007 10:10 am - Jan 11, 2007 10:10am" 
-     *
-     *    2) otherwise, present the date followed by the range expression 
-     *    for the time.
-     *    For example, interval pattern from "Jan 10, 2007 10:10 am" 
-     *    to "Jan 10, 2007 11:10am" is 
-     *    "Jan 10, 2007 10:10 am - 11:10am" 
-     *
-     * 2. even a pattern does not request a certain calendar field,
-     *    the interval pattern needs to include such field if such fields are
-     *    different between 2 dates.
-     *    For example, a pattern/skeleton is "hm", but the interval pattern 
-     *    includes year, month, and date when year, month, and date differs.
-     * 
-     *
-     * @param status    output param set to success/failure code on exit
-     * @internal ICU 4.0 
-     */
-    void initializePattern(UErrorCode& status); 
-                              
-
-
-    /**
-     * Set fall back interval pattern given a calendar field,
-     * a skeleton, and a date time pattern generator.
-     * @param field      the largest different calendar field
-     * @param skeleton   a skeleton
-     * @param dtpng      date time pattern generator
-     * @param status     output param set to success/failure code on exit
-     * @internal ICU 4.0 
-     */
-    void setFallbackPattern(UCalendarDateFields field, 
-                            const UnicodeString& skeleton,
-                            DateTimePatternGenerator* dtpng,
-                            UErrorCode& status);
-                            
-
-
-    /** 
-     * get separated date and time skeleton from a combined skeleton.
-     *
-     * The difference between date skeleton and normalizedDateSkeleton are:
-     * 1. both 'y' and 'd' are appeared only once in normalizeDateSkeleton
-     * 2. 'E' and 'EE' are normalized into 'EEE'
-     * 3. 'MM' is normalized into 'M'
-     *
-     ** the difference between time skeleton and normalizedTimeSkeleton are:
-     * 1. both 'H' and 'h' are normalized as 'h' in normalized time skeleton,
-     * 2. 'a' is omitted in normalized time skeleton.
-     * 3. there is only one appearance for 'h', 'm','v', 'z' in normalized time
-     *    skeleton
-     *
-     *
-     *  @param skeleton               given combined skeleton.
-     *  @param date                   Output parameter for date only skeleton.
-     *  @param normalizedDate         Output parameter for normalized date only
-     *
-     *  @param time                   Output parameter for time only skeleton.
-     *  @param normalizedTime         Output parameter for normalized time only
-     *                                skeleton.
-     *
-     * @internal ICU 4.0 
-     */
-    static void  U_EXPORT2 getDateTimeSkeleton(const UnicodeString& skeleton,
-                                    UnicodeString& date,
-                                    UnicodeString& normalizedDate,
-                                    UnicodeString& time,
-                                    UnicodeString& normalizedTime);
-
-
-
-    /**
-     * Generate date or time interval pattern from resource,
-     * and set them into the interval pattern locale to this formatter.
-     *
-     * It needs to handle the following: 
-     * 1. need to adjust field width.
-     *    For example, the interval patterns saved in DateIntervalInfo
-     *    includes "dMMMy", but not "dMMMMy".
-     *    Need to get interval patterns for dMMMMy from dMMMy.
-     *    Another example, the interval patterns saved in DateIntervalInfo
-     *    includes "hmv", but not "hmz".
-     *    Need to get interval patterns for "hmz' from 'hmv'
-     *
-     * 2. there might be no pattern for 'y' differ for skeleton "Md",
-     *    in order to get interval patterns for 'y' differ,
-     *    need to look for it from skeleton 'yMd'
-     *
-     * @param dateSkeleton   normalized date skeleton
-     * @param timeSkeleton   normalized time skeleton
-     * @return               whether the resource is found for the skeleton.
-     *                       TRUE if interval pattern found for the skeleton,
-     *                       FALSE otherwise.
-     * @internal ICU 4.0
-     */
-    UBool setSeparateDateTimePtn(const UnicodeString& dateSkeleton, 
-                                 const UnicodeString& timeSkeleton);
-                                   
-
-
-
-    /**
-     * Generate interval pattern from existing resource
-     *
-     * It not only save the interval patterns,
-     * but also return the extended skeleton and its best match skeleton.
-     *
-     * @param field           largest different calendar field
-     * @param skeleton        skeleton
-     * @param bestSkeleton    the best match skeleton which has interval pattern
-     *                        defined in resource
-     * @param differenceInfo  the difference between skeleton and best skeleton
-     *         0 means the best matched skeleton is the same as input skeleton
-     *         1 means the fields are the same, but field width are different
-     *         2 means the only difference between fields are v/z,
-     *        -1 means there are other fields difference 
-     *
-     * @param extendedSkeleton      extended skeleton
-     * @param extendedBestSkeleton  extended best match skeleton
-     * @return                      whether the interval pattern is found 
-     *                              through extending skeleton or not.
-     *                              TRUE if interval pattern is found by
-     *                              extending skeleton, FALSE otherwise.
-     * @internal ICU 4.0
-     */
-    UBool setIntervalPattern(UCalendarDateFields field, 
-                             const UnicodeString* skeleton, 
-                             const UnicodeString* bestSkeleton, 
-                             int8_t differenceInfo, 
-                             UnicodeString* extendedSkeleton = NULL,
-                             UnicodeString* extendedBestSkeleton = NULL);
-
-    /**
-     * Adjust field width in best match interval pattern to match
-     * the field width in input skeleton.
-     *
-     * TODO (xji) make a general solution
-     * The adjusting rule can be:
-     * 1. always adjust
-     * 2. never adjust
-     * 3. default adjust, which means adjust according to the following rules
-     * 3.1 always adjust string, such as MMM and MMMM
-     * 3.2 never adjust between string and numeric, such as MM and MMM
-     * 3.3 always adjust year
-     * 3.4 do not adjust 'd', 'h', or 'm' if h presents
-     * 3.5 do not adjust 'M' if it is numeric(?)
-     *
-     * Since date interval format is well-formed format,
-     * date and time skeletons are normalized previously,
-     * till this stage, the adjust here is only "adjust strings, such as MMM
-     * and MMMM, EEE and EEEE.
-     *
-     * @param inputSkeleton            the input skeleton
-     * @param bestMatchSkeleton        the best match skeleton
-     * @param bestMatchIntervalpattern the best match interval pattern
-     * @param differenceInfo           the difference between 2 skeletons
-     *                                 1 means only field width differs
-     *                                 2 means v/z exchange
-     * @param adjustedIntervalPattern  adjusted interval pattern
-     * @internal ICU 4.0
-     */
-    static void U_EXPORT2 adjustFieldWidth(
-                            const UnicodeString& inputSkeleton,
-                            const UnicodeString& bestMatchSkeleton,
-                            const UnicodeString& bestMatchIntervalPattern,
-                            int8_t differenceInfo,
-                            UnicodeString& adjustedIntervalPattern);
-
-    /**
-     * Concat a single date pattern with a time interval pattern,
-     * set it into the intervalPatterns, while field is time field.
-     * This is used to handle time interval patterns on skeleton with
-     * both time and date. Present the date followed by 
-     * the range expression for the time.
-     * @param format         date and time format
-     * @param formatLen      format string length
-     * @param datePattern    date pattern
-     * @param field          time calendar field: AM_PM, HOUR, MINUTE
-     * @param status         output param set to success/failure code on exit
-     * @internal ICU 4.0 
-     */
-    void concatSingleDate2TimeInterval(const UChar* format,
-                                       int32_t formatLen,
-                                       const UnicodeString& datePattern,
-                                       UCalendarDateFields field,
-                                       UErrorCode& status); 
-
-    /**
-     * check whether a calendar field present in a skeleton.
-     * @param field      calendar field need to check
-     * @param skeleton   given skeleton on which to check the calendar field
-     * @return           true if field present in a skeleton.
-     * @internal ICU 4.0 
-     */
-    static UBool U_EXPORT2 fieldExistsInSkeleton(UCalendarDateFields field, 
-                                                 const UnicodeString& skeleton);
-
-
-    /**
-     * Split interval patterns into 2 part.
-     * @param intervalPattern  interval pattern
-     * @return the index in interval pattern which split the pattern into 2 part
-     * @internal ICU 4.0
-     */
-    static int32_t  U_EXPORT2 splitPatternInto2Part(const UnicodeString& intervalPattern);
-
-
-    /**
-     * Break interval patterns as 2 part and save them into pattern info.
-     * @param field            calendar field
-     * @param intervalPattern  interval pattern
-     * @internal ICU 4.0
-     */
-    void setIntervalPattern(UCalendarDateFields field,
-                            const UnicodeString& intervalPattern);
-
-
-    /**
-     * Break interval patterns as 2 part and save them into pattern info.
-     * @param field            calendar field
-     * @param intervalPattern  interval pattern
-     * @param laterDateFirst   whether later date appear first in interval pattern
-     * @internal ICU 4.0
-     */
-    void setIntervalPattern(UCalendarDateFields field,
-                            const UnicodeString& intervalPattern,
-                            UBool laterDateFirst);
-
-
-    /**
-     * Set pattern information.
-     *
-     * @param field            calendar field
-     * @param firstPart        the first part in interval pattern
-     * @param secondPart       the second part in interval pattern
-     * @param laterDateFirst   whether the first date in intervalPattern
-     *                         is earlier date or later date
-     * @internal ICU 4.0
-     */
-    void setPatternInfo(UCalendarDateFields field,
-                        const UnicodeString* firstPart,
-                        const UnicodeString* secondpart,
-                        UBool laterDateFirst);
-
-
-    // from calendar field to pattern letter
-    static const UChar fgCalendarFieldToPatternLetter[];
-
-
-    /**
-     * The interval patterns for this locale.
-     */
-    DateIntervalInfo*     fInfo;
-
-    /**
-     * The DateFormat object used to format single pattern
-     */
-    SimpleDateFormat*     fDateFormat;
-
-    /**
-     * The 2 calendars with the from and to date.
-     * could re-use the calendar in fDateFormat,
-     * but keeping 2 calendars make it clear and clean.
-     */
-    Calendar* fFromCalendar;
-    Calendar* fToCalendar;
-
-    /**
-     * Following are interval information relavent (locale) to this formatter.
-     */
-    UnicodeString fSkeleton;
-    PatternInfo fIntervalPatterns[DateIntervalInfo::kIPI_MAX_INDEX];
-};
- 
-
-
- 
-
-
-inline UBool 
-DateIntervalFormat::operator!=(const Format& other) const  {
-    return !operator==(other); 
-}
- 
-U_NAMESPACE_END
-
-#endif /* #if !UCONFIG_NO_FORMATTING */
-
-#endif // _DTITVFMT_H__
-//eof


[46/57] [abbrv] remove couch_replicator

Posted by be...@apache.org.
http://git-wip-us.apache.org/repos/asf/couchdb/blob/4c39d7a5/apps/couch_replicator/src/couch_replicator_httpc.erl
----------------------------------------------------------------------
diff --git a/apps/couch_replicator/src/couch_replicator_httpc.erl b/apps/couch_replicator/src/couch_replicator_httpc.erl
deleted file mode 100644
index c13bf18..0000000
--- a/apps/couch_replicator/src/couch_replicator_httpc.erl
+++ /dev/null
@@ -1,297 +0,0 @@
-% Licensed 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.
-
--module(couch_replicator_httpc).
-
--include_lib("couch/include/couch_db.hrl").
--include("couch_replicator_api_wrap.hrl").
--include_lib("ibrowse/include/ibrowse.hrl").
-
--export([setup/1]).
--export([send_req/3]).
--export([full_url/2]).
-
--import(couch_util, [
-    get_value/2,
-    get_value/3
-]).
-
--define(replace(L, K, V), lists:keystore(K, 1, L, {K, V})).
--define(MAX_WAIT, 5 * 60 * 1000).
-
-
-setup(#httpdb{httpc_pool = nil, url = Url, http_connections = MaxConns} = Db) ->
-    {ok, Pid} = couch_replicator_httpc_pool:start_link(Url, [{max_connections, MaxConns}]),
-    {ok, Db#httpdb{httpc_pool = Pid}}.
-
-
-send_req(HttpDb, Params1, Callback) ->
-    Params2 = ?replace(Params1, qs,
-        [{K, ?b2l(iolist_to_binary(V))} || {K, V} <- get_value(qs, Params1, [])]),
-    Params = ?replace(Params2, ibrowse_options,
-        lists:keysort(1, get_value(ibrowse_options, Params2, []))),
-    {Worker, Response} = send_ibrowse_req(HttpDb, Params),
-    process_response(Response, Worker, HttpDb, Params, Callback).
-
-
-send_ibrowse_req(#httpdb{headers = BaseHeaders} = HttpDb, Params) ->
-    Method = get_value(method, Params, get),
-    UserHeaders = lists:keysort(1, get_value(headers, Params, [])),
-    Headers1 = lists:ukeymerge(1, UserHeaders, BaseHeaders),
-    Headers2 = oauth_header(HttpDb, Params) ++ Headers1,
-    Url = full_url(HttpDb, Params),
-    Body = get_value(body, Params, []),
-    case get_value(path, Params) of
-    "_changes" ->
-        {ok, Worker} = ibrowse:spawn_link_worker_process(Url);
-    _ ->
-        {ok, Worker} = couch_replicator_httpc_pool:get_worker(HttpDb#httpdb.httpc_pool)
-    end,
-    IbrowseOptions = [
-        {response_format, binary}, {inactivity_timeout, HttpDb#httpdb.timeout} |
-        lists:ukeymerge(1, get_value(ibrowse_options, Params, []),
-            HttpDb#httpdb.ibrowse_options)
-    ],
-    Response = ibrowse:send_req_direct(
-        Worker, Url, Headers2, Method, Body, IbrowseOptions, infinity),
-    {Worker, Response}.
-
-
-process_response({error, sel_conn_closed}, _Worker, HttpDb, Params, Callback) ->
-    send_req(HttpDb, Params, Callback);
-
-process_response({error, {'EXIT', {normal, _}}}, _Worker, HttpDb, Params, Cb) ->
-    % ibrowse worker terminated because remote peer closed the socket
-    % -> not an error
-    send_req(HttpDb, Params, Cb);
-
-process_response({ibrowse_req_id, ReqId}, Worker, HttpDb, Params, Callback) ->
-    process_stream_response(ReqId, Worker, HttpDb, Params, Callback);
-
-process_response({ok, Code, Headers, Body}, Worker, HttpDb, Params, Callback) ->
-    release_worker(Worker, HttpDb),
-    case list_to_integer(Code) of
-    Ok when (Ok >= 200 andalso Ok < 300) ; (Ok >= 400 andalso Ok < 500) ->
-        EJson = case Body of
-        <<>> ->
-            null;
-        Json ->
-            ?JSON_DECODE(Json)
-        end,
-        Callback(Ok, Headers, EJson);
-    R when R =:= 301 ; R =:= 302 ; R =:= 303 ->
-        do_redirect(Worker, R, Headers, HttpDb, Params, Callback);
-    Error ->
-        maybe_retry({code, Error}, Worker, HttpDb, Params, Callback)
-    end;
-
-process_response(Error, Worker, HttpDb, Params, Callback) ->
-    maybe_retry(Error, Worker, HttpDb, Params, Callback).
-
-
-process_stream_response(ReqId, Worker, HttpDb, Params, Callback) ->
-    receive
-    {ibrowse_async_headers, ReqId, Code, Headers} ->
-        case list_to_integer(Code) of
-        Ok when (Ok >= 200 andalso Ok < 300) ; (Ok >= 400 andalso Ok < 500) ->
-            StreamDataFun = fun() ->
-                stream_data_self(HttpDb, Params, Worker, ReqId, Callback)
-            end,
-            ibrowse:stream_next(ReqId),
-            try
-                Ret = Callback(Ok, Headers, StreamDataFun),
-                release_worker(Worker, HttpDb),
-                clean_mailbox_req(ReqId),
-                Ret
-            catch throw:{maybe_retry_req, Err} ->
-                clean_mailbox_req(ReqId),
-                maybe_retry(Err, Worker, HttpDb, Params, Callback)
-            end;
-        R when R =:= 301 ; R =:= 302 ; R =:= 303 ->
-            do_redirect(Worker, R, Headers, HttpDb, Params, Callback);
-        Error ->
-            report_error(Worker, HttpDb, Params, {code, Error})
-        end;
-    {ibrowse_async_response, ReqId, {error, _} = Error} ->
-        maybe_retry(Error, Worker, HttpDb, Params, Callback)
-    after HttpDb#httpdb.timeout + 500 ->
-        % Note: ibrowse should always reply with timeouts, but this doesn't
-        % seem to be always true when there's a very high rate of requests
-        % and many open connections.
-        maybe_retry(timeout, Worker, HttpDb, Params, Callback)
-    end.
-
-
-clean_mailbox_req(ReqId) ->
-    receive
-    {ibrowse_async_response, ReqId, _} ->
-        clean_mailbox_req(ReqId);
-    {ibrowse_async_response_end, ReqId} ->
-        clean_mailbox_req(ReqId)
-    after 0 ->
-        ok
-    end.
-
-
-release_worker(Worker, #httpdb{httpc_pool = Pool}) ->
-    ok = couch_replicator_httpc_pool:release_worker(Pool, Worker).
-
-
-maybe_retry(Error, Worker, #httpdb{retries = 0} = HttpDb, Params, _Cb) ->
-    report_error(Worker, HttpDb, Params, {error, Error});
-
-maybe_retry(Error, Worker, #httpdb{retries = Retries, wait = Wait} = HttpDb,
-    Params, Cb) ->
-    release_worker(Worker, HttpDb),
-    Method = string:to_upper(atom_to_list(get_value(method, Params, get))),
-    Url = couch_util:url_strip_password(full_url(HttpDb, Params)),
-    ?LOG_INFO("Retrying ~s request to ~s in ~p seconds due to error ~s",
-        [Method, Url, Wait / 1000, error_cause(Error)]),
-    ok = timer:sleep(Wait),
-    Wait2 = erlang:min(Wait * 2, ?MAX_WAIT),
-    send_req(HttpDb#httpdb{retries = Retries - 1, wait = Wait2}, Params, Cb).
-
-
-report_error(Worker, HttpDb, Params, Error) ->
-    Method = string:to_upper(atom_to_list(get_value(method, Params, get))),
-    Url = couch_util:url_strip_password(full_url(HttpDb, Params)),
-    do_report_error(Url, Method, Error),
-    release_worker(Worker, HttpDb),
-    exit({http_request_failed, Method, Url, Error}).
-
-
-do_report_error(Url, Method, {code, Code}) ->
-    ?LOG_ERROR("Replicator, request ~s to ~p failed. The received "
-        "HTTP error code is ~p", [Method, Url, Code]);
-
-do_report_error(FullUrl, Method, Error) ->
-    ?LOG_ERROR("Replicator, request ~s to ~p failed due to error ~s",
-        [Method, FullUrl, error_cause(Error)]).
-
-
-error_cause({error, Cause}) ->
-    lists:flatten(io_lib:format("~p", [Cause]));
-error_cause(Cause) ->
-    lists:flatten(io_lib:format("~p", [Cause])).
-
-
-stream_data_self(#httpdb{timeout = T} = HttpDb, Params, Worker, ReqId, Cb) ->
-    case accumulate_messages(ReqId, [], T + 500) of
-    {Data, ibrowse_async_response} ->
-        ibrowse:stream_next(ReqId),
-        {Data, fun() -> stream_data_self(HttpDb, Params, Worker, ReqId, Cb) end};
-    {Data, ibrowse_async_response_end} ->
-        {Data, fun() -> throw({maybe_retry_req, more_data_expected}) end}
-    end.
-
-accumulate_messages(ReqId, Acc, Timeout) ->
-    receive
-    {ibrowse_async_response, ReqId, {error, Error}} ->
-        throw({maybe_retry_req, Error});
-    {ibrowse_async_response, ReqId, <<>>} ->
-        accumulate_messages(ReqId, Acc, Timeout);
-    {ibrowse_async_response, ReqId, Data} ->
-        accumulate_messages(ReqId, [Data | Acc], 0);
-    {ibrowse_async_response_end, ReqId} ->
-        {iolist_to_binary(lists:reverse(Acc)), ibrowse_async_response_end}
-    after Timeout ->
-        % Note: ibrowse should always reply with timeouts, but this doesn't
-        % seem to be always true when there's a very high rate of requests
-        % and many open connections.
-        if Acc =:= [] ->
-            throw({maybe_retry_req, timeout});
-        true ->
-            {iolist_to_binary(lists:reverse(Acc)), ibrowse_async_response}
-        end
-    end.
-
-
-full_url(#httpdb{url = BaseUrl}, Params) ->
-    Path = get_value(path, Params, []),
-    QueryArgs = get_value(qs, Params, []),
-    BaseUrl ++ Path ++ query_args_to_string(QueryArgs, []).
-
-
-query_args_to_string([], []) ->
-    "";
-query_args_to_string([], Acc) ->
-    "?" ++ string:join(lists:reverse(Acc), "&");
-query_args_to_string([{K, V} | Rest], Acc) ->
-    query_args_to_string(Rest, [K ++ "=" ++ couch_httpd:quote(V) | Acc]).
-
-
-oauth_header(#httpdb{oauth = nil}, _ConnParams) ->
-    [];
-oauth_header(#httpdb{url = BaseUrl, oauth = OAuth}, ConnParams) ->
-    Consumer = {
-        OAuth#oauth.consumer_key,
-        OAuth#oauth.consumer_secret,
-        OAuth#oauth.signature_method
-    },
-    Method = case get_value(method, ConnParams, get) of
-    get -> "GET";
-    post -> "POST";
-    put -> "PUT";
-    head -> "HEAD"
-    end,
-    QSL = get_value(qs, ConnParams, []),
-    OAuthParams = oauth:sign(Method,
-        BaseUrl ++ get_value(path, ConnParams, []),
-        QSL, Consumer, OAuth#oauth.token, OAuth#oauth.token_secret) -- QSL,
-    [{"Authorization",
-        "OAuth " ++ oauth:header_params_encode(OAuthParams)}].
-
-
-do_redirect(Worker, Code, Headers, #httpdb{url = Url} = HttpDb, Params, Cb) ->
-    release_worker(Worker, HttpDb),
-    RedirectUrl = redirect_url(Headers, Url),
-    {HttpDb2, Params2} = after_redirect(RedirectUrl, Code, HttpDb, Params),
-    send_req(HttpDb2, Params2, Cb).
-
-
-redirect_url(RespHeaders, OrigUrl) ->
-    MochiHeaders = mochiweb_headers:make(RespHeaders),
-    RedUrl = mochiweb_headers:get_value("Location", MochiHeaders),
-    #url{
-        host = Host,
-        host_type = HostType,
-        port = Port,
-        path = Path,  % includes query string
-        protocol = Proto
-    } = ibrowse_lib:parse_url(RedUrl),
-    #url{
-        username = User,
-        password = Passwd
-    } = ibrowse_lib:parse_url(OrigUrl),
-    Creds = case is_list(User) andalso is_list(Passwd) of
-    true ->
-        User ++ ":" ++ Passwd ++ "@";
-    false ->
-        []
-    end,
-    HostPart = case HostType of
-    ipv6_address ->
-        "[" ++ Host ++ "]";
-    _ ->
-        Host
-    end,
-    atom_to_list(Proto) ++ "://" ++ Creds ++ HostPart ++ ":" ++
-        integer_to_list(Port) ++ Path.
-
-after_redirect(RedirectUrl, 303, HttpDb, Params) ->
-    after_redirect(RedirectUrl, HttpDb, ?replace(Params, method, get));
-after_redirect(RedirectUrl, _Code, HttpDb, Params) ->
-    after_redirect(RedirectUrl, HttpDb, Params).
-
-after_redirect(RedirectUrl, HttpDb, Params) ->
-    Params2 = lists:keydelete(path, 1, lists:keydelete(qs, 1, Params)),
-    {HttpDb#httpdb{url = RedirectUrl}, Params2}.

http://git-wip-us.apache.org/repos/asf/couchdb/blob/4c39d7a5/apps/couch_replicator/src/couch_replicator_httpc_pool.erl
----------------------------------------------------------------------
diff --git a/apps/couch_replicator/src/couch_replicator_httpc_pool.erl b/apps/couch_replicator/src/couch_replicator_httpc_pool.erl
deleted file mode 100644
index a82a2df..0000000
--- a/apps/couch_replicator/src/couch_replicator_httpc_pool.erl
+++ /dev/null
@@ -1,138 +0,0 @@
-% Licensed 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.
-
--module(couch_replicator_httpc_pool).
--behaviour(gen_server).
-
-% public API
--export([start_link/2, stop/1]).
--export([get_worker/1, release_worker/2]).
-
-% gen_server API
--export([init/1, handle_call/3, handle_info/2, handle_cast/2]).
--export([code_change/3, terminate/2]).
-
--include_lib("couch/include/couch_db.hrl").
-
--import(couch_util, [
-    get_value/2,
-    get_value/3
-]).
-
--record(state, {
-    url,
-    limit,                  % max # of workers allowed
-    free = [],              % free workers (connections)
-    busy = [],              % busy workers (connections)
-    waiting = queue:new()   % blocked clients waiting for a worker
-}).
-
-
-start_link(Url, Options) ->
-    gen_server:start_link(?MODULE, {Url, Options}, []).
-
-
-stop(Pool) ->
-    ok = gen_server:call(Pool, stop, infinity).
-
-
-get_worker(Pool) ->
-    {ok, _Worker} = gen_server:call(Pool, get_worker, infinity).
-
-
-release_worker(Pool, Worker) ->
-    ok = gen_server:cast(Pool, {release_worker, Worker}).
-
-
-init({Url, Options}) ->
-    process_flag(trap_exit, true),
-    State = #state{
-        url = Url,
-        limit = get_value(max_connections, Options)
-    },
-    {ok, State}.
-
-
-handle_call(get_worker, From, #state{waiting = Waiting} = State) ->
-    #state{url = Url, limit = Limit, busy = Busy, free = Free} = State,
-    case length(Busy) >= Limit of
-    true ->
-        {noreply, State#state{waiting = queue:in(From, Waiting)}};
-    false ->
-        case Free of
-        [] ->
-           {ok, Worker} = ibrowse:spawn_link_worker_process(Url),
-           Free2 = Free;
-        [Worker | Free2] ->
-           ok
-        end,
-        NewState = State#state{free = Free2, busy = [Worker | Busy]},
-        {reply, {ok, Worker}, NewState}
-    end;
-
-handle_call(stop, _From, State) ->
-    {stop, normal, ok, State}.
-
-
-handle_cast({release_worker, Worker}, #state{waiting = Waiting} = State) ->
-    case is_process_alive(Worker) andalso
-        lists:member(Worker, State#state.busy) of
-    true ->
-        case queue:out(Waiting) of
-        {empty, Waiting2} ->
-            Busy2 = State#state.busy -- [Worker],
-            Free2 = [Worker | State#state.free];
-        {{value, From}, Waiting2} ->
-            gen_server:reply(From, {ok, Worker}),
-            Busy2 = State#state.busy,
-            Free2 = State#state.free
-        end,
-        NewState = State#state{
-           busy = Busy2,
-           free = Free2,
-           waiting = Waiting2
-        },
-        {noreply, NewState};
-   false ->
-        {noreply, State}
-   end.
-
-
-handle_info({'EXIT', Pid, _Reason}, #state{busy = Busy, free = Free} = State) ->
-    case Free -- [Pid] of
-    Free ->
-        case Busy -- [Pid] of
-        Busy ->
-            {noreply, State};
-        Busy2 ->
-            case queue:out(State#state.waiting) of
-            {empty, _} ->
-                {noreply, State#state{busy = Busy2}};
-            {{value, From}, Waiting2} ->
-                {ok, Worker} = ibrowse:spawn_link_worker_process(State#state.url),
-                gen_server:reply(From, {ok, Worker}),
-                {noreply, State#state{busy = [Worker | Busy2], waiting = Waiting2}}
-            end
-        end;
-    Free2 ->
-        {noreply, State#state{free = Free2}}
-    end.
-
-
-code_change(_OldVsn, State, _Extra) ->
-    {ok, State}.
-
-
-terminate(_Reason, State) ->
-    lists:foreach(fun ibrowse_http_client:stop/1, State#state.free),
-    lists:foreach(fun ibrowse_http_client:stop/1, State#state.busy).
-

http://git-wip-us.apache.org/repos/asf/couchdb/blob/4c39d7a5/apps/couch_replicator/src/couch_replicator_httpd.erl
----------------------------------------------------------------------
diff --git a/apps/couch_replicator/src/couch_replicator_httpd.erl b/apps/couch_replicator/src/couch_replicator_httpd.erl
deleted file mode 100644
index 0a21d52..0000000
--- a/apps/couch_replicator/src/couch_replicator_httpd.erl
+++ /dev/null
@@ -1,66 +0,0 @@
-% Licensed 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.
-
--module(couch_replicator_httpd).
-
--include_lib("couch/include/couch_db.hrl").
-
--import(couch_httpd, [
-    send_json/2,
-    send_json/3,
-    send_method_not_allowed/2
-]).
-
--import(couch_util, [
-    to_binary/1
-]).
-
--export([handle_req/1]).
-
-
-handle_req(#httpd{method = 'POST', user_ctx = UserCtx} = Req) ->
-    couch_httpd:validate_ctype(Req, "application/json"),
-    RepDoc = {Props} = couch_httpd:json_body_obj(Req),
-    validate_rep_props(Props),
-    {ok, Rep} = couch_replicator_utils:parse_rep_doc(RepDoc, UserCtx),
-    case couch_replicator:replicate(Rep) of
-    {error, {Error, Reason}} ->
-        send_json(
-            Req, 500,
-            {[{error, to_binary(Error)}, {reason, to_binary(Reason)}]});
-    {error, not_found} ->
-        % Tried to cancel a replication that didn't exist.
-        send_json(Req, 404, {[{error, <<"not found">>}]});
-    {error, Reason} ->
-        send_json(Req, 500, {[{error, to_binary(Reason)}]});
-    {ok, {cancelled, RepId}} ->
-        send_json(Req, 200, {[{ok, true}, {<<"_local_id">>, RepId}]});
-    {ok, {continuous, RepId}} ->
-        send_json(Req, 202, {[{ok, true}, {<<"_local_id">>, RepId}]});
-    {ok, {HistoryResults}} ->
-        send_json(Req, {[{ok, true} | HistoryResults]})
-    end;
-
-handle_req(Req) ->
-    send_method_not_allowed(Req, "POST").
-
-validate_rep_props([]) ->
-    ok;
-validate_rep_props([{<<"query_params">>, {Params}}|Rest]) ->
-    lists:foreach(fun
-        ({_,V}) when is_binary(V) -> ok;
-        ({K,_}) -> throw({bad_request,
-            <<K/binary," value must be a string.">>})
-        end, Params),
-    validate_rep_props(Rest);
-validate_rep_props([_|Rest]) ->
-    validate_rep_props(Rest).

http://git-wip-us.apache.org/repos/asf/couchdb/blob/4c39d7a5/apps/couch_replicator/src/couch_replicator_job_sup.erl
----------------------------------------------------------------------
diff --git a/apps/couch_replicator/src/couch_replicator_job_sup.erl b/apps/couch_replicator/src/couch_replicator_job_sup.erl
deleted file mode 100644
index 484cc1a..0000000
--- a/apps/couch_replicator/src/couch_replicator_job_sup.erl
+++ /dev/null
@@ -1,31 +0,0 @@
-% Licensed 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.
-
--module(couch_replicator_job_sup).
--behaviour(supervisor).
--export([init/1, start_link/0]).
-
--include_lib("couch/include/couch_db.hrl").
-
-start_link() ->
-    supervisor:start_link({local,?MODULE}, ?MODULE, []).
-
-%%=============================================================================
-%% supervisor callbacks
-%%=============================================================================
-
-init([]) ->
-    {ok, {{one_for_one, 3, 10}, []}}.
-
-%%=============================================================================
-%% internal functions
-%%=============================================================================

http://git-wip-us.apache.org/repos/asf/couchdb/blob/4c39d7a5/apps/couch_replicator/src/couch_replicator_js_functions.hrl
----------------------------------------------------------------------
diff --git a/apps/couch_replicator/src/couch_replicator_js_functions.hrl b/apps/couch_replicator/src/couch_replicator_js_functions.hrl
deleted file mode 100644
index 3f1db7c..0000000
--- a/apps/couch_replicator/src/couch_replicator_js_functions.hrl
+++ /dev/null
@@ -1,151 +0,0 @@
-% Licensed 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.
-
--define(REP_DB_DOC_VALIDATE_FUN, <<"
-    function(newDoc, oldDoc, userCtx) {
-        function reportError(error_msg) {
-            log('Error writing document `' + newDoc._id +
-                '\\' to the replicator database: ' + error_msg);
-            throw({forbidden: error_msg});
-        }
-
-        function validateEndpoint(endpoint, fieldName) {
-            if ((typeof endpoint !== 'string') &&
-                ((typeof endpoint !== 'object') || (endpoint === null))) {
-
-                reportError('The `' + fieldName + '\\' property must exist' +
-                    ' and be either a string or an object.');
-            }
-
-            if (typeof endpoint === 'object') {
-                if ((typeof endpoint.url !== 'string') || !endpoint.url) {
-                    reportError('The url property must exist in the `' +
-                        fieldName + '\\' field and must be a non-empty string.');
-                }
-
-                if ((typeof endpoint.auth !== 'undefined') &&
-                    ((typeof endpoint.auth !== 'object') ||
-                        endpoint.auth === null)) {
-
-                    reportError('`' + fieldName +
-                        '.auth\\' must be a non-null object.');
-                }
-
-                if ((typeof endpoint.headers !== 'undefined') &&
-                    ((typeof endpoint.headers !== 'object') ||
-                        endpoint.headers === null)) {
-
-                    reportError('`' + fieldName +
-                        '.headers\\' must be a non-null object.');
-                }
-            }
-        }
-
-        var isReplicator = (userCtx.roles.indexOf('_replicator') >= 0);
-        var isAdmin = (userCtx.roles.indexOf('_admin') >= 0);
-
-        if (oldDoc && !newDoc._deleted && !isReplicator &&
-            (oldDoc._replication_state === 'triggered')) {
-            reportError('Only the replicator can edit replication documents ' +
-                'that are in the triggered state.');
-        }
-
-        if (!newDoc._deleted) {
-            validateEndpoint(newDoc.source, 'source');
-            validateEndpoint(newDoc.target, 'target');
-
-            if ((typeof newDoc.create_target !== 'undefined') &&
-                (typeof newDoc.create_target !== 'boolean')) {
-
-                reportError('The `create_target\\' field must be a boolean.');
-            }
-
-            if ((typeof newDoc.continuous !== 'undefined') &&
-                (typeof newDoc.continuous !== 'boolean')) {
-
-                reportError('The `continuous\\' field must be a boolean.');
-            }
-
-            if ((typeof newDoc.doc_ids !== 'undefined') &&
-                !isArray(newDoc.doc_ids)) {
-
-                reportError('The `doc_ids\\' field must be an array of strings.');
-            }
-
-            if ((typeof newDoc.filter !== 'undefined') &&
-                ((typeof newDoc.filter !== 'string') || !newDoc.filter)) {
-
-                reportError('The `filter\\' field must be a non-empty string.');
-            }
-
-            if ((typeof newDoc.query_params !== 'undefined') &&
-                ((typeof newDoc.query_params !== 'object') ||
-                    newDoc.query_params === null)) {
-
-                reportError('The `query_params\\' field must be an object.');
-            }
-
-            if (newDoc.user_ctx) {
-                var user_ctx = newDoc.user_ctx;
-
-                if ((typeof user_ctx !== 'object') || (user_ctx === null)) {
-                    reportError('The `user_ctx\\' property must be a ' +
-                        'non-null object.');
-                }
-
-                if (!(user_ctx.name === null ||
-                    (typeof user_ctx.name === 'undefined') ||
-                    ((typeof user_ctx.name === 'string') &&
-                        user_ctx.name.length > 0))) {
-
-                    reportError('The `user_ctx.name\\' property must be a ' +
-                        'non-empty string or null.');
-                }
-
-                if (!isAdmin && (user_ctx.name !== userCtx.name)) {
-                    reportError('The given `user_ctx.name\\' is not valid');
-                }
-
-                if (user_ctx.roles && !isArray(user_ctx.roles)) {
-                    reportError('The `user_ctx.roles\\' property must be ' +
-                        'an array of strings.');
-                }
-
-                if (!isAdmin && user_ctx.roles) {
-                    for (var i = 0; i < user_ctx.roles.length; i++) {
-                        var role = user_ctx.roles[i];
-
-                        if (typeof role !== 'string' || role.length === 0) {
-                            reportError('Roles must be non-empty strings.');
-                        }
-                        if (userCtx.roles.indexOf(role) === -1) {
-                            reportError('Invalid role (`' + role +
-                                '\\') in the `user_ctx\\'');
-                        }
-                    }
-                }
-            } else {
-                if (!isAdmin) {
-                    reportError('The `user_ctx\\' property is missing (it is ' +
-                       'optional for admins only).');
-                }
-            }
-        } else {
-            if (!isAdmin) {
-                if (!oldDoc.user_ctx || (oldDoc.user_ctx.name !== userCtx.name)) {
-                    reportError('Replication documents can only be deleted by ' +
-                        'admins or by the users who created them.');
-                }
-            }
-        }
-    }
-">>).

http://git-wip-us.apache.org/repos/asf/couchdb/blob/4c39d7a5/apps/couch_replicator/src/couch_replicator_manager.erl
----------------------------------------------------------------------
diff --git a/apps/couch_replicator/src/couch_replicator_manager.erl b/apps/couch_replicator/src/couch_replicator_manager.erl
deleted file mode 100644
index 8055727..0000000
--- a/apps/couch_replicator/src/couch_replicator_manager.erl
+++ /dev/null
@@ -1,709 +0,0 @@
-% Licensed 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.
-
--module(couch_replicator_manager).
--behaviour(gen_server).
-
-% public API
--export([replication_started/1, replication_completed/2, replication_error/2]).
-
--export([before_doc_update/2, after_doc_read/2]).
-
-% gen_server callbacks
--export([start_link/0, init/1, handle_call/3, handle_info/2, handle_cast/2]).
--export([code_change/3, terminate/2]).
-
--include_lib("couch/include/couch_db.hrl").
--include("couch_replicator.hrl").
--include("couch_replicator_js_functions.hrl").
-
--define(DOC_TO_REP, couch_rep_doc_id_to_rep_id).
--define(REP_TO_STATE, couch_rep_id_to_rep_state).
--define(INITIAL_WAIT, 2.5). % seconds
--define(MAX_WAIT, 600).     % seconds
--define(OWNER, <<"owner">>).
-
--define(replace(L, K, V), lists:keystore(K, 1, L, {K, V})).
-
--record(rep_state, {
-    rep,
-    starting,
-    retries_left,
-    max_retries,
-    wait = ?INITIAL_WAIT
-}).
-
--import(couch_util, [
-    get_value/2,
-    get_value/3,
-    to_binary/1
-]).
-
--record(state, {
-    changes_feed_loop = nil,
-    db_notifier = nil,
-    rep_db_name = nil,
-    rep_start_pids = [],
-    max_retries
-}).
-
-
-start_link() ->
-    gen_server:start_link({local, ?MODULE}, ?MODULE, [], []).
-
-
-replication_started(#rep{id = {BaseId, _} = RepId}) ->
-    case rep_state(RepId) of
-    nil ->
-        ok;
-    #rep_state{rep = #rep{doc_id = DocId}} ->
-        update_rep_doc(DocId, [
-            {<<"_replication_state">>, <<"triggered">>},
-            {<<"_replication_state_reason">>, undefined},
-            {<<"_replication_id">>, ?l2b(BaseId)},
-            {<<"_replication_stats">>, undefined}]),
-        ok = gen_server:call(?MODULE, {rep_started, RepId}, infinity),
-        ?LOG_INFO("Document `~s` triggered replication `~s`",
-            [DocId, pp_rep_id(RepId)])
-    end.
-
-
-replication_completed(#rep{id = RepId}, Stats) ->
-    case rep_state(RepId) of
-    nil ->
-        ok;
-    #rep_state{rep = #rep{doc_id = DocId}} ->
-        update_rep_doc(DocId, [
-            {<<"_replication_state">>, <<"completed">>},
-            {<<"_replication_state_reason">>, undefined},
-            {<<"_replication_stats">>, {Stats}}]),
-        ok = gen_server:call(?MODULE, {rep_complete, RepId}, infinity),
-        ?LOG_INFO("Replication `~s` finished (triggered by document `~s`)",
-            [pp_rep_id(RepId), DocId])
-    end.
-
-
-replication_error(#rep{id = {BaseId, _} = RepId}, Error) ->
-    case rep_state(RepId) of
-    nil ->
-        ok;
-    #rep_state{rep = #rep{doc_id = DocId}} ->
-        update_rep_doc(DocId, [
-            {<<"_replication_state">>, <<"error">>},
-            {<<"_replication_state_reason">>, to_binary(error_reason(Error))},
-            {<<"_replication_id">>, ?l2b(BaseId)}]),
-        ok = gen_server:call(?MODULE, {rep_error, RepId, Error}, infinity)
-    end.
-
-
-init(_) ->
-    process_flag(trap_exit, true),
-    ?DOC_TO_REP = ets:new(?DOC_TO_REP, [named_table, set, protected]),
-    ?REP_TO_STATE = ets:new(?REP_TO_STATE, [named_table, set, protected]),
-    Server = self(),
-    ok = couch_config:register(
-        fun("replicator", "db", NewName) ->
-            ok = gen_server:cast(Server, {rep_db_changed, ?l2b(NewName)});
-        ("replicator", "max_replication_retry_count", V) ->
-            ok = gen_server:cast(Server, {set_max_retries, retries_value(V)})
-        end
-    ),
-    {Loop, RepDbName} = changes_feed_loop(),
-    {ok, #state{
-        changes_feed_loop = Loop,
-        rep_db_name = RepDbName,
-        db_notifier = db_update_notifier(),
-        max_retries = retries_value(
-            couch_config:get("replicator", "max_replication_retry_count", "10"))
-    }}.
-
-
-handle_call({rep_db_update, {ChangeProps} = Change}, _From, State) ->
-    NewState = try
-        process_update(State, Change)
-    catch
-    _Tag:Error ->
-        {RepProps} = get_value(doc, ChangeProps),
-        DocId = get_value(<<"_id">>, RepProps),
-        rep_db_update_error(Error, DocId),
-        State
-    end,
-    {reply, ok, NewState};
-
-
-handle_call({rep_started, RepId}, _From, State) ->
-    case rep_state(RepId) of
-    nil ->
-        ok;
-    RepState ->
-        NewRepState = RepState#rep_state{
-            starting = false,
-            retries_left = State#state.max_retries,
-            max_retries = State#state.max_retries,
-            wait = ?INITIAL_WAIT
-        },
-        true = ets:insert(?REP_TO_STATE, {RepId, NewRepState})
-    end,
-    {reply, ok, State};
-
-handle_call({rep_complete, RepId}, _From, State) ->
-    true = ets:delete(?REP_TO_STATE, RepId),
-    {reply, ok, State};
-
-handle_call({rep_error, RepId, Error}, _From, State) ->
-    {reply, ok, replication_error(State, RepId, Error)};
-
-handle_call(Msg, From, State) ->
-    ?LOG_ERROR("Replication manager received unexpected call ~p from ~p",
-        [Msg, From]),
-    {stop, {error, {unexpected_call, Msg}}, State}.
-
-
-handle_cast({rep_db_changed, NewName}, #state{rep_db_name = NewName} = State) ->
-    {noreply, State};
-
-handle_cast({rep_db_changed, _NewName}, State) ->
-    {noreply, restart(State)};
-
-handle_cast({rep_db_created, NewName}, #state{rep_db_name = NewName} = State) ->
-    {noreply, State};
-
-handle_cast({rep_db_created, _NewName}, State) ->
-    {noreply, restart(State)};
-
-handle_cast({set_max_retries, MaxRetries}, State) ->
-    {noreply, State#state{max_retries = MaxRetries}};
-
-handle_cast(Msg, State) ->
-    ?LOG_ERROR("Replication manager received unexpected cast ~p", [Msg]),
-    {stop, {error, {unexpected_cast, Msg}}, State}.
-
-
-handle_info({'EXIT', From, normal}, #state{changes_feed_loop = From} = State) ->
-    % replicator DB deleted
-    {noreply, State#state{changes_feed_loop = nil, rep_db_name = nil}};
-
-handle_info({'EXIT', From, Reason}, #state{db_notifier = From} = State) ->
-    ?LOG_ERROR("Database update notifier died. Reason: ~p", [Reason]),
-    {stop, {db_update_notifier_died, Reason}, State};
-
-handle_info({'EXIT', From, normal}, #state{rep_start_pids = Pids} = State) ->
-    % one of the replication start processes terminated successfully
-    {noreply, State#state{rep_start_pids = Pids -- [From]}};
-
-handle_info({'DOWN', _Ref, _, _, _}, State) ->
-    % From a db monitor created by a replication process. Ignore.
-    {noreply, State};
-
-handle_info(Msg, State) ->
-    ?LOG_ERROR("Replication manager received unexpected message ~p", [Msg]),
-    {stop, {unexpected_msg, Msg}, State}.
-
-
-terminate(_Reason, State) ->
-    #state{
-        rep_start_pids = StartPids,
-        changes_feed_loop = Loop,
-        db_notifier = DbNotifier
-    } = State,
-    stop_all_replications(),
-    lists:foreach(
-        fun(Pid) ->
-            catch unlink(Pid),
-            catch exit(Pid, stop)
-        end,
-        [Loop | StartPids]),
-    true = ets:delete(?REP_TO_STATE),
-    true = ets:delete(?DOC_TO_REP),
-    couch_db_update_notifier:stop(DbNotifier).
-
-
-code_change(_OldVsn, State, _Extra) ->
-    {ok, State}.
-
-
-changes_feed_loop() ->
-    {ok, RepDb} = ensure_rep_db_exists(),
-    RepDbName = couch_db:name(RepDb),
-    couch_db:close(RepDb),
-    Server = self(),
-    Pid = spawn_link(
-        fun() ->
-            DbOpenOptions = [{user_ctx, RepDb#db.user_ctx}, sys_db],
-            {ok, Db} = couch_db:open_int(RepDbName, DbOpenOptions),
-            ChangesFeedFun = couch_changes:handle_changes(
-                #changes_args{
-                    include_docs = true,
-                    feed = "continuous",
-                    timeout = infinity
-                },
-                {json_req, null},
-                Db
-            ),
-            ChangesFeedFun(
-                fun({change, Change, _}, _) ->
-                    case has_valid_rep_id(Change) of
-                    true ->
-                        ok = gen_server:call(
-                            Server, {rep_db_update, Change}, infinity);
-                    false ->
-                        ok
-                    end;
-                (_, _) ->
-                    ok
-                end
-            )
-        end
-    ),
-    {Pid, RepDbName}.
-
-
-has_valid_rep_id({Change}) ->
-    has_valid_rep_id(get_value(<<"id">>, Change));
-has_valid_rep_id(<<?DESIGN_DOC_PREFIX, _Rest/binary>>) ->
-    false;
-has_valid_rep_id(_Else) ->
-    true.
-
-
-db_update_notifier() ->
-    Server = self(),
-    {ok, Notifier} = couch_db_update_notifier:start_link(
-        fun({created, DbName}) ->
-            case ?l2b(couch_config:get("replicator", "db", "_replicator")) of
-            DbName ->
-                ok = gen_server:cast(Server, {rep_db_created, DbName});
-            _ ->
-                ok
-            end;
-        (_) ->
-            % no need to handle the 'deleted' event - the changes feed loop
-            % dies when the database is deleted
-            ok
-        end
-    ),
-    Notifier.
-
-
-restart(#state{changes_feed_loop = Loop, rep_start_pids = StartPids} = State) ->
-    stop_all_replications(),
-    lists:foreach(
-        fun(Pid) ->
-            catch unlink(Pid),
-            catch exit(Pid, rep_db_changed)
-        end,
-        [Loop | StartPids]),
-    {NewLoop, NewRepDbName} = changes_feed_loop(),
-    State#state{
-        changes_feed_loop = NewLoop,
-        rep_db_name = NewRepDbName,
-        rep_start_pids = []
-    }.
-
-
-process_update(State, {Change}) ->
-    {RepProps} = JsonRepDoc = get_value(doc, Change),
-    DocId = get_value(<<"_id">>, RepProps),
-    case get_value(<<"deleted">>, Change, false) of
-    true ->
-        rep_doc_deleted(DocId),
-        State;
-    false ->
-        case get_value(<<"_replication_state">>, RepProps) of
-        undefined ->
-            maybe_start_replication(State, DocId, JsonRepDoc);
-        <<"triggered">> ->
-            maybe_start_replication(State, DocId, JsonRepDoc);
-        <<"completed">> ->
-            replication_complete(DocId),
-            State;
-        <<"error">> ->
-            case ets:lookup(?DOC_TO_REP, DocId) of
-            [] ->
-                maybe_start_replication(State, DocId, JsonRepDoc);
-            _ ->
-                State
-            end
-        end
-    end.
-
-
-rep_db_update_error(Error, DocId) ->
-    case Error of
-    {bad_rep_doc, Reason} ->
-        ok;
-    _ ->
-        Reason = to_binary(Error)
-    end,
-    ?LOG_ERROR("Replication manager, error processing document `~s`: ~s",
-        [DocId, Reason]),
-    update_rep_doc(DocId, [{<<"_replication_state">>, <<"error">>},
-                           {<<"_replication_state_reason">>, Reason}]).
-
-
-rep_user_ctx({RepDoc}) ->
-    case get_value(<<"user_ctx">>, RepDoc) of
-    undefined ->
-        #user_ctx{};
-    {UserCtx} ->
-        #user_ctx{
-            name = get_value(<<"name">>, UserCtx, null),
-            roles = get_value(<<"roles">>, UserCtx, [])
-        }
-    end.
-
-
-maybe_start_replication(State, DocId, RepDoc) ->
-    #rep{id = {BaseId, _} = RepId} = Rep = parse_rep_doc(RepDoc),
-    case rep_state(RepId) of
-    nil ->
-        RepState = #rep_state{
-            rep = Rep,
-            starting = true,
-            retries_left = State#state.max_retries,
-            max_retries = State#state.max_retries
-        },
-        true = ets:insert(?REP_TO_STATE, {RepId, RepState}),
-        true = ets:insert(?DOC_TO_REP, {DocId, RepId}),
-        ?LOG_INFO("Attempting to start replication `~s` (document `~s`).",
-            [pp_rep_id(RepId), DocId]),
-        Pid = spawn_link(fun() -> start_replication(Rep, 0) end),
-        State#state{rep_start_pids = [Pid | State#state.rep_start_pids]};
-    #rep_state{rep = #rep{doc_id = DocId}} ->
-        State;
-    #rep_state{starting = false, rep = #rep{doc_id = OtherDocId}} ->
-        ?LOG_INFO("The replication specified by the document `~s` was already"
-            " triggered by the document `~s`", [DocId, OtherDocId]),
-        maybe_tag_rep_doc(DocId, RepDoc, ?l2b(BaseId)),
-        State;
-    #rep_state{starting = true, rep = #rep{doc_id = OtherDocId}} ->
-        ?LOG_INFO("The replication specified by the document `~s` is already"
-            " being triggered by the document `~s`", [DocId, OtherDocId]),
-        maybe_tag_rep_doc(DocId, RepDoc, ?l2b(BaseId)),
-        State
-    end.
-
-
-parse_rep_doc(RepDoc) ->
-    {ok, Rep} = try
-        couch_replicator_utils:parse_rep_doc(RepDoc, rep_user_ctx(RepDoc))
-    catch
-    throw:{error, Reason} ->
-        throw({bad_rep_doc, Reason});
-    Tag:Err ->
-        throw({bad_rep_doc, to_binary({Tag, Err})})
-    end,
-    Rep.
-
-
-maybe_tag_rep_doc(DocId, {RepProps}, RepId) ->
-    case get_value(<<"_replication_id">>, RepProps) of
-    RepId ->
-        ok;
-    _ ->
-        update_rep_doc(DocId, [{<<"_replication_id">>, RepId}])
-    end.
-
-
-start_replication(Rep, Wait) ->
-    ok = timer:sleep(Wait * 1000),
-    case (catch couch_replicator:async_replicate(Rep)) of
-    {ok, _} ->
-        ok;
-    Error ->
-        replication_error(Rep, Error)
-    end.
-
-
-replication_complete(DocId) ->
-    case ets:lookup(?DOC_TO_REP, DocId) of
-    [{DocId, {BaseId, Ext} = RepId}] ->
-        case rep_state(RepId) of
-        nil ->
-            % Prior to OTP R14B02, temporary child specs remain in
-            % in the supervisor after a worker finishes - remove them.
-            % We want to be able to start the same replication but with
-            % eventually different values for parameters that don't
-            % contribute to its ID calculation.
-            case erlang:system_info(otp_release) < "R14B02" of
-            true ->
-                spawn(fun() ->
-                    _ = supervisor:delete_child(couch_replicator_job_sup, BaseId ++ Ext)
-                end);
-            false ->
-                ok
-            end;
-        #rep_state{} ->
-            ok
-        end,
-        true = ets:delete(?DOC_TO_REP, DocId);
-    _ ->
-        ok
-    end.
-
-
-rep_doc_deleted(DocId) ->
-    case ets:lookup(?DOC_TO_REP, DocId) of
-    [{DocId, RepId}] ->
-        couch_replicator:cancel_replication(RepId),
-        true = ets:delete(?REP_TO_STATE, RepId),
-        true = ets:delete(?DOC_TO_REP, DocId),
-        ?LOG_INFO("Stopped replication `~s` because replication document `~s`"
-            " was deleted", [pp_rep_id(RepId), DocId]);
-    [] ->
-        ok
-    end.
-
-
-replication_error(State, RepId, Error) ->
-    case rep_state(RepId) of
-    nil ->
-        State;
-    RepState ->
-        maybe_retry_replication(RepState, Error, State)
-    end.
-
-maybe_retry_replication(#rep_state{retries_left = 0} = RepState, Error, State) ->
-    #rep_state{
-        rep = #rep{id = RepId, doc_id = DocId},
-        max_retries = MaxRetries
-    } = RepState,
-    couch_replicator:cancel_replication(RepId),
-    true = ets:delete(?REP_TO_STATE, RepId),
-    true = ets:delete(?DOC_TO_REP, DocId),
-    ?LOG_ERROR("Error in replication `~s` (triggered by document `~s`): ~s"
-        "~nReached maximum retry attempts (~p).",
-        [pp_rep_id(RepId), DocId, to_binary(error_reason(Error)), MaxRetries]),
-    State;
-
-maybe_retry_replication(RepState, Error, State) ->
-    #rep_state{
-        rep = #rep{id = RepId, doc_id = DocId} = Rep
-    } = RepState,
-    #rep_state{wait = Wait} = NewRepState = state_after_error(RepState),
-    true = ets:insert(?REP_TO_STATE, {RepId, NewRepState}),
-    ?LOG_ERROR("Error in replication `~s` (triggered by document `~s`): ~s"
-        "~nRestarting replication in ~p seconds.",
-        [pp_rep_id(RepId), DocId, to_binary(error_reason(Error)), Wait]),
-    Pid = spawn_link(fun() -> start_replication(Rep, Wait) end),
-    State#state{rep_start_pids = [Pid | State#state.rep_start_pids]}.
-
-
-stop_all_replications() ->
-    ?LOG_INFO("Stopping all ongoing replications because the replicator"
-        " database was deleted or changed", []),
-    ets:foldl(
-        fun({_, RepId}, _) ->
-            couch_replicator:cancel_replication(RepId)
-        end,
-        ok, ?DOC_TO_REP),
-    true = ets:delete_all_objects(?REP_TO_STATE),
-    true = ets:delete_all_objects(?DOC_TO_REP).
-
-
-update_rep_doc(RepDocId, KVs) ->
-    {ok, RepDb} = ensure_rep_db_exists(),
-    try
-        case couch_db:open_doc(RepDb, RepDocId, [ejson_body]) of
-        {ok, LatestRepDoc} ->
-            update_rep_doc(RepDb, LatestRepDoc, KVs);
-        _ ->
-            ok
-        end
-    catch throw:conflict ->
-        % Shouldn't happen, as by default only the role _replicator can
-        % update replication documents.
-        ?LOG_ERROR("Conflict error when updating replication document `~s`."
-            " Retrying.", [RepDocId]),
-        ok = timer:sleep(5),
-        update_rep_doc(RepDocId, KVs)
-    after
-        couch_db:close(RepDb)
-    end.
-
-update_rep_doc(RepDb, #doc{body = {RepDocBody}} = RepDoc, KVs) ->
-    NewRepDocBody = lists:foldl(
-        fun({K, undefined}, Body) ->
-                lists:keydelete(K, 1, Body);
-            ({<<"_replication_state">> = K, State} = KV, Body) ->
-                case get_value(K, Body) of
-                State ->
-                    Body;
-                _ ->
-                    Body1 = lists:keystore(K, 1, Body, KV),
-                    lists:keystore(
-                        <<"_replication_state_time">>, 1, Body1,
-                        {<<"_replication_state_time">>, timestamp()})
-                end;
-            ({K, _V} = KV, Body) ->
-                lists:keystore(K, 1, Body, KV)
-        end,
-        RepDocBody, KVs),
-    case NewRepDocBody of
-    RepDocBody ->
-        ok;
-    _ ->
-        % Might not succeed - when the replication doc is deleted right
-        % before this update (not an error, ignore).
-        couch_db:update_doc(RepDb, RepDoc#doc{body = {NewRepDocBody}}, [])
-    end.
-
-
-% RFC3339 timestamps.
-% Note: doesn't include the time seconds fraction (RFC3339 says it's optional).
-timestamp() ->
-    {{Year, Month, Day}, {Hour, Min, Sec}} = calendar:now_to_local_time(now()),
-    UTime = erlang:universaltime(),
-    LocalTime = calendar:universal_time_to_local_time(UTime),
-    DiffSecs = calendar:datetime_to_gregorian_seconds(LocalTime) -
-        calendar:datetime_to_gregorian_seconds(UTime),
-    zone(DiffSecs div 3600, (DiffSecs rem 3600) div 60),
-    iolist_to_binary(
-        io_lib:format("~4..0w-~2..0w-~2..0wT~2..0w:~2..0w:~2..0w~s",
-            [Year, Month, Day, Hour, Min, Sec,
-                zone(DiffSecs div 3600, (DiffSecs rem 3600) div 60)])).
-
-zone(Hr, Min) when Hr >= 0, Min >= 0 ->
-    io_lib:format("+~2..0w:~2..0w", [Hr, Min]);
-zone(Hr, Min) ->
-    io_lib:format("-~2..0w:~2..0w", [abs(Hr), abs(Min)]).
-
-
-
-ensure_rep_db_exists() ->
-    DbName = ?l2b(couch_config:get("replicator", "db", "_replicator")),
-    UserCtx = #user_ctx{roles = [<<"_admin">>, <<"_replicator">>]},
-    case couch_db:open_int(DbName, [sys_db, {user_ctx, UserCtx}, nologifmissing]) of
-    {ok, Db} ->
-        Db;
-    _Error ->
-        {ok, Db} = couch_db:create(DbName, [sys_db, {user_ctx, UserCtx}])
-    end,
-    ensure_rep_ddoc_exists(Db, <<"_design/_replicator">>),
-    {ok, Db}.
-
-
-ensure_rep_ddoc_exists(RepDb, DDocID) ->
-    case couch_db:open_doc(RepDb, DDocID, []) of
-    {ok, _Doc} ->
-        ok;
-    _ ->
-        DDoc = couch_doc:from_json_obj({[
-            {<<"_id">>, DDocID},
-            {<<"language">>, <<"javascript">>},
-            {<<"validate_doc_update">>, ?REP_DB_DOC_VALIDATE_FUN}
-        ]}),
-        {ok, _Rev} = couch_db:update_doc(RepDb, DDoc, [])
-     end.
-
-
-% pretty-print replication id
-pp_rep_id(#rep{id = RepId}) ->
-    pp_rep_id(RepId);
-pp_rep_id({Base, Extension}) ->
-    Base ++ Extension.
-
-
-rep_state(RepId) ->
-    case ets:lookup(?REP_TO_STATE, RepId) of
-    [{RepId, RepState}] ->
-        RepState;
-    [] ->
-        nil
-    end.
-
-
-error_reason({error, {Error, Reason}})
-  when is_atom(Error), is_binary(Reason) ->
-    io_lib:format("~s: ~s", [Error, Reason]);
-error_reason({error, Reason}) ->
-    Reason;
-error_reason(Reason) ->
-    Reason.
-
-
-retries_value("infinity") ->
-    infinity;
-retries_value(Value) ->
-    list_to_integer(Value).
-
-
-state_after_error(#rep_state{retries_left = Left, wait = Wait} = State) ->
-    Wait2 = erlang:min(trunc(Wait * 2), ?MAX_WAIT),
-    case Left of
-    infinity ->
-        State#rep_state{wait = Wait2};
-    _ ->
-        State#rep_state{retries_left = Left - 1, wait = Wait2}
-    end.
-
-
-before_doc_update(#doc{id = <<?DESIGN_DOC_PREFIX, _/binary>>} = Doc, _Db) ->
-    Doc;
-before_doc_update(#doc{body = {Body}} = Doc, #db{user_ctx=UserCtx} = Db) ->
-    #user_ctx{roles = Roles, name = Name} = UserCtx,
-    case lists:member(<<"_replicator">>, Roles) of
-    true ->
-        Doc;
-    false ->
-        case couch_util:get_value(?OWNER, Body) of
-        undefined ->
-            Doc#doc{body = {?replace(Body, ?OWNER, Name)}};
-        Name ->
-            Doc;
-        Other ->
-            case (catch couch_db:check_is_admin(Db)) of
-            ok when Other =:= null ->
-                Doc#doc{body = {?replace(Body, ?OWNER, Name)}};
-            ok ->
-                Doc;
-            _ ->
-                throw({forbidden, <<"Can't update replication documents",
-                    " from other users.">>})
-            end
-        end
-    end.
-
-
-after_doc_read(#doc{id = <<?DESIGN_DOC_PREFIX, _/binary>>} = Doc, _Db) ->
-    Doc;
-after_doc_read(#doc{body = {Body}} = Doc, #db{user_ctx=UserCtx} = Db) ->
-    #user_ctx{name = Name} = UserCtx,
-    case (catch couch_db:check_is_admin(Db)) of
-    ok ->
-        Doc;
-    _ ->
-        case couch_util:get_value(?OWNER, Body) of
-        Name ->
-            Doc;
-        _Other ->
-            Source = strip_credentials(couch_util:get_value(<<"source">>, Body)),
-            Target = strip_credentials(couch_util:get_value(<<"target">>, Body)),
-            NewBody0 = ?replace(Body, <<"source">>, Source),
-            NewBody = ?replace(NewBody0, <<"target">>, Target),
-            #doc{revs = {Pos, [_ | Revs]}} = Doc,
-            NewDoc = Doc#doc{body = {NewBody}, revs = {Pos - 1, Revs}},
-            NewRevId = couch_db:new_revid(NewDoc),
-            NewDoc#doc{revs = {Pos, [NewRevId | Revs]}}
-        end
-    end.
-
-
-strip_credentials(undefined) ->
-    undefined;
-strip_credentials(Url) when is_binary(Url) ->
-    re:replace(Url,
-        "http(s)?://(?:[^:]+):[^@]+@(.*)$",
-        "http\\1://\\2",
-        [{return, binary}]);
-strip_credentials({Props}) ->
-    {lists:keydelete(<<"oauth">>, 1, Props)}.

http://git-wip-us.apache.org/repos/asf/couchdb/blob/4c39d7a5/apps/couch_replicator/src/couch_replicator_manager_sup.erl
----------------------------------------------------------------------
diff --git a/apps/couch_replicator/src/couch_replicator_manager_sup.erl b/apps/couch_replicator/src/couch_replicator_manager_sup.erl
deleted file mode 100644
index f292546..0000000
--- a/apps/couch_replicator/src/couch_replicator_manager_sup.erl
+++ /dev/null
@@ -1,47 +0,0 @@
-
-% Licensed 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.
-
--module(couch_replicator_manager_sup).
-
--behaviour(supervisor).
-
-%% API
--export([start_link/0]).
-
-%% Supervisor callbacks
--export([init/1]).
-
-%% Helper macro for declaring children of supervisor
--define(CHILD(I, Type), {I, {I, start_link, []}, permanent, 5000, Type, [I]}).
-
-%% ===================================================================
-%% API functions
-%% ===================================================================
-
-start_link() ->
-    supervisor:start_link({local, ?MODULE}, ?MODULE, []).
-
-%% ===================================================================
-%% Supervisor callbacks
-%% ===================================================================
-
-init([]) ->
-    Children = [
-        {couch_replicator_manager,
-            {couch_replicator_manager, start_link, []},
-            permanent,
-            brutal_kill,
-            worker,
-            [couch_replicator_manager]}
-    ],
-    {ok, { {one_for_one, 10, 3600}, Children} }.

http://git-wip-us.apache.org/repos/asf/couchdb/blob/4c39d7a5/apps/couch_replicator/src/couch_replicator_notifier.erl
----------------------------------------------------------------------
diff --git a/apps/couch_replicator/src/couch_replicator_notifier.erl b/apps/couch_replicator/src/couch_replicator_notifier.erl
deleted file mode 100644
index 39fd68b..0000000
--- a/apps/couch_replicator/src/couch_replicator_notifier.erl
+++ /dev/null
@@ -1,57 +0,0 @@
-% Licensed 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.
-
--module(couch_replicator_notifier).
-
--behaviour(gen_event).
-
-% public API
--export([start_link/1, stop/1, notify/1]).
-
-% gen_event callbacks
--export([init/1, terminate/2, code_change/3]).
--export([handle_event/2, handle_call/2, handle_info/2]).
-
--include_lib("couch/include/couch_db.hrl").
-
-start_link(FunAcc) ->
-    couch_event_sup:start_link(couch_replication,
-        {couch_replicator_notifier, make_ref()}, FunAcc).
-
-notify(Event) ->
-    gen_event:notify(couch_replication, Event).
-
-stop(Pid) ->
-    couch_event_sup:stop(Pid).
-
-
-init(FunAcc) ->
-    {ok, FunAcc}.
-
-terminate(_Reason, _State) ->
-    ok.
-
-handle_event(Event, Fun) when is_function(Fun, 1) ->
-    Fun(Event),
-    {ok, Fun};
-handle_event(Event, {Fun, Acc}) when is_function(Fun, 2) ->
-    Acc2 = Fun(Event, Acc),
-    {ok, {Fun, Acc2}}.
-
-handle_call(_Msg, State) ->
-    {reply, ok, State}.
-
-handle_info(_Msg, State) ->
-    {ok, State}.
-
-code_change(_OldVsn, State, _Extra) ->
-    {ok, State}.

http://git-wip-us.apache.org/repos/asf/couchdb/blob/4c39d7a5/apps/couch_replicator/src/couch_replicator_sup.erl
----------------------------------------------------------------------
diff --git a/apps/couch_replicator/src/couch_replicator_sup.erl b/apps/couch_replicator/src/couch_replicator_sup.erl
deleted file mode 100644
index 7ae5367..0000000
--- a/apps/couch_replicator/src/couch_replicator_sup.erl
+++ /dev/null
@@ -1,63 +0,0 @@
-
-% Licensed 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.
-
--module(couch_replicator_sup).
-
--behaviour(supervisor).
-
-%% API
--export([start_link/0]).
--export([stop/0]).
-
-%% Supervisor callbacks
--export([init/1]).
-
-%% Helper macro for declaring children of supervisor
--define(CHILD(I, Type), {I, {I, start_link, []}, permanent, 5000, Type, [I]}).
-
-%% ===================================================================
-%% API functions
-%% ===================================================================
-
-start_link() ->
-    supervisor:start_link({local, ?MODULE}, ?MODULE, []).
-
-stop() ->
-    catch exit(whereis(couch_replicator_sup), normal).
-
-%% ===================================================================
-%% Supervisor callbacks
-%% ===================================================================
-
-init([]) ->
-    Children = [
-        {couch_replication_event,
-            {gen_event, start_link, [{local, couch_replication}]},
-            permanent,
-            brutal_kill,
-            worker,
-            dynamic},
-        {couch_replicator_job_sup,
-            {couch_replicator_job_sup, start_link, []},
-            permanent,
-            infinity,
-            supervisor,
-            [couch_replicator_job_sup]},
-        {couch_replicator_manager_sup,
-            {couch_replicator_manager_sup, start_link, []},
-            permanent,
-            infinity,
-            supervisor,
-            [couch_replicator_manager_sup]}
-    ],
-    {ok, { {one_for_one, 100, 3600}, Children} }.

http://git-wip-us.apache.org/repos/asf/couchdb/blob/4c39d7a5/apps/couch_replicator/src/couch_replicator_utils.erl
----------------------------------------------------------------------
diff --git a/apps/couch_replicator/src/couch_replicator_utils.erl b/apps/couch_replicator/src/couch_replicator_utils.erl
deleted file mode 100644
index 085df43..0000000
--- a/apps/couch_replicator/src/couch_replicator_utils.erl
+++ /dev/null
@@ -1,419 +0,0 @@
-% Licensed 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.
-
--module(couch_replicator_utils).
-
--export([parse_rep_doc/2]).
--export([open_db/1, close_db/1]).
--export([start_db_compaction_notifier/2, stop_db_compaction_notifier/1]).
--export([replication_id/2]).
--export([sum_stats/2]).
-
--include_lib("couch/include/couch_db.hrl").
--include("couch_replicator_api_wrap.hrl").
--include("couch_replicator.hrl").
--include_lib("ibrowse/include/ibrowse.hrl").
-
--import(couch_util, [
-    get_value/2,
-    get_value/3
-]).
-
-
-parse_rep_doc({Props}, UserCtx) ->
-    ProxyParams = parse_proxy_params(get_value(<<"proxy">>, Props, <<>>)),
-    Options = make_options(Props),
-    case get_value(cancel, Options, false) andalso
-        (get_value(id, Options, nil) =/= nil) of
-    true ->
-        {ok, #rep{options = Options, user_ctx = UserCtx}};
-    false ->
-        Source = parse_rep_db(get_value(<<"source">>, Props),
-                              ProxyParams, Options),
-        Target = parse_rep_db(get_value(<<"target">>, Props),
-                              ProxyParams, Options),
-
-
-        {RepType, View} = case get_value(<<"filter">>, Props) of
-                <<"_view">> ->
-                    {QP}  = get_value(query_params, Options, {[]}),
-                    ViewParam = get_value(<<"view">>, QP),
-                    View1 = case re:split(ViewParam, <<"/">>) of
-                        [DName, ViewName] ->
-                            {<< "_design/", DName/binary >>, ViewName};
-                        _ ->
-                            throw({bad_request, "Invalid `view` parameter."})
-                    end,
-                    {view, View1};
-                _ ->
-                    {db, nil}
-            end,
-
-        Rep = #rep{
-            source = Source,
-            target = Target,
-            options = Options,
-            user_ctx = UserCtx,
-            type = RepType,
-            view = View,
-            doc_id = get_value(<<"_id">>, Props, null)
-        },
-        {ok, Rep#rep{id = replication_id(Rep)}}
-    end.
-
-
-replication_id(#rep{options = Options} = Rep) ->
-    BaseId = replication_id(Rep, ?REP_ID_VERSION),
-    {BaseId, maybe_append_options([continuous, create_target], Options)}.
-
-
-% Versioned clauses for generating replication IDs.
-% If a change is made to how replications are identified,
-% please add a new clause and increase ?REP_ID_VERSION.
-
-replication_id(#rep{user_ctx = UserCtx} = Rep, 3) ->
-    UUID = couch_server:get_uuid(),
-    Src = get_rep_endpoint(UserCtx, Rep#rep.source),
-    Tgt = get_rep_endpoint(UserCtx, Rep#rep.target),
-    maybe_append_filters([UUID, Src, Tgt], Rep);
-
-replication_id(#rep{user_ctx = UserCtx} = Rep, 2) ->
-    {ok, HostName} = inet:gethostname(),
-    Port = case (catch mochiweb_socket_server:get(couch_httpd, port)) of
-    P when is_number(P) ->
-        P;
-    _ ->
-        % On restart we might be called before the couch_httpd process is
-        % started.
-        % TODO: we might be under an SSL socket server only, or both under
-        % SSL and a non-SSL socket.
-        % ... mochiweb_socket_server:get(https, port)
-        list_to_integer(couch_config:get("httpd", "port", "5984"))
-    end,
-    Src = get_rep_endpoint(UserCtx, Rep#rep.source),
-    Tgt = get_rep_endpoint(UserCtx, Rep#rep.target),
-    maybe_append_filters([HostName, Port, Src, Tgt], Rep);
-
-replication_id(#rep{user_ctx = UserCtx} = Rep, 1) ->
-    {ok, HostName} = inet:gethostname(),
-    Src = get_rep_endpoint(UserCtx, Rep#rep.source),
-    Tgt = get_rep_endpoint(UserCtx, Rep#rep.target),
-    maybe_append_filters([HostName, Src, Tgt], Rep).
-
-
-maybe_append_filters(Base,
-        #rep{source = Source, user_ctx = UserCtx, options = Options}) ->
-    Base2 = Base ++
-        case get_value(filter, Options) of
-        undefined ->
-            case get_value(doc_ids, Options) of
-            undefined ->
-                [];
-            DocIds ->
-                [DocIds]
-            end;
-        <<"_", _/binary>> = Filter ->
-                [Filter, get_value(query_params, Options, {[]})];
-        Filter ->
-            [filter_code(Filter, Source, UserCtx),
-                get_value(query_params, Options, {[]})]
-        end,
-    couch_util:to_hex(couch_util:md5(term_to_binary(Base2))).
-
-
-filter_code(Filter, Source, UserCtx) ->
-    {DDocName, FilterName} =
-    case re:run(Filter, "(.*?)/(.*)", [{capture, [1, 2], binary}]) of
-    {match, [DDocName0, FilterName0]} ->
-        {DDocName0, FilterName0};
-    _ ->
-        throw({error, <<"Invalid filter. Must match `ddocname/filtername`.">>})
-    end,
-    Db = case (catch couch_replicator_api_wrap:db_open(Source, [{user_ctx, UserCtx}])) of
-    {ok, Db0} ->
-        Db0;
-    DbError ->
-        DbErrorMsg = io_lib:format("Could not open source database `~s`: ~s",
-           [couch_replicator_api_wrap:db_uri(Source), couch_util:to_binary(DbError)]),
-        throw({error, iolist_to_binary(DbErrorMsg)})
-    end,
-    try
-        Body = case (catch couch_replicator_api_wrap:open_doc(
-            Db, <<"_design/", DDocName/binary>>, [ejson_body])) of
-        {ok, #doc{body = Body0}} ->
-            Body0;
-        DocError ->
-            DocErrorMsg = io_lib:format(
-                "Couldn't open document `_design/~s` from source "
-                "database `~s`: ~s", [DDocName, couch_replicator_api_wrap:db_uri(Source),
-                    couch_util:to_binary(DocError)]),
-            throw({error, iolist_to_binary(DocErrorMsg)})
-        end,
-        Code = couch_util:get_nested_json_value(
-            Body, [<<"filters">>, FilterName]),
-        re:replace(Code, [$^, "\s*(.*?)\s*", $$], "\\1", [{return, binary}])
-    after
-        couch_replicator_api_wrap:db_close(Db)
-    end.
-
-
-maybe_append_options(Options, RepOptions) ->
-    lists:foldl(fun(Option, Acc) ->
-        Acc ++
-        case get_value(Option, RepOptions, false) of
-        true ->
-            "+" ++ atom_to_list(Option);
-        false ->
-            ""
-        end
-    end, [], Options).
-
-
-get_rep_endpoint(_UserCtx, #httpdb{url=Url, headers=Headers, oauth=OAuth}) ->
-    DefaultHeaders = (#httpdb{})#httpdb.headers,
-    case OAuth of
-    nil ->
-        {remote, Url, Headers -- DefaultHeaders};
-    #oauth{} ->
-        {remote, Url, Headers -- DefaultHeaders, OAuth}
-    end;
-get_rep_endpoint(UserCtx, <<DbName/binary>>) ->
-    {local, DbName, UserCtx}.
-
-
-parse_rep_db({Props}, ProxyParams, Options) ->
-    Url = maybe_add_trailing_slash(get_value(<<"url">>, Props)),
-    {AuthProps} = get_value(<<"auth">>, Props, {[]}),
-    {BinHeaders} = get_value(<<"headers">>, Props, {[]}),
-    Headers = lists:ukeysort(1, [{?b2l(K), ?b2l(V)} || {K, V} <- BinHeaders]),
-    DefaultHeaders = (#httpdb{})#httpdb.headers,
-    OAuth = case get_value(<<"oauth">>, AuthProps) of
-    undefined ->
-        nil;
-    {OauthProps} ->
-        #oauth{
-            consumer_key = ?b2l(get_value(<<"consumer_key">>, OauthProps)),
-            token = ?b2l(get_value(<<"token">>, OauthProps)),
-            token_secret = ?b2l(get_value(<<"token_secret">>, OauthProps)),
-            consumer_secret = ?b2l(get_value(<<"consumer_secret">>, OauthProps)),
-            signature_method =
-                case get_value(<<"signature_method">>, OauthProps) of
-                undefined ->        hmac_sha1;
-                <<"PLAINTEXT">> ->  plaintext;
-                <<"HMAC-SHA1">> ->  hmac_sha1;
-                <<"RSA-SHA1">> ->   rsa_sha1
-                end
-        }
-    end,
-    #httpdb{
-        url = Url,
-        oauth = OAuth,
-        headers = lists:ukeymerge(1, Headers, DefaultHeaders),
-        ibrowse_options = lists:keysort(1,
-            [{socket_options, get_value(socket_options, Options)} |
-                ProxyParams ++ ssl_params(Url)]),
-        timeout = get_value(connection_timeout, Options),
-        http_connections = get_value(http_connections, Options),
-        retries = get_value(retries, Options)
-    };
-parse_rep_db(<<"http://", _/binary>> = Url, ProxyParams, Options) ->
-    parse_rep_db({[{<<"url">>, Url}]}, ProxyParams, Options);
-parse_rep_db(<<"https://", _/binary>> = Url, ProxyParams, Options) ->
-    parse_rep_db({[{<<"url">>, Url}]}, ProxyParams, Options);
-parse_rep_db(<<DbName/binary>>, _ProxyParams, _Options) ->
-    DbName.
-
-
-maybe_add_trailing_slash(Url) when is_binary(Url) ->
-    maybe_add_trailing_slash(?b2l(Url));
-maybe_add_trailing_slash(Url) ->
-    case lists:last(Url) of
-    $/ ->
-        Url;
-    _ ->
-        Url ++ "/"
-    end.
-
-
-make_options(Props) ->
-    Options = lists:ukeysort(1, convert_options(Props)),
-    DefWorkers = couch_config:get("replicator", "worker_processes", "4"),
-    DefBatchSize = couch_config:get("replicator", "worker_batch_size", "500"),
-    DefConns = couch_config:get("replicator", "http_connections", "20"),
-    DefTimeout = couch_config:get("replicator", "connection_timeout", "30000"),
-    DefRetries = couch_config:get("replicator", "retries_per_request", "10"),
-    UseCheckpoints = couch_config:get("replicator", "use_checkpoints", "true"),
-    DefCheckpointInterval = couch_config:get("replicator", "checkpoint_interval", "5000"),
-    {ok, DefSocketOptions} = couch_util:parse_term(
-        couch_config:get("replicator", "socket_options",
-            "[{keepalive, true}, {nodelay, false}]")),
-    lists:ukeymerge(1, Options, lists:keysort(1, [
-        {connection_timeout, list_to_integer(DefTimeout)},
-        {retries, list_to_integer(DefRetries)},
-        {http_connections, list_to_integer(DefConns)},
-        {socket_options, DefSocketOptions},
-        {worker_batch_size, list_to_integer(DefBatchSize)},
-        {worker_processes, list_to_integer(DefWorkers)},
-        {use_checkpoints, list_to_existing_atom(UseCheckpoints)},
-        {checkpoint_interval, list_to_integer(DefCheckpointInterval)}
-    ])).
-
-
-convert_options([])->
-    [];
-convert_options([{<<"cancel">>, V} | R]) ->
-    [{cancel, V} | convert_options(R)];
-convert_options([{IdOpt, V} | R]) when IdOpt =:= <<"_local_id">>;
-        IdOpt =:= <<"replication_id">>; IdOpt =:= <<"id">> ->
-    Id = lists:splitwith(fun(X) -> X =/= $+ end, ?b2l(V)),
-    [{id, Id} | convert_options(R)];
-convert_options([{<<"create_target">>, V} | R]) ->
-    [{create_target, V} | convert_options(R)];
-convert_options([{<<"continuous">>, V} | R]) ->
-    [{continuous, V} | convert_options(R)];
-convert_options([{<<"filter">>, V} | R]) ->
-    [{filter, V} | convert_options(R)];
-convert_options([{<<"query_params">>, V} | R]) ->
-    [{query_params, V} | convert_options(R)];
-convert_options([{<<"doc_ids">>, null} | R]) ->
-    convert_options(R);
-convert_options([{<<"doc_ids">>, V} | R]) ->
-    % Ensure same behaviour as old replicator: accept a list of percent
-    % encoded doc IDs.
-    DocIds = [?l2b(couch_httpd:unquote(Id)) || Id <- V],
-    [{doc_ids, DocIds} | convert_options(R)];
-convert_options([{<<"worker_processes">>, V} | R]) ->
-    [{worker_processes, couch_util:to_integer(V)} | convert_options(R)];
-convert_options([{<<"worker_batch_size">>, V} | R]) ->
-    [{worker_batch_size, couch_util:to_integer(V)} | convert_options(R)];
-convert_options([{<<"http_connections">>, V} | R]) ->
-    [{http_connections, couch_util:to_integer(V)} | convert_options(R)];
-convert_options([{<<"connection_timeout">>, V} | R]) ->
-    [{connection_timeout, couch_util:to_integer(V)} | convert_options(R)];
-convert_options([{<<"retries_per_request">>, V} | R]) ->
-    [{retries, couch_util:to_integer(V)} | convert_options(R)];
-convert_options([{<<"socket_options">>, V} | R]) ->
-    {ok, SocketOptions} = couch_util:parse_term(V),
-    [{socket_options, SocketOptions} | convert_options(R)];
-convert_options([{<<"since_seq">>, V} | R]) ->
-    [{since_seq, V} | convert_options(R)];
-convert_options([{<<"use_checkpoints">>, V} | R]) ->
-    [{use_checkpoints, V} | convert_options(R)];
-convert_options([{<<"checkpoint_interval">>, V} | R]) ->
-    [{checkpoint_interval, couch_util:to_integer(V)} | convert_options(R)];
-convert_options([_ | R]) -> % skip unknown option
-    convert_options(R).
-
-
-parse_proxy_params(ProxyUrl) when is_binary(ProxyUrl) ->
-    parse_proxy_params(?b2l(ProxyUrl));
-parse_proxy_params([]) ->
-    [];
-parse_proxy_params(ProxyUrl) ->
-    #url{
-        host = Host,
-        port = Port,
-        username = User,
-        password = Passwd
-    } = ibrowse_lib:parse_url(ProxyUrl),
-    [{proxy_host, Host}, {proxy_port, Port}] ++
-        case is_list(User) andalso is_list(Passwd) of
-        false ->
-            [];
-        true ->
-            [{proxy_user, User}, {proxy_password, Passwd}]
-        end.
-
-
-ssl_params(Url) ->
-    case ibrowse_lib:parse_url(Url) of
-    #url{protocol = https} ->
-        Depth = list_to_integer(
-            couch_config:get("replicator", "ssl_certificate_max_depth", "3")
-        ),
-        VerifyCerts = couch_config:get("replicator", "verify_ssl_certificates"),
-        CertFile = couch_config:get("replicator", "cert_file", nil),
-        KeyFile = couch_config:get("replicator", "key_file", nil),
-        Password = couch_config:get("replicator", "password", nil),
-        SslOpts = [{depth, Depth} | ssl_verify_options(VerifyCerts =:= "true")],
-        SslOpts1 = case CertFile /= nil andalso KeyFile /= nil of
-            true ->
-                case Password of
-                    nil ->
-                        [{certfile, CertFile}, {keyfile, KeyFile}] ++ SslOpts;
-                    _ ->
-                        [{certfile, CertFile}, {keyfile, KeyFile},
-                            {password, Password}] ++ SslOpts
-                end;
-            false -> SslOpts
-        end,
-        [{is_ssl, true}, {ssl_options, SslOpts1}];
-    #url{protocol = http} ->
-        []
-    end.
-
-ssl_verify_options(Value) ->
-    ssl_verify_options(Value, erlang:system_info(otp_release)).
-
-ssl_verify_options(true, OTPVersion) when OTPVersion >= "R14" ->
-    CAFile = couch_config:get("replicator", "ssl_trusted_certificates_file"),
-    [{verify, verify_peer}, {cacertfile, CAFile}];
-ssl_verify_options(false, OTPVersion) when OTPVersion >= "R14" ->
-    [{verify, verify_none}];
-ssl_verify_options(true, _OTPVersion) ->
-    CAFile = couch_config:get("replicator", "ssl_trusted_certificates_file"),
-    [{verify, 2}, {cacertfile, CAFile}];
-ssl_verify_options(false, _OTPVersion) ->
-    [{verify, 0}].
-
-
-open_db(#db{name = Name, user_ctx = UserCtx, options = Options}) ->
-    {ok, Db} = couch_db:open(Name, [{user_ctx, UserCtx} | Options]),
-    Db;
-open_db(HttpDb) ->
-    HttpDb.
-
-
-close_db(#db{} = Db) ->
-    couch_db:close(Db);
-close_db(_HttpDb) ->
-    ok.
-
-
-start_db_compaction_notifier(#db{name = DbName}, Server) ->
-    {ok, Notifier} = couch_db_update_notifier:start_link(
-        fun({compacted, DbName1}) when DbName1 =:= DbName ->
-                ok = gen_server:cast(Server, {db_compacted, DbName});
-            (_) ->
-                ok
-        end),
-    Notifier;
-start_db_compaction_notifier(_, _) ->
-    nil.
-
-
-stop_db_compaction_notifier(nil) ->
-    ok;
-stop_db_compaction_notifier(Notifier) ->
-    couch_db_update_notifier:stop(Notifier).
-
-
-sum_stats(#rep_stats{} = S1, #rep_stats{} = S2) ->
-    #rep_stats{
-        missing_checked =
-            S1#rep_stats.missing_checked + S2#rep_stats.missing_checked,
-        missing_found = S1#rep_stats.missing_found + S2#rep_stats.missing_found,
-        docs_read = S1#rep_stats.docs_read + S2#rep_stats.docs_read,
-        docs_written = S1#rep_stats.docs_written + S2#rep_stats.docs_written,
-        doc_write_failures =
-            S1#rep_stats.doc_write_failures + S2#rep_stats.doc_write_failures
-    }.


[15/57] [abbrv] remove couch_collate

Posted by be...@apache.org.
http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/udata.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/udata.h b/apps/couch_collate/platform/osx/icu/unicode/udata.h
deleted file mode 100644
index 84046d5..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/udata.h
+++ /dev/null
@@ -1,389 +0,0 @@
-/*
-******************************************************************************
-*
-*   Copyright (C) 1999-2008, International Business Machines
-*   Corporation and others.  All Rights Reserved.
-*
-******************************************************************************
-*   file name:  udata.h
-*   encoding:   US-ASCII
-*   tab size:   8 (not used)
-*   indentation:4
-*
-*   created on: 1999oct25
-*   created by: Markus W. Scherer
-*/
-
-#ifndef __UDATA_H__
-#define __UDATA_H__
-
-#include "unicode/utypes.h"
-
-U_CDECL_BEGIN
-
-/**
- * \file
- * \brief C API: Data loading interface
- *
- * <h2>Information about data loading interface</h2>
- *
- * This API is used to find and efficiently load data for ICU and applications
- * using ICU. It provides an abstract interface that specifies a data type and
- * name to find and load the data. Normally this API is used by other ICU APIs
- * to load required data out of the ICU data library, but it can be used to
- * load data out of other places.
- *
- * See the User Guide Data Management chapter.
- */
- 
-#ifndef U_HIDE_INTERNAL_API
-/**
- * Character used to separate package names from tree names 
- * @internal ICU 3.0
- */
-#define U_TREE_SEPARATOR '-'
-
-/**
- * String used to separate package names from tree names 
- * @internal ICU 3.0
- */
-#define U_TREE_SEPARATOR_STRING "-"
-
-/**
- * Character used to separate parts of entry names
- * @internal ICU 3.0
- */
-#define U_TREE_ENTRY_SEP_CHAR '/'
-
-/**
- * String used to separate parts of entry names
- * @internal ICU 3.0
- */
-#define U_TREE_ENTRY_SEP_STRING "/"
-
-/**
- * Alias for standard ICU data 
- * @internal ICU 3.0
- */
-#define U_ICUDATA_ALIAS "ICUDATA"
-
-#endif /* U_HIDE_INTERNAL_API */
-
-/**
- * UDataInfo contains the properties about the requested data.
- * This is meta data.
- *
- * <p>This structure may grow in the future, indicated by the
- * <code>size</code> field.</p>
- *
- * <p>The platform data property fields help determine if a data
- * file can be efficiently used on a given machine.
- * The particular fields are of importance only if the data
- * is affected by the properties - if there is integer data
- * with word sizes > 1 byte, char* text, or UChar* text.</p>
- *
- * <p>The implementation for the <code>udata_open[Choice]()</code>
- * functions may reject data based on the value in <code>isBigEndian</code>.
- * No other field is used by the <code>udata</code> API implementation.</p>
- *
- * <p>The <code>dataFormat</code> may be used to identify
- * the kind of data, e.g. a converter table.</p>
- *
- * <p>The <code>formatVersion</code> field should be used to
- * make sure that the format can be interpreted.
- * I may be a good idea to check only for the one or two highest
- * of the version elements to allow the data memory to
- * get more or somewhat rearranged contents, for as long
- * as the using code can still interpret the older contents.</p>
- *
- * <p>The <code>dataVersion</code> field is intended to be a
- * common place to store the source version of the data;
- * for data from the Unicode character database, this could
- * reflect the Unicode version.</p>
- * @stable ICU 2.0
- */
-typedef struct {
-    /** sizeof(UDataInfo)
-     *  @stable ICU 2.0 */
-    uint16_t size;
-
-    /** unused, set to 0 
-     *  @stable ICU 2.0*/
-    uint16_t reservedWord;
-
-    /* platform data properties */
-    /** 0 for little-endian machine, 1 for big-endian
-     *  @stable ICU 2.0 */
-    uint8_t isBigEndian;
-
-    /** see U_CHARSET_FAMILY values in utypes.h 
-     *  @stable ICU 2.0*/
-    uint8_t charsetFamily;
-
-    /** sizeof(UChar), one of { 1, 2, 4 } 
-     *  @stable ICU 2.0*/
-    uint8_t sizeofUChar;
-
-    /** unused, set to 0 
-     *  @stable ICU 2.0*/
-    uint8_t reservedByte;
-
-    /** data format identifier 
-     *  @stable ICU 2.0*/
-    uint8_t dataFormat[4];
-
-    /** versions: [0] major [1] minor [2] milli [3] micro 
-     *  @stable ICU 2.0*/
-    uint8_t formatVersion[4];
-
-    /** versions: [0] major [1] minor [2] milli [3] micro 
-     *  @stable ICU 2.0*/
-    uint8_t dataVersion[4];
-} UDataInfo;
-
-/* API for reading data -----------------------------------------------------*/
-
-/**
- * Forward declaration of the data memory type.
- * @stable ICU 2.0
- */
-typedef struct UDataMemory UDataMemory;
-
-/**
- * Callback function for udata_openChoice().
- * @param context parameter passed into <code>udata_openChoice()</code>.
- * @param type The type of the data as passed into <code>udata_openChoice()</code>.
- *             It may be <code>NULL</code>.
- * @param name The name of the data as passed into <code>udata_openChoice()</code>.
- * @param pInfo A pointer to the <code>UDataInfo</code> structure
- *              of data that has been loaded and will be returned
- *              by <code>udata_openChoice()</code> if this function
- *              returns <code>TRUE</code>.
- * @return TRUE if the current data memory is acceptable
- * @stable ICU 2.0
- */
-typedef UBool U_CALLCONV
-UDataMemoryIsAcceptable(void *context,
-                        const char *type, const char *name,
-                        const UDataInfo *pInfo);
-
-
-/**
- * Convenience function.
- * This function works the same as <code>udata_openChoice</code>
- * except that any data that matches the type and name
- * is assumed to be acceptable.
- * @param path Specifies an absolute path and/or a basename for the
- *             finding of the data in the file system.
- *             <code>NULL</code> for ICU data.
- * @param type A string that specifies the type of data to be loaded.
- *             For example, resource bundles are loaded with type "res",
- *             conversion tables with type "cnv".
- *             This may be <code>NULL</code> or empty.
- * @param name A string that specifies the name of the data.
- * @param pErrorCode An ICU UErrorCode parameter. It must not be <code>NULL</code>.
- * @return A pointer (handle) to a data memory object, or <code>NULL</code>
- *         if an error occurs. Call <code>udata_getMemory()</code>
- *         to get a pointer to the actual data.
- *
- * @see udata_openChoice
- * @stable ICU 2.0
- */
-U_STABLE UDataMemory * U_EXPORT2
-udata_open(const char *path, const char *type, const char *name,
-           UErrorCode *pErrorCode);
-
-/**
- * Data loading function.
- * This function is used to find and load efficiently data for
- * ICU and applications using ICU.
- * It provides an abstract interface that allows to specify a data
- * type and name to find and load the data.
- *
- * <p>The implementation depends on platform properties and user preferences
- * and may involve loading shared libraries (DLLs), mapping
- * files into memory, or fopen()/fread() files.
- * It may also involve using static memory or database queries etc.
- * Several or all data items may be combined into one entity
- * (DLL, memory-mappable file).</p>
- *
- * <p>The data is always preceded by a header that includes
- * a <code>UDataInfo</code> structure.
- * The caller's <code>isAcceptable()</code> function is called to make
- * sure that the data is useful. It may be called several times if it
- * rejects the data and there is more than one location with data
- * matching the type and name.</p>
- *
- * <p>If <code>path==NULL</code>, then ICU data is loaded.
- * Otherwise, it is separated into a basename and a basename-less directory string.
- * The basename is used as the data package name, and the directory is
- * logically prepended to the ICU data directory string.</p>
- *
- * <p>For details about ICU data loading see the User Guide
- * Data Management chapter. (http://icu-project.org/userguide/icudata.html)</p>
- *
- * @param path Specifies an absolute path and/or a basename for the
- *             finding of the data in the file system.
- *             <code>NULL</code> for ICU data.
- * @param type A string that specifies the type of data to be loaded.
- *             For example, resource bundles are loaded with type "res",
- *             conversion tables with type "cnv".
- *             This may be <code>NULL</code> or empty.
- * @param name A string that specifies the name of the data.
- * @param isAcceptable This function is called to verify that loaded data
- *                     is useful for the client code. If it returns FALSE
- *                     for all data items, then <code>udata_openChoice()</code>
- *                     will return with an error.
- * @param context Arbitrary parameter to be passed into isAcceptable.
- * @param pErrorCode An ICU UErrorCode parameter. It must not be <code>NULL</code>.
- * @return A pointer (handle) to a data memory object, or <code>NULL</code>
- *         if an error occurs. Call <code>udata_getMemory()</code>
- *         to get a pointer to the actual data.
- * @stable ICU 2.0
- */
-U_STABLE UDataMemory * U_EXPORT2
-udata_openChoice(const char *path, const char *type, const char *name,
-                 UDataMemoryIsAcceptable *isAcceptable, void *context,
-                 UErrorCode *pErrorCode);
-
-/**
- * Close the data memory.
- * This function must be called to allow the system to
- * release resources associated with this data memory.
- * @param pData The pointer to data memory object
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2
-udata_close(UDataMemory *pData);
-
-/**
- * Get the pointer to the actual data inside the data memory.
- * The data is read-only.
- * @param pData The pointer to data memory object
- * @stable ICU 2.0
- */
-U_STABLE const void * U_EXPORT2
-udata_getMemory(UDataMemory *pData);
-
-/**
- * Get the information from the data memory header.
- * This allows to get access to the header containing
- * platform data properties etc. which is not part of
- * the data itself and can therefore not be accessed
- * via the pointer that <code>udata_getMemory()</code> returns.
- *
- * @param pData pointer to the data memory object
- * @param pInfo pointer to a UDataInfo object;
- *              its <code>size</code> field must be set correctly,
- *              typically to <code>sizeof(UDataInfo)</code>.
- *
- * <code>*pInfo</code> will be filled with the UDataInfo structure
- * in the data memory object. If this structure is smaller than
- * <code>pInfo->size</code>, then the <code>size</code> will be
- * adjusted and only part of the structure will be filled.
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2
-udata_getInfo(UDataMemory *pData, UDataInfo *pInfo);
-
-/**
- * This function bypasses the normal ICU data loading process and
- * allows you to force ICU's system data to come out of a user-specified
- * area in memory.
- *
- * The format of this data is that of the icu common data file, as is
- * generated by the pkgdata tool with mode=common or mode=dll.
- * You can read in a whole common mode file and pass the address to the start of the
- * data, or (with the appropriate link options) pass in the pointer to
- * the data that has been loaded from a dll by the operating system,
- * as shown in this code:
- *
- *       extern const  char U_IMPORT U_ICUDATA_ENTRY_POINT []; 
- *        // U_ICUDATA_ENTRY_POINT is same as entry point specified to pkgdata tool
- *       UErrorCode  status = U_ZERO_ERROR;
- *
- *       udata_setCommonData(&U_ICUDATA_ENTRY_POINT, &status);
- *
- * Warning: ICU must NOT have even attempted to access its data yet
- * when this call is made, or U_USING_DEFAULT_WARNING code will
- * be returned. Be careful of UnicodeStrings in static initialization which
- * may attempt to load a converter (use the UNICODE_STRING(x) macro instead).
- *
- * Also note that it is important that the declaration be as above. The entry point
- * must not be declared as an extern void*.
- *
- * This function has no effect on application (non ICU) data.  See udata_setAppData()
- * for similar functionality for application data.
- *
- * @param data pointer to ICU common data
- * @param err outgoing error status <code>U_USING_DEFAULT_WARNING, U_UNSUPPORTED_ERROR</code>
- * @stable ICU 2.0
- */
-
-U_STABLE void U_EXPORT2
-udata_setCommonData(const void *data, UErrorCode *err);
-
-
-/**
- * This function bypasses the normal ICU data loading process for application-specific
- * data and allows you to force the it to come out of a user-specified
- * pointer.
- *
- * The format of this data is that of the icu common data file, like 'icudt26l.dat'
- * or the corresponding shared library (DLL) file.
- * The application must read in or otherwise construct an image of the data and then
- * pass the address of it to this function.
- *
- *
- * Warning:  setAppData will set a U_USING_DEFAULT_WARNING code if
- *           data with the specifed path that has already been opened, or
- *           if setAppData with the same path has already been called.
- *           Any such calls to setAppData will have no effect.
- *
- *
- * @param packageName the package name by which the application will refer
- *             to (open) this data
- * @param data pointer to the data
- * @param err outgoing error status <code>U_USING_DEFAULT_WARNING, U_UNSUPPORTED_ERROR</code>
- * @see udata_setCommonData
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2
-udata_setAppData(const char *packageName, const void *data, UErrorCode *err);
-
-/**
- * Possible settings for udata_setFileAccess()
- * @see udata_setFileAccess
- * @stable ICU 3.4
- */
-typedef enum UDataFileAccess {
-    /** ICU looks for data in single files first, then in packages. (default) */
-    UDATA_FILES_FIRST,
-    /** ICU only loads data from packages, not from single files. */
-    UDATA_ONLY_PACKAGES,
-    /** ICU loads data from packages first, and only from single files
-        if the data cannot be found in a package. */
-    UDATA_PACKAGES_FIRST,
-    /** ICU does not access the file system for data loading. */
-    UDATA_NO_FILES,
-    /** An alias for the default access mode. */
-    UDATA_DEFAULT_ACCESS = UDATA_FILES_FIRST,
-    UDATA_FILE_ACCESS_COUNT
-} UDataFileAccess;
-
-/**
- * This function may be called to control how ICU loads data. It must be called
- * before any ICU data is loaded, including application data loaded with ures/ResourceBundle or
- * udata APIs. It should be called before u_init.  This function is not multithread safe.  
- * The results of calling it while other threads are loading data are undefined.
- * @param access The type of file access to be used
- * @param status Error code.
- * @see UDataFileAccess
- * @stable ICU 3.4 
- */
-U_STABLE void U_EXPORT2
-udata_setFileAccess(UDataFileAccess access, UErrorCode *status);
-
-U_CDECL_END
-
-#endif

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/udatpg.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/udatpg.h b/apps/couch_collate/platform/osx/icu/unicode/udatpg.h
deleted file mode 100644
index 206637f..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/udatpg.h
+++ /dev/null
@@ -1,471 +0,0 @@
-/*
-*******************************************************************************
-*
-*   Copyright (C) 2007-2008, International Business Machines
-*   Corporation and others.  All Rights Reserved.
-*
-*******************************************************************************
-*   file name:  udatpg.h
-*   encoding:   US-ASCII
-*   tab size:   8 (not used)
-*   indentation:4
-*
-*   created on: 2007jul30
-*   created by: Markus W. Scherer
-*/
-
-#ifndef __UDATPG_H__
-#define __UDATPG_H__
-
-#include "unicode/utypes.h"
-#include "unicode/uenum.h"
-
-/**
- * \file
- * \brief C API: Wrapper for DateTimePatternGenerator (unicode/dtptngen.h).
- *
- * UDateTimePatternGenerator provides flexible generation of date format patterns, 
- * like "yy-MM-dd". The user can build up the generator by adding successive 
- * patterns. Once that is done, a query can be made using a "skeleton", which is 
- * a pattern which just includes the desired fields and lengths. The generator 
- * will return the "best fit" pattern corresponding to that skeleton.
- * <p>The main method people will use is udatpg_getBestPattern, since normally
- * UDateTimePatternGenerator is pre-built with data from a particular locale. 
- * However, generators can be built directly from other data as well.
- * <p><i>Issue: may be useful to also have a function that returns the list of 
- * fields in a pattern, in order, since we have that internally.
- * That would be useful for getting the UI order of field elements.</i>
- */
-
-/**
- * Opaque type for a date/time pattern generator object.
- * @stable ICU 4.0
- */
-typedef void *UDateTimePatternGenerator;
-
-/**
- * Field number constants for udatpg_getAppendItemFormats() and similar functions.
- * These constants are separate from UDateFormatField despite semantic overlap
- * because some fields are merged for the date/time pattern generator.
- * @stable ICU 4.0
- */
-typedef enum UDateTimePatternField {
-    /** @stable ICU 4.0 */
-    UDATPG_ERA_FIELD,
-    /** @stable ICU 4.0 */
-    UDATPG_YEAR_FIELD,
-    /** @stable ICU 4.0 */
-    UDATPG_QUARTER_FIELD,
-    /** @stable ICU 4.0 */
-    UDATPG_MONTH_FIELD,
-    /** @stable ICU 4.0 */
-    UDATPG_WEEK_OF_YEAR_FIELD,
-    /** @stable ICU 4.0 */
-    UDATPG_WEEK_OF_MONTH_FIELD,
-    /** @stable ICU 4.0 */
-    UDATPG_WEEKDAY_FIELD,
-    /** @stable ICU 4.0 */
-    UDATPG_DAY_OF_YEAR_FIELD,
-    /** @stable ICU 4.0 */
-    UDATPG_DAY_OF_WEEK_IN_MONTH_FIELD,
-    /** @stable ICU 4.0 */
-    UDATPG_DAY_FIELD,
-    /** @stable ICU 4.0 */
-    UDATPG_DAYPERIOD_FIELD,
-    /** @stable ICU 4.0 */
-    UDATPG_HOUR_FIELD,
-    /** @stable ICU 4.0 */
-    UDATPG_MINUTE_FIELD,
-    /** @stable ICU 4.0 */
-    UDATPG_SECOND_FIELD,
-    /** @stable ICU 4.0 */
-    UDATPG_FRACTIONAL_SECOND_FIELD,
-    /** @stable ICU 4.0 */
-    UDATPG_ZONE_FIELD,
-    /** @stable ICU 4.0 */
-    UDATPG_FIELD_COUNT
-} UDateTimePatternField;
-
-/**
- * Status return values from udatpg_addPattern().
- * @stable ICU 4.0
- */
-typedef enum UDateTimePatternConflict {
-    /** @stable ICU 4.0 */
-    UDATPG_NO_CONFLICT,
-    /** @stable ICU 4.0 */
-    UDATPG_BASE_CONFLICT,
-    /** @stable ICU 4.0 */
-    UDATPG_CONFLICT,
-    /** @stable ICU 4.0 */
-    UDATPG_CONFLICT_COUNT
-} UDateTimePatternConflict;
-
-/**
-  * Open a generator according to a given locale.
-  * @param locale
-  * @param pErrorCode a pointer to the UErrorCode which must not indicate a
-  *                   failure before the function call.
-  * @return a pointer to UDateTimePatternGenerator.
-  * @stable ICU 4.0
-  */
-U_DRAFT UDateTimePatternGenerator * U_EXPORT2
-udatpg_open(const char *locale, UErrorCode *pErrorCode);
-
-/**
-  * Open an empty generator, to be constructed with udatpg_addPattern(...) etc.
-  * @param pErrorCode a pointer to the UErrorCode which must not indicate a
-  *                   failure before the function call.
-  * @return a pointer to UDateTimePatternGenerator.
-  * @stable ICU 4.0
-  */
-U_DRAFT UDateTimePatternGenerator * U_EXPORT2
-udatpg_openEmpty(UErrorCode *pErrorCode);
-
-/**
-  * Close a generator.
-  * @param dtpg a pointer to UDateTimePatternGenerator.
-  * @stable ICU 4.0
-  */
-U_DRAFT void U_EXPORT2
-udatpg_close(UDateTimePatternGenerator *dtpg);
-
-/**
-  * Create a copy pf a generator.
-  * @param dtpg a pointer to UDateTimePatternGenerator to be copied.
-  * @param pErrorCode a pointer to the UErrorCode which must not indicate a
-  *                   failure before the function call.
-  * @return a pointer to a new UDateTimePatternGenerator.
-  * @stable ICU 4.0
- */
-U_DRAFT UDateTimePatternGenerator * U_EXPORT2
-udatpg_clone(const UDateTimePatternGenerator *dtpg, UErrorCode *pErrorCode);
-
-/**
- * Get the best pattern matching the input skeleton. It is guaranteed to
- * have all of the fields in the skeleton.
- * 
- * Note that this function uses a non-const UDateTimePatternGenerator:
- * It uses a stateful pattern parser which is set up for each generator object,
- * rather than creating one for each function call.
- * Consecutive calls to this function do not affect each other,
- * but this function cannot be used concurrently on a single generator object.
- * 
- * @param dtpg a pointer to UDateTimePatternGenerator.
- * @param skeleton
- *            The skeleton is a pattern containing only the variable fields.
- *            For example, "MMMdd" and "mmhh" are skeletons.
- * @param length the length of skeleton
- * @param bestPattern
- *            The best pattern found from the given skeleton.
- * @param capacity the capacity of bestPattern.
- * @param pErrorCode a pointer to the UErrorCode which must not indicate a
- *                   failure before the function call.
- * @return the length of bestPattern.
- * @stable ICU 4.0
- */
-U_DRAFT int32_t U_EXPORT2
-udatpg_getBestPattern(UDateTimePatternGenerator *dtpg,
-                      const UChar *skeleton, int32_t length,
-                      UChar *bestPattern, int32_t capacity,
-                      UErrorCode *pErrorCode);
-
-/**
-  * Get a unique skeleton from a given pattern. For example,
-  * both "MMM-dd" and "dd/MMM" produce the skeleton "MMMdd".
-  * 
-  * Note that this function uses a non-const UDateTimePatternGenerator:
-  * It uses a stateful pattern parser which is set up for each generator object,
-  * rather than creating one for each function call.
-  * Consecutive calls to this function do not affect each other,
-  * but this function cannot be used concurrently on a single generator object.
-  *
-  * @param dtpg     a pointer to UDateTimePatternGenerator.
-  * @param pattern  input pattern, such as "dd/MMM".
-  * @param length   the length of pattern.
-  * @param skeleton such as "MMMdd"
-  * @param capacity the capacity of skeleton.
-  * @param pErrorCode a pointer to the UErrorCode which must not indicate a
-  *                  failure before the function call.
-  * @return the length of skeleton.
-  * @stable ICU 4.0
-  */
-U_DRAFT int32_t U_EXPORT2
-udatpg_getSkeleton(UDateTimePatternGenerator *dtpg,
-                   const UChar *pattern, int32_t length,
-                   UChar *skeleton, int32_t capacity,
-                   UErrorCode *pErrorCode);
-
-/**
- * Get a unique base skeleton from a given pattern. This is the same
- * as the skeleton, except that differences in length are minimized so
- * as to only preserve the difference between string and numeric form. So
- * for example, both "MMM-dd" and "d/MMM" produce the skeleton "MMMd"
- * (notice the single d).
- *
- * Note that this function uses a non-const UDateTimePatternGenerator:
- * It uses a stateful pattern parser which is set up for each generator object,
- * rather than creating one for each function call.
- * Consecutive calls to this function do not affect each other,
- * but this function cannot be used concurrently on a single generator object.
- *
- * @param dtpg     a pointer to UDateTimePatternGenerator.
- * @param pattern  input pattern, such as "dd/MMM".
- * @param length   the length of pattern.
- * @param baseSkeleton such as "Md"
- * @param capacity the capacity of base skeleton.
- * @param pErrorCode a pointer to the UErrorCode which must not indicate a
- *                  failure before the function call.
- * @return the length of baseSkeleton.
- * @stable ICU 4.0
- */
-U_DRAFT int32_t U_EXPORT2
-udatpg_getBaseSkeleton(UDateTimePatternGenerator *dtpg,
-                       const UChar *pattern, int32_t length,
-                       UChar *baseSkeleton, int32_t capacity,
-                       UErrorCode *pErrorCode);
-
-/**
- * Adds a pattern to the generator. If the pattern has the same skeleton as
- * an existing pattern, and the override parameter is set, then the previous
- * value is overriden. Otherwise, the previous value is retained. In either
- * case, the conflicting status is set and previous vale is stored in 
- * conflicting pattern.
- * <p>
- * Note that single-field patterns (like "MMM") are automatically added, and
- * don't need to be added explicitly!
- *
- * @param dtpg     a pointer to UDateTimePatternGenerator.
- * @param pattern  input pattern, such as "dd/MMM"
- * @param patternLength the length of pattern.
- * @param override  When existing values are to be overridden use true, 
- *                  otherwise use false.
- * @param conflictingPattern  Previous pattern with the same skeleton.
- * @param capacity the capacity of conflictingPattern.
- * @param pLength a pointer to the length of conflictingPattern.
- * @param pErrorCode a pointer to the UErrorCode which must not indicate a
- *                  failure before the function call.
- * @return conflicting status. The value could be UDATPG_NO_CONFLICT, 
- *                  UDATPG_BASE_CONFLICT or UDATPG_CONFLICT.
- * @stable ICU 4.0
- */
-U_DRAFT UDateTimePatternConflict U_EXPORT2
-udatpg_addPattern(UDateTimePatternGenerator *dtpg,
-                  const UChar *pattern, int32_t patternLength,
-                  UBool override,
-                  UChar *conflictingPattern, int32_t capacity, int32_t *pLength,
-                  UErrorCode *pErrorCode);
-
-/**
-  * An AppendItem format is a pattern used to append a field if there is no
-  * good match. For example, suppose that the input skeleton is "GyyyyMMMd",
-  * and there is no matching pattern internally, but there is a pattern
-  * matching "yyyyMMMd", say "d-MM-yyyy". Then that pattern is used, plus the
-  * G. The way these two are conjoined is by using the AppendItemFormat for G
-  * (era). So if that value is, say "{0}, {1}" then the final resulting
-  * pattern is "d-MM-yyyy, G".
-  * <p>
-  * There are actually three available variables: {0} is the pattern so far,
-  * {1} is the element we are adding, and {2} is the name of the element.
-  * <p>
-  * This reflects the way that the CLDR data is organized.
-  *
-  * @param dtpg   a pointer to UDateTimePatternGenerator.
-  * @param field  UDateTimePatternField, such as UDATPG_ERA_FIELD
-  * @param value  pattern, such as "{0}, {1}"
-  * @param length the length of value.
-  * @stable ICU 4.0
-  */
-U_DRAFT void U_EXPORT2
-udatpg_setAppendItemFormat(UDateTimePatternGenerator *dtpg,
-                           UDateTimePatternField field,
-                           const UChar *value, int32_t length);
-
-/**
- * Getter corresponding to setAppendItemFormat. Values below 0 or at or
- * above UDATPG_FIELD_COUNT are illegal arguments.
- *
- * @param dtpg   A pointer to UDateTimePatternGenerator.
- * @param field  UDateTimePatternField, such as UDATPG_ERA_FIELD
- * @param pLength A pointer that will receive the length of appendItemFormat.
- * @return appendItemFormat for field.
- * @stable ICU 4.0
- */
-U_DRAFT const UChar * U_EXPORT2
-udatpg_getAppendItemFormat(const UDateTimePatternGenerator *dtpg,
-                           UDateTimePatternField field,
-                           int32_t *pLength);
-
-/**
-   * Set the name of field, eg "era" in English for ERA. These are only
-   * used if the corresponding AppendItemFormat is used, and if it contains a
-   * {2} variable.
-   * <p>
-   * This reflects the way that the CLDR data is organized.
-   *
-   * @param dtpg   a pointer to UDateTimePatternGenerator.
-   * @param field  UDateTimePatternField
-   * @param value  name for the field.
-   * @param length the length of value.
-   * @stable ICU 4.0
-   */
-U_DRAFT void U_EXPORT2
-udatpg_setAppendItemName(UDateTimePatternGenerator *dtpg,
-                         UDateTimePatternField field,
-                         const UChar *value, int32_t length);
-
-/**
- * Getter corresponding to setAppendItemNames. Values below 0 or at or above
- * UDATPG_FIELD_COUNT are illegal arguments.
- *
- * @param dtpg   a pointer to UDateTimePatternGenerator.
- * @param field  UDateTimePatternField, such as UDATPG_ERA_FIELD
- * @param pLength A pointer that will receive the length of the name for field.
- * @return name for field
- * @stable ICU 4.0
- */
-U_DRAFT const UChar * U_EXPORT2
-udatpg_getAppendItemName(const UDateTimePatternGenerator *dtpg,
-                         UDateTimePatternField field,
-                         int32_t *pLength);
-
-/**
- * The date time format is a message format pattern used to compose date and
- * time patterns. The default value is "{0} {1}", where {0} will be replaced
- * by the date pattern and {1} will be replaced by the time pattern.
- * <p>
- * This is used when the input skeleton contains both date and time fields,
- * but there is not a close match among the added patterns. For example,
- * suppose that this object was created by adding "dd-MMM" and "hh:mm", and
- * its datetimeFormat is the default "{0} {1}". Then if the input skeleton
- * is "MMMdhmm", there is not an exact match, so the input skeleton is
- * broken up into two components "MMMd" and "hmm". There are close matches
- * for those two skeletons, so the result is put together with this pattern,
- * resulting in "d-MMM h:mm".
- *
- * @param dtpg a pointer to UDateTimePatternGenerator.
- * @param dtFormat
- *            message format pattern, here {0} will be replaced by the date
- *            pattern and {1} will be replaced by the time pattern.
- * @param length the length of dtFormat.
- * @stable ICU 4.0
- */
-U_DRAFT void U_EXPORT2
-udatpg_setDateTimeFormat(const UDateTimePatternGenerator *dtpg,
-                         const UChar *dtFormat, int32_t length);
-
-/**
- * Getter corresponding to setDateTimeFormat.
- * @param dtpg   a pointer to UDateTimePatternGenerator.
- * @param pLength A pointer that will receive the length of the format
- * @return dateTimeFormat.
- * @stable ICU 4.0
- */
-U_DRAFT const UChar * U_EXPORT2
-udatpg_getDateTimeFormat(const UDateTimePatternGenerator *dtpg,
-                         int32_t *pLength);
-
-/**
- * The decimal value is used in formatting fractions of seconds. If the
- * skeleton contains fractional seconds, then this is used with the
- * fractional seconds. For example, suppose that the input pattern is
- * "hhmmssSSSS", and the best matching pattern internally is "H:mm:ss", and
- * the decimal string is ",". Then the resulting pattern is modified to be
- * "H:mm:ss,SSSS"
- *
- * @param dtpg a pointer to UDateTimePatternGenerator.
- * @param decimal
- * @param length the length of decimal.
- * @stable ICU 4.0
- */
-U_DRAFT void U_EXPORT2
-udatpg_setDecimal(UDateTimePatternGenerator *dtpg,
-                  const UChar *decimal, int32_t length);
-
-/**
- * Getter corresponding to setDecimal.
- * 
- * @param dtpg a pointer to UDateTimePatternGenerator.
- * @param pLength A pointer that will receive the length of the decimal string.
- * @return corresponding to the decimal point.
- * @stable ICU 4.0
- */
-U_DRAFT const UChar * U_EXPORT2
-udatpg_getDecimal(const UDateTimePatternGenerator *dtpg,
-                  int32_t *pLength);
-
-/**
- * Adjusts the field types (width and subtype) of a pattern to match what is
- * in a skeleton. That is, if you supply a pattern like "d-M H:m", and a
- * skeleton of "MMMMddhhmm", then the input pattern is adjusted to be
- * "dd-MMMM hh:mm". This is used internally to get the best match for the
- * input skeleton, but can also be used externally.
- *
- * Note that this function uses a non-const UDateTimePatternGenerator:
- * It uses a stateful pattern parser which is set up for each generator object,
- * rather than creating one for each function call.
- * Consecutive calls to this function do not affect each other,
- * but this function cannot be used concurrently on a single generator object.
- *
- * @param dtpg a pointer to UDateTimePatternGenerator.
- * @param pattern Input pattern
- * @param patternLength the length of input pattern.
- * @param skeleton
- * @param skeletonLength the length of input skeleton.
- * @param dest  pattern adjusted to match the skeleton fields widths and subtypes.
- * @param destCapacity the capacity of dest.
- * @param pErrorCode a pointer to the UErrorCode which must not indicate a
- *                  failure before the function call.
- * @return the length of dest.
- * @stable ICU 4.0
- */
-U_DRAFT int32_t U_EXPORT2
-udatpg_replaceFieldTypes(UDateTimePatternGenerator *dtpg,
-                         const UChar *pattern, int32_t patternLength,
-                         const UChar *skeleton, int32_t skeletonLength,
-                         UChar *dest, int32_t destCapacity,
-                         UErrorCode *pErrorCode);
-
-/**
- * Return a UEnumeration list of all the skeletons in canonical form.
- * Call udatpg_getPatternForSkeleton() to get the corresponding pattern.
- * 
- * @param dtpg a pointer to UDateTimePatternGenerator.
- * @param pErrorCode a pointer to the UErrorCode which must not indicate a
- *                  failure before the function call
- * @return a UEnumeration list of all the skeletons
- *         The caller must close the object.
- * @stable ICU 4.0
- */
-U_DRAFT UEnumeration * U_EXPORT2
-udatpg_openSkeletons(const UDateTimePatternGenerator *dtpg, UErrorCode *pErrorCode);
-
-/**
- * Return a UEnumeration list of all the base skeletons in canonical form.
- *
- * @param dtpg a pointer to UDateTimePatternGenerator.
- * @param pErrorCode a pointer to the UErrorCode which must not indicate a
- *             failure before the function call.
- * @return a UEnumeration list of all the base skeletons
- *             The caller must close the object.
- * @stable ICU 4.0
- */
-U_DRAFT UEnumeration * U_EXPORT2
-udatpg_openBaseSkeletons(const UDateTimePatternGenerator *dtpg, UErrorCode *pErrorCode);
-
-/**
- * Get the pattern corresponding to a given skeleton.
- * 
- * @param dtpg a pointer to UDateTimePatternGenerator.
- * @param skeleton 
- * @param skeletonLength pointer to the length of skeleton.
- * @param pLength pointer to the length of return pattern.
- * @return pattern corresponding to a given skeleton.
- * @stable ICU 4.0
- */
-U_DRAFT const UChar * U_EXPORT2
-udatpg_getPatternForSkeleton(const UDateTimePatternGenerator *dtpg,
-                             const UChar *skeleton, int32_t skeletonLength,
-                             int32_t *pLength);
-
-#endif

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/udeprctd.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/udeprctd.h b/apps/couch_collate/platform/osx/icu/unicode/udeprctd.h
deleted file mode 100644
index 9bf45f3..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/udeprctd.h
+++ /dev/null
@@ -1,50 +0,0 @@
-/*
-*******************************************************************************
-*   Copyright (C) 2004-2008, International Business Machines
-*   Corporation and others.  All Rights Reserved.
-*******************************************************************************
-*
-*   file name:  
-*   encoding:   US-ASCII
-*   tab size:   8 (not used)
-*   indentation:4
-*
-*   Created by: genheaders.pl, a perl script written by Ram Viswanadha
-*
-*  Contains data for commenting out APIs.
-*  Gets included by umachine.h
-*
-*  THIS FILE IS MACHINE-GENERATED, DON'T PLAY WITH IT IF YOU DON'T KNOW WHAT
-*  YOU ARE DOING, OTHERWISE VERY BAD THINGS WILL HAPPEN!
-*/
-
-#ifndef UDEPRCTD_H
-#define UDEPRCTD_H
-
-#ifdef U_HIDE_DEPRECATED_API
-
-#    if U_DISABLE_RENAMING
-#        define ucol_getContractions ucol_getContractions_DEPRECATED_API_DO_NOT_USE
-#        define ucol_getLocale ucol_getLocale_DEPRECATED_API_DO_NOT_USE
-#        define ures_countArrayItems ures_countArrayItems_DEPRECATED_API_DO_NOT_USE
-#        define ures_getLocale ures_getLocale_DEPRECATED_API_DO_NOT_USE
-#        define ures_getVersionNumber ures_getVersionNumber_DEPRECATED_API_DO_NOT_USE
-#        define utrans_getAvailableID utrans_getAvailableID_DEPRECATED_API_DO_NOT_USE
-#        define utrans_getID utrans_getID_DEPRECATED_API_DO_NOT_USE
-#        define utrans_open utrans_open_DEPRECATED_API_DO_NOT_USE
-#        define utrans_unregister utrans_unregister_DEPRECATED_API_DO_NOT_USE
-#    else
-#        define ucol_getContractions_4_0 ucol_getContractions_DEPRECATED_API_DO_NOT_USE
-#        define ucol_getLocale_4_0 ucol_getLocale_DEPRECATED_API_DO_NOT_USE
-#        define ures_countArrayItems_4_0 ures_countArrayItems_DEPRECATED_API_DO_NOT_USE
-#        define ures_getLocale_4_0 ures_getLocale_DEPRECATED_API_DO_NOT_USE
-#        define ures_getVersionNumber_4_0 ures_getVersionNumber_DEPRECATED_API_DO_NOT_USE
-#        define utrans_getAvailableID_4_0 utrans_getAvailableID_DEPRECATED_API_DO_NOT_USE
-#        define utrans_getID_4_0 utrans_getID_DEPRECATED_API_DO_NOT_USE
-#        define utrans_open_4_0 utrans_open_DEPRECATED_API_DO_NOT_USE
-#        define utrans_unregister_4_0 utrans_unregister_DEPRECATED_API_DO_NOT_USE
-#    endif /* U_DISABLE_RENAMING */
-
-#endif /* U_HIDE_DEPRECATED_API */
-#endif /* UDEPRCTD_H */
-

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/udraft.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/udraft.h b/apps/couch_collate/platform/osx/icu/unicode/udraft.h
deleted file mode 100644
index 5426adf..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/udraft.h
+++ /dev/null
@@ -1,166 +0,0 @@
-/*
-*******************************************************************************
-*   Copyright (C) 2004-2008, International Business Machines
-*   Corporation and others.  All Rights Reserved.
-*******************************************************************************
-*
-*   file name:  
-*   encoding:   US-ASCII
-*   tab size:   8 (not used)
-*   indentation:4
-*
-*   Created by: genheaders.pl, a perl script written by Ram Viswanadha
-*
-*  Contains data for commenting out APIs.
-*  Gets included by umachine.h
-*
-*  THIS FILE IS MACHINE-GENERATED, DON'T PLAY WITH IT IF YOU DON'T KNOW WHAT
-*  YOU ARE DOING, OTHERWISE VERY BAD THINGS WILL HAPPEN!
-*/
-
-#ifndef UDRAFT_H
-#define UDRAFT_H
-
-#ifdef U_HIDE_DRAFT_API
-
-#    if U_DISABLE_RENAMING
-#        define afkLanguageCode afkLanguageCode_DRAFT_API_DO_NOT_USE
-#        define armiScriptCode armiScriptCode_DRAFT_API_DO_NOT_USE
-#        define u_fclose u_fclose_DRAFT_API_DO_NOT_USE
-#        define u_feof u_feof_DRAFT_API_DO_NOT_USE
-#        define u_fflush u_fflush_DRAFT_API_DO_NOT_USE
-#        define u_fgetConverter u_fgetConverter_DRAFT_API_DO_NOT_USE
-#        define u_fgetc u_fgetc_DRAFT_API_DO_NOT_USE
-#        define u_fgetcodepage u_fgetcodepage_DRAFT_API_DO_NOT_USE
-#        define u_fgetcx u_fgetcx_DRAFT_API_DO_NOT_USE
-#        define u_fgetfile u_fgetfile_DRAFT_API_DO_NOT_USE
-#        define u_fgetlocale u_fgetlocale_DRAFT_API_DO_NOT_USE
-#        define u_fgets u_fgets_DRAFT_API_DO_NOT_USE
-#        define u_file_read u_file_read_DRAFT_API_DO_NOT_USE
-#        define u_file_write u_file_write_DRAFT_API_DO_NOT_USE
-#        define u_finit u_finit_DRAFT_API_DO_NOT_USE
-#        define u_fopen u_fopen_DRAFT_API_DO_NOT_USE
-#        define u_fprintf u_fprintf_DRAFT_API_DO_NOT_USE
-#        define u_fprintf_u u_fprintf_u_DRAFT_API_DO_NOT_USE
-#        define u_fputc u_fputc_DRAFT_API_DO_NOT_USE
-#        define u_fputs u_fputs_DRAFT_API_DO_NOT_USE
-#        define u_frewind u_frewind_DRAFT_API_DO_NOT_USE
-#        define u_fscanf u_fscanf_DRAFT_API_DO_NOT_USE
-#        define u_fscanf_u u_fscanf_u_DRAFT_API_DO_NOT_USE
-#        define u_fsetcodepage u_fsetcodepage_DRAFT_API_DO_NOT_USE
-#        define u_fsetlocale u_fsetlocale_DRAFT_API_DO_NOT_USE
-#        define u_fsettransliterator u_fsettransliterator_DRAFT_API_DO_NOT_USE
-#        define u_fstropen u_fstropen_DRAFT_API_DO_NOT_USE
-#        define u_fungetc u_fungetc_DRAFT_API_DO_NOT_USE
-#        define u_snprintf u_snprintf_DRAFT_API_DO_NOT_USE
-#        define u_snprintf_u u_snprintf_u_DRAFT_API_DO_NOT_USE
-#        define u_sprintf u_sprintf_DRAFT_API_DO_NOT_USE
-#        define u_sprintf_u u_sprintf_u_DRAFT_API_DO_NOT_USE
-#        define u_sscanf u_sscanf_DRAFT_API_DO_NOT_USE
-#        define u_sscanf_u u_sscanf_u_DRAFT_API_DO_NOT_USE
-#        define u_vfprintf u_vfprintf_DRAFT_API_DO_NOT_USE
-#        define u_vfprintf_u u_vfprintf_u_DRAFT_API_DO_NOT_USE
-#        define u_vfscanf u_vfscanf_DRAFT_API_DO_NOT_USE
-#        define u_vfscanf_u u_vfscanf_u_DRAFT_API_DO_NOT_USE
-#        define u_vsnprintf u_vsnprintf_DRAFT_API_DO_NOT_USE
-#        define u_vsnprintf_u u_vsnprintf_u_DRAFT_API_DO_NOT_USE
-#        define u_vsprintf u_vsprintf_DRAFT_API_DO_NOT_USE
-#        define u_vsprintf_u u_vsprintf_u_DRAFT_API_DO_NOT_USE
-#        define u_vsscanf u_vsscanf_DRAFT_API_DO_NOT_USE
-#        define u_vsscanf_u u_vsscanf_u_DRAFT_API_DO_NOT_USE
-#        define ucal_clone ucal_clone_DRAFT_API_DO_NOT_USE
-#        define ucal_getCanonicalTimeZoneID ucal_getCanonicalTimeZoneID_DRAFT_API_DO_NOT_USE
-#        define ucurr_countCurrencies ucurr_countCurrencies_DRAFT_API_DO_NOT_USE
-#        define ucurr_forLocaleAndDate ucurr_forLocaleAndDate_DRAFT_API_DO_NOT_USE
-#        define uloc_addLikelySubtags uloc_addLikelySubtags_DRAFT_API_DO_NOT_USE
-#        define uloc_getCharacterOrientation uloc_getCharacterOrientation_DRAFT_API_DO_NOT_USE
-#        define uloc_getLineOrientation uloc_getLineOrientation_DRAFT_API_DO_NOT_USE
-#        define uloc_minimizeSubtags uloc_minimizeSubtags_DRAFT_API_DO_NOT_USE
-#        define uregex_getMatchCallback uregex_getMatchCallback_DRAFT_API_DO_NOT_USE
-#        define uregex_getStackLimit uregex_getStackLimit_DRAFT_API_DO_NOT_USE
-#        define uregex_getTimeLimit uregex_getTimeLimit_DRAFT_API_DO_NOT_USE
-#        define uregex_hasAnchoringBounds uregex_hasAnchoringBounds_DRAFT_API_DO_NOT_USE
-#        define uregex_hasTransparentBounds uregex_hasTransparentBounds_DRAFT_API_DO_NOT_USE
-#        define uregex_hitEnd uregex_hitEnd_DRAFT_API_DO_NOT_USE
-#        define uregex_regionEnd uregex_regionEnd_DRAFT_API_DO_NOT_USE
-#        define uregex_regionStart uregex_regionStart_DRAFT_API_DO_NOT_USE
-#        define uregex_requireEnd uregex_requireEnd_DRAFT_API_DO_NOT_USE
-#        define uregex_setMatchCallback uregex_setMatchCallback_DRAFT_API_DO_NOT_USE
-#        define uregex_setRegion uregex_setRegion_DRAFT_API_DO_NOT_USE
-#        define uregex_setStackLimit uregex_setStackLimit_DRAFT_API_DO_NOT_USE
-#        define uregex_setTimeLimit uregex_setTimeLimit_DRAFT_API_DO_NOT_USE
-#        define uregex_useAnchoringBounds uregex_useAnchoringBounds_DRAFT_API_DO_NOT_USE
-#        define uregex_useTransparentBounds uregex_useTransparentBounds_DRAFT_API_DO_NOT_USE
-#    else
-#        define afkLanguageCode_4_0 afkLanguageCode_DRAFT_API_DO_NOT_USE
-#        define armiScriptCode_4_0 armiScriptCode_DRAFT_API_DO_NOT_USE
-#        define u_fclose_4_0 u_fclose_DRAFT_API_DO_NOT_USE
-#        define u_feof_4_0 u_feof_DRAFT_API_DO_NOT_USE
-#        define u_fflush_4_0 u_fflush_DRAFT_API_DO_NOT_USE
-#        define u_fgetConverter_4_0 u_fgetConverter_DRAFT_API_DO_NOT_USE
-#        define u_fgetc_4_0 u_fgetc_DRAFT_API_DO_NOT_USE
-#        define u_fgetcodepage_4_0 u_fgetcodepage_DRAFT_API_DO_NOT_USE
-#        define u_fgetcx_4_0 u_fgetcx_DRAFT_API_DO_NOT_USE
-#        define u_fgetfile_4_0 u_fgetfile_DRAFT_API_DO_NOT_USE
-#        define u_fgetlocale_4_0 u_fgetlocale_DRAFT_API_DO_NOT_USE
-#        define u_fgets_4_0 u_fgets_DRAFT_API_DO_NOT_USE
-#        define u_file_read_4_0 u_file_read_DRAFT_API_DO_NOT_USE
-#        define u_file_write_4_0 u_file_write_DRAFT_API_DO_NOT_USE
-#        define u_finit_4_0 u_finit_DRAFT_API_DO_NOT_USE
-#        define u_fopen_4_0 u_fopen_DRAFT_API_DO_NOT_USE
-#        define u_fprintf_4_0 u_fprintf_DRAFT_API_DO_NOT_USE
-#        define u_fprintf_u_4_0 u_fprintf_u_DRAFT_API_DO_NOT_USE
-#        define u_fputc_4_0 u_fputc_DRAFT_API_DO_NOT_USE
-#        define u_fputs_4_0 u_fputs_DRAFT_API_DO_NOT_USE
-#        define u_frewind_4_0 u_frewind_DRAFT_API_DO_NOT_USE
-#        define u_fscanf_4_0 u_fscanf_DRAFT_API_DO_NOT_USE
-#        define u_fscanf_u_4_0 u_fscanf_u_DRAFT_API_DO_NOT_USE
-#        define u_fsetcodepage_4_0 u_fsetcodepage_DRAFT_API_DO_NOT_USE
-#        define u_fsetlocale_4_0 u_fsetlocale_DRAFT_API_DO_NOT_USE
-#        define u_fsettransliterator_4_0 u_fsettransliterator_DRAFT_API_DO_NOT_USE
-#        define u_fstropen_4_0 u_fstropen_DRAFT_API_DO_NOT_USE
-#        define u_fungetc_4_0 u_fungetc_DRAFT_API_DO_NOT_USE
-#        define u_snprintf_4_0 u_snprintf_DRAFT_API_DO_NOT_USE
-#        define u_snprintf_u_4_0 u_snprintf_u_DRAFT_API_DO_NOT_USE
-#        define u_sprintf_4_0 u_sprintf_DRAFT_API_DO_NOT_USE
-#        define u_sprintf_u_4_0 u_sprintf_u_DRAFT_API_DO_NOT_USE
-#        define u_sscanf_4_0 u_sscanf_DRAFT_API_DO_NOT_USE
-#        define u_sscanf_u_4_0 u_sscanf_u_DRAFT_API_DO_NOT_USE
-#        define u_vfprintf_4_0 u_vfprintf_DRAFT_API_DO_NOT_USE
-#        define u_vfprintf_u_4_0 u_vfprintf_u_DRAFT_API_DO_NOT_USE
-#        define u_vfscanf_4_0 u_vfscanf_DRAFT_API_DO_NOT_USE
-#        define u_vfscanf_u_4_0 u_vfscanf_u_DRAFT_API_DO_NOT_USE
-#        define u_vsnprintf_4_0 u_vsnprintf_DRAFT_API_DO_NOT_USE
-#        define u_vsnprintf_u_4_0 u_vsnprintf_u_DRAFT_API_DO_NOT_USE
-#        define u_vsprintf_4_0 u_vsprintf_DRAFT_API_DO_NOT_USE
-#        define u_vsprintf_u_4_0 u_vsprintf_u_DRAFT_API_DO_NOT_USE
-#        define u_vsscanf_4_0 u_vsscanf_DRAFT_API_DO_NOT_USE
-#        define u_vsscanf_u_4_0 u_vsscanf_u_DRAFT_API_DO_NOT_USE
-#        define ucal_clone_4_0 ucal_clone_DRAFT_API_DO_NOT_USE
-#        define ucal_getCanonicalTimeZoneID_4_0 ucal_getCanonicalTimeZoneID_DRAFT_API_DO_NOT_USE
-#        define ucurr_countCurrencies_4_0 ucurr_countCurrencies_DRAFT_API_DO_NOT_USE
-#        define ucurr_forLocaleAndDate_4_0 ucurr_forLocaleAndDate_DRAFT_API_DO_NOT_USE
-#        define uloc_addLikelySubtags_4_0 uloc_addLikelySubtags_DRAFT_API_DO_NOT_USE
-#        define uloc_getCharacterOrientation_4_0 uloc_getCharacterOrientation_DRAFT_API_DO_NOT_USE
-#        define uloc_getLineOrientation_4_0 uloc_getLineOrientation_DRAFT_API_DO_NOT_USE
-#        define uloc_minimizeSubtags_4_0 uloc_minimizeSubtags_DRAFT_API_DO_NOT_USE
-#        define uregex_getMatchCallback_4_0 uregex_getMatchCallback_DRAFT_API_DO_NOT_USE
-#        define uregex_getStackLimit_4_0 uregex_getStackLimit_DRAFT_API_DO_NOT_USE
-#        define uregex_getTimeLimit_4_0 uregex_getTimeLimit_DRAFT_API_DO_NOT_USE
-#        define uregex_hasAnchoringBounds_4_0 uregex_hasAnchoringBounds_DRAFT_API_DO_NOT_USE
-#        define uregex_hasTransparentBounds_4_0 uregex_hasTransparentBounds_DRAFT_API_DO_NOT_USE
-#        define uregex_hitEnd_4_0 uregex_hitEnd_DRAFT_API_DO_NOT_USE
-#        define uregex_regionEnd_4_0 uregex_regionEnd_DRAFT_API_DO_NOT_USE
-#        define uregex_regionStart_4_0 uregex_regionStart_DRAFT_API_DO_NOT_USE
-#        define uregex_requireEnd_4_0 uregex_requireEnd_DRAFT_API_DO_NOT_USE
-#        define uregex_setMatchCallback_4_0 uregex_setMatchCallback_DRAFT_API_DO_NOT_USE
-#        define uregex_setRegion_4_0 uregex_setRegion_DRAFT_API_DO_NOT_USE
-#        define uregex_setStackLimit_4_0 uregex_setStackLimit_DRAFT_API_DO_NOT_USE
-#        define uregex_setTimeLimit_4_0 uregex_setTimeLimit_DRAFT_API_DO_NOT_USE
-#        define uregex_useAnchoringBounds_4_0 uregex_useAnchoringBounds_DRAFT_API_DO_NOT_USE
-#        define uregex_useTransparentBounds_4_0 uregex_useTransparentBounds_DRAFT_API_DO_NOT_USE
-#    endif /* U_DISABLE_RENAMING */
-
-#endif /* U_HIDE_DRAFT_API */
-#endif /* UDRAFT_H */
-

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/uenum.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/uenum.h b/apps/couch_collate/platform/osx/icu/unicode/uenum.h
deleted file mode 100644
index ff9b299..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/uenum.h
+++ /dev/null
@@ -1,134 +0,0 @@
-/*
-*******************************************************************************
-*
-*   Copyright (C) 2002-2005, International Business Machines
-*   Corporation and others.  All Rights Reserved.
-*
-*******************************************************************************
-*   file name:  uenum.h
-*   encoding:   US-ASCII
-*   tab size:   8 (not used)
-*   indentation:2
-*
-*   created on: 2002jul08
-*   created by: Vladimir Weinstein
-*/
-
-#ifndef __UENUM_H
-#define __UENUM_H
-
-#include "unicode/utypes.h"
-
-/**
- * \file
- * \brief C API: String Enumeration 
- */
- 
-/**
- * An enumeration object.
- * For usage in C programs.
- * @stable ICU 2.2
- */
-struct UEnumeration;
-/** structure representing an enumeration object instance @stable ICU 2.2 */
-typedef struct UEnumeration UEnumeration;
-
-/**
- * Disposes of resources in use by the iterator.  If en is NULL,
- * does nothing.  After this call, any char* or UChar* pointer
- * returned by uenum_unext() or uenum_next() is invalid.
- * @param en UEnumeration structure pointer
- * @stable ICU 2.2
- */
-U_STABLE void U_EXPORT2
-uenum_close(UEnumeration* en);
-
-/**
- * Returns the number of elements that the iterator traverses.  If
- * the iterator is out-of-sync with its service, status is set to
- * U_ENUM_OUT_OF_SYNC_ERROR.
- * This is a convenience function. It can end up being very
- * expensive as all the items might have to be pre-fetched (depending
- * on the type of data being traversed). Use with caution and only 
- * when necessary.
- * @param en UEnumeration structure pointer
- * @param status error code, can be U_ENUM_OUT_OF_SYNC_ERROR if the
- *               iterator is out of sync.
- * @return number of elements in the iterator
- * @stable ICU 2.2
- */
-U_STABLE int32_t U_EXPORT2
-uenum_count(UEnumeration* en, UErrorCode* status);
-
-/**
- * Returns the next element in the iterator's list.  If there are
- * no more elements, returns NULL.  If the iterator is out-of-sync
- * with its service, status is set to U_ENUM_OUT_OF_SYNC_ERROR and
- * NULL is returned.  If the native service string is a char* string,
- * it is converted to UChar* with the invariant converter.
- * The result is terminated by (UChar)0.
- * @param en the iterator object
- * @param resultLength pointer to receive the length of the result
- *                     (not including the terminating \\0).
- *                     If the pointer is NULL it is ignored.
- * @param status the error code, set to U_ENUM_OUT_OF_SYNC_ERROR if
- *               the iterator is out of sync with its service.
- * @return a pointer to the string.  The string will be
- *         zero-terminated.  The return pointer is owned by this iterator
- *         and must not be deleted by the caller.  The pointer is valid
- *         until the next call to any uenum_... method, including
- *         uenum_next() or uenum_unext().  When all strings have been
- *         traversed, returns NULL.
- * @stable ICU 2.2
- */
-U_STABLE const UChar* U_EXPORT2
-uenum_unext(UEnumeration* en,
-            int32_t* resultLength,
-            UErrorCode* status);
-
-/**
- * Returns the next element in the iterator's list.  If there are
- * no more elements, returns NULL.  If the iterator is out-of-sync
- * with its service, status is set to U_ENUM_OUT_OF_SYNC_ERROR and
- * NULL is returned.  If the native service string is a UChar*
- * string, it is converted to char* with the invariant converter.
- * The result is terminated by (char)0.  If the conversion fails
- * (because a character cannot be converted) then status is set to
- * U_INVARIANT_CONVERSION_ERROR and the return value is undefined
- * (but non-NULL).
- * @param en the iterator object
- * @param resultLength pointer to receive the length of the result
- *                     (not including the terminating \\0).
- *                     If the pointer is NULL it is ignored.
- * @param status the error code, set to U_ENUM_OUT_OF_SYNC_ERROR if
- *               the iterator is out of sync with its service.  Set to
- *               U_INVARIANT_CONVERSION_ERROR if the underlying native string is
- *               UChar* and conversion to char* with the invariant converter
- *               fails. This error pertains only to current string, so iteration
- *               might be able to continue successfully.
- * @return a pointer to the string.  The string will be
- *         zero-terminated.  The return pointer is owned by this iterator
- *         and must not be deleted by the caller.  The pointer is valid
- *         until the next call to any uenum_... method, including
- *         uenum_next() or uenum_unext().  When all strings have been
- *         traversed, returns NULL.
- * @stable ICU 2.2
- */
-U_STABLE const char* U_EXPORT2
-uenum_next(UEnumeration* en,
-           int32_t* resultLength,
-           UErrorCode* status);
-
-/**
- * Resets the iterator to the current list of service IDs.  This
- * re-establishes sync with the service and rewinds the iterator
- * to start at the first element.
- * @param en the iterator object
- * @param status the error code, set to U_ENUM_OUT_OF_SYNC_ERROR if
- *               the iterator is out of sync with its service.  
- * @stable ICU 2.2
- */
-U_STABLE void U_EXPORT2
-uenum_reset(UEnumeration* en, UErrorCode* status);
-
-#endif

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/uidna.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/uidna.h b/apps/couch_collate/platform/osx/icu/unicode/uidna.h
deleted file mode 100644
index 52aa6e9..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/uidna.h
+++ /dev/null
@@ -1,312 +0,0 @@
-/*
- *******************************************************************************
- *
- *   Copyright (C) 2003-2007, International Business Machines
- *   Corporation and others.  All Rights Reserved.
- *
- *******************************************************************************
- *   file name:  uidna.h
- *   encoding:   US-ASCII
- *   tab size:   8 (not used)
- *   indentation:4
- *
- *   created on: 2003feb1
- *   created by: Ram Viswanadha
- */
-
-#ifndef __UIDNA_H__
-#define __UIDNA_H__
-
-#include "unicode/utypes.h"
-
-#if !UCONFIG_NO_IDNA
-
-#include "unicode/parseerr.h"
-  
-/**
- * \file
- * \brief C API: Internationalized Domain Names in Applications Tranformation
- *
- * UIDNA API implements the IDNA protocol as defined in the IDNA RFC 
- * (http://www.ietf.org/rfc/rfc3490.txt).
- * The RFC defines 2 operations: ToASCII and ToUnicode. Domain labels 
- * containing non-ASCII code points are required to be processed by
- * ToASCII operation before passing it to resolver libraries. Domain names
- * that are obtained from resolver libraries are required to be processed by
- * ToUnicode operation before displaying the domain name to the user.
- * IDNA requires that implementations process input strings with Nameprep
- * (http://www.ietf.org/rfc/rfc3491.txt), 
- * which is a profile of Stringprep (http://www.ietf.org/rfc/rfc3454.txt), 
- * and then with Punycode (http://www.ietf.org/rfc/rfc3492.txt). 
- * Implementations of IDNA MUST fully implement Nameprep and Punycode; 
- * neither Nameprep nor Punycode are optional.
- * The input and output of ToASCII and ToUnicode operations are Unicode 
- * and are designed to be chainable, i.e., applying ToASCII or ToUnicode operations
- * multiple times to an input string will yield the same result as applying the operation
- * once.
- * ToUnicode(ToUnicode(ToUnicode...(ToUnicode(string)))) == ToUnicode(string) 
- * ToASCII(ToASCII(ToASCII...(ToASCII(string))) == ToASCII(string).
- *
- */
-
-/** 
- * Option to prohibit processing of unassigned codepoints in the input and
- * do not check if the input conforms to STD-3 ASCII rules.
- * 
- * @see  uidna_toASCII uidna_toUnicode
- * @stable ICU 2.6
- */
-#define UIDNA_DEFAULT          0x0000
-/** 
- * Option to allow processing of unassigned codepoints in the input
- * 
- * @see  uidna_toASCII uidna_toUnicode
- * @stable ICU 2.6
- */
-#define UIDNA_ALLOW_UNASSIGNED 0x0001
-/** 
- * Option to check if input conforms to STD-3 ASCII rules
- * 
- * @see  uidna_toASCII uidna_toUnicode
- * @stable ICU 2.6
- */
-#define UIDNA_USE_STD3_RULES   0x0002
-
-/**
- * This function implements the ToASCII operation as defined in the IDNA RFC.
- * This operation is done on <b>single labels</b> before sending it to something that expects
- * ASCII names. A label is an individual part of a domain name. Labels are usually
- * separated by dots; e.g." "www.example.com" is composed of 3 labels 
- * "www","example", and "com".
- *
- *
- * @param src               Input UChar array containing label in Unicode.
- * @param srcLength         Number of UChars in src, or -1 if NUL-terminated.
- * @param dest              Output UChar array with ASCII (ACE encoded) label.
- * @param destCapacity      Size of dest.
- * @param options           A bit set of options:
- *
- *  - UIDNA_DEFAULT             Use default options, i.e., do not process unassigned code points
- *                              and do not use STD3 ASCII rules
- *                              If unassigned code points are found the operation fails with 
- *                              U_UNASSIGNED_ERROR error code.
- *
- *  - UIDNA_ALLOW_UNASSIGNED    Unassigned values can be converted to ASCII for query operations
- *                              If this option is set, the unassigned code points are in the input 
- *                              are treated as normal Unicode code points.
- *                          
- *  - UIDNA_USE_STD3_RULES      Use STD3 ASCII rules for host name syntax restrictions
- *                              If this option is set and the input does not satisfy STD3 rules,  
- *                              the operation will fail with U_IDNA_STD3_ASCII_RULES_ERROR
- *
- * @param parseError        Pointer to UParseError struct to receive information on position 
- *                          of error if an error is encountered. Can be NULL.
- * @param status            ICU in/out error code parameter.
- *                          U_INVALID_CHAR_FOUND if src contains
- *                          unmatched single surrogates.
- *                          U_INDEX_OUTOFBOUNDS_ERROR if src contains
- *                          too many code points.
- *                          U_BUFFER_OVERFLOW_ERROR if destCapacity is not enough
- * @return The length of the result string, if successful - or in case of a buffer overflow,
- *         in which case it will be greater than destCapacity.
- * @stable ICU 2.6
- */
-U_STABLE int32_t U_EXPORT2
-uidna_toASCII(const UChar* src, int32_t srcLength, 
-              UChar* dest, int32_t destCapacity,
-              int32_t options,
-              UParseError* parseError,
-              UErrorCode* status);
-
-
-/**
- * This function implements the ToUnicode operation as defined in the IDNA RFC.
- * This operation is done on <b>single labels</b> before sending it to something that expects
- * Unicode names. A label is an individual part of a domain name. Labels are usually
- * separated by dots; for e.g." "www.example.com" is composed of 3 labels 
- * "www","example", and "com".
- *
- * @param src               Input UChar array containing ASCII (ACE encoded) label.
- * @param srcLength         Number of UChars in src, or -1 if NUL-terminated.
- * @param dest Output       Converted UChar array containing Unicode equivalent of label.
- * @param destCapacity      Size of dest.
- * @param options           A bit set of options:
- *  
- *  - UIDNA_DEFAULT             Use default options, i.e., do not process unassigned code points
- *                              and do not use STD3 ASCII rules
- *                              If unassigned code points are found the operation fails with 
- *                              U_UNASSIGNED_ERROR error code.
- *
- *  - UIDNA_ALLOW_UNASSIGNED      Unassigned values can be converted to ASCII for query operations
- *                              If this option is set, the unassigned code points are in the input 
- *                              are treated as normal Unicode code points. <b> Note: </b> This option is 
- *                              required on toUnicode operation because the RFC mandates 
- *                              verification of decoded ACE input by applying toASCII and comparing
- *                              its output with source
- *
- *                          
- *                          
- *  - UIDNA_USE_STD3_RULES      Use STD3 ASCII rules for host name syntax restrictions
- *                              If this option is set and the input does not satisfy STD3 rules,  
- *                              the operation will fail with U_IDNA_STD3_ASCII_RULES_ERROR
- *
- * @param parseError        Pointer to UParseError struct to receive information on position 
- *                          of error if an error is encountered. Can be NULL.
- * @param status            ICU in/out error code parameter.
- *                          U_INVALID_CHAR_FOUND if src contains
- *                          unmatched single surrogates.
- *                          U_INDEX_OUTOFBOUNDS_ERROR if src contains
- *                          too many code points.
- *                          U_BUFFER_OVERFLOW_ERROR if destCapacity is not enough
- * @return The length of the result string, if successful - or in case of a buffer overflow,
- *         in which case it will be greater than destCapacity.
- * @stable ICU 2.6
- */
-U_STABLE int32_t U_EXPORT2
-uidna_toUnicode(const UChar* src, int32_t srcLength,
-                UChar* dest, int32_t destCapacity,
-                int32_t options,
-                UParseError* parseError,
-                UErrorCode* status);
-
-
-/**
- * Convenience function that implements the IDNToASCII operation as defined in the IDNA RFC.
- * This operation is done on complete domain names, e.g: "www.example.com". 
- * It is important to note that this operation can fail. If it fails, then the input 
- * domain name cannot be used as an Internationalized Domain Name and the application
- * should have methods defined to deal with the failure.
- * 
- * <b>Note:</b> IDNA RFC specifies that a conformant application should divide a domain name
- * into separate labels, decide whether to apply allowUnassigned and useSTD3ASCIIRules on each, 
- * and then convert. This function does not offer that level of granularity. The options once  
- * set will apply to all labels in the domain name
- *
- * @param src               Input UChar array containing IDN in Unicode.
- * @param srcLength         Number of UChars in src, or -1 if NUL-terminated.
- * @param dest              Output UChar array with ASCII (ACE encoded) IDN.
- * @param destCapacity      Size of dest.
- * @param options           A bit set of options:
- *  
- *  - UIDNA_DEFAULT             Use default options, i.e., do not process unassigned code points
- *                              and do not use STD3 ASCII rules
- *                              If unassigned code points are found the operation fails with 
- *                              U_UNASSIGNED_CODE_POINT_FOUND error code.
- *
- *  - UIDNA_ALLOW_UNASSIGNED    Unassigned values can be converted to ASCII for query operations
- *                              If this option is set, the unassigned code points are in the input 
- *                              are treated as normal Unicode code points.
- *                          
- *  - UIDNA_USE_STD3_RULES      Use STD3 ASCII rules for host name syntax restrictions
- *                              If this option is set and the input does not satisfy STD3 rules,  
- *                              the operation will fail with U_IDNA_STD3_ASCII_RULES_ERROR
- * 
- * @param parseError        Pointer to UParseError struct to receive information on position 
- *                          of error if an error is encountered. Can be NULL.
- * @param status            ICU in/out error code parameter.
- *                          U_INVALID_CHAR_FOUND if src contains
- *                          unmatched single surrogates.
- *                          U_INDEX_OUTOFBOUNDS_ERROR if src contains
- *                          too many code points.
- *                          U_BUFFER_OVERFLOW_ERROR if destCapacity is not enough
- * @return The length of the result string, if successful - or in case of a buffer overflow,
- *         in which case it will be greater than destCapacity.
- * @stable ICU 2.6
- */
-U_STABLE int32_t U_EXPORT2
-uidna_IDNToASCII(  const UChar* src, int32_t srcLength,
-                   UChar* dest, int32_t destCapacity,
-                   int32_t options,
-                   UParseError* parseError,
-                   UErrorCode* status);
-
-/**
- * Convenience function that implements the IDNToUnicode operation as defined in the IDNA RFC.
- * This operation is done on complete domain names, e.g: "www.example.com". 
- *
- * <b>Note:</b> IDNA RFC specifies that a conformant application should divide a domain name
- * into separate labels, decide whether to apply allowUnassigned and useSTD3ASCIIRules on each, 
- * and then convert. This function does not offer that level of granularity. The options once  
- * set will apply to all labels in the domain name
- *
- * @param src               Input UChar array containing IDN in ASCII (ACE encoded) form.
- * @param srcLength         Number of UChars in src, or -1 if NUL-terminated.
- * @param dest Output       UChar array containing Unicode equivalent of source IDN.
- * @param destCapacity      Size of dest.
- * @param options           A bit set of options:
- *  
- *  - UIDNA_DEFAULT             Use default options, i.e., do not process unassigned code points
- *                              and do not use STD3 ASCII rules
- *                              If unassigned code points are found the operation fails with 
- *                              U_UNASSIGNED_CODE_POINT_FOUND error code.
- *
- *  - UIDNA_ALLOW_UNASSIGNED    Unassigned values can be converted to ASCII for query operations
- *                              If this option is set, the unassigned code points are in the input 
- *                              are treated as normal Unicode code points.
- *                          
- *  - UIDNA_USE_STD3_RULES      Use STD3 ASCII rules for host name syntax restrictions
- *                              If this option is set and the input does not satisfy STD3 rules,  
- *                              the operation will fail with U_IDNA_STD3_ASCII_RULES_ERROR
- *
- * @param parseError        Pointer to UParseError struct to receive information on position 
- *                          of error if an error is encountered. Can be NULL.
- * @param status            ICU in/out error code parameter.
- *                          U_INVALID_CHAR_FOUND if src contains
- *                          unmatched single surrogates.
- *                          U_INDEX_OUTOFBOUNDS_ERROR if src contains
- *                          too many code points.
- *                          U_BUFFER_OVERFLOW_ERROR if destCapacity is not enough
- * @return The length of the result string, if successful - or in case of a buffer overflow,
- *         in which case it will be greater than destCapacity.
- * @stable ICU 2.6
- */
-U_STABLE int32_t U_EXPORT2
-uidna_IDNToUnicode(  const UChar* src, int32_t srcLength,
-                     UChar* dest, int32_t destCapacity,
-                     int32_t options,
-                     UParseError* parseError,
-                     UErrorCode* status);
-
-/**
- * Compare two IDN strings for equivalence.
- * This function splits the domain names into labels and compares them.
- * According to IDN RFC, whenever two labels are compared, they are 
- * considered equal if and only if their ASCII forms (obtained by 
- * applying toASCII) match using an case-insensitive ASCII comparison.
- * Two domain names are considered a match if and only if all labels 
- * match regardless of whether label separators match.
- *
- * @param s1                First source string.
- * @param length1           Length of first source string, or -1 if NUL-terminated.
- *
- * @param s2                Second source string.
- * @param length2           Length of second source string, or -1 if NUL-terminated.
- * @param options           A bit set of options:
- *  
- *  - UIDNA_DEFAULT             Use default options, i.e., do not process unassigned code points
- *                              and do not use STD3 ASCII rules
- *                              If unassigned code points are found the operation fails with 
- *                              U_UNASSIGNED_CODE_POINT_FOUND error code.
- *
- *  - UIDNA_ALLOW_UNASSIGNED    Unassigned values can be converted to ASCII for query operations
- *                              If this option is set, the unassigned code points are in the input 
- *                              are treated as normal Unicode code points.
- *                          
- *  - UIDNA_USE_STD3_RULES      Use STD3 ASCII rules for host name syntax restrictions
- *                              If this option is set and the input does not satisfy STD3 rules,  
- *                              the operation will fail with U_IDNA_STD3_ASCII_RULES_ERROR
- *
- * @param status            ICU error code in/out parameter.
- *                          Must fulfill U_SUCCESS before the function call.
- * @return <0 or 0 or >0 as usual for string comparisons
- * @stable ICU 2.6
- */
-U_STABLE int32_t U_EXPORT2
-uidna_compare(  const UChar *s1, int32_t length1,
-                const UChar *s2, int32_t length2,
-                int32_t options,
-                UErrorCode* status);
-
-#endif /* #if !UCONFIG_NO_IDNA */
-
-#endif

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/uintrnal.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/uintrnal.h b/apps/couch_collate/platform/osx/icu/unicode/uintrnal.h
deleted file mode 100644
index 6a01f6b..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/uintrnal.h
+++ /dev/null
@@ -1,180 +0,0 @@
-/*
-*******************************************************************************
-*   Copyright (C) 2004-2008, International Business Machines
-*   Corporation and others.  All Rights Reserved.
-*******************************************************************************
-*
-*   file name:  
-*   encoding:   US-ASCII
-*   tab size:   8 (not used)
-*   indentation:4
-*
-*   Created by: genheaders.pl, a perl script written by Ram Viswanadha
-*
-*  Contains data for commenting out APIs.
-*  Gets included by umachine.h
-*
-*  THIS FILE IS MACHINE-GENERATED, DON'T PLAY WITH IT IF YOU DON'T KNOW WHAT
-*  YOU ARE DOING, OTHERWISE VERY BAD THINGS WILL HAPPEN!
-*/
-
-#ifndef UINTRNAL_H
-#define UINTRNAL_H
-
-#ifdef U_HIDE_INTERNAL_API
-
-#    if U_DISABLE_RENAMING
-#        define RegexPatternDump RegexPatternDump_INTERNAL_API_DO_NOT_USE
-#        define pl_addFontRun pl_addFontRun_INTERNAL_API_DO_NOT_USE
-#        define pl_addLocaleRun pl_addLocaleRun_INTERNAL_API_DO_NOT_USE
-#        define pl_addValueRun pl_addValueRun_INTERNAL_API_DO_NOT_USE
-#        define pl_close pl_close_INTERNAL_API_DO_NOT_USE
-#        define pl_closeFontRuns pl_closeFontRuns_INTERNAL_API_DO_NOT_USE
-#        define pl_closeLine pl_closeLine_INTERNAL_API_DO_NOT_USE
-#        define pl_closeLocaleRuns pl_closeLocaleRuns_INTERNAL_API_DO_NOT_USE
-#        define pl_closeValueRuns pl_closeValueRuns_INTERNAL_API_DO_NOT_USE
-#        define pl_countLineRuns pl_countLineRuns_INTERNAL_API_DO_NOT_USE
-#        define pl_create pl_create_INTERNAL_API_DO_NOT_USE
-#        define pl_getAscent pl_getAscent_INTERNAL_API_DO_NOT_USE
-#        define pl_getDescent pl_getDescent_INTERNAL_API_DO_NOT_USE
-#        define pl_getFontRunCount pl_getFontRunCount_INTERNAL_API_DO_NOT_USE
-#        define pl_getFontRunFont pl_getFontRunFont_INTERNAL_API_DO_NOT_USE
-#        define pl_getFontRunLastLimit pl_getFontRunLastLimit_INTERNAL_API_DO_NOT_USE
-#        define pl_getFontRunLimit pl_getFontRunLimit_INTERNAL_API_DO_NOT_USE
-#        define pl_getLeading pl_getLeading_INTERNAL_API_DO_NOT_USE
-#        define pl_getLineAscent pl_getLineAscent_INTERNAL_API_DO_NOT_USE
-#        define pl_getLineDescent pl_getLineDescent_INTERNAL_API_DO_NOT_USE
-#        define pl_getLineLeading pl_getLineLeading_INTERNAL_API_DO_NOT_USE
-#        define pl_getLineVisualRun pl_getLineVisualRun_INTERNAL_API_DO_NOT_USE
-#        define pl_getLineWidth pl_getLineWidth_INTERNAL_API_DO_NOT_USE
-#        define pl_getLocaleRunCount pl_getLocaleRunCount_INTERNAL_API_DO_NOT_USE
-#        define pl_getLocaleRunLastLimit pl_getLocaleRunLastLimit_INTERNAL_API_DO_NOT_USE
-#        define pl_getLocaleRunLimit pl_getLocaleRunLimit_INTERNAL_API_DO_NOT_USE
-#        define pl_getLocaleRunLocale pl_getLocaleRunLocale_INTERNAL_API_DO_NOT_USE
-#        define pl_getParagraphLevel pl_getParagraphLevel_INTERNAL_API_DO_NOT_USE
-#        define pl_getTextDirection pl_getTextDirection_INTERNAL_API_DO_NOT_USE
-#        define pl_getValueRunCount pl_getValueRunCount_INTERNAL_API_DO_NOT_USE
-#        define pl_getValueRunLastLimit pl_getValueRunLastLimit_INTERNAL_API_DO_NOT_USE
-#        define pl_getValueRunLimit pl_getValueRunLimit_INTERNAL_API_DO_NOT_USE
-#        define pl_getValueRunValue pl_getValueRunValue_INTERNAL_API_DO_NOT_USE
-#        define pl_getVisualRunAscent pl_getVisualRunAscent_INTERNAL_API_DO_NOT_USE
-#        define pl_getVisualRunDescent pl_getVisualRunDescent_INTERNAL_API_DO_NOT_USE
-#        define pl_getVisualRunDirection pl_getVisualRunDirection_INTERNAL_API_DO_NOT_USE
-#        define pl_getVisualRunFont pl_getVisualRunFont_INTERNAL_API_DO_NOT_USE
-#        define pl_getVisualRunGlyphCount pl_getVisualRunGlyphCount_INTERNAL_API_DO_NOT_USE
-#        define pl_getVisualRunGlyphToCharMap pl_getVisualRunGlyphToCharMap_INTERNAL_API_DO_NOT_USE
-#        define pl_getVisualRunGlyphs pl_getVisualRunGlyphs_INTERNAL_API_DO_NOT_USE
-#        define pl_getVisualRunLeading pl_getVisualRunLeading_INTERNAL_API_DO_NOT_USE
-#        define pl_getVisualRunPositions pl_getVisualRunPositions_INTERNAL_API_DO_NOT_USE
-#        define pl_isComplex pl_isComplex_INTERNAL_API_DO_NOT_USE
-#        define pl_line pl_line_INTERNAL_API_DO_NOT_USE
-#        define pl_nextLine pl_nextLine_INTERNAL_API_DO_NOT_USE
-#        define pl_openEmptyFontRuns pl_openEmptyFontRuns_INTERNAL_API_DO_NOT_USE
-#        define pl_openEmptyLocaleRuns pl_openEmptyLocaleRuns_INTERNAL_API_DO_NOT_USE
-#        define pl_openEmptyValueRuns pl_openEmptyValueRuns_INTERNAL_API_DO_NOT_USE
-#        define pl_openFontRuns pl_openFontRuns_INTERNAL_API_DO_NOT_USE
-#        define pl_openLocaleRuns pl_openLocaleRuns_INTERNAL_API_DO_NOT_USE
-#        define pl_openValueRuns pl_openValueRuns_INTERNAL_API_DO_NOT_USE
-#        define pl_paragraph pl_paragraph_INTERNAL_API_DO_NOT_USE
-#        define pl_reflow pl_reflow_INTERNAL_API_DO_NOT_USE
-#        define pl_resetFontRuns pl_resetFontRuns_INTERNAL_API_DO_NOT_USE
-#        define pl_resetLocaleRuns pl_resetLocaleRuns_INTERNAL_API_DO_NOT_USE
-#        define pl_resetValueRuns pl_resetValueRuns_INTERNAL_API_DO_NOT_USE
-#        define pl_visualRun pl_visualRun_INTERNAL_API_DO_NOT_USE
-#        define ucol_equals ucol_equals_INTERNAL_API_DO_NOT_USE
-#        define ucol_forgetUCA ucol_forgetUCA_INTERNAL_API_DO_NOT_USE
-#        define ucol_getAttributeOrDefault ucol_getAttributeOrDefault_INTERNAL_API_DO_NOT_USE
-#        define ucol_getUnsafeSet ucol_getUnsafeSet_INTERNAL_API_DO_NOT_USE
-#        define ucol_nextProcessed ucol_nextProcessed_INTERNAL_API_DO_NOT_USE
-#        define ucol_prepareShortStringOpen ucol_prepareShortStringOpen_INTERNAL_API_DO_NOT_USE
-#        define ucol_previousProcessed ucol_previousProcessed_INTERNAL_API_DO_NOT_USE
-#        define uprv_getDefaultCodepage uprv_getDefaultCodepage_INTERNAL_API_DO_NOT_USE
-#        define uprv_getDefaultLocaleID uprv_getDefaultLocaleID_INTERNAL_API_DO_NOT_USE
-#        define ures_openFillIn ures_openFillIn_INTERNAL_API_DO_NOT_USE
-#        define usearch_search usearch_search_INTERNAL_API_DO_NOT_USE
-#        define usearch_searchBackwards usearch_searchBackwards_INTERNAL_API_DO_NOT_USE
-#        define utf8_appendCharSafeBody utf8_appendCharSafeBody_INTERNAL_API_DO_NOT_USE
-#        define utf8_back1SafeBody utf8_back1SafeBody_INTERNAL_API_DO_NOT_USE
-#        define utf8_countTrailBytes utf8_countTrailBytes_INTERNAL_API_DO_NOT_USE
-#        define utf8_nextCharSafeBody utf8_nextCharSafeBody_INTERNAL_API_DO_NOT_USE
-#        define utf8_prevCharSafeBody utf8_prevCharSafeBody_INTERNAL_API_DO_NOT_USE
-#    else
-#        define RegexPatternDump_4_0 RegexPatternDump_INTERNAL_API_DO_NOT_USE
-#        define pl_addFontRun_4_0 pl_addFontRun_INTERNAL_API_DO_NOT_USE
-#        define pl_addLocaleRun_4_0 pl_addLocaleRun_INTERNAL_API_DO_NOT_USE
-#        define pl_addValueRun_4_0 pl_addValueRun_INTERNAL_API_DO_NOT_USE
-#        define pl_closeFontRuns_4_0 pl_closeFontRuns_INTERNAL_API_DO_NOT_USE
-#        define pl_closeLine_4_0 pl_closeLine_INTERNAL_API_DO_NOT_USE
-#        define pl_closeLocaleRuns_4_0 pl_closeLocaleRuns_INTERNAL_API_DO_NOT_USE
-#        define pl_closeValueRuns_4_0 pl_closeValueRuns_INTERNAL_API_DO_NOT_USE
-#        define pl_close_4_0 pl_close_INTERNAL_API_DO_NOT_USE
-#        define pl_countLineRuns_4_0 pl_countLineRuns_INTERNAL_API_DO_NOT_USE
-#        define pl_create_4_0 pl_create_INTERNAL_API_DO_NOT_USE
-#        define pl_getAscent_4_0 pl_getAscent_INTERNAL_API_DO_NOT_USE
-#        define pl_getDescent_4_0 pl_getDescent_INTERNAL_API_DO_NOT_USE
-#        define pl_getFontRunCount_4_0 pl_getFontRunCount_INTERNAL_API_DO_NOT_USE
-#        define pl_getFontRunFont_4_0 pl_getFontRunFont_INTERNAL_API_DO_NOT_USE
-#        define pl_getFontRunLastLimit_4_0 pl_getFontRunLastLimit_INTERNAL_API_DO_NOT_USE
-#        define pl_getFontRunLimit_4_0 pl_getFontRunLimit_INTERNAL_API_DO_NOT_USE
-#        define pl_getLeading_4_0 pl_getLeading_INTERNAL_API_DO_NOT_USE
-#        define pl_getLineAscent_4_0 pl_getLineAscent_INTERNAL_API_DO_NOT_USE
-#        define pl_getLineDescent_4_0 pl_getLineDescent_INTERNAL_API_DO_NOT_USE
-#        define pl_getLineLeading_4_0 pl_getLineLeading_INTERNAL_API_DO_NOT_USE
-#        define pl_getLineVisualRun_4_0 pl_getLineVisualRun_INTERNAL_API_DO_NOT_USE
-#        define pl_getLineWidth_4_0 pl_getLineWidth_INTERNAL_API_DO_NOT_USE
-#        define pl_getLocaleRunCount_4_0 pl_getLocaleRunCount_INTERNAL_API_DO_NOT_USE
-#        define pl_getLocaleRunLastLimit_4_0 pl_getLocaleRunLastLimit_INTERNAL_API_DO_NOT_USE
-#        define pl_getLocaleRunLimit_4_0 pl_getLocaleRunLimit_INTERNAL_API_DO_NOT_USE
-#        define pl_getLocaleRunLocale_4_0 pl_getLocaleRunLocale_INTERNAL_API_DO_NOT_USE
-#        define pl_getParagraphLevel_4_0 pl_getParagraphLevel_INTERNAL_API_DO_NOT_USE
-#        define pl_getTextDirection_4_0 pl_getTextDirection_INTERNAL_API_DO_NOT_USE
-#        define pl_getValueRunCount_4_0 pl_getValueRunCount_INTERNAL_API_DO_NOT_USE
-#        define pl_getValueRunLastLimit_4_0 pl_getValueRunLastLimit_INTERNAL_API_DO_NOT_USE
-#        define pl_getValueRunLimit_4_0 pl_getValueRunLimit_INTERNAL_API_DO_NOT_USE
-#        define pl_getValueRunValue_4_0 pl_getValueRunValue_INTERNAL_API_DO_NOT_USE
-#        define pl_getVisualRunAscent_4_0 pl_getVisualRunAscent_INTERNAL_API_DO_NOT_USE
-#        define pl_getVisualRunDescent_4_0 pl_getVisualRunDescent_INTERNAL_API_DO_NOT_USE
-#        define pl_getVisualRunDirection_4_0 pl_getVisualRunDirection_INTERNAL_API_DO_NOT_USE
-#        define pl_getVisualRunFont_4_0 pl_getVisualRunFont_INTERNAL_API_DO_NOT_USE
-#        define pl_getVisualRunGlyphCount_4_0 pl_getVisualRunGlyphCount_INTERNAL_API_DO_NOT_USE
-#        define pl_getVisualRunGlyphToCharMap_4_0 pl_getVisualRunGlyphToCharMap_INTERNAL_API_DO_NOT_USE
-#        define pl_getVisualRunGlyphs_4_0 pl_getVisualRunGlyphs_INTERNAL_API_DO_NOT_USE
-#        define pl_getVisualRunLeading_4_0 pl_getVisualRunLeading_INTERNAL_API_DO_NOT_USE
-#        define pl_getVisualRunPositions_4_0 pl_getVisualRunPositions_INTERNAL_API_DO_NOT_USE
-#        define pl_isComplex_4_0 pl_isComplex_INTERNAL_API_DO_NOT_USE
-#        define pl_line_4_0 pl_line_INTERNAL_API_DO_NOT_USE
-#        define pl_nextLine_4_0 pl_nextLine_INTERNAL_API_DO_NOT_USE
-#        define pl_openEmptyFontRuns_4_0 pl_openEmptyFontRuns_INTERNAL_API_DO_NOT_USE
-#        define pl_openEmptyLocaleRuns_4_0 pl_openEmptyLocaleRuns_INTERNAL_API_DO_NOT_USE
-#        define pl_openEmptyValueRuns_4_0 pl_openEmptyValueRuns_INTERNAL_API_DO_NOT_USE
-#        define pl_openFontRuns_4_0 pl_openFontRuns_INTERNAL_API_DO_NOT_USE
-#        define pl_openLocaleRuns_4_0 pl_openLocaleRuns_INTERNAL_API_DO_NOT_USE
-#        define pl_openValueRuns_4_0 pl_openValueRuns_INTERNAL_API_DO_NOT_USE
-#        define pl_paragraph_4_0 pl_paragraph_INTERNAL_API_DO_NOT_USE
-#        define pl_reflow_4_0 pl_reflow_INTERNAL_API_DO_NOT_USE
-#        define pl_resetFontRuns_4_0 pl_resetFontRuns_INTERNAL_API_DO_NOT_USE
-#        define pl_resetLocaleRuns_4_0 pl_resetLocaleRuns_INTERNAL_API_DO_NOT_USE
-#        define pl_resetValueRuns_4_0 pl_resetValueRuns_INTERNAL_API_DO_NOT_USE
-#        define pl_visualRun_4_0 pl_visualRun_INTERNAL_API_DO_NOT_USE
-#        define ucol_equals_4_0 ucol_equals_INTERNAL_API_DO_NOT_USE
-#        define ucol_forgetUCA_4_0 ucol_forgetUCA_INTERNAL_API_DO_NOT_USE
-#        define ucol_getAttributeOrDefault_4_0 ucol_getAttributeOrDefault_INTERNAL_API_DO_NOT_USE
-#        define ucol_getUnsafeSet_4_0 ucol_getUnsafeSet_INTERNAL_API_DO_NOT_USE
-#        define ucol_nextProcessed_4_0 ucol_nextProcessed_INTERNAL_API_DO_NOT_USE
-#        define ucol_prepareShortStringOpen_4_0 ucol_prepareShortStringOpen_INTERNAL_API_DO_NOT_USE
-#        define ucol_previousProcessed_4_0 ucol_previousProcessed_INTERNAL_API_DO_NOT_USE
-#        define uprv_getDefaultCodepage_4_0 uprv_getDefaultCodepage_INTERNAL_API_DO_NOT_USE
-#        define uprv_getDefaultLocaleID_4_0 uprv_getDefaultLocaleID_INTERNAL_API_DO_NOT_USE
-#        define ures_openFillIn_4_0 ures_openFillIn_INTERNAL_API_DO_NOT_USE
-#        define usearch_searchBackwards_4_0 usearch_searchBackwards_INTERNAL_API_DO_NOT_USE
-#        define usearch_search_4_0 usearch_search_INTERNAL_API_DO_NOT_USE
-#        define utf8_appendCharSafeBody_4_0 utf8_appendCharSafeBody_INTERNAL_API_DO_NOT_USE
-#        define utf8_back1SafeBody_4_0 utf8_back1SafeBody_INTERNAL_API_DO_NOT_USE
-#        define utf8_countTrailBytes_4_0 utf8_countTrailBytes_INTERNAL_API_DO_NOT_USE
-#        define utf8_nextCharSafeBody_4_0 utf8_nextCharSafeBody_INTERNAL_API_DO_NOT_USE
-#        define utf8_prevCharSafeBody_4_0 utf8_prevCharSafeBody_INTERNAL_API_DO_NOT_USE
-#    endif /* U_DISABLE_RENAMING */
-
-#endif /* U_HIDE_INTERNAL_API */
-#endif /* UINTRNAL_H */
-


[48/57] [abbrv] remove couch_mrview

Posted by be...@apache.org.
http://git-wip-us.apache.org/repos/asf/couchdb/blob/75150a18/apps/couch_mrview/test/10-index-changes.t
----------------------------------------------------------------------
diff --git a/apps/couch_mrview/test/10-index-changes.t b/apps/couch_mrview/test/10-index-changes.t
deleted file mode 100644
index ce79eac..0000000
--- a/apps/couch_mrview/test/10-index-changes.t
+++ /dev/null
@@ -1,217 +0,0 @@
-#!/usr/bin/env escript
-%% -*- erlang -*-
-%%! -pa ./deps/*/ebin -pa ./apps/*/ebin -pa ./test/etap
-
-% Licensed 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.
-
-main(_) ->
-    etap:plan(8),
-    case (catch test()) of
-        ok ->
-            etap:end_tests();
-        Other ->
-            etap:diag(io_lib:format("Test died abnormally: ~p", [Other])),
-            etap:bail(Other)
-    end,
-    timer:sleep(300),
-    ok.
-
-test() ->
-    test_util:start_couch(),
-    {ok, Db} = couch_mrview_test_util:init_db(<<"foo">>, changes),
-    test_normal_changes(Db),
-    test_stream_once(Db),
-    test_stream_once_since(Db),
-    test_stream_once_timeout(Db),
-    test_stream_once_heartbeat(Db),
-    test_stream(Db),
-    test_indexer(Db),
-    test_util:stop_couch(),
-    ok.
-
-test_normal_changes(Db) ->
-    Result = run_query(Db, []),
-    Expect = {ok, 11, [
-                {{2, 1, <<"1">>}, 1},
-                {{3, 10, <<"10">>}, 10},
-                {{4, 2, <<"2">>}, 2},
-                {{5, 3, <<"3">>}, 3},
-                {{6, 4, <<"4">>}, 4},
-                {{7, 5, <<"5">>}, 5},
-                {{8, 6, <<"6">>}, 6},
-                {{9, 7, <<"7">>}, 7},
-                {{10, 8, <<"8">>}, 8},
-                {{11, 9, <<"9">>}, 9}
-    ]},
-    etap:is(Result, Expect, "normal changes worked.").
-
-test_stream_once(Db) ->
-    Result = run_query(Db, [{stream, once}]),
-    Expect = {ok, 11, [
-                {{2, 1, <<"1">>}, 1},
-                {{3, 10, <<"10">>}, 10},
-                {{4, 2, <<"2">>}, 2},
-                {{5, 3, <<"3">>}, 3},
-                {{6, 4, <<"4">>}, 4},
-                {{7, 5, <<"5">>}, 5},
-                {{8, 6, <<"6">>}, 6},
-                {{9, 7, <<"7">>}, 7},
-                {{10, 8, <<"8">>}, 8},
-                {{11, 9, <<"9">>}, 9}
-    ]},
-    etap:is(Result, Expect, "stream once since 0 worked.").
-
-
-test_stream_once_since(Db) ->
-    Self = self(),
-    spawn(fun() ->
-                Result = run_query(Db, [{since, 11},
-                                        {stream, once}]),
-                Self ! {result, Result}
-        end),
-
-    spawn(fun() ->
-                timer:sleep(1000),
-                {ok, Db1} = save_doc(Db, 11),
-                couch_mrview:refresh(Db1, <<"_design/bar">>)
-        end),
-
-    Expect = {ok,12,[{{12,11,<<"11">>},11}]},
-
-    receive
-        {result, Result} ->
-            etap:is(Result, Expect, "normal changes worked.")
-    after 5000 ->
-            io:format("never got the change", [])
-    end.
-
-
-test_stream_once_timeout(Db) ->
-    Self = self(),
-    spawn(fun() ->
-                Result = run_query(Db, [{since, 12},
-                                        {stream, once},
-                                        {timeout, 3000}]),
-                Self ! {result, Result}
-        end),
-
-
-
-    Expect = {ok, 12, []},
-
-    receive
-        {result, Result} ->
-            etap:is(Result, Expect, "got timeout.")
-    after 5000 ->
-            io:format("never got the change", [])
-    end.
-
-test_stream_once_heartbeat(Db) ->
-    Self = self(),
-    spawn(fun() ->
-                Result = run_query(Db, [{since, 12},
-                                        {stream, once},
-                                        {heartbeat, 1000}]),
-                Self ! {result, Result}
-        end),
-
-    spawn(fun() ->
-                timer:sleep(3000),
-                {ok, Db1} = save_doc(Db, 12),
-                couch_mrview:refresh(Db1, <<"_design/bar">>)
-        end),
-
-    Expect = {ok,13,[heartbeat,
-                     heartbeat,
-                     heartbeat,
-                     {{13,12,<<"12">>},12}]},
-
-
-
-    receive
-        {result, Result} ->
-            etap:is(Result, Expect, "heartbeat OK.")
-    after 5000 ->
-            io:format("never got the change", [])
-    end.
-
-
-test_stream(Db) ->
-    Self = self(),
-    spawn(fun() ->
-                Result = run_query(Db, [{since, 13},
-                                        stream,
-                                        {timeout, 3000}]),
-                Self ! {result, Result}
-        end),
-
-    spawn(fun() ->
-                timer:sleep(1000),
-                {ok, Db1} = save_doc(Db, 13),
-                couch_mrview:refresh(Db1, <<"_design/bar">>),
-                {ok, Db2} = save_doc(Db1, 14),
-                couch_mrview:refresh(Db2, <<"_design/bar">>)
-        end),
-
-    Expect = {ok, 15,[{{14,13,<<"13">>},13},
-                     {{15,14,<<"14">>},14}]},
-
-    receive
-        {result, Result} ->
-            etap:is(Result, Expect, "stream OK.")
-    after 5000 ->
-            io:format("never got the change", [])
-    end.
-
-
-test_indexer(Db) ->
-    Result = run_query(Db, [{since, 14}, refresh]),
-    Expect = {ok, 15, [{{15,14,<<"14">>},14}]},
-    etap:is(Result, Expect, "refresh index by hand OK."),
-
-    {ok, Db1} = save_doc(Db, 15),
-    timer:sleep(1500),
-    Result1 = run_query(Db1, [{since, 14}], false),
-    Expect1 = {ok, 16, [{{15,14,<<"14">>},14},
-                       {{16,15,<<"15">>},15}]},
-    etap:is(Result1, Expect1, "changes indexed in background OK."),
-    ok.
-
-
-save_doc(Db, Id) ->
-    Doc = couch_mrview_test_util:doc(Id),
-    {ok, _Rev} = couch_db:update_doc(Db, Doc, []),
-    {ok, _} =  couch_db:ensure_full_commit(Db),
-    couch_db:reopen(Db).
-
-run_query(Db, Opts) ->
-    run_query(Db, Opts, true).
-
-run_query(Db, Opts, Refresh) ->
-    Fun = fun
-        (stop, {LastSeq, Acc}) ->
-            {ok, LastSeq, Acc};
-        (heartbeat, Acc) ->
-            {ok, [heartbeat | Acc]};
-        (Event, Acc) ->
-            {ok, [Event | Acc]}
-    end,
-    case Refresh of
-        true ->
-            couch_mrview:refresh(Db, <<"_design/bar">>);
-        false ->
-            ok
-    end,
-    {ok, LastSeq, R} = couch_mrview_changes:handle_changes(Db, <<"_design/bar">>,
-                                                  <<"baz">>, Fun, [], Opts),
-    {ok, LastSeq, lists:reverse(R)}.


[54/57] [abbrv] couchdb commit: updated refs/heads/1994-merge-rcouch-multi-repo to b19d055

Posted by be...@apache.org.
remove couch_httpd


Project: http://git-wip-us.apache.org/repos/asf/couchdb/repo
Commit: http://git-wip-us.apache.org/repos/asf/couchdb/commit/c0855434
Tree: http://git-wip-us.apache.org/repos/asf/couchdb/tree/c0855434
Diff: http://git-wip-us.apache.org/repos/asf/couchdb/diff/c0855434

Branch: refs/heads/1994-merge-rcouch-multi-repo
Commit: c085543470ed9e83eff47ce216115ff26511911c
Parents: 372b033
Author: Benoit Chesneau <bc...@gmail.com>
Authored: Thu Feb 13 16:40:06 2014 +0100
Committer: Benoit Chesneau <bc...@gmail.com>
Committed: Thu Feb 13 16:40:06 2014 +0100

----------------------------------------------------------------------
 apps/couch_httpd/src/couch_httpd.app.src        |   28 -
 apps/couch_httpd/src/couch_httpd.erl            | 1051 ---------------
 apps/couch_httpd/src/couch_httpd_app.erl        |   24 -
 apps/couch_httpd/src/couch_httpd_auth.erl       |  380 ------
 apps/couch_httpd/src/couch_httpd_changes.erl    |  452 -------
 apps/couch_httpd/src/couch_httpd_cors.erl       |  351 -----
 apps/couch_httpd/src/couch_httpd_db.erl         | 1226 ------------------
 apps/couch_httpd/src/couch_httpd_external.erl   |  177 ---
 .../src/couch_httpd_misc_handlers.erl           |  318 -----
 apps/couch_httpd/src/couch_httpd_oauth.erl      |  387 ------
 apps/couch_httpd/src/couch_httpd_proxy.erl      |  426 ------
 apps/couch_httpd/src/couch_httpd_rewrite.erl    |  480 -------
 .../src/couch_httpd_stats_handlers.erl          |   56 -
 apps/couch_httpd/src/couch_httpd_sup.erl        |  112 --
 apps/couch_httpd/src/couch_httpd_util.erl       |   80 --
 apps/couch_httpd/src/couch_httpd_vhost.erl      |  383 ------
 16 files changed, 5931 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/couchdb/blob/c0855434/apps/couch_httpd/src/couch_httpd.app.src
----------------------------------------------------------------------
diff --git a/apps/couch_httpd/src/couch_httpd.app.src b/apps/couch_httpd/src/couch_httpd.app.src
deleted file mode 100644
index 367a33d..0000000
--- a/apps/couch_httpd/src/couch_httpd.app.src
+++ /dev/null
@@ -1,28 +0,0 @@
-% Licensed 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.
-
-{application, couch_httpd, [
-        {description, "CouchDB HTTP API"},
-        {vsn, "1.6.0"},
-        {modules, []},
-        {registered, [couch_httpd_sup]},
-        {applications, [kernel,
-                        stdlib,
-                        crypto,
-                        asn1,
-                        public_key,
-                        ssl,
-                        inets]},
-        {included_applications, [mochiweb]},
-        {mod, {couch_httpd_app, []}},
-        {env, []}
-]}.

http://git-wip-us.apache.org/repos/asf/couchdb/blob/c0855434/apps/couch_httpd/src/couch_httpd.erl
----------------------------------------------------------------------
diff --git a/apps/couch_httpd/src/couch_httpd.erl b/apps/couch_httpd/src/couch_httpd.erl
deleted file mode 100644
index 29f9db0..0000000
--- a/apps/couch_httpd/src/couch_httpd.erl
+++ /dev/null
@@ -1,1051 +0,0 @@
-% Licensed 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.
-
--module(couch_httpd).
--include_lib("couch/include/couch_db.hrl").
-
--export([start_link/1,  handle_request/5]).
-
--export([header_value/2,header_value/3,qs_value/2,qs_value/3,qs/1,qs_json_value/3]).
--export([path/1,absolute_uri/2,body_length/1]).
--export([verify_is_server_admin/1,unquote/1,quote/1,recv/2,recv_chunked/4,error_info/1]).
--export([make_fun_spec_strs/1]).
--export([make_arity_1_fun/1, make_arity_2_fun/1, make_arity_3_fun/1]).
--export([parse_form/1,json_body/1,json_body_obj/1,body/1]).
--export([doc_etag/1, make_etag/1, etag_match/2, etag_respond/3, etag_maybe/2]).
--export([primary_header_value/2,partition/1,serve_file/3,serve_file/4, server_header/0]).
--export([start_chunked_response/3,send_chunk/2,log_request/2]).
--export([start_response_length/4, start_response/3, send/2]).
--export([start_json_response/2, start_json_response/3, end_json_response/1]).
--export([send_response/4,send_method_not_allowed/2,send_error/4, send_redirect/2,send_chunked_error/2]).
--export([send_json/2,send_json/3,send_json/4,last_chunk/1,parse_multipart_request/3]).
--export([accepted_encodings/1,handle_request_int/5,validate_referer/1,validate_ctype/2]).
--export([http_1_0_keep_alive/2]).
--export([set_auth_handlers/0]).
-
-start_link(couch_http) ->
-    Port = couch_config:get("httpd", "port", "5984"),
-    start_link(couch_http, [{port, Port}]);
-start_link(couch_https) ->
-    Port = couch_config:get("ssl", "port", "6984"),
-    CertFile = couch_config:get("ssl", "cert_file", nil),
-    KeyFile = couch_config:get("ssl", "key_file", nil),
-    Options = case CertFile /= nil andalso KeyFile /= nil of
-        true ->
-            SslOpts = [{certfile, CertFile}, {keyfile, KeyFile}],
-
-            %% set password if one is needed for the cert
-            SslOpts1 = case couch_config:get("ssl", "password", nil) of
-                nil -> SslOpts;
-                Password ->
-                    SslOpts ++ [{password, Password}]
-            end,
-            % do we verify certificates ?
-            FinalSslOpts = case couch_config:get("ssl",
-                    "verify_ssl_certificates", "false") of
-                "false" -> SslOpts1;
-                "true" ->
-                    case couch_config:get("ssl",
-                            "cacert_file", nil) of
-                        nil ->
-                            io:format("Verify SSL certificate "
-                                ++"enabled but file containing "
-                                ++"PEM encoded CA certificates is "
-                                ++"missing", []),
-                            throw({error, missing_cacerts});
-                        CaCertFile ->
-                            Depth = list_to_integer(couch_config:get("ssl",
-                                    "ssl_certificate_max_depth",
-                                    "1")),
-                            FinalOpts = [
-                                {cacertfile, CaCertFile},
-                                {depth, Depth},
-                                {verify, verify_peer}],
-                            % allows custom verify fun.
-                            case couch_config:get("ssl",
-                                    "verify_fun", nil) of
-                                nil -> FinalOpts;
-                                SpecStr ->
-                                    FinalOpts
-                                    ++ [{verify_fun, make_arity_3_fun(SpecStr)}]
-                            end
-                    end
-            end,
-
-            [{port, Port},
-                {ssl, true},
-                {ssl_opts, FinalSslOpts}];
-        false ->
-            io:format("SSL enabled but PEM certificates are missing.", []),
-            throw({error, missing_certs})
-    end,
-    start_link(couch_https, Options).
-start_link(Name, Options) ->
-    % read config and register for configuration changes
-
-    % just stop if one of the config settings change. couch_sup
-    % will restart us and then we will pick up the new settings.
-
-    BindAddress = couch_config:get("httpd", "bind_address", any),
-    validate_bind_address(BindAddress),
-    DefaultSpec = "{couch_httpd_db, handle_request}",
-    DefaultFun = make_arity_1_fun(
-        couch_config:get("httpd", "default_handler", DefaultSpec)
-    ),
-
-    UrlHandlersList = lists:map(
-        fun({UrlKey, SpecStr}) ->
-            {?l2b(UrlKey), make_arity_1_fun(SpecStr)}
-        end, couch_config:get("httpd_global_handlers")),
-
-    DbUrlHandlersList = lists:map(
-        fun({UrlKey, SpecStr}) ->
-            {?l2b(UrlKey), make_arity_2_fun(SpecStr)}
-        end, couch_config:get("httpd_db_handlers")),
-
-    DesignUrlHandlersList = lists:map(
-        fun({UrlKey, SpecStr}) ->
-            {?l2b(UrlKey), make_arity_3_fun(SpecStr)}
-        end, couch_config:get("httpd_design_handlers")),
-
-    UrlHandlers = dict:from_list(UrlHandlersList),
-    DbUrlHandlers = dict:from_list(DbUrlHandlersList),
-    DesignUrlHandlers = dict:from_list(DesignUrlHandlersList),
-    {ok, ServerOptions} = couch_util:parse_term(
-        couch_config:get("httpd", "server_options", "[]")),
-    {ok, SocketOptions} = couch_util:parse_term(
-        couch_config:get("httpd", "socket_options", "[]")),
-
-    set_auth_handlers(),
-
-    % ensure uuid is set so that concurrent replications
-    % get the same value.
-    couch_server:get_uuid(),
-
-    Loop = fun(Req)->
-        case SocketOptions of
-        [] ->
-            ok;
-        _ ->
-            ok = mochiweb_socket:setopts(Req:get(socket), SocketOptions)
-        end,
-        apply(?MODULE, handle_request, [
-            Req, DefaultFun, UrlHandlers, DbUrlHandlers, DesignUrlHandlers
-        ])
-    end,
-
-    % set mochiweb options
-    FinalOptions = lists:append([Options, ServerOptions, [
-            {loop, Loop},
-            {name, Name},
-            {ip, BindAddress}]]),
-
-    % launch mochiweb
-    mochiweb_http:start_link(FinalOptions).
-
-set_auth_handlers() ->
-    AuthenticationSrcs = make_fun_spec_strs(
-        couch_config:get("httpd", "authentication_handlers", "")),
-    AuthHandlers = lists:map(
-        fun(A) -> {make_arity_1_fun(A), ?l2b(A)} end, AuthenticationSrcs),
-    ok = application:set_env(couch_httpd, auth_handlers, AuthHandlers).
-
-% SpecStr is a string like "{my_module, my_fun}"
-%  or "{my_module, my_fun, <<"my_arg">>}"
-make_arity_1_fun(SpecStr) ->
-    case couch_util:parse_term(SpecStr) of
-    {ok, {Mod, Fun, SpecArg}} ->
-        fun(Arg) -> Mod:Fun(Arg, SpecArg) end;
-    {ok, {Mod, Fun}} ->
-        fun(Arg) -> Mod:Fun(Arg) end
-    end.
-
-make_arity_2_fun(SpecStr) ->
-    case couch_util:parse_term(SpecStr) of
-    {ok, {Mod, Fun, SpecArg}} ->
-        fun(Arg1, Arg2) -> Mod:Fun(Arg1, Arg2, SpecArg) end;
-    {ok, {Mod, Fun}} ->
-        fun(Arg1, Arg2) -> Mod:Fun(Arg1, Arg2) end
-    end.
-
-make_arity_3_fun(SpecStr) ->
-    case couch_util:parse_term(SpecStr) of
-    {ok, {Mod, Fun, SpecArg}} ->
-        fun(Arg1, Arg2, Arg3) -> Mod:Fun(Arg1, Arg2, Arg3, SpecArg) end;
-    {ok, {Mod, Fun}} ->
-        fun(Arg1, Arg2, Arg3) -> Mod:Fun(Arg1, Arg2, Arg3) end
-    end.
-
-% SpecStr is "{my_module, my_fun}, {my_module2, my_fun2}"
-make_fun_spec_strs(SpecStr) ->
-    re:split(SpecStr, "(?<=})\\s*,\\s*(?={)", [{return, list}]).
-
-handle_request(MochiReq, DefaultFun, UrlHandlers, DbUrlHandlers,
-    DesignUrlHandlers) ->
-    %% reset rewrite count for new request
-    erlang:put(?REWRITE_COUNT, 0),
-
-    MochiReq1 = couch_httpd_vhost:dispatch_host(MochiReq),
-
-    handle_request_int(MochiReq1, DefaultFun,
-                UrlHandlers, DbUrlHandlers, DesignUrlHandlers).
-
-handle_request_int(MochiReq, DefaultFun,
-            UrlHandlers, DbUrlHandlers, DesignUrlHandlers) ->
-    Begin = now(),
-    % for the path, use the raw path with the query string and fragment
-    % removed, but URL quoting left intact
-    RawUri = MochiReq:get(raw_path),
-    {"/" ++ Path, _, _} = mochiweb_util:urlsplit_path(RawUri),
-
-    Headers = MochiReq:get(headers),
-
-    % get requested path
-    RequestedPath = case MochiReq:get_header_value("x-couchdb-vhost-path") of
-        undefined ->
-            case MochiReq:get_header_value("x-couchdb-requested-path") of
-                undefined -> RawUri;
-                R -> R
-            end;
-        P -> P
-    end,
-
-    HandlerKey =
-    case mochiweb_util:partition(Path, "/") of
-    {"", "", ""} ->
-        <<"/">>; % Special case the root url handler
-    {FirstPart, _, _} ->
-        list_to_binary(FirstPart)
-    end,
-    ?LOG_DEBUG("~p ~s ~p from ~p~nHeaders: ~p", [
-        MochiReq:get(method),
-        RawUri,
-        MochiReq:get(version),
-        MochiReq:get(peer),
-        mochiweb_headers:to_list(MochiReq:get(headers))
-    ]),
-
-    Method1 =
-    case MochiReq:get(method) of
-        % already an atom
-        Meth when is_atom(Meth) -> Meth;
-
-        % Non standard HTTP verbs aren't atoms (COPY, MOVE etc) so convert when
-        % possible (if any module references the atom, then it's existing).
-        Meth -> couch_util:to_existing_atom(Meth)
-    end,
-    increment_method_stats(Method1),
-
-    % allow broken HTTP clients to fake a full method vocabulary with an X-HTTP-METHOD-OVERRIDE header
-    MethodOverride = MochiReq:get_primary_header_value("X-HTTP-Method-Override"),
-    Method2 = case lists:member(MethodOverride, ["GET", "HEAD", "POST",
-                                                 "PUT", "DELETE",
-                                                 "TRACE", "CONNECT",
-                                                 "COPY"]) of
-    true ->
-        ?LOG_INFO("MethodOverride: ~s (real method was ~s)", [MethodOverride, Method1]),
-        case Method1 of
-        'POST' -> couch_util:to_existing_atom(MethodOverride);
-        _ ->
-            % Ignore X-HTTP-Method-Override when the original verb isn't POST.
-            % I'd like to send a 406 error to the client, but that'd require a nasty refactor.
-            % throw({not_acceptable, <<"X-HTTP-Method-Override may only be used with POST requests.">>})
-            Method1
-        end;
-    _ -> Method1
-    end,
-
-    % alias HEAD to GET as mochiweb takes care of stripping the body
-    Method = case Method2 of
-        'HEAD' -> 'GET';
-        Other -> Other
-    end,
-
-    HttpReq = #httpd{
-        mochi_req = MochiReq,
-        peer = MochiReq:get(peer),
-        method = Method,
-        requested_path_parts =
-            [?l2b(unquote(Part)) || Part <- string:tokens(RequestedPath, "/")],
-        path_parts = [?l2b(unquote(Part)) || Part <- string:tokens(Path, "/")],
-        db_url_handlers = DbUrlHandlers,
-        design_url_handlers = DesignUrlHandlers,
-        default_fun = DefaultFun,
-        url_handlers = UrlHandlers,
-        user_ctx = erlang:erase(pre_rewrite_user_ctx),
-        auth = erlang:erase(pre_rewrite_auth)
-    },
-
-    HandlerFun = couch_util:dict_find(HandlerKey, UrlHandlers, DefaultFun),
-    {ok, AuthHandlers} = application:get_env(couch_httpd, auth_handlers),
-
-    {ok, Resp} =
-    try
-        case couch_httpd_cors:is_preflight_request(HttpReq) of
-        #httpd{} ->
-            case authenticate_request(HttpReq, AuthHandlers) of
-            #httpd{} = Req ->
-                HandlerFun(Req);
-            Response ->
-                Response
-            end;
-        Response ->
-            Response
-        end
-    catch
-        throw:{http_head_abort, Resp0} ->
-            {ok, Resp0};
-        throw:{invalid_json, S} ->
-            ?LOG_ERROR("attempted upload of invalid JSON (set log_level to debug to log it)", []),
-            ?LOG_DEBUG("Invalid JSON: ~p",[S]),
-            send_error(HttpReq, {bad_request, invalid_json});
-        throw:unacceptable_encoding ->
-            ?LOG_ERROR("unsupported encoding method for the response", []),
-            send_error(HttpReq, {not_acceptable, "unsupported encoding"});
-        throw:bad_accept_encoding_value ->
-            ?LOG_ERROR("received invalid Accept-Encoding header", []),
-            send_error(HttpReq, bad_request);
-        exit:normal ->
-            exit(normal);
-        exit:snappy_nif_not_loaded ->
-            ErrorReason = "To access the database or view index, Apache CouchDB"
-                " must be built with Erlang OTP R13B04 or higher.",
-            ?LOG_ERROR("~s", [ErrorReason]),
-            send_error(HttpReq, {bad_otp_release, ErrorReason});
-        exit:{body_too_large, _} ->
-            send_error(HttpReq, request_entity_too_large);
-        throw:Error ->
-            Stack = erlang:get_stacktrace(),
-            ?LOG_DEBUG("Minor error in HTTP request: ~p",[Error]),
-            ?LOG_DEBUG("Stacktrace: ~p",[Stack]),
-            send_error(HttpReq, Error);
-        error:badarg ->
-            Stack = erlang:get_stacktrace(),
-            ?LOG_ERROR("Badarg error in HTTP request",[]),
-            ?LOG_INFO("Stacktrace: ~p",[Stack]),
-            send_error(HttpReq, badarg);
-        error:function_clause ->
-            Stack = erlang:get_stacktrace(),
-            ?LOG_ERROR("function_clause error in HTTP request",[]),
-            ?LOG_INFO("Stacktrace: ~p",[Stack]),
-            send_error(HttpReq, function_clause);
-        Tag:Error ->
-            Stack = erlang:get_stacktrace(),
-            ?LOG_ERROR("Uncaught error in HTTP request: ~p",[{Tag, Error}]),
-            ?LOG_INFO("Stacktrace: ~p",[Stack]),
-            send_error(HttpReq, Error)
-    end,
-    RequestTime = round(timer:now_diff(now(), Begin)/1000),
-    couch_stats_collector:record({couchdb, request_time}, RequestTime),
-    couch_stats_collector:increment({httpd, requests}),
-    {ok, Resp}.
-
-% Try authentication handlers in order until one sets a user_ctx
-% the auth funs also have the option of returning a response
-% move this to couch_httpd_auth?
-authenticate_request(#httpd{user_ctx=#user_ctx{}} = Req, _AuthHandlers) ->
-    Req;
-authenticate_request(#httpd{} = Req, []) ->
-    case couch_config:get("couch_httpd_auth", "require_valid_user", "false") of
-    "true" ->
-        throw({unauthorized, <<"Authentication required.">>});
-    "false" ->
-        Req#httpd{user_ctx=#user_ctx{}}
-    end;
-authenticate_request(#httpd{} = Req, [{AuthFun, AuthSrc} | RestAuthHandlers]) ->
-    R = case AuthFun(Req) of
-        #httpd{user_ctx=#user_ctx{}=UserCtx}=Req2 ->
-            Req2#httpd{user_ctx=UserCtx#user_ctx{handler=AuthSrc}};
-        Else -> Else
-    end,
-    authenticate_request(R, RestAuthHandlers);
-authenticate_request(Response, _AuthSrcs) ->
-    Response.
-
-increment_method_stats(Method) ->
-    couch_stats_collector:increment({httpd_request_methods, Method}).
-
-validate_referer(Req) ->
-    Host = host_for_request(Req),
-    Referer = header_value(Req, "Referer", fail),
-    case Referer of
-    fail ->
-        throw({bad_request, <<"Referer header required.">>});
-    Referer ->
-        {_,RefererHost,_,_,_} = mochiweb_util:urlsplit(Referer),
-        if
-            RefererHost =:= Host -> ok;
-            true -> throw({bad_request, <<"Referer header must match host.">>})
-        end
-    end.
-
-validate_ctype(Req, Ctype) ->
-    case header_value(Req, "Content-Type") of
-    undefined ->
-        throw({bad_ctype, "Content-Type must be "++Ctype});
-    ReqCtype ->
-        case string:tokens(ReqCtype, ";") of
-        [Ctype] -> ok;
-        [Ctype, _Rest] -> ok;
-        _Else ->
-            throw({bad_ctype, "Content-Type must be "++Ctype})
-        end
-    end.
-
-% Utilities
-
-partition(Path) ->
-    mochiweb_util:partition(Path, "/").
-
-header_value(#httpd{mochi_req=MochiReq}, Key) ->
-    MochiReq:get_header_value(Key).
-
-header_value(#httpd{mochi_req=MochiReq}, Key, Default) ->
-    case MochiReq:get_header_value(Key) of
-    undefined -> Default;
-    Value -> Value
-    end.
-
-primary_header_value(#httpd{mochi_req=MochiReq}, Key) ->
-    MochiReq:get_primary_header_value(Key).
-
-accepted_encodings(#httpd{mochi_req=MochiReq}) ->
-    case MochiReq:accepted_encodings(["gzip", "identity"]) of
-    bad_accept_encoding_value ->
-        throw(bad_accept_encoding_value);
-    [] ->
-        throw(unacceptable_encoding);
-    EncList ->
-        EncList
-    end.
-
-serve_file(Req, RelativePath, DocumentRoot) ->
-    serve_file(Req, RelativePath, DocumentRoot, []).
-
-serve_file(#httpd{mochi_req=MochiReq}=Req, RelativePath, DocumentRoot,
-           ExtraHeaders) ->
-    log_request(Req, 200),
-    ResponseHeaders = server_header()
-        ++ couch_httpd_auth:cookie_auth_header(Req, [])
-        ++ ExtraHeaders,
-    {ok, MochiReq:serve_file(RelativePath, DocumentRoot,
-            couch_httpd_cors:cors_headers(Req, ResponseHeaders))}.
-
-qs_value(Req, Key) ->
-    qs_value(Req, Key, undefined).
-
-qs_value(Req, Key, Default) ->
-    couch_util:get_value(Key, qs(Req), Default).
-
-qs_json_value(Req, Key, Default) ->
-    case qs_value(Req, Key, Default) of
-    Default ->
-        Default;
-    Result ->
-        ?JSON_DECODE(Result)
-    end.
-
-qs(#httpd{mochi_req=MochiReq}) ->
-    MochiReq:parse_qs().
-
-path(#httpd{mochi_req=MochiReq}) ->
-    MochiReq:get(path).
-
-host_for_request(#httpd{mochi_req=MochiReq}) ->
-    XHost = couch_config:get("httpd", "x_forwarded_host", "X-Forwarded-Host"),
-    case MochiReq:get_header_value(XHost) of
-        undefined ->
-            case MochiReq:get_header_value("Host") of
-                undefined ->
-                    {ok, {Address, Port}} = case MochiReq:get(socket) of
-                        {ssl, SslSocket} -> ssl:sockname(SslSocket);
-                        Socket -> inet:sockname(Socket)
-                    end,
-                    inet_parse:ntoa(Address) ++ ":" ++ integer_to_list(Port);
-                Value1 ->
-                    Value1
-            end;
-        Value -> Value
-    end.
-
-absolute_uri(#httpd{mochi_req=MochiReq}=Req, Path) ->
-    Host = host_for_request(Req),
-    XSsl = couch_config:get("httpd", "x_forwarded_ssl", "X-Forwarded-Ssl"),
-    Scheme = case MochiReq:get_header_value(XSsl) of
-                 "on" -> "https";
-                 _ ->
-                     XProto = couch_config:get("httpd", "x_forwarded_proto", "X-Forwarded-Proto"),
-                     case MochiReq:get_header_value(XProto) of
-                         %% Restrict to "https" and "http" schemes only
-                         "https" -> "https";
-                         _ -> case MochiReq:get(scheme) of
-                                  https -> "https";
-                                  http -> "http"
-                              end
-                     end
-             end,
-    Scheme ++ "://" ++ Host ++ Path.
-
-unquote(UrlEncodedString) ->
-    mochiweb_util:unquote(UrlEncodedString).
-
-quote(UrlDecodedString) ->
-    mochiweb_util:quote_plus(UrlDecodedString).
-
-parse_form(#httpd{mochi_req=MochiReq}) ->
-    mochiweb_multipart:parse_form(MochiReq).
-
-recv(#httpd{mochi_req=MochiReq}, Len) ->
-    MochiReq:recv(Len).
-
-recv_chunked(#httpd{mochi_req=MochiReq}, MaxChunkSize, ChunkFun, InitState) ->
-    % Fun is called once with each chunk
-    % Fun({Length, Binary}, State)
-    % called with Length == 0 on the last time.
-    MochiReq:stream_body(MaxChunkSize, ChunkFun, InitState).
-
-body_length(#httpd{mochi_req=MochiReq}) ->
-    MochiReq:get(body_length).
-
-body(#httpd{mochi_req=MochiReq, req_body=undefined}) ->
-    MaxSize = list_to_integer(
-        couch_config:get("couchdb", "max_document_size", "4294967296")),
-    MochiReq:recv_body(MaxSize);
-body(#httpd{req_body=ReqBody}) ->
-    ReqBody.
-
-json_body(Httpd) ->
-    ?JSON_DECODE(body(Httpd)).
-
-json_body_obj(Httpd) ->
-    case json_body(Httpd) of
-        {Props} -> {Props};
-        _Else ->
-            throw({bad_request, "Request body must be a JSON object"})
-    end.
-
-
-
-doc_etag(#doc{revs={Start, [DiskRev|_]}}) ->
-    "\"" ++ ?b2l(couch_doc:rev_to_str({Start, DiskRev})) ++ "\"".
-
-make_etag(Term) ->
-    <<SigInt:128/integer>> = couch_util:md5(term_to_binary(Term)),
-    iolist_to_binary([$", io_lib:format("~.36B", [SigInt]), $"]).
-
-etag_match(Req, CurrentEtag) when is_binary(CurrentEtag) ->
-    etag_match(Req, binary_to_list(CurrentEtag));
-
-etag_match(Req, CurrentEtag) ->
-    EtagsToMatch = string:tokens(
-        header_value(Req, "If-None-Match", ""), ", "),
-    lists:member(CurrentEtag, EtagsToMatch).
-
-etag_respond(Req, CurrentEtag, RespFun) ->
-    case etag_match(Req, CurrentEtag) of
-    true ->
-        % the client has this in their cache.
-        send_response(Req, 304, [{"ETag", CurrentEtag}], <<>>);
-    false ->
-        % Run the function.
-        RespFun()
-    end.
-
-etag_maybe(Req, RespFun) ->
-    try
-        RespFun()
-    catch
-        throw:{etag_match, ETag} ->
-            send_response(Req, 304, [{"ETag", ETag}], <<>>)
-    end.
-
-verify_is_server_admin(#httpd{user_ctx=UserCtx}) ->
-    verify_is_server_admin(UserCtx);
-verify_is_server_admin(#user_ctx{roles=Roles}) ->
-    case lists:member(<<"_admin">>, Roles) of
-    true -> ok;
-    false -> throw({unauthorized, <<"You are not a server admin.">>})
-    end.
-
-log_request(#httpd{mochi_req=MochiReq,peer=Peer}=Req, Code) ->
-    ?LOG_INFO("~s - - ~s ~s ~B", [
-        Peer,
-        MochiReq:get(method),
-        MochiReq:get(raw_path),
-        Code
-    ]),
-    gen_event:notify(couch_plugin, {log_request, Req, Code}).
-
-
-start_response_length(#httpd{mochi_req=MochiReq}=Req, Code, Headers, Length) ->
-    log_request(Req, Code),
-    couch_stats_collector:increment({httpd_status_codes, Code}),
-    Headers1 = Headers ++ server_header() ++
-               couch_httpd_auth:cookie_auth_header(Req, Headers),
-    Headers2 = couch_httpd_cors:cors_headers(Req, Headers1),
-    Resp = MochiReq:start_response_length({Code, Headers2, Length}),
-    case MochiReq:get(method) of
-    'HEAD' -> throw({http_head_abort, Resp});
-    _ -> ok
-    end,
-    {ok, Resp}.
-
-start_response(#httpd{mochi_req=MochiReq}=Req, Code, Headers) ->
-    log_request(Req, Code),
-    couch_stats_collector:increment({httpd_status_codes, Code}),
-    CookieHeader = couch_httpd_auth:cookie_auth_header(Req, Headers),
-    Headers1 = Headers ++ server_header() ++ CookieHeader,
-    Headers2 = couch_httpd_cors:cors_headers(Req, Headers1),
-    Resp = MochiReq:start_response({Code, Headers2}),
-    case MochiReq:get(method) of
-        'HEAD' -> throw({http_head_abort, Resp});
-        _ -> ok
-    end,
-    {ok, Resp}.
-
-send(Resp, Data) ->
-    Resp:send(Data),
-    {ok, Resp}.
-
-no_resp_conn_header([]) ->
-    true;
-no_resp_conn_header([{Hdr, _}|Rest]) ->
-    case string:to_lower(Hdr) of
-        "connection" -> false;
-        _ -> no_resp_conn_header(Rest)
-    end.
-
-http_1_0_keep_alive(Req, Headers) ->
-    KeepOpen = Req:should_close() == false,
-    IsHttp10 = Req:get(version) == {1, 0},
-    NoRespHeader = no_resp_conn_header(Headers),
-    case KeepOpen andalso IsHttp10 andalso NoRespHeader of
-        true -> [{"Connection", "Keep-Alive"} | Headers];
-        false -> Headers
-    end.
-
-start_chunked_response(#httpd{mochi_req=MochiReq}=Req, Code, Headers) ->
-    log_request(Req, Code),
-    couch_stats_collector:increment({httpd_status_codes, Code}),
-    Headers1 = http_1_0_keep_alive(MochiReq, Headers),
-    Headers2 = Headers1 ++ server_header() ++
-               couch_httpd_auth:cookie_auth_header(Req, Headers1),
-    Headers3 = couch_httpd_cors:cors_headers(Req, Headers2),
-    Resp = MochiReq:respond({Code, Headers3, chunked}),
-    case MochiReq:get(method) of
-    'HEAD' -> throw({http_head_abort, Resp});
-    _ -> ok
-    end,
-    {ok, Resp}.
-
-send_chunk(Resp, Data) ->
-    case iolist_size(Data) of
-    0 -> ok; % do nothing
-    _ -> Resp:write_chunk(Data)
-    end,
-    {ok, Resp}.
-
-last_chunk(Resp) ->
-    Resp:write_chunk([]),
-    {ok, Resp}.
-
-send_response(#httpd{mochi_req=MochiReq}=Req, Code, Headers, Body) ->
-    log_request(Req, Code),
-    couch_stats_collector:increment({httpd_status_codes, Code}),
-    Headers1 = http_1_0_keep_alive(MochiReq, Headers),
-    if Code >= 500 ->
-        ?LOG_ERROR("httpd ~p error response:~n ~s", [Code, Body]);
-    Code >= 400 ->
-        ?LOG_DEBUG("httpd ~p error response:~n ~s", [Code, Body]);
-    true -> ok
-    end,
-    Headers2 = Headers1 ++ server_header() ++
-               couch_httpd_auth:cookie_auth_header(Req, Headers1),
-    Headers3 = couch_httpd_cors:cors_headers(Req, Headers2),
-
-    {ok, MochiReq:respond({Code, Headers3, Body})}.
-
-send_method_not_allowed(Req, Methods) ->
-    send_error(Req, 405, [{"Allow", Methods}], <<"method_not_allowed">>, ?l2b("Only " ++ Methods ++ " allowed")).
-
-send_json(Req, Value) ->
-    send_json(Req, 200, Value).
-
-send_json(Req, Code, Value) ->
-    send_json(Req, Code, [], Value).
-
-send_json(Req, Code, Headers, Value) ->
-    initialize_jsonp(Req),
-    DefaultHeaders = [
-        {"Content-Type", negotiate_content_type(Req)},
-        {"Cache-Control", "must-revalidate"}
-    ],
-    Body = [start_jsonp(), ?JSON_ENCODE(Value), end_jsonp(), $\n],
-    send_response(Req, Code, DefaultHeaders ++ Headers, Body).
-
-start_json_response(Req, Code) ->
-    start_json_response(Req, Code, []).
-
-start_json_response(Req, Code, Headers) ->
-    initialize_jsonp(Req),
-    DefaultHeaders = [
-        {"Content-Type", negotiate_content_type(Req)},
-        {"Cache-Control", "must-revalidate"}
-    ],
-    {ok, Resp} = start_chunked_response(Req, Code, DefaultHeaders ++ Headers),
-    case start_jsonp() of
-        [] -> ok;
-        Start -> send_chunk(Resp, Start)
-    end,
-    {ok, Resp}.
-
-end_json_response(Resp) ->
-    send_chunk(Resp, end_jsonp() ++ [$\n]),
-    last_chunk(Resp).
-
-initialize_jsonp(Req) ->
-    case get(jsonp) of
-        undefined -> put(jsonp, qs_value(Req, "callback", no_jsonp));
-        _ -> ok
-    end,
-    case get(jsonp) of
-        no_jsonp -> [];
-        [] -> [];
-        CallBack ->
-            try
-                % make sure jsonp is configured on (default off)
-                case couch_config:get("httpd", "allow_jsonp", "false") of
-                "true" ->
-                    validate_callback(CallBack);
-                _Else ->
-                    put(jsonp, no_jsonp)
-                end
-            catch
-                Error ->
-                    put(jsonp, no_jsonp),
-                    throw(Error)
-            end
-    end.
-
-start_jsonp() ->
-    case get(jsonp) of
-        no_jsonp -> [];
-        [] -> [];
-        CallBack -> ["/* CouchDB */", CallBack, "("]
-    end.
-
-end_jsonp() ->
-    case erlang:erase(jsonp) of
-        no_jsonp -> [];
-        [] -> [];
-        _ -> ");"
-    end.
-
-validate_callback(CallBack) when is_binary(CallBack) ->
-    validate_callback(binary_to_list(CallBack));
-validate_callback([]) ->
-    ok;
-validate_callback([Char | Rest]) ->
-    case Char of
-        _ when Char >= $a andalso Char =< $z -> ok;
-        _ when Char >= $A andalso Char =< $Z -> ok;
-        _ when Char >= $0 andalso Char =< $9 -> ok;
-        _ when Char == $. -> ok;
-        _ when Char == $_ -> ok;
-        _ when Char == $[ -> ok;
-        _ when Char == $] -> ok;
-        _ ->
-            throw({bad_request, invalid_callback})
-    end,
-    validate_callback(Rest).
-
-
-error_info({Error, Reason}) when is_list(Reason) ->
-    error_info({Error, ?l2b(Reason)});
-error_info(bad_request) ->
-    {400, <<"bad_request">>, <<>>};
-error_info({bad_request, Reason}) ->
-    {400, <<"bad_request">>, Reason};
-error_info({query_parse_error, Reason}) ->
-    {400, <<"query_parse_error">>, Reason};
-% Prior art for md5 mismatch resulting in a 400 is from AWS S3
-error_info(md5_mismatch) ->
-    {400, <<"content_md5_mismatch">>, <<"Possible message corruption.">>};
-error_info(not_found) ->
-    {404, <<"not_found">>, <<"missing">>};
-error_info({not_found, Reason}) ->
-    {404, <<"not_found">>, Reason};
-error_info({not_acceptable, Reason}) ->
-    {406, <<"not_acceptable">>, Reason};
-error_info(conflict) ->
-    {409, <<"conflict">>, <<"Document update conflict.">>};
-error_info({forbidden, Msg}) ->
-    {403, <<"forbidden">>, Msg};
-error_info({unauthorized, Msg}) ->
-    {401, <<"unauthorized">>, Msg};
-error_info(file_exists) ->
-    {412, <<"file_exists">>, <<"The database could not be "
-        "created, the file already exists.">>};
-error_info(request_entity_too_large) ->
-    {413, <<"too_large">>, <<"the request entity is too large">>};
-error_info({bad_ctype, Reason}) ->
-    {415, <<"bad_content_type">>, Reason};
-error_info(requested_range_not_satisfiable) ->
-    {416, <<"requested_range_not_satisfiable">>, <<"Requested range not satisfiable">>};
-error_info({error, illegal_database_name, Name}) ->
-    Message = "Name: '" ++ Name ++ "'. Only lowercase characters (a-z), "
-        ++ "digits (0-9), and any of the characters _, $, (, ), +, -, and / "
-        ++ "are allowed. Must begin with a letter.",
-    {400, <<"illegal_database_name">>, couch_util:to_binary(Message)};
-error_info({missing_stub, Reason}) ->
-    {412, <<"missing_stub">>, Reason};
-error_info({Error, Reason}) ->
-    {500, couch_util:to_binary(Error), couch_util:to_binary(Reason)};
-error_info(Error) ->
-    {500, <<"unknown_error">>, couch_util:to_binary(Error)}.
-
-error_headers(#httpd{mochi_req=MochiReq}=Req, Code, ErrorStr, ReasonStr) ->
-    if Code == 401 ->
-        % this is where the basic auth popup is triggered
-        case MochiReq:get_header_value("X-CouchDB-WWW-Authenticate") of
-        undefined ->
-            case couch_config:get("httpd", "WWW-Authenticate", nil) of
-            nil ->
-                % If the client is a browser and the basic auth popup isn't turned on
-                % redirect to the session page.
-                case ErrorStr of
-                <<"unauthorized">> ->
-                    case couch_config:get("couch_httpd_auth", "authentication_redirect", nil) of
-                    nil -> {Code, []};
-                    AuthRedirect ->
-                        case couch_config:get("couch_httpd_auth", "require_valid_user", "false") of
-                        "true" ->
-                            % send the browser popup header no matter what if we are require_valid_user
-                            {Code, [{"WWW-Authenticate", "Basic realm=\"server\""}]};
-                        _False ->
-                            case MochiReq:accepts_content_type("application/json") of
-                            true ->
-                                {Code, []};
-                            false ->
-                                case MochiReq:accepts_content_type("text/html") of
-                                true ->
-                                    % Redirect to the path the user requested, not
-                                    % the one that is used internally.
-                                    UrlReturnRaw = case MochiReq:get_header_value("x-couchdb-vhost-path") of
-                                    undefined ->
-                                        MochiReq:get(path);
-                                    VHostPath ->
-                                        VHostPath
-                                    end,
-                                    RedirectLocation = lists:flatten([
-                                        AuthRedirect,
-                                        "?return=", couch_util:url_encode(UrlReturnRaw),
-                                        "&reason=", couch_util:url_encode(ReasonStr)
-                                    ]),
-                                    {302, [{"Location", absolute_uri(Req, RedirectLocation)}]};
-                                false ->
-                                    {Code, []}
-                                end
-                            end
-                        end
-                    end;
-                _Else ->
-                    {Code, []}
-                end;
-            Type ->
-                {Code, [{"WWW-Authenticate", Type}]}
-            end;
-        Type ->
-           {Code, [{"WWW-Authenticate", Type}]}
-        end;
-    true ->
-        {Code, []}
-    end.
-
-send_error(_Req, {already_sent, Resp, _Error}) ->
-    {ok, Resp};
-
-send_error(Req, Error) ->
-    {Code, ErrorStr, ReasonStr} = error_info(Error),
-    {Code1, Headers} = error_headers(Req, Code, ErrorStr, ReasonStr),
-    send_error(Req, Code1, Headers, ErrorStr, ReasonStr).
-
-send_error(Req, Code, ErrorStr, ReasonStr) ->
-    send_error(Req, Code, [], ErrorStr, ReasonStr).
-
-send_error(Req, Code, Headers, ErrorStr, ReasonStr) ->
-    send_json(Req, Code, Headers,
-        {[{<<"error">>,  ErrorStr},
-         {<<"reason">>, ReasonStr}]}).
-
-% give the option for list functions to output html or other raw errors
-send_chunked_error(Resp, {_Error, {[{<<"body">>, Reason}]}}) ->
-    send_chunk(Resp, Reason),
-    last_chunk(Resp);
-
-send_chunked_error(Resp, Error) ->
-    {Code, ErrorStr, ReasonStr} = error_info(Error),
-    JsonError = {[{<<"code">>, Code},
-        {<<"error">>,  ErrorStr},
-        {<<"reason">>, ReasonStr}]},
-    send_chunk(Resp, ?l2b([$\n,?JSON_ENCODE(JsonError),$\n])),
-    last_chunk(Resp).
-
-send_redirect(Req, Path) ->
-     send_response(Req, 301, [{"Location", absolute_uri(Req, Path)}], <<>>).
-
-negotiate_content_type(Req) ->
-    case get(jsonp) of
-        no_jsonp -> negotiate_content_type1(Req);
-        [] -> negotiate_content_type1(Req);
-        _Callback -> "text/javascript"
-    end.
-
-negotiate_content_type1(#httpd{mochi_req=MochiReq}) ->
-    %% Determine the appropriate Content-Type header for a JSON response
-    %% depending on the Accept header in the request. A request that explicitly
-    %% lists the correct JSON MIME type will get that type, otherwise the
-    %% response will have the generic MIME type "text/plain"
-    AcceptedTypes = case MochiReq:get_header_value("Accept") of
-        undefined       -> [];
-        AcceptHeader    -> string:tokens(AcceptHeader, ", ")
-    end,
-    case lists:member("application/json", AcceptedTypes) of
-        true  -> "application/json";
-        false -> "text/plain; charset=utf-8"
-    end.
-
-server_header() ->
-    [{"Server", "CouchDB/" ++ couch_server:get_version() ++
-                " (Erlang OTP/" ++ erlang:system_info(otp_release) ++ ")"}].
-
-
--record(mp, {boundary, buffer, data_fun, callback}).
-
-
-parse_multipart_request(ContentType, DataFun, Callback) ->
-    Boundary0 = iolist_to_binary(get_boundary(ContentType)),
-    Boundary = <<"\r\n--", Boundary0/binary>>,
-    Mp = #mp{boundary= Boundary,
-            buffer= <<>>,
-            data_fun=DataFun,
-            callback=Callback},
-    {Mp2, _NilCallback} = read_until(Mp, <<"--", Boundary0/binary>>,
-        fun nil_callback/1),
-    #mp{buffer=Buffer, data_fun=DataFun2, callback=Callback2} =
-            parse_part_header(Mp2),
-    {Buffer, DataFun2, Callback2}.
-
-nil_callback(_Data)->
-    fun nil_callback/1.
-
-get_boundary({"multipart/" ++ _, Opts}) ->
-    case couch_util:get_value("boundary", Opts) of
-        S when is_list(S) ->
-            S
-    end;
-get_boundary(ContentType) ->
-    {"multipart/" ++ _ , Opts} = mochiweb_util:parse_header(ContentType),
-    get_boundary({"multipart/", Opts}).
-
-
-
-split_header(<<>>) ->
-    [];
-split_header(Line) ->
-    {Name, [$: | Value]} = lists:splitwith(fun (C) -> C =/= $: end,
-                                           binary_to_list(Line)),
-    [{string:to_lower(string:strip(Name)),
-     mochiweb_util:parse_header(Value)}].
-
-read_until(#mp{data_fun=DataFun, buffer=Buffer}=Mp, Pattern, Callback) ->
-    case couch_util:find_in_binary(Pattern, Buffer) of
-    not_found ->
-        Callback2 = Callback(Buffer),
-        {Buffer2, DataFun2} = DataFun(),
-        Buffer3 = iolist_to_binary(Buffer2),
-        read_until(Mp#mp{data_fun=DataFun2,buffer=Buffer3}, Pattern, Callback2);
-    {partial, 0} ->
-        {NewData, DataFun2} = DataFun(),
-        read_until(Mp#mp{data_fun=DataFun2,
-                buffer= iolist_to_binary([Buffer,NewData])},
-                Pattern, Callback);
-    {partial, Skip} ->
-        <<DataChunk:Skip/binary, Rest/binary>> = Buffer,
-        Callback2 = Callback(DataChunk),
-        {NewData, DataFun2} = DataFun(),
-        read_until(Mp#mp{data_fun=DataFun2,
-                buffer= iolist_to_binary([Rest | NewData])},
-                Pattern, Callback2);
-    {exact, 0} ->
-        PatternLen = size(Pattern),
-        <<_:PatternLen/binary, Rest/binary>> = Buffer,
-        {Mp#mp{buffer= Rest}, Callback};
-    {exact, Skip} ->
-        PatternLen = size(Pattern),
-        <<DataChunk:Skip/binary, _:PatternLen/binary, Rest/binary>> = Buffer,
-        Callback2 = Callback(DataChunk),
-        {Mp#mp{buffer= Rest}, Callback2}
-    end.
-
-
-parse_part_header(#mp{callback=UserCallBack}=Mp) ->
-    {Mp2, AccCallback} = read_until(Mp, <<"\r\n\r\n">>,
-            fun(Next) -> acc_callback(Next, []) end),
-    HeaderData = AccCallback(get_data),
-
-    Headers =
-    lists:foldl(fun(Line, Acc) ->
-            split_header(Line) ++ Acc
-        end, [], re:split(HeaderData,<<"\r\n">>, [])),
-    NextCallback = UserCallBack({headers, Headers}),
-    parse_part_body(Mp2#mp{callback=NextCallback}).
-
-parse_part_body(#mp{boundary=Prefix, callback=Callback}=Mp) ->
-    {Mp2, WrappedCallback} = read_until(Mp, Prefix,
-            fun(Data) -> body_callback_wrapper(Data, Callback) end),
-    Callback2 = WrappedCallback(get_callback),
-    Callback3 = Callback2(body_end),
-    case check_for_last(Mp2#mp{callback=Callback3}) of
-    {last, #mp{callback=Callback3}=Mp3} ->
-        Mp3#mp{callback=Callback3(eof)};
-    {more, Mp3} ->
-        parse_part_header(Mp3)
-    end.
-
-acc_callback(get_data, Acc)->
-    iolist_to_binary(lists:reverse(Acc));
-acc_callback(Data, Acc)->
-    fun(Next) -> acc_callback(Next, [Data | Acc]) end.
-
-body_callback_wrapper(get_callback, Callback) ->
-    Callback;
-body_callback_wrapper(Data, Callback) ->
-    Callback2 = Callback({body, Data}),
-    fun(Next) -> body_callback_wrapper(Next, Callback2) end.
-
-
-check_for_last(#mp{buffer=Buffer, data_fun=DataFun}=Mp) ->
-    case Buffer of
-    <<"--",_/binary>> -> {last, Mp};
-    <<_, _, _/binary>> -> {more, Mp};
-    _ -> % not long enough
-        {Data, DataFun2} = DataFun(),
-        check_for_last(Mp#mp{buffer= <<Buffer/binary, Data/binary>>,
-                data_fun = DataFun2})
-    end.
-
-validate_bind_address(Address) ->
-    case inet_parse:address(Address) of
-        {ok, _} -> ok;
-        _ -> throw({error, invalid_bind_address})
-    end.

http://git-wip-us.apache.org/repos/asf/couchdb/blob/c0855434/apps/couch_httpd/src/couch_httpd_app.erl
----------------------------------------------------------------------
diff --git a/apps/couch_httpd/src/couch_httpd_app.erl b/apps/couch_httpd/src/couch_httpd_app.erl
deleted file mode 100644
index f3a9bb6..0000000
--- a/apps/couch_httpd/src/couch_httpd_app.erl
+++ /dev/null
@@ -1,24 +0,0 @@
-% Licensed 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.
-
--module(couch_httpd_app).
-
--behaviour(application).
-
--export([start/2, stop/1]).
-
-start(_Type, _Args) ->
-    couch_util:start_app_deps(couch_httpd),
-    couch_httpd_sup:start_link().
-
-stop(_) ->
-    ok.

http://git-wip-us.apache.org/repos/asf/couchdb/blob/c0855434/apps/couch_httpd/src/couch_httpd_auth.erl
----------------------------------------------------------------------
diff --git a/apps/couch_httpd/src/couch_httpd_auth.erl b/apps/couch_httpd/src/couch_httpd_auth.erl
deleted file mode 100644
index d99e5b8..0000000
--- a/apps/couch_httpd/src/couch_httpd_auth.erl
+++ /dev/null
@@ -1,380 +0,0 @@
-% Licensed 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.
-
--module(couch_httpd_auth).
--include_lib("couch/include/couch_db.hrl").
-
--export([default_authentication_handler/1,special_test_authentication_handler/1]).
--export([cookie_authentication_handler/1]).
--export([null_authentication_handler/1]).
--export([proxy_authentication_handler/1, proxy_authentification_handler/1]).
--export([cookie_auth_header/2]).
--export([handle_session_req/1]).
-
--import(couch_httpd, [header_value/2, send_json/2,send_json/4, send_method_not_allowed/2]).
-
-special_test_authentication_handler(Req) ->
-    case header_value(Req, "WWW-Authenticate") of
-    "X-Couch-Test-Auth " ++ NamePass ->
-        % NamePass is a colon separated string: "joe schmoe:a password".
-        [Name, Pass] = re:split(NamePass, ":", [{return, list}, {parts, 2}]),
-        case {Name, Pass} of
-        {"Jan Lehnardt", "apple"} -> ok;
-        {"Christopher Lenz", "dog food"} -> ok;
-        {"Noah Slater", "biggiesmalls endian"} -> ok;
-        {"Chris Anderson", "mp3"} -> ok;
-        {"Damien Katz", "pecan pie"} -> ok;
-        {_, _} ->
-            throw({unauthorized, <<"Name or password is incorrect.">>})
-        end,
-        Req#httpd{user_ctx=#user_ctx{name=?l2b(Name)}};
-    _ ->
-        % No X-Couch-Test-Auth credentials sent, give admin access so the
-        % previous authentication can be restored after the test
-        Req#httpd{user_ctx=#user_ctx{roles=[<<"_admin">>]}}
-    end.
-
-basic_name_pw(Req) ->
-    AuthorizationHeader = header_value(Req, "Authorization"),
-    case AuthorizationHeader of
-    "Basic " ++ Base64Value ->
-        case re:split(base64:decode(Base64Value), ":",
-                      [{return, list}, {parts, 2}]) of
-        ["_", "_"] ->
-            % special name and pass to be logged out
-            nil;
-        [User, Pass] ->
-            {User, Pass};
-        _ ->
-            nil
-        end;
-    _ ->
-        nil
-    end.
-
-default_authentication_handler(Req) ->
-    case basic_name_pw(Req) of
-    {User, Pass} ->
-        case couch_auth_cache:get_user_creds(User) of
-            nil ->
-                throw({unauthorized, <<"Name or password is incorrect.">>});
-            UserProps ->
-                case authenticate(?l2b(Pass), UserProps) of
-                    true ->
-                        Req#httpd{user_ctx=#user_ctx{
-                            name=?l2b(User),
-                            roles=couch_util:get_value(<<"roles">>, UserProps, [])
-                        }};
-                    _Else ->
-                        throw({unauthorized, <<"Name or password is incorrect.">>})
-                end
-        end;
-    nil ->
-        case couch_server:has_admins() of
-        true ->
-            Req;
-        false ->
-            case couch_config:get("couch_httpd_auth", "require_valid_user", "false") of
-                "true" -> Req;
-                % If no admins, and no user required, then everyone is admin!
-                % Yay, admin party!
-                _ -> Req#httpd{user_ctx=#user_ctx{roles=[<<"_admin">>]}}
-            end
-        end
-    end.
-
-null_authentication_handler(Req) ->
-    Req#httpd{user_ctx=#user_ctx{roles=[<<"_admin">>]}}.
-
-%% @doc proxy auth handler.
-%
-% This handler allows creation of a userCtx object from a user authenticated remotly.
-% The client just pass specific headers to CouchDB and the handler create the userCtx.
-% Headers  name can be defined in local.ini. By thefault they are :
-%
-%   * X-Auth-CouchDB-UserName : contain the username, (x_auth_username in
-%   couch_httpd_auth section)
-%   * X-Auth-CouchDB-Roles : contain the user roles, list of roles separated by a
-%   comma (x_auth_roles in couch_httpd_auth section)
-%   * X-Auth-CouchDB-Token : token to authenticate the authorization (x_auth_token
-%   in couch_httpd_auth section). This token is an hmac-sha1 created from secret key
-%   and username. The secret key should be the same in the client and couchdb node. s
-%   ecret key is the secret key in couch_httpd_auth section of ini. This token is optional
-%   if value of proxy_use_secret key in couch_httpd_auth section of ini isn't true.
-%
-proxy_authentication_handler(Req) ->
-    case proxy_auth_user(Req) of
-        nil -> Req;
-        Req2 -> Req2
-    end.
-
-%% @deprecated
-proxy_authentification_handler(Req) ->
-    proxy_authentication_handler(Req).
-
-proxy_auth_user(Req) ->
-    XHeaderUserName = couch_config:get("couch_httpd_auth", "x_auth_username",
-                                "X-Auth-CouchDB-UserName"),
-    XHeaderRoles = couch_config:get("couch_httpd_auth", "x_auth_roles",
-                                "X-Auth-CouchDB-Roles"),
-    XHeaderToken = couch_config:get("couch_httpd_auth", "x_auth_token",
-                                "X-Auth-CouchDB-Token"),
-    case header_value(Req, XHeaderUserName) of
-        undefined -> nil;
-        UserName ->
-            Roles = case header_value(Req, XHeaderRoles) of
-                undefined -> [];
-                Else ->
-                    [?l2b(R) || R <- string:tokens(Else, ",")]
-            end,
-            case couch_config:get("couch_httpd_auth", "proxy_use_secret", "false") of
-                "true" ->
-                    case couch_config:get("couch_httpd_auth", "secret", nil) of
-                        nil ->
-                            Req#httpd{user_ctx=#user_ctx{name=?l2b(UserName), roles=Roles}};
-                        Secret ->
-                            ExpectedToken = couch_util:to_hex(crypto:sha_mac(Secret, UserName)),
-                            case header_value(Req, XHeaderToken) of
-                                Token when Token == ExpectedToken ->
-                                    Req#httpd{user_ctx=#user_ctx{name=?l2b(UserName),
-                                                            roles=Roles}};
-                                _ -> nil
-                            end
-                    end;
-                _ ->
-                    Req#httpd{user_ctx=#user_ctx{name=?l2b(UserName), roles=Roles}}
-            end
-    end.
-
-
-cookie_authentication_handler(#httpd{mochi_req=MochiReq}=Req) ->
-    case MochiReq:get_cookie_value("AuthSession") of
-    undefined -> Req;
-    [] -> Req;
-    Cookie ->
-        [User, TimeStr, HashStr] = try
-            AuthSession = couch_util:decodeBase64Url(Cookie),
-            [_A, _B, _Cs] = re:split(?b2l(AuthSession), ":",
-                                     [{return, list}, {parts, 3}])
-        catch
-            _:_Error ->
-                Reason = <<"Malformed AuthSession cookie. Please clear your cookies.">>,
-                throw({bad_request, Reason})
-        end,
-        % Verify expiry and hash
-        CurrentTime = make_cookie_time(),
-        case couch_config:get("couch_httpd_auth", "secret", nil) of
-        nil ->
-            ?LOG_DEBUG("cookie auth secret is not set",[]),
-            Req;
-        SecretStr ->
-            Secret = ?l2b(SecretStr),
-            case couch_auth_cache:get_user_creds(User) of
-            nil -> Req;
-            UserProps ->
-                UserSalt = couch_util:get_value(<<"salt">>, UserProps, <<"">>),
-                FullSecret = <<Secret/binary, UserSalt/binary>>,
-                ExpectedHash = crypto:sha_mac(FullSecret, User ++ ":" ++ TimeStr),
-                Hash = ?l2b(HashStr),
-                Timeout = list_to_integer(
-                    couch_config:get("couch_httpd_auth", "timeout", "600")),
-                ?LOG_DEBUG("timeout ~p", [Timeout]),
-                case (catch erlang:list_to_integer(TimeStr, 16)) of
-                    TimeStamp when CurrentTime < TimeStamp + Timeout ->
-                        case couch_passwords:verify(ExpectedHash, Hash) of
-                            true ->
-                                TimeLeft = TimeStamp + Timeout - CurrentTime,
-                                ?LOG_DEBUG("Successful cookie auth as: ~p", [User]),
-                                Req#httpd{user_ctx=#user_ctx{
-                                    name=?l2b(User),
-                                    roles=couch_util:get_value(<<"roles">>, UserProps, [])
-                                }, auth={FullSecret, TimeLeft < Timeout*0.9}};
-                            _Else ->
-                                Req
-                        end;
-                    _Else ->
-                        Req
-                end
-            end
-        end
-    end.
-
-cookie_auth_header(#httpd{user_ctx=#user_ctx{name=null}}, _Headers) -> [];
-cookie_auth_header(#httpd{user_ctx=#user_ctx{name=User}, auth={Secret, true}}=Req, Headers) ->
-    % Note: we only set the AuthSession cookie if:
-    %  * a valid AuthSession cookie has been received
-    %  * we are outside a 10% timeout window
-    %  * and if an AuthSession cookie hasn't already been set e.g. by a login
-    %    or logout handler.
-    % The login and logout handlers need to set the AuthSession cookie
-    % themselves.
-    CookieHeader = couch_util:get_value("Set-Cookie", Headers, ""),
-    Cookies = mochiweb_cookies:parse_cookie(CookieHeader),
-    AuthSession = couch_util:get_value("AuthSession", Cookies),
-    if AuthSession == undefined ->
-        TimeStamp = make_cookie_time(),
-        [cookie_auth_cookie(Req, ?b2l(User), Secret, TimeStamp)];
-    true ->
-        []
-    end;
-cookie_auth_header(_Req, _Headers) -> [].
-
-cookie_auth_cookie(Req, User, Secret, TimeStamp) ->
-    SessionData = User ++ ":" ++ erlang:integer_to_list(TimeStamp, 16),
-    Hash = crypto:sha_mac(Secret, SessionData),
-    mochiweb_cookies:cookie("AuthSession",
-        couch_util:encodeBase64Url(SessionData ++ ":" ++ ?b2l(Hash)),
-        [{path, "/"}] ++ cookie_scheme(Req) ++ max_age()).
-
-ensure_cookie_auth_secret() ->
-    case couch_config:get("couch_httpd_auth", "secret", nil) of
-        nil ->
-            NewSecret = ?b2l(couch_uuids:random()),
-            couch_config:set("couch_httpd_auth", "secret", NewSecret),
-            NewSecret;
-        Secret -> Secret
-    end.
-
-% session handlers
-% Login handler with user db
-handle_session_req(#httpd{method='POST', mochi_req=MochiReq}=Req) ->
-    ReqBody = MochiReq:recv_body(),
-    Form = case MochiReq:get_primary_header_value("content-type") of
-        % content type should be json
-        "application/x-www-form-urlencoded" ++ _ ->
-            mochiweb_util:parse_qs(ReqBody);
-        "application/json" ++ _ ->
-            {Pairs} = ?JSON_DECODE(ReqBody),
-            lists:map(fun({Key, Value}) ->
-              {?b2l(Key), ?b2l(Value)}
-            end, Pairs);
-        _ ->
-            []
-    end,
-    UserName = ?l2b(couch_util:get_value("name", Form, "")),
-    Password = ?l2b(couch_util:get_value("password", Form, "")),
-    ?LOG_DEBUG("Attempt Login: ~s",[UserName]),
-    User = case couch_auth_cache:get_user_creds(UserName) of
-        nil -> [];
-        Result -> Result
-    end,
-    UserSalt = couch_util:get_value(<<"salt">>, User, <<>>),
-    case authenticate(Password, User) of
-        true ->
-            % setup the session cookie
-            Secret = ?l2b(ensure_cookie_auth_secret()),
-            CurrentTime = make_cookie_time(),
-            Cookie = cookie_auth_cookie(Req, ?b2l(UserName), <<Secret/binary, UserSalt/binary>>, CurrentTime),
-            % TODO document the "next" feature in Futon
-            {Code, Headers} = case couch_httpd:qs_value(Req, "next", nil) of
-                nil ->
-                    {200, [Cookie]};
-                Redirect ->
-                    {302, [Cookie, {"Location", couch_httpd:absolute_uri(Req, Redirect)}]}
-            end,
-            send_json(Req#httpd{req_body=ReqBody}, Code, Headers,
-                {[
-                    {ok, true},
-                    {name, couch_util:get_value(<<"name">>, User, null)},
-                    {roles, couch_util:get_value(<<"roles">>, User, [])}
-                ]});
-        _Else ->
-            % clear the session
-            Cookie = mochiweb_cookies:cookie("AuthSession", "", [{path, "/"}] ++ cookie_scheme(Req)),
-            {Code, Headers} = case couch_httpd:qs_value(Req, "fail", nil) of
-                nil ->
-                    {401, [Cookie]};
-                Redirect ->
-                    {302, [Cookie, {"Location", couch_httpd:absolute_uri(Req, Redirect)}]}
-            end,
-            send_json(Req, Code, Headers, {[{error, <<"unauthorized">>},{reason, <<"Name or password is incorrect.">>}]})
-    end;
-% get user info
-% GET /_session
-handle_session_req(#httpd{method='GET', user_ctx=UserCtx}=Req) ->
-    Name = UserCtx#user_ctx.name,
-    ForceLogin = couch_httpd:qs_value(Req, "basic", "false"),
-    case {Name, ForceLogin} of
-        {null, "true"} ->
-            throw({unauthorized, <<"Please login.">>});
-        {Name, _} ->
-            send_json(Req, {[
-                % remove this ok
-                {ok, true},
-                {<<"userCtx">>, {[
-                    {name, Name},
-                    {roles, UserCtx#user_ctx.roles}
-                ]}},
-                {info, {[
-                    {authentication_db, ?l2b(couch_config:get("couch_httpd_auth", "authentication_db"))},
-                    {authentication_handlers, [auth_name(H) || H <- couch_httpd:make_fun_spec_strs(
-                            couch_config:get("httpd", "authentication_handlers"))]}
-                ] ++ maybe_value(authenticated, UserCtx#user_ctx.handler, fun(Handler) ->
-                        auth_name(?b2l(Handler))
-                    end)}}
-            ]})
-    end;
-% logout by deleting the session
-handle_session_req(#httpd{method='DELETE'}=Req) ->
-    Cookie = mochiweb_cookies:cookie("AuthSession", "", [{path, "/"}] ++ cookie_scheme(Req)),
-    {Code, Headers} = case couch_httpd:qs_value(Req, "next", nil) of
-        nil ->
-            {200, [Cookie]};
-        Redirect ->
-            {302, [Cookie, {"Location", couch_httpd:absolute_uri(Req, Redirect)}]}
-    end,
-    send_json(Req, Code, Headers, {[{ok, true}]});
-handle_session_req(Req) ->
-    send_method_not_allowed(Req, "GET,HEAD,POST,DELETE").
-
-maybe_value(_Key, undefined, _Fun) -> [];
-maybe_value(Key, Else, Fun) ->
-    [{Key, Fun(Else)}].
-
-authenticate(Pass, UserProps) ->
-    UserSalt = couch_util:get_value(<<"salt">>, UserProps, <<>>),
-    {PasswordHash, ExpectedHash} =
-        case couch_util:get_value(<<"password_scheme">>, UserProps, <<"simple">>) of
-        <<"simple">> ->
-            {couch_passwords:simple(Pass, UserSalt),
-            couch_util:get_value(<<"password_sha">>, UserProps, nil)};
-        <<"pbkdf2">> ->
-            Iterations = couch_util:get_value(<<"iterations">>, UserProps, 10000),
-            {couch_passwords:pbkdf2(Pass, UserSalt, Iterations),
-             couch_util:get_value(<<"derived_key">>, UserProps, nil)}
-    end,
-    couch_passwords:verify(PasswordHash, ExpectedHash).
-
-auth_name(String) when is_list(String) ->
-    [_,_,_,_,_,Name|_] = re:split(String, "[\\W_]", [{return, list}]),
-    ?l2b(Name).
-
-make_cookie_time() ->
-    {NowMS, NowS, _} = erlang:now(),
-    NowMS * 1000000 + NowS.
-
-cookie_scheme(#httpd{mochi_req=MochiReq}) ->
-    [{http_only, true}] ++
-    case MochiReq:get(scheme) of
-        http -> [];
-        https -> [{secure, true}]
-    end.
-
-max_age() ->
-    case couch_config:get("couch_httpd_auth", "allow_persistent_cookies", "false") of
-        "false" ->
-            [];
-        "true" ->
-            Timeout = list_to_integer(
-                couch_config:get("couch_httpd_auth", "timeout", "600")),
-            [{max_age, Timeout}]
-    end.

http://git-wip-us.apache.org/repos/asf/couchdb/blob/c0855434/apps/couch_httpd/src/couch_httpd_changes.erl
----------------------------------------------------------------------
diff --git a/apps/couch_httpd/src/couch_httpd_changes.erl b/apps/couch_httpd/src/couch_httpd_changes.erl
deleted file mode 100644
index 6cb0b16..0000000
--- a/apps/couch_httpd/src/couch_httpd_changes.erl
+++ /dev/null
@@ -1,452 +0,0 @@
-% Licensed 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.
-
--module(couch_httpd_changes).
-
--export([handle_changes_req/2,
-         handle_changes/3,
-         handle_view_changes/3]).
-
--include_lib("couch/include/couch_db.hrl").
-
-handle_changes_req(#httpd{method='POST'}=Req, Db) ->
-    couch_httpd:validate_ctype(Req, "application/json"),
-    handle_changes_req1(Req, Db);
-handle_changes_req(#httpd{method='GET'}=Req, Db) ->
-    handle_changes_req1(Req, Db);
-handle_changes_req(#httpd{path_parts=[_,<<"_changes">>]}=Req, _Db) ->
-    couch_httpd:send_method_not_allowed(Req, "GET,HEAD,POST").
-
-handle_changes_req1(Req, #db{name=DbName}=Db) ->
-    AuthDbName = ?l2b(couch_config:get("couch_httpd_auth", "authentication_db")),
-    case AuthDbName of
-    DbName ->
-        % in the authentication database, _changes is admin-only.
-        ok = couch_db:check_is_admin(Db);
-    _Else ->
-        % on other databases, _changes is free for all.
-        ok
-    end,
-
-    MakeCallback = fun(Resp) ->
-        fun({change, {ChangeProp}=Change, _}, "eventsource") ->
-            Seq = proplists:get_value(<<"seq">>, ChangeProp),
-            couch_httpd:send_chunk(Resp, ["data: ", ?JSON_ENCODE(Change),
-                              "\n", "id: ", ?JSON_ENCODE(Seq),
-                              "\n\n"]);
-        ({change, Change, _}, "continuous") ->
-            couch_httpd:send_chunk(Resp, [?JSON_ENCODE(Change) | "\n"]);
-        ({change, Change, Prepend}, _) ->
-            couch_httpd:send_chunk(Resp, [Prepend, ?JSON_ENCODE(Change)]);
-        (start, "eventsource") ->
-            ok;
-        (start, "continuous") ->
-            ok;
-        (start, _) ->
-            couch_httpd:send_chunk(Resp, "{\"results\":[\n");
-        ({stop, _EndSeq}, "eventsource") ->
-            couch_httpd:end_json_response(Resp);
-        ({stop, EndSeq}, "continuous") ->
-            couch_httpd:send_chunk(
-                Resp,
-                [?JSON_ENCODE({[{<<"last_seq">>, EndSeq}]}) | "\n"]
-            ),
-            couch_httpd:end_json_response(Resp);
-        ({stop, EndSeq}, _) ->
-            couch_httpd:send_chunk(
-                Resp,
-                io_lib:format("\n],\n\"last_seq\":~w}\n", [EndSeq])
-            ),
-            couch_httpd:end_json_response(Resp);
-        (timeout, _) ->
-            couch_httpd:send_chunk(Resp, "\n")
-        end
-    end,
-    ChangesArgs = parse_changes_query(Req, Db),
-    ChangesFun = handle_changes(ChangesArgs, Req, Db),
-    WrapperFun = case ChangesArgs#changes_args.feed of
-    "normal" ->
-        {ok, Info} = couch_db:get_db_info(Db),
-        CurrentEtag = couch_httpd:make_etag(Info),
-        fun(FeedChangesFun) ->
-            couch_httpd:etag_respond(
-                Req,
-                CurrentEtag,
-                fun() ->
-                    {ok, Resp} = couch_httpd:start_json_response(
-                         Req, 200, [{"ETag", CurrentEtag}]
-                    ),
-                    FeedChangesFun(MakeCallback(Resp))
-                end
-            )
-        end;
-    "eventsource" ->
-        Headers = [
-            {"Content-Type", "text/event-stream"},
-            {"Cache-Control", "no-cache"}
-        ],
-        {ok, Resp} = couch_httpd:start_chunked_response(Req, 200, Headers),
-        fun(FeedChangesFun) ->
-            FeedChangesFun(MakeCallback(Resp))
-        end;
-    _ ->
-        % "longpoll" or "continuous"
-        {ok, Resp} = couch_httpd:start_json_response(Req, 200),
-        fun(FeedChangesFun) ->
-            FeedChangesFun(MakeCallback(Resp))
-        end
-    end,
-    couch_stats_collector:increment(
-        {httpd, clients_requesting_changes}
-    ),
-    try
-        WrapperFun(ChangesFun)
-    after
-    couch_stats_collector:decrement(
-        {httpd, clients_requesting_changes}
-    )
-    end.
-
-
-handle_changes(ChangesArgs, Req, Db) ->
-
-    case ChangesArgs#changes_args.filter of
-        "_view" ->
-            handle_view_changes(ChangesArgs, Req, Db);
-        _ ->
-            couch_changes:handle_changes(ChangesArgs, Req, Db)
-    end.
-
-%% wrapper around couch_mrview_changes.
-%% This wrapper mimic couch_changes:handle_changes/3 and return a
-%% Changefun that can be used by the handle_changes_req function. Also
-%% while couch_mrview_changes:handle_changes/6 is returning tha view
-%% changes this function return docs corresponding to the changes
-%% instead so it can be used to replace the _view filter.
-handle_view_changes(ChangesArgs, Req, Db) ->
-    %% parse view parameter
-    {DDocId, VName} = parse_view_param(Req),
-
-    %% get view options
-    {Query, NoIndex} = case Req of
-        {json_req, {Props}} ->
-            {Q} = couch_util:get_value(<<"query">>, Props, {[]}),
-            NoIndex1 = (couch_util:get_value(<<"use_index">>, Q,
-                                            <<"yes">>) =:= <<"no">>),
-            {Q, NoIndex1};
-        _ ->
-            NoIndex1 = couch_httpd:qs_value(Req, "use_index", "yes") =:= "no",
-            {couch_httpd:qs(Req), NoIndex1}
-    end,
-    ViewOptions = parse_view_options(Query, []),
-
-    {ok, Infos} = couch_mrview:get_info(Db, DDocId),
-    IsIndexed = lists:member(<<"seq_indexed">>,
-                             proplists:get_value(update_options, Infos,
-                                                 [])),
-
-    case {IsIndexed, NoIndex} of
-        {true, false} ->
-            handle_view_changes(Db, DDocId, VName, ViewOptions, ChangesArgs,
-                                Req);
-        {true, true} when ViewOptions /= [] ->
-            ?LOG_ERROR("Tried to filter a non sequence indexed view~n",[]),
-            throw({bad_request, seqs_not_indexed});
-        {false, _} when ViewOptions /= [] ->
-            ?LOG_ERROR("Tried to filter a non sequence indexed view~n",[]),
-            throw({bad_request, seqs_not_indexed});
-        {_, _} ->
-            %% old method we are getting changes using the btree instead
-            %% which is not efficient, log it
-            ?LOG_WARN("Filter without using a seq_indexed view.~n", []),
-            couch_changes:handle_changes(ChangesArgs, Req, Db)
-    end.
-
-handle_view_changes(#db{name=DbName}=Db0, DDocId, VName, ViewOptions,
-                    ChangesArgs, Req) ->
-    #changes_args{
-        feed = ResponseType,
-        since = Since,
-        db_open_options = DbOptions} = ChangesArgs,
-
-    Refresh = refresh_option(Req),
-
-    Options0 = [{since, Since},
-                {view_options, ViewOptions},
-                {refresh, Refresh}],
-    Options = case ResponseType of
-        "continuous" -> [stream | Options0];
-        "eventsource" -> [stream | Options0];
-        "longpoll" -> [{stream, once} | Options0];
-        _ -> Options0
-    end,
-
-    %% reopen the db with the db options given to the changes args
-    couch_db:close(Db0),
-    DbOptions1 = [{user_ctx, Db0#db.user_ctx} | DbOptions],
-    {ok, Db} = couch_db:open(DbName, DbOptions1),
-
-
-    %% initialise the changes fun
-    ChangesFun = fun(Callback) ->
-            Callback(start, ResponseType),
-
-            Acc0 = {"", 0, Db, Callback, ChangesArgs},
-            couch_mrview_changes:handle_changes(DbName, DDocId, VName,
-                                               fun view_changes_cb/2,
-                                               Acc0, Options)
-    end,
-    ChangesFun.
-
-
-view_changes_cb(stop, {LastSeq, {_, _, _, Callback, Args}}) ->
-    Callback({stop, LastSeq}, Args#changes_args.feed);
-
-view_changes_cb(heartbeat, {_, _, _, Callback, Args}=Acc) ->
-    Callback(timeout, Args#changes_args.feed),
-    {ok, Acc};
-view_changes_cb({{Seq, _Key, DocId}, Val},
-                {Prepend, OldLimit, Db0, Callback, Args}=Acc) ->
-
-    %% is the key removed from the index?
-    Removed = case Val of
-        {[{<<"_removed">>, true}]} -> true;
-        _ -> false
-    end,
-
-    #changes_args{
-        feed = ResponseType,
-        limit = Limit} = Args,
-
-    %% if the doc sequence is > to the one in the db record, reopen the
-    %% database since it means we don't have the latest db value.
-    Db = case Db0#db.update_seq >= Seq of
-        true -> Db0;
-        false ->
-            {ok, Db1} = couch_db:reopen_db(Db0),
-            Db1
-    end,
-
-    case couch_db:get_doc_info(Db, DocId) of
-        {ok, DocInfo} ->
-            %% get change row
-            {Deleted, ChangeRow} = view_change_row(Db, DocInfo, Args),
-
-            case Removed of
-                true when Deleted /= true ->
-                    %% the key has been removed from the view but the
-                    %% document hasn't been deleted so ignore it.
-                    {ok, Acc};
-                _ ->
-                    %% emit change row
-                    Callback({change, ChangeRow, Prepend}, ResponseType),
-
-                    %% if we achieved the limit, stop here, else continue.
-                    NewLimit = OldLimit + 1,
-                    if Limit > NewLimit ->
-                            {ok, {<<",\n">>, NewLimit, Db, Callback, Args}};
-                        true ->
-                            {stop, {<<"">>, NewLimit, Db, Callback, Args}}
-                    end
-            end;
-        {error, not_found} ->
-            %% doc not found, continue
-            {ok, Acc};
-        Error ->
-            throw(Error)
-    end.
-
-
-view_change_row(Db, DocInfo, Args) ->
-    #doc_info{id = Id, high_seq = Seq, revs = Revs} = DocInfo,
-    [#rev_info{rev=Rev, deleted=Del} | _] = Revs,
-
-    #changes_args{style=Style,
-                  include_docs=InDoc,
-                  doc_options = DocOpts,
-                  conflicts=Conflicts}=Args,
-
-    Changes = case Style of
-        main_only ->
-            [{[{<<"rev">>, couch_doc:rev_to_str(Rev)}]}];
-        all_docs ->
-            [{[{<<"rev">>, couch_doc:rev_to_str(R)}]}
-                || #rev_info{rev=R} <- Revs]
-    end,
-
-    {Del, {[{<<"seq">>, Seq}, {<<"id">>, Id}, {<<"changes">>, Changes}] ++
-     deleted_item(Del) ++ case InDoc of
-            true ->
-                Opts = case Conflicts of
-                    true -> [deleted, conflicts];
-                    false -> [deleted]
-                end,
-                Doc = couch_index_util:load_doc(Db, DocInfo, Opts),
-                case Doc of
-                    null ->
-                        [{doc, null}];
-                    _ ->
-                        [{doc, couch_doc:to_json_obj(Doc, DocOpts)}]
-                end;
-            false ->
-                []
-    end}}.
-
-parse_changes_query(Req, Db) ->
-    ChangesArgs = lists:foldl(fun({Key, Value}, Args) ->
-        case {string:to_lower(Key), Value} of
-        {"feed", _} ->
-            Args#changes_args{feed=Value};
-        {"descending", "true"} ->
-            Args#changes_args{dir=rev};
-        {"since", "now"} ->
-            UpdateSeq = couch_util:with_db(Db#db.name, fun(WDb) ->
-                                        couch_db:get_update_seq(WDb)
-                                end),
-            Args#changes_args{since=UpdateSeq};
-        {"since", _} ->
-            Args#changes_args{since=list_to_integer(Value)};
-        {"last-event-id", _} ->
-            Args#changes_args{since=list_to_integer(Value)};
-        {"limit", _} ->
-            Args#changes_args{limit=list_to_integer(Value)};
-        {"style", _} ->
-            Args#changes_args{style=list_to_existing_atom(Value)};
-        {"heartbeat", "true"} ->
-            Args#changes_args{heartbeat=true};
-        {"heartbeat", _} ->
-            Args#changes_args{heartbeat=list_to_integer(Value)};
-        {"timeout", _} ->
-            Args#changes_args{timeout=list_to_integer(Value)};
-        {"include_docs", "true"} ->
-            Args#changes_args{include_docs=true};
-        {"attachments", "true"} ->
-            Opts = Args#changes_args.doc_options,
-            Args#changes_args{doc_options=[attachments|Opts]};
-        {"att_encoding_info", "true"} ->
-            Opts = Args#changes_args.doc_options,
-            Args#changes_args{doc_options=[att_encoding_info|Opts]};
-        {"conflicts", "true"} ->
-            Args#changes_args{conflicts=true};
-        {"filter", _} ->
-            Args#changes_args{filter=Value};
-        _Else -> % unknown key value pair, ignore.
-            Args
-        end
-    end, #changes_args{}, couch_httpd:qs(Req)),
-    %% if it's an EventSource request with a Last-event-ID header
-    %% that should override the `since` query string, since it's
-    %% probably the browser reconnecting.
-    case ChangesArgs#changes_args.feed of
-        "eventsource" ->
-            case couch_httpd:header_value(Req, "last-event-id") of
-                undefined ->
-                    ChangesArgs;
-                Value ->
-                    ChangesArgs#changes_args{since=list_to_integer(Value)}
-            end;
-        _ ->
-            ChangesArgs
-    end.
-
-parse_view_param({json_req, {Props}}) ->
-    {Query} = couch_util:get_value(<<"query">>, Props),
-    parse_view_param1(couch_util:get_value(<<"view">>, Query, <<"">>));
-parse_view_param(Req) ->
-    parse_view_param1(list_to_binary(couch_httpd:qs_value(Req, "view", ""))).
-
-parse_view_param1(ViewParam) ->
-    case re:split(ViewParam, <<"/">>) of
-        [DName, ViewName] ->
-            {<< "_design/", DName/binary >>, ViewName};
-        _ ->
-            throw({bad_request, "Invalid `view` parameter."})
-    end.
-
-parse_view_options([], Acc) ->
-    Acc;
-parse_view_options([{K, V} | Rest], Acc) ->
-    Acc1 = case couch_util:to_binary(K) of
-        <<"reduce">> ->
-            [{reduce, couch_mrview_http:parse_boolean(V)}];
-        <<"key">> ->
-            V1 = parse_json(V),
-            [{start_key, V1}, {end_key, V1} | Acc];
-        <<"keys">> ->
-            [{keys, parse_json(V)} | Acc];
-        <<"startkey">> ->
-            [{start_key, parse_json(V)} | Acc];
-        <<"start_key">> ->
-            [{start_key, parse_json(V)} | Acc];
-        <<"startkey_docid">> ->
-            [{start_key_docid, couch_util:to_binary(V)} | Acc];
-        <<"start_key_docid">> ->
-            [{start_key_docid, couch_util:to_binary(V)} | Acc];
-        <<"endkey">> ->
-            [{end_key, parse_json(V)} | Acc];
-        <<"end_key">> ->
-            [{end_key, parse_json(V)} | Acc];
-        <<"endkey_docid">> ->
-            [{start_key_docid, couch_util:to_binary(V)} | Acc];
-        <<"end_key_docid">> ->
-            [{start_key_docid, couch_util:to_binary(V)} | Acc];
-        <<"limit">> ->
-            [{limit, couch_mrview_http:parse_pos_int(V)} | Acc];
-        <<"count">> ->
-            throw({query_parse_error, <<"QS param `count` is not `limit`">>});
-        <<"stale">> when V =:= <<"ok">> orelse V =:= "ok" ->
-            [{stale, ok} | Acc];
-        <<"stale">> when V =:= <<"update_after">> orelse V =:= "update_after" ->
-            [{stale, update_after} | Acc];
-        <<"stale">> ->
-            throw({query_parse_error, <<"Invalid value for `stale`.">>});
-        <<"descending">> ->
-            case couch_mrview_http:parse_boolean(V) of
-                true ->
-                    [{direction, rev} | Acc];
-                _ ->
-                    [{direction, fwd} | Acc]
-            end;
-        <<"skip">> ->
-            [{skip, couch_mrview_http:parse_pos_int(V)} | Acc];
-        <<"group">> ->
-            case couch_mrview_http:parse_booolean(V) of
-                true ->
-                    [{group_level, exact} | Acc];
-                _ ->
-                    [{group_level, 0} | Acc]
-            end;
-        <<"group_level">> ->
-            [{group_level, couch_mrview_http:parse_pos_int(V)} | Acc];
-        <<"inclusive_end">> ->
-            [{inclusive_end, couch_mrview_http:parse_boolean(V)}];
-        _ ->
-            Acc
-    end,
-    parse_view_options(Rest, Acc1).
-
-refresh_option({json_req, {Props}}) ->
-    {Query} = couch_util:get_value(<<"query">>, Props),
-    couch_util:get_value(<<"refresh">>, Query, true);
-refresh_option(Req) ->
-    case couch_httpd:qs_value(Req, "refresh", "true") of
-        "false" -> false;
-        _ -> true
-    end.
-
-parse_json(V) when is_list(V) ->
-    ?JSON_DECODE(V);
-parse_json(V) ->
-    V.
-
-deleted_item(true) -> [{<<"deleted">>, true}];
-deleted_item(_) -> [].


[57/57] [abbrv] couchdb commit: updated refs/heads/1994-merge-rcouch-multi-repo to b19d055

Posted by be...@apache.org.
move to multiple repository

Use multiple repository instead of having applications in the apps/
folder. For now just take the easy way by fetching apps in deps/ folder
so I can still launch the tests. The application node_package from basho
is also still in use and should be removed in the next step.


Project: http://git-wip-us.apache.org/repos/asf/couchdb/repo
Commit: http://git-wip-us.apache.org/repos/asf/couchdb/commit/b19d0557
Tree: http://git-wip-us.apache.org/repos/asf/couchdb/tree/b19d0557
Diff: http://git-wip-us.apache.org/repos/asf/couchdb/diff/b19d0557

Branch: refs/heads/1994-merge-rcouch-multi-repo
Commit: b19d0557638df05cfbee945e998c31beea507a88
Parents: a3d75ba
Author: Benoit Chesneau <bc...@gmail.com>
Authored: Thu Feb 13 19:08:46 2014 +0100
Committer: Benoit Chesneau <bc...@gmail.com>
Committed: Thu Feb 13 19:08:46 2014 +0100

----------------------------------------------------------------------
 Makefile                | 10 +++++-----
 rebar.config            |  6 +++---
 test/etap/test_util.erl |  2 +-
 3 files changed, 9 insertions(+), 9 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/couchdb/blob/b19d0557/Makefile
----------------------------------------------------------------------
diff --git a/Makefile b/Makefile
index 117ff9c..a88b9ec 100644
--- a/Makefile
+++ b/Makefile
@@ -119,13 +119,13 @@ export ERL_LIBS
 
 test: testbuild
 	prove $(COUCHDB_ETAP_DIR)/*.t
-	prove $(BASE_DIR)/apps/couch_mrview/test/*.t
-	prove $(BASE_DIR)/apps/couch_replicator/test/*.t
+	prove $(BASE_DIR)/deps/couch_mrview/test/*.t
+	prove $(BASE_DIR)/deps/couch_replicator/test/*.t
 
 verbose-test: testbuild
 	prove -v $(COUCHDB_ETAP_DIR)/*.t
-	prove -v $(BASE_DIR)/apps/couch_mrview/test/*.t
-	prove -v $(BASE_DIR)/apps/couch_replicator/test/*.t
+	prove -v $(BASE_DIR)/deps/couch_mrview/test/*.t
+	prove -v $(BASE_DIR)/deps/couch_replicator/test/*.t
 
 testjs: testbuild
 	$(ESCRIPT) $(BASE_DIR)/test/javascript/test_js.escript
@@ -141,7 +141,7 @@ testbuild: testclean
 	mkdir -p $(BASE_DIR)/test/out/bin
 	mkdir -p $(BASE_DIR)/test/out/share
 	mkdir -p $(BASE_DIR)/test/out/log
-	cp $(BASE_DIR)/apps/couch/priv/couchjs $(BASE_DIR)/test/out/bin/
+	cp $(BASE_DIR)/deps/couch/priv/couchjs $(BASE_DIR)/test/out/bin/
 	cp -r $(BASE_DIR)/share/server $(BASE_DIR)/test/out/share
 	cp -r $(BASE_DIR)/share/www $(BASE_DIR)/test/out/share
 	cp $(BASE_DIR)/etc/couchdb/local.ini $(BASE_DIR)/test/out/

http://git-wip-us.apache.org/repos/asf/couchdb/blob/b19d0557/rebar.config
----------------------------------------------------------------------
diff --git a/rebar.config b/rebar.config
index 232b6ff..4c956ab 100644
--- a/rebar.config
+++ b/rebar.config
@@ -36,7 +36,7 @@
     %% json module, encode/decode module
     {jiffy, ".*",
         {git, "http://git-wip-us.apache.org/repos/asf/couchdb-jiffy.git",
-         {branch, "import"}},
+         {branch, "import"}}},
 
     %% lager logging module
     {lager, ".*",
@@ -71,11 +71,11 @@
 
      {couch_plugins, ".*",
       {git, "http://git-wip-us.apache.org/repos/asf/couchdb-couch-plugins.git",
-       {branch, "import"}}},
+       {branch, "1994-merge-rcouch"}}},
 
      {couch_dbupdates, ".*",
       {git, "http://git-wip-us.apache.org/repos/asf/couchdb-couch-dbupdates.git",
-       {branch, "import"}}}
+       {branch, "1994-merge-rcouch"}}}
 
 ]}.
 

http://git-wip-us.apache.org/repos/asf/couchdb/blob/b19d0557/test/etap/test_util.erl
----------------------------------------------------------------------
diff --git a/test/etap/test_util.erl b/test/etap/test_util.erl
index 9208335..caad0b4 100644
--- a/test/etap/test_util.erl
+++ b/test/etap/test_util.erl
@@ -25,7 +25,7 @@ builddir() ->
     filename:absname(filename:join([Current, "..", ".."])).
 
 srcdir() ->
-    filename:join([builddir(), "apps"]).
+    filename:join([builddir(), "deps"]).
 
 depsdir() ->
     filename:join([builddir(), "deps"]).


[16/57] [abbrv] remove couch_collate

Posted by be...@apache.org.
http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/ucoleitr.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/ucoleitr.h b/apps/couch_collate/platform/osx/icu/unicode/ucoleitr.h
deleted file mode 100644
index 9c951a9..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/ucoleitr.h
+++ /dev/null
@@ -1,315 +0,0 @@
-/*
-*******************************************************************************
-*   Copyright (C) 2001-2008, International Business Machines
-*   Corporation and others.  All Rights Reserved.
-*******************************************************************************
-*
-* File ucoleitr.cpp
-*
-* Modification History:
-*
-* Date        Name        Description
-* 02/15/2001  synwee      Modified all methods to process its own function 
-*                         instead of calling the equivalent c++ api (coleitr.h)
-*******************************************************************************/
-
-#ifndef UCOLEITR_H
-#define UCOLEITR_H
-
-#include "unicode/utypes.h"
-
-#if !UCONFIG_NO_COLLATION
-
-/**  
- * This indicates an error has occured during processing or if no more CEs is 
- * to be returned.
- * @stable ICU 2.0
- */
-#define UCOL_NULLORDER        ((int32_t)0xFFFFFFFF)
-
-/**  
- * This indicates an error has occured during processing or there are no more CEs 
- * to be returned.
- *
- * @internal
- */
-#define UCOL_PROCESSED_NULLORDER        ((int64_t)U_INT64_MAX)
-
-#include "unicode/ucol.h"
-
-/** 
- * The UCollationElements struct.
- * For usage in C programs.
- * @stable ICU 2.0
- */
-typedef struct UCollationElements UCollationElements;
-
-/**
- * \file
- * \brief C API: UCollationElements
- *
- * The UCollationElements API is used as an iterator to walk through each 
- * character of an international string. Use the iterator to return the
- * ordering priority of the positioned character. The ordering priority of a 
- * character, which we refer to as a key, defines how a character is collated 
- * in the given collation object.
- * For example, consider the following in Spanish:
- * <pre>
- * .       "ca" -> the first key is key('c') and second key is key('a').
- * .       "cha" -> the first key is key('ch') and second key is key('a').
- * </pre>
- * And in German,
- * <pre>
- * .       "<ae ligature>b"-> the first key is key('a'), the second key is key('e'), and
- * .       the third key is key('b').
- * </pre>
- * <p>Example of the iterator usage: (without error checking)
- * <pre>
- * .  void CollationElementIterator_Example()
- * .  {
- * .      UChar *s;
- * .      t_int32 order, primaryOrder;
- * .      UCollationElements *c;
- * .      UCollatorOld *coll;
- * .      UErrorCode success = U_ZERO_ERROR;
- * .      s=(UChar*)malloc(sizeof(UChar) * (strlen("This is a test")+1) );
- * .      u_uastrcpy(s, "This is a test");
- * .      coll = ucol_open(NULL, &success);
- * .      c = ucol_openElements(coll, str, u_strlen(str), &status);
- * .      order = ucol_next(c, &success);
- * .      ucol_reset(c);
- * .      order = ucol_prev(c, &success);
- * .      free(s);
- * .      ucol_close(coll);
- * .      ucol_closeElements(c);
- * .  }
- * </pre>
- * <p>
- * ucol_next() returns the collation order of the next.
- * ucol_prev() returns the collation order of the previous character.
- * The Collation Element Iterator moves only in one direction between calls to
- * ucol_reset. That is, ucol_next() and ucol_prev can not be inter-used. 
- * Whenever ucol_prev is to be called after ucol_next() or vice versa, 
- * ucol_reset has to be called first to reset the status, shifting pointers to 
- * either the end or the start of the string. Hence at the next call of 
- * ucol_prev or ucol_next, the first or last collation order will be returned. 
- * If a change of direction is done without a ucol_reset, the result is 
- * undefined.
- * The result of a forward iterate (ucol_next) and reversed result of the  
- * backward iterate (ucol_prev) on the same string are equivalent, if 
- * collation orders with the value UCOL_IGNORABLE are ignored.
- * Character based on the comparison level of the collator.  A collation order 
- * consists of primary order, secondary order and tertiary order.  The data 
- * type of the collation order is <strong>t_int32</strong>. 
- *
- * @see UCollator
- */
-
-/**
- * Open the collation elements for a string.
- *
- * @param coll The collator containing the desired collation rules.
- * @param text The text to iterate over.
- * @param textLength The number of characters in text, or -1 if null-terminated
- * @param status A pointer to an UErrorCode to receive any errors.
- * @return a struct containing collation element information
- * @stable ICU 2.0
- */
-U_STABLE UCollationElements* U_EXPORT2 
-ucol_openElements(const UCollator  *coll,
-                  const UChar      *text,
-                        int32_t    textLength,
-                        UErrorCode *status);
-
-/**
- * get a hash code for a key... Not very useful!
- * @param key    the given key.
- * @param length the size of the key array.
- * @return       the hash code.
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2 
-ucol_keyHashCode(const uint8_t* key, int32_t length);
-
-/**
- * Close a UCollationElements.
- * Once closed, a UCollationElements may no longer be used.
- * @param elems The UCollationElements to close.
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2 
-ucol_closeElements(UCollationElements *elems);
-
-/**
- * Reset the collation elements to their initial state.
- * This will move the 'cursor' to the beginning of the text.
- * Property settings for collation will be reset to the current status.
- * @param elems The UCollationElements to reset.
- * @see ucol_next
- * @see ucol_previous
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2 
-ucol_reset(UCollationElements *elems);
-
-/**
- * Get the ordering priority of the next collation element in the text.
- * A single character may contain more than one collation element.
- * @param elems The UCollationElements containing the text.
- * @param status A pointer to an UErrorCode to receive any errors.
- * @return The next collation elements ordering, otherwise returns NULLORDER 
- *         if an error has occured or if the end of string has been reached
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2 
-ucol_next(UCollationElements *elems, UErrorCode *status);
-
-/**
- * Get the ordering priority of the previous collation element in the text.
- * A single character may contain more than one collation element.
- * Note that internally a stack is used to store buffered collation elements. 
- * It is very rare that the stack will overflow, however if such a case is 
- * encountered, the problem can be solved by increasing the size 
- * UCOL_EXPAND_CE_BUFFER_SIZE in ucol_imp.h.
- * @param elems The UCollationElements containing the text.
- * @param status A pointer to an UErrorCode to receive any errors. Noteably 
- *               a U_BUFFER_OVERFLOW_ERROR is returned if the internal stack
- *               buffer has been exhausted.
- * @return The previous collation elements ordering, otherwise returns 
- *         NULLORDER if an error has occured or if the start of string has 
- *         been reached.
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2 
-ucol_previous(UCollationElements *elems, UErrorCode *status);
-
-/**
- * Get the processed ordering priority of the next collation element in the text.
- * A single character may contain more than one collation element.
- *
- * @param elems The UCollationElements containing the text.
- * @param ixLow a pointer to an int32_t to receive the iterator index before fetching the CE.
- * @param ixHigh a pointer to an int32_t to receive the iterator index after fetching the CE.
- * @param status A pointer to an UErrorCode to receive any errors.
- * @return The next collation elements ordering, otherwise returns UCOL_PROCESSED_NULLORDER 
- *         if an error has occured or if the end of string has been reached
- *
- * @internal
- */
-U_INTERNAL int64_t U_EXPORT2
-ucol_nextProcessed(UCollationElements *elems, int32_t *ixLow, int32_t *ixHigh, UErrorCode *status);
-
-/**
- * Get the processed ordering priority of the previous collation element in the text.
- * A single character may contain more than one collation element.
- * Note that internally a stack is used to store buffered collation elements. 
- * It is very rare that the stack will overflow, however if such a case is 
- * encountered, the problem can be solved by increasing the size 
- * UCOL_EXPAND_CE_BUFFER_SIZE in ucol_imp.h.
- *
- * @param elems The UCollationElements containing the text.
- * @param ixLow A pointer to an int32_t to receive the iterator index after fetching the CE
- * @param ixHigh A pointer to an int32_t to receiver the iterator index before fetching the CE
- * @param status A pointer to an UErrorCode to receive any errors. Noteably 
- *               a U_BUFFER_OVERFLOW_ERROR is returned if the internal stack
- *               buffer has been exhausted.
- * @return The previous collation elements ordering, otherwise returns 
- *         UCOL_PROCESSED_NULLORDER if an error has occured or if the start of
- *         string has been reached.
- *
- * @internal
- */
-U_INTERNAL int64_t U_EXPORT2
-ucol_previousProcessed(UCollationElements *elems, int32_t *ixLow, int32_t *ixHigh, UErrorCode *status);
-
-/**
- * Get the maximum length of any expansion sequences that end with the 
- * specified comparison order.
- * This is useful for .... ?
- * @param elems The UCollationElements containing the text.
- * @param order A collation order returned by previous or next.
- * @return maximum size of the expansion sequences ending with the collation 
- *         element or 1 if collation element does not occur at the end of any 
- *         expansion sequence
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2 
-ucol_getMaxExpansion(const UCollationElements *elems, int32_t order);
-
-/**
- * Set the text containing the collation elements.
- * Property settings for collation will remain the same.
- * In order to reset the iterator to the current collation property settings,
- * the API reset() has to be called.
- * @param elems The UCollationElements to set.
- * @param text The source text containing the collation elements.
- * @param textLength The length of text, or -1 if null-terminated.
- * @param status A pointer to an UErrorCode to receive any errors.
- * @see ucol_getText
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2 
-ucol_setText(      UCollationElements *elems, 
-             const UChar              *text,
-                   int32_t            textLength,
-                   UErrorCode         *status);
-
-/**
- * Get the offset of the current source character.
- * This is an offset into the text of the character containing the current
- * collation elements.
- * @param elems The UCollationElements to query.
- * @return The offset of the current source character.
- * @see ucol_setOffset
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2 
-ucol_getOffset(const UCollationElements *elems);
-
-/**
- * Set the offset of the current source character.
- * This is an offset into the text of the character to be processed.
- * Property settings for collation will remain the same.
- * In order to reset the iterator to the current collation property settings,
- * the API reset() has to be called.
- * @param elems The UCollationElements to set.
- * @param offset The desired character offset.
- * @param status A pointer to an UErrorCode to receive any errors.
- * @see ucol_getOffset
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2 
-ucol_setOffset(UCollationElements *elems,
-               int32_t        offset,
-               UErrorCode         *status);
-
-/**
-* Get the primary order of a collation order.
-* @param order the collation order
-* @return the primary order of a collation order.
-* @stable ICU 2.6
-*/
-U_STABLE int32_t U_EXPORT2
-ucol_primaryOrder (int32_t order); 
-
-/**
-* Get the secondary order of a collation order.
-* @param order the collation order
-* @return the secondary order of a collation order.
-* @stable ICU 2.6
-*/
-U_STABLE int32_t U_EXPORT2
-ucol_secondaryOrder (int32_t order); 
-
-/**
-* Get the tertiary order of a collation order.
-* @param order the collation order
-* @return the tertiary order of a collation order.
-* @stable ICU 2.6
-*/
-U_STABLE int32_t U_EXPORT2
-ucol_tertiaryOrder (int32_t order); 
-
-#endif /* #if !UCONFIG_NO_COLLATION */
-
-#endif

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/uconfig.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/uconfig.h b/apps/couch_collate/platform/osx/icu/unicode/uconfig.h
deleted file mode 100644
index 232bb04..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/uconfig.h
+++ /dev/null
@@ -1,228 +0,0 @@
-/*  
-**********************************************************************
-*   Copyright (C) 2002-2008, International Business Machines
-*   Corporation and others.  All Rights Reserved.
-**********************************************************************
-*   file name:  uconfig.h
-*   encoding:   US-ASCII
-*   tab size:   8 (not used)
-*   indentation:4
-*
-*   created on: 2002sep19
-*   created by: Markus W. Scherer
-*/
-
-#ifndef __UCONFIG_H__
-#define __UCONFIG_H__
-
-
-/*!
- * \file
- * \brief Switches for excluding parts of ICU library code modules.
- *
- * Allows to build partial, smaller libraries for special purposes.
- * By default, all modules are built.
- * The switches are fairly coarse, controlling large modules.
- * Basic services cannot be turned off.
- *
- * Building with any of these options does not guarantee that the
- * ICU build process will completely work. It is recommended that
- * the ICU libraries and data be built using the normal build.
- * At that time you should remove the data used by those services.
- * After building the ICU data library, you should rebuild the ICU
- * libraries with these switches customized to your needs.
- *
- * @stable ICU 2.4
- */
-
-/**
- * \def UCONFIG_USE_LOCAL
- * If this switch is defined, ICU will attempt to load a header file named "uconfig_local.h"
- * prior to determining default settings for uconfig variables.
- * 
- * @internal ICU 4.0
- * 
- */
-#if defined(UCONFIG_USE_LOCAL)
-#include "uconfig_local.h"
-#endif
-
-/**
- * \def UCONFIG_ONLY_COLLATION
- * This switch turns off modules that are not needed for collation.
- *
- * It does not turn off legacy conversion because that is necessary
- * for ICU to work on EBCDIC platforms (for the default converter).
- * If you want "only collation" and do not build for EBCDIC,
- * then you can define UCONFIG_NO_LEGACY_CONVERSION 1 as well.
- *
- * @stable ICU 2.4
- */
-#ifndef UCONFIG_ONLY_COLLATION
-#   define UCONFIG_ONLY_COLLATION 0
-#endif
-
-#if UCONFIG_ONLY_COLLATION
-    /* common library */
-#   define UCONFIG_NO_BREAK_ITERATION 1
-#   define UCONFIG_NO_IDNA 1
-
-    /* i18n library */
-#   if UCONFIG_NO_COLLATION
-#       error Contradictory collation switches in uconfig.h.
-#   endif
-#   define UCONFIG_NO_FORMATTING 1
-#   define UCONFIG_NO_TRANSLITERATION 1
-#   define UCONFIG_NO_REGULAR_EXPRESSIONS 1
-#endif
-
-/* common library switches -------------------------------------------------- */
-
-/**
- * \def UCONFIG_NO_FILE_IO
- * This switch turns off all file access in the common library
- * where file access is only used for data loading.
- * ICU data must then be provided in the form of a data DLL (or with an
- * equivalent way to link to the data residing in an executable,
- * as in building a combined library with both the common library's code and
- * the data), or via udata_setCommonData().
- * Application data must be provided via udata_setAppData() or by using
- * "open" functions that take pointers to data, for example ucol_openBinary().
- *
- * File access is not used at all in the i18n library.
- *
- * File access cannot be turned off for the icuio library or for the ICU
- * test suites and ICU tools.
- *
- * @stable ICU 3.6
- */
-#ifndef UCONFIG_NO_FILE_IO
-#   define UCONFIG_NO_FILE_IO 0
-#endif
-
-/**
- * \def UCONFIG_NO_CONVERSION
- * ICU will not completely build with this switch turned on.
- * This switch turns off all converters.
- *
- * @stable ICU 3.2
- */
-#ifndef UCONFIG_NO_CONVERSION
-#   define UCONFIG_NO_CONVERSION 0
-#endif
-
-#if UCONFIG_NO_CONVERSION
-#   define UCONFIG_NO_LEGACY_CONVERSION 1
-#endif
-
-/**
- * \def UCONFIG_NO_LEGACY_CONVERSION
- * This switch turns off all converters except for
- * - Unicode charsets (UTF-7/8/16/32, CESU-8, SCSU, BOCU-1)
- * - US-ASCII
- * - ISO-8859-1
- *
- * Turning off legacy conversion is not possible on EBCDIC platforms
- * because they need ibm-37 or ibm-1047 default converters.
- *
- * @stable ICU 2.4
- */
-#ifndef UCONFIG_NO_LEGACY_CONVERSION
-#   define UCONFIG_NO_LEGACY_CONVERSION 0
-#endif
-
-/**
- * \def UCONFIG_NO_NORMALIZATION
- * This switch turns off normalization.
- * It implies turning off several other services as well, for example
- * collation and IDNA.
- *
- * @stable ICU 2.6
- */
-#ifndef UCONFIG_NO_NORMALIZATION
-#   define UCONFIG_NO_NORMALIZATION 0
-#elif UCONFIG_NO_NORMALIZATION
-    /* common library */
-#   define UCONFIG_NO_IDNA 1
-
-    /* i18n library */
-#   if UCONFIG_ONLY_COLLATION
-#       error Contradictory collation switches in uconfig.h.
-#   endif
-#   define UCONFIG_NO_COLLATION 1
-#   define UCONFIG_NO_TRANSLITERATION 1
-#endif
-
-/**
- * \def UCONFIG_NO_BREAK_ITERATION
- * This switch turns off break iteration.
- *
- * @stable ICU 2.4
- */
-#ifndef UCONFIG_NO_BREAK_ITERATION
-#   define UCONFIG_NO_BREAK_ITERATION 0
-#endif
-
-/**
- * \def UCONFIG_NO_IDNA
- * This switch turns off IDNA.
- *
- * @stable ICU 2.6
- */
-#ifndef UCONFIG_NO_IDNA
-#   define UCONFIG_NO_IDNA 0
-#endif
-
-/* i18n library switches ---------------------------------------------------- */
-
-/**
- * \def UCONFIG_NO_COLLATION
- * This switch turns off collation and collation-based string search.
- *
- * @stable ICU 2.4
- */
-#ifndef UCONFIG_NO_COLLATION
-#   define UCONFIG_NO_COLLATION 0
-#endif
-
-/**
- * \def UCONFIG_NO_FORMATTING
- * This switch turns off formatting and calendar/timezone services.
- *
- * @stable ICU 2.4
- */
-#ifndef UCONFIG_NO_FORMATTING
-#   define UCONFIG_NO_FORMATTING 0
-#endif
-
-/**
- * \def UCONFIG_NO_TRANSLITERATION
- * This switch turns off transliteration.
- *
- * @stable ICU 2.4
- */
-#ifndef UCONFIG_NO_TRANSLITERATION
-#   define UCONFIG_NO_TRANSLITERATION 0
-#endif
-
-/**
- * \def UCONFIG_NO_REGULAR_EXPRESSIONS
- * This switch turns off regular expressions.
- *
- * @stable ICU 2.4
- */
-#ifndef UCONFIG_NO_REGULAR_EXPRESSIONS
-#   define UCONFIG_NO_REGULAR_EXPRESSIONS 0
-#endif
-
-/**
- * \def UCONFIG_NO_SERVICE
- * This switch turns off service registration.
- *
- * @stable ICU 3.2
- */
-#ifndef UCONFIG_NO_SERVICE
-#   define UCONFIG_NO_SERVICE 1
-#endif
-
-#endif

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/ucsdet.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/ucsdet.h b/apps/couch_collate/platform/osx/icu/unicode/ucsdet.h
deleted file mode 100644
index 31f622c..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/ucsdet.h
+++ /dev/null
@@ -1,349 +0,0 @@
-/*
- **********************************************************************
- *   Copyright (C) 2005-2007, International Business Machines
- *   Corporation and others.  All Rights Reserved.
- **********************************************************************
- *   file name:  ucsdet.h
- *   encoding:   US-ASCII
- *   indentation:4
- *
- *   created on: 2005Aug04
- *   created by: Andy Heninger
- *
- *   ICU Character Set Detection, API for C
- *
- *   Draft version 18 Oct 2005
- *
- */
-
-#ifndef __UCSDET_H
-#define __UCSDET_H
-
-#include "unicode/utypes.h"
-
-#if !UCONFIG_NO_CONVERSION
-#include "unicode/uenum.h"
-
-/**
- * \file 
- * \brief C API: Charset Detection API
- *
- * This API provides a facility for detecting the
- * charset or encoding of character data in an unknown text format.
- * The input data can be from an array of bytes.
- * <p>
- * Character set detection is at best an imprecise operation.  The detection
- * process will attempt to identify the charset that best matches the characteristics
- * of the byte data, but the process is partly statistical in nature, and
- * the results can not be guaranteed to always be correct.
- * <p>
- * For best accuracy in charset detection, the input data should be primarily
- * in a single language, and a minimum of a few hundred bytes worth of plain text
- * in the language are needed.  The detection process will attempt to
- * ignore html or xml style markup that could otherwise obscure the content.
- */
- 
-
-struct UCharsetDetector;
-/**
-  * Structure representing a charset detector
-  * @stable ICU 3.6
-  */
-typedef struct UCharsetDetector UCharsetDetector;
-
-struct UCharsetMatch;
-/**
-  *  Opaque structure representing a match that was identified
-  *  from a charset detection operation.
-  *  @stable ICU 3.6
-  */
-typedef struct UCharsetMatch UCharsetMatch;
-
-/**
-  *  Open a charset detector.
-  *
-  *  @param status Any error conditions occurring during the open
-  *                operation are reported back in this variable.
-  *  @return the newly opened charset detector.
-  *  @stable ICU 3.6
-  */
-U_STABLE UCharsetDetector * U_EXPORT2
-ucsdet_open(UErrorCode   *status);
-
-/**
-  * Close a charset detector.  All storage and any other resources
-  *   owned by this charset detector will be released.  Failure to
-  *   close a charset detector when finished with it can result in
-  *   memory leaks in the application.
-  *
-  *  @param ucsd  The charset detector to be closed.
-  *  @stable ICU 3.6
-  */
-U_STABLE void U_EXPORT2
-ucsdet_close(UCharsetDetector *ucsd);
-
-/**
-  * Set the input byte data whose charset is to detected.
-  *
-  * Ownership of the input  text byte array remains with the caller.
-  * The input string must not be altered or deleted until the charset
-  * detector is either closed or reset to refer to different input text.
-  *
-  * @param ucsd   the charset detector to be used.
-  * @param textIn the input text of unknown encoding.   .
-  * @param len    the length of the input text, or -1 if the text
-  *               is NUL terminated.
-  * @param status any error conditions are reported back in this variable.
-  *
-  * @stable ICU 3.6
-  */
-U_STABLE void U_EXPORT2
-ucsdet_setText(UCharsetDetector *ucsd, const char *textIn, int32_t len, UErrorCode *status);
-
-
-/** Set the declared encoding for charset detection.
- *  The declared encoding of an input text is an encoding obtained
- *  by the user from an http header or xml declaration or similar source that
- *  can be provided as an additional hint to the charset detector.
- *
- *  How and whether the declared encoding will be used during the
- *  detection process is TBD.
- *
- * @param ucsd      the charset detector to be used.
- * @param encoding  an encoding for the current data obtained from
- *                  a header or declaration or other source outside
- *                  of the byte data itself.
- * @param length    the length of the encoding name, or -1 if the name string
- *                  is NUL terminated.
- * @param status    any error conditions are reported back in this variable.
- *
- * @stable ICU 3.6
- */
-U_STABLE void U_EXPORT2
-ucsdet_setDeclaredEncoding(UCharsetDetector *ucsd, const char *encoding, int32_t length, UErrorCode *status);
-
-
-/**
- * Return the charset that best matches the supplied input data.
- * 
- * Note though, that because the detection 
- * only looks at the start of the input data,
- * there is a possibility that the returned charset will fail to handle
- * the full set of input data.
- * <p>
- * The returned UCharsetMatch object is owned by the UCharsetDetector.
- * It will remain valid until the detector input is reset, or until
- * the detector is closed.
- * <p>
- * The function will fail if
- *  <ul>
- *    <li>no charset appears to match the data.</li>
- *    <li>no input text has been provided</li>
- *  </ul>
- *
- * @param ucsd      the charset detector to be used.
- * @param status    any error conditions are reported back in this variable.
- * @return          a UCharsetMatch  representing the best matching charset,
- *                  or NULL if no charset matches the byte data.
- *
- * @stable ICU 3.6
- */
-U_STABLE const UCharsetMatch * U_EXPORT2
-ucsdet_detect(UCharsetDetector *ucsd, UErrorCode *status);
-    
-
-/**
- *  Find all charset matches that appear to be consistent with the input,
- *  returning an array of results.  The results are ordered with the
- *  best quality match first.
- *
- *  Because the detection only looks at a limited amount of the
- *  input byte data, some of the returned charsets may fail to handle
- *  the all of input data.
- *  <p>
- *  The returned UCharsetMatch objects are owned by the UCharsetDetector.
- *  They will remain valid until the detector is closed or modified
- *  
- * <p>
- * Return an error if 
- *  <ul>
- *    <li>no charsets appear to match the input data.</li>
- *    <li>no input text has been provided</li>
- *  </ul>
- * 
- * @param ucsd          the charset detector to be used.
- * @param matchesFound  pointer to a variable that will be set to the
- *                      number of charsets identified that are consistent with
- *                      the input data.  Output only.
- * @param status        any error conditions are reported back in this variable.
- * @return              A pointer to an array of pointers to UCharSetMatch objects.
- *                      This array, and the UCharSetMatch instances to which it refers,
- *                      are owned by the UCharsetDetector, and will remain valid until
- *                      the detector is closed or modified.
- * @stable ICU 3.6
- */
-U_STABLE const UCharsetMatch ** U_EXPORT2
-ucsdet_detectAll(UCharsetDetector *ucsd, int32_t *matchesFound, UErrorCode *status);
-
-
-
-/**
- *  Get the name of the charset represented by a UCharsetMatch.
- *
- *  The storage for the returned name string is owned by the
- *  UCharsetMatch, and will remain valid while the UCharsetMatch
- *  is valid.
- *
- *  The name returned is suitable for use with the ICU conversion APIs.
- *
- *  @param ucsm    The charset match object.
- *  @param status  Any error conditions are reported back in this variable.
- *  @return        The name of the matching charset.
- *
- *  @stable ICU 3.6
- */
-U_STABLE const char * U_EXPORT2
-ucsdet_getName(const UCharsetMatch *ucsm, UErrorCode *status);
-
-/**
- *  Get a confidence number for the quality of the match of the byte
- *  data with the charset.  Confidence numbers range from zero to 100,
- *  with 100 representing complete confidence and zero representing
- *  no confidence.
- *
- *  The confidence values are somewhat arbitrary.  They define an
- *  an ordering within the results for any single detection operation
- *  but are not generally comparable between the results for different input.
- *
- *  A confidence value of ten does have a general meaning - it is used
- *  for charsets that can represent the input data, but for which there
- *  is no other indication that suggests that the charset is the correct one.
- *  Pure 7 bit ASCII data, for example, is compatible with a
- *  great many charsets, most of which will appear as possible matches
- *  with a confidence of 10.
- *
- *  @param ucsm    The charset match object.
- *  @param status  Any error conditions are reported back in this variable.
- *  @return        A confidence number for the charset match.
- *
- *  @stable ICU 3.6
- */
-U_STABLE int32_t U_EXPORT2
-ucsdet_getConfidence(const UCharsetMatch *ucsm, UErrorCode *status);
-
-/**
- *  Get the RFC 3066 code for the language of the input data.
- *
- *  The Charset Detection service is intended primarily for detecting
- *  charsets, not language.  For some, but not all, charsets, a language is
- *  identified as a byproduct of the detection process, and that is what
- *  is returned by this function.
- *
- *  CAUTION:
- *    1.  Language information is not available for input data encoded in
- *        all charsets. In particular, no language is identified
- *        for UTF-8 input data.
- *
- *    2.  Closely related languages may sometimes be confused.
- *
- *  If more accurate language detection is required, a linguistic
- *  analysis package should be used.
- *
- *  The storage for the returned name string is owned by the
- *  UCharsetMatch, and will remain valid while the UCharsetMatch
- *  is valid.
- *
- *  @param ucsm    The charset match object.
- *  @param status  Any error conditions are reported back in this variable.
- *  @return        The RFC 3066 code for the language of the input data, or
- *                 an empty string if the language could not be determined.
- *
- *  @stable ICU 3.6
- */
-U_STABLE const char * U_EXPORT2
-ucsdet_getLanguage(const UCharsetMatch *ucsm, UErrorCode *status);
-
-
-/**
-  *  Get the entire input text as a UChar string, placing it into
-  *  a caller-supplied buffer.  A terminating
-  *  NUL character will be appended to the buffer if space is available.
-  *
-  *  The number of UChars in the output string, not including the terminating
-  *  NUL, is returned. 
-  *
-  *  If the supplied buffer is smaller than required to hold the output,
-  *  the contents of the buffer are undefined.  The full output string length
-  *  (in UChars) is returned as always, and can be used to allocate a buffer
-  *  of the correct size.
-  *
-  *
-  * @param ucsm    The charset match object.
-  * @param buf     A UChar buffer to be filled with the converted text data.
-  * @param cap     The capacity of the buffer in UChars.
-  * @param status  Any error conditions are reported back in this variable.
-  * @return        The number of UChars in the output string.
-  *
-  * @stable ICU 3.6
-  */
-U_STABLE  int32_t U_EXPORT2
-ucsdet_getUChars(const UCharsetMatch *ucsm,
-                 UChar *buf, int32_t cap, UErrorCode *status);
-
-
-
-/**
-  *  Get an iterator over the set of all detectable charsets - 
-  *  over the charsets that are known to the charset detection
-  *  service.
-  *
-  *  The returned UEnumeration provides access to the names of
-  *  the charsets.
-  *
-  *  The state of the Charset detector that is passed in does not
-  *  affect the result of this function, but requiring a valid, open
-  *  charset detector as a parameter insures that the charset detection
-  *  service has been safely initialized and that the required detection
-  *  data is available.
-  *
-  *  @param ucsd a Charset detector.
-  *  @param status  Any error conditions are reported back in this variable.
-  *  @return an iterator providing access to the detectable charset names.
-  *  @stable ICU 3.6
-  */
-U_STABLE  UEnumeration * U_EXPORT2
-ucsdet_getAllDetectableCharsets(const UCharsetDetector *ucsd,  UErrorCode *status);
-
-
-/**
-  *  Test whether input filtering is enabled for this charset detector.
-  *  Input filtering removes text that appears to be HTML or xml
-  *  markup from the input before applying the code page detection
-  *  heuristics.
-  *
-  *  @param ucsd  The charset detector to check.
-  *  @return TRUE if filtering is enabled.
-  *  @stable ICU 3.6
-  */
-U_STABLE  UBool U_EXPORT2
-ucsdet_isInputFilterEnabled(const UCharsetDetector *ucsd);
-
-
-/**
- * Enable filtering of input text. If filtering is enabled,
- * text within angle brackets ("<" and ">") will be removed
- * before detection, which will remove most HTML or xml markup.
- *
- * @param ucsd   the charset detector to be modified.
- * @param filter <code>true</code> to enable input text filtering.
- * @return The previous setting.
- *
- * @stable ICU 3.6
- */
-U_STABLE  UBool U_EXPORT2
-ucsdet_enableInputFilter(UCharsetDetector *ucsd, UBool filter);
-
-#endif
-#endif   /* __UCSDET_H */
-
-

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/ucurr.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/ucurr.h b/apps/couch_collate/platform/osx/icu/unicode/ucurr.h
deleted file mode 100644
index c6b3713..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/ucurr.h
+++ /dev/null
@@ -1,270 +0,0 @@
-/*
-**********************************************************************
-* Copyright (c) 2002-2008, International Business Machines
-* Corporation and others.  All Rights Reserved.
-**********************************************************************
-*/
-#ifndef _UCURR_H_
-#define _UCURR_H_
-
-#include "unicode/utypes.h"
-#include "unicode/uenum.h"
-
-/**
- * \file 
- * \brief C API: Encapsulates information about a currency.
- */
-
-#if !UCONFIG_NO_FORMATTING
-
-/**
- * The ucurr API encapsulates information about a currency, as defined by
- * ISO 4217.  A currency is represented by a 3-character string
- * containing its ISO 4217 code.  This API can return various data
- * necessary the proper display of a currency:
- *
- * <ul><li>A display symbol, for a specific locale
- * <li>The number of fraction digits to display
- * <li>A rounding increment
- * </ul>
- *
- * The <tt>DecimalFormat</tt> class uses these data to display
- * currencies.
- * @author Alan Liu
- * @since ICU 2.2
- */
-
-/**
- * Finds a currency code for the given locale.
- * @param locale the locale for which to retrieve a currency code. 
- *               Currency can be specified by the "currency" keyword
- *               in which case it overrides the default currency code
- * @param buff   fill in buffer. Can be NULL for preflighting.
- * @param buffCapacity capacity of the fill in buffer. Can be 0 for
- *               preflighting. If it is non-zero, the buff parameter
- *               must not be NULL.
- * @param ec error code
- * @return length of the currency string. It should always be 3. If 0,
- *                currency couldn't be found or the input values are 
- *                invalid. 
- * @stable ICU 2.8
- */
-U_STABLE int32_t U_EXPORT2
-ucurr_forLocale(const char* locale,
-                UChar* buff,
-                int32_t buffCapacity,
-                UErrorCode* ec);
-
-/**
- * Selector constants for ucurr_getName().
- *
- * @see ucurr_getName
- * @stable ICU 2.6
- */
-typedef enum UCurrNameStyle {
-    /**
-     * Selector for ucurr_getName indicating a symbolic name for a
-     * currency, such as "$" for USD.
-     * @stable ICU 2.6
-     */
-    UCURR_SYMBOL_NAME,
-
-    /**
-     * Selector for ucurr_getName indicating the long name for a
-     * currency, such as "US Dollar" for USD.
-     * @stable ICU 2.6
-     */
-    UCURR_LONG_NAME
-} UCurrNameStyle;
-
-#if !UCONFIG_NO_SERVICE
-/**
- * @stable ICU 2.6
- */
-typedef const void* UCurrRegistryKey;
-
-/**
- * Register an (existing) ISO 4217 currency code for the given locale.
- * Only the country code and the two variants EURO and PRE_EURO are
- * recognized.
- * @param isoCode the three-letter ISO 4217 currency code
- * @param locale  the locale for which to register this currency code
- * @param status the in/out status code
- * @return a registry key that can be used to unregister this currency code, or NULL
- * if there was an error.
- * @stable ICU 2.6
- */
-U_STABLE UCurrRegistryKey U_EXPORT2
-ucurr_register(const UChar* isoCode, 
-                   const char* locale,  
-                   UErrorCode* status);
-/**
- * Unregister the previously-registered currency definitions using the
- * URegistryKey returned from ucurr_register.  Key becomes invalid after
- * a successful call and should not be used again.  Any currency 
- * that might have been hidden by the original ucurr_register call is 
- * restored.
- * @param key the registry key returned by a previous call to ucurr_register
- * @param status the in/out status code, no special meanings are assigned
- * @return TRUE if the currency for this key was successfully unregistered
- * @stable ICU 2.6
- */
-U_STABLE UBool U_EXPORT2
-ucurr_unregister(UCurrRegistryKey key, UErrorCode* status);
-#endif /* UCONFIG_NO_SERVICE */
-
-/**
- * Returns the display name for the given currency in the
- * given locale.  For example, the display name for the USD
- * currency object in the en_US locale is "$".
- * @param currency null-terminated 3-letter ISO 4217 code
- * @param locale locale in which to display currency
- * @param nameStyle selector for which kind of name to return
- * @param isChoiceFormat fill-in set to TRUE if the returned value
- * is a ChoiceFormat pattern; otherwise it is a static string
- * @param len fill-in parameter to receive length of result
- * @param ec error code
- * @return pointer to display string of 'len' UChars.  If the resource
- * data contains no entry for 'currency', then 'currency' itself is
- * returned.  If *isChoiceFormat is TRUE, then the result is a
- * ChoiceFormat pattern.  Otherwise it is a static string.
- * @stable ICU 2.6
- */
-U_STABLE const UChar* U_EXPORT2
-ucurr_getName(const UChar* currency,
-              const char* locale,
-              UCurrNameStyle nameStyle,
-              UBool* isChoiceFormat,
-              int32_t* len,
-              UErrorCode* ec);
-
-/**
- * Returns the number of the number of fraction digits that should
- * be displayed for the given currency.
- * @param currency null-terminated 3-letter ISO 4217 code
- * @param ec input-output error code
- * @return a non-negative number of fraction digits to be
- * displayed, or 0 if there is an error
- * @stable ICU 3.0
- */
-U_STABLE int32_t U_EXPORT2
-ucurr_getDefaultFractionDigits(const UChar* currency,
-                               UErrorCode* ec);
-
-/**
- * Returns the rounding increment for the given currency, or 0.0 if no
- * rounding is done by the currency.
- * @param currency null-terminated 3-letter ISO 4217 code
- * @param ec input-output error code
- * @return the non-negative rounding increment, or 0.0 if none,
- * or 0.0 if there is an error
- * @stable ICU 3.0
- */
-U_STABLE double U_EXPORT2
-ucurr_getRoundingIncrement(const UChar* currency,
-                           UErrorCode* ec);
-
-/**
- * Selector constants for ucurr_openCurrencies().
- *
- * @see ucurr_openCurrencies
- * @stable ICU 3.2
- */
-typedef enum UCurrCurrencyType {
-    /**
-     * Select all ISO-4217 currency codes.
-     * @stable ICU 3.2
-     */
-    UCURR_ALL = INT32_MAX,
-    /**
-     * Select only ISO-4217 commonly used currency codes.
-     * These currencies can be found in common use, and they usually have
-     * bank notes or coins associated with the currency code.
-     * This does not include fund codes, precious metals and other
-     * various ISO-4217 codes limited to special financial products.
-     * @stable ICU 3.2
-     */
-    UCURR_COMMON = 1,
-    /**
-     * Select ISO-4217 uncommon currency codes.
-     * These codes respresent fund codes, precious metals and other
-     * various ISO-4217 codes limited to special financial products.
-     * A fund code is a monetary resource associated with a currency.
-     * @stable ICU 3.2
-     */
-    UCURR_UNCOMMON = 2,
-    /**
-     * Select only deprecated ISO-4217 codes.
-     * These codes are no longer in general public use.
-     * @stable ICU 3.2
-     */
-    UCURR_DEPRECATED = 4,
-    /**
-     * Select only non-deprecated ISO-4217 codes.
-     * These codes are in general public use.
-     * @stable ICU 3.2
-     */
-    UCURR_NON_DEPRECATED = 8
-} UCurrCurrencyType;
-
-/**
- * Provides a UEnumeration object for listing ISO-4217 codes.
- * @param currType You can use one of several UCurrCurrencyType values for this
- *      variable. You can also | (or) them together to get a specific list of
- *      currencies. Most people will want to use the (UCURR_CURRENCY|UCURR_NON_DEPRECATED) value to
- *      get a list of current currencies.
- * @param pErrorCode Error code
- * @stable ICU 3.2
- */
-U_STABLE UEnumeration * U_EXPORT2
-ucurr_openISOCurrencies(uint32_t currType, UErrorCode *pErrorCode);
-
-/** 
- * Finds the number of valid currency codes for the
- * given locale and date.
- * @param locale the locale for which to retrieve the
- *               currency count.
- * @param date   the date for which to retrieve the
- *               currency count for the given locale.
- * @param ec     error code
- * @return       the number of currency codes for the
- *               given locale and date.  If 0, currency
- *               codes couldn't be found for the input
- *               values are invalid.
- * @draft ICU 4.0
- */
-U_DRAFT int32_t U_EXPORT2
-ucurr_countCurrencies(const char* locale, 
-                 UDate date, 
-                 UErrorCode* ec); 
-
-/** 
- * Finds a currency code for the given locale and date 
- * @param locale the locale for which to retrieve a currency code.  
- *               Currency can be specified by the "currency" keyword 
- *               in which case it overrides the default currency code 
- * @param date   the date for which to retrieve a currency code for 
- *               the given locale. 
- * @param index  the index within the available list of currency codes
- *               for the given locale on the given date.
- * @param buff   fill in buffer. Can be NULL for preflighting. 
- * @param buffCapacity capacity of the fill in buffer. Can be 0 for 
- *               preflighting. If it is non-zero, the buff parameter 
- *               must not be NULL. 
- * @param ec     error code 
- * @return       length of the currency string. It should always be 3. 
- *               If 0, currency couldn't be found or the input values are  
- *               invalid.  
- * @draft ICU 4.0 
- */ 
-U_DRAFT int32_t U_EXPORT2 
-ucurr_forLocaleAndDate(const char* locale, 
-                UDate date, 
-                int32_t index,
-                UChar* buff, 
-                int32_t buffCapacity, 
-                UErrorCode* ec); 
-
-#endif /* #if !UCONFIG_NO_FORMATTING */
-
-#endif

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/udat.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/udat.h b/apps/couch_collate/platform/osx/icu/unicode/udat.h
deleted file mode 100644
index e4b43a4..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/udat.h
+++ /dev/null
@@ -1,962 +0,0 @@
-/*
- *******************************************************************************
- * Copyright (C) 1996-2009, International Business Machines
- * Corporation and others. All Rights Reserved.
- *******************************************************************************
-*/
-
-#ifndef UDAT_H
-#define UDAT_H
-
-#include "unicode/utypes.h"
-
-#if !UCONFIG_NO_FORMATTING
-
-#include "unicode/ucal.h"
-#include "unicode/unum.h"
-/**
- * \file
- * \brief C API: DateFormat
- *
- * <h2> Date Format C API</h2>
- *
- * Date Format C API  consists of functions that convert dates and
- * times from their internal representations to textual form and back again in a
- * language-independent manner. Converting from the internal representation (milliseconds
- * since midnight, January 1, 1970) to text is known as "formatting," and converting
- * from text to millis is known as "parsing."  We currently define only one concrete
- * structure UDateFormat, which can handle pretty much all normal
- * date formatting and parsing actions.
- * <P>
- * Date Format helps you to format and parse dates for any locale. Your code can
- * be completely independent of the locale conventions for months, days of the
- * week, or even the calendar format: lunar vs. solar.
- * <P>
- * To format a date for the current Locale with default time and date style,
- * use one of the static factory methods:
- * <pre>
- * \code
- *  UErrorCode status = U_ZERO_ERROR;
- *  UChar *myString;
- *  int32_t myStrlen = 0;
- *  UDateFormat* dfmt = udat_open(UDAT_DEFAULT, UDAT_DEFAULT, NULL, NULL, -1, NULL, -1, &status);
- *  myStrlen = udat_format(dfmt, myDate, NULL, myStrlen, NULL, &status);
- *  if (status==U_BUFFER_OVERFLOW_ERROR){
- *      status=U_ZERO_ERROR;
- *      myString=(UChar*)malloc(sizeof(UChar) * (myStrlen+1) );
- *      udat_format(dfmt, myDate, myString, myStrlen+1, NULL, &status);
- *  }
- * \endcode
- * </pre>
- * If you are formatting multiple numbers, it is more efficient to get the
- * format and use it multiple times so that the system doesn't have to fetch the
- * information about the local language and country conventions multiple times.
- * <pre>
- * \code
- *  UErrorCode status = U_ZERO_ERROR;
- *  int32_t i, myStrlen = 0;
- *  UChar* myString;
- *  char buffer[1024];
- *  UDate myDateArr[] = { 0.0, 100000000.0, 2000000000.0 }; // test values
- *  UDateFormat* df = udat_open(UDAT_DEFAULT, UDAT_DEFAULT, NULL, NULL, -1, NULL, 0, &status);
- *  for (i = 0; i < 3; i++) {
- *      myStrlen = udat_format(df, myDateArr[i], NULL, myStrlen, NULL, &status);
- *      if(status == U_BUFFER_OVERFLOW_ERROR){
- *          status = U_ZERO_ERROR;
- *          myString = (UChar*)malloc(sizeof(UChar) * (myStrlen+1) );
- *          udat_format(df, myDateArr[i], myString, myStrlen+1, NULL, &status);
- *          printf("%s\n", u_austrcpy(buffer, myString) );
- *          free(myString);
- *      }
- *  }
- * \endcode
- * </pre>
- * To get specific fields of a date, you can use UFieldPosition to
- * get specific fields.
- * <pre>
- * \code
- *  UErrorCode status = U_ZERO_ERROR;
- *  UFieldPosition pos;
- *  UChar *myString;
- *  int32_t myStrlen = 0;
- *  char buffer[1024];
- *
- *  pos.field = 1;  // Same as the DateFormat::EField enum
- *  UDateFormat* dfmt = udat_open(UDAT_DEFAULT, UDAT_DEFAULT, NULL, -1, NULL, 0, &status);
- *  myStrlen = udat_format(dfmt, myDate, NULL, myStrlen, &pos, &status);
- *  if (status==U_BUFFER_OVERFLOW_ERROR){
- *      status=U_ZERO_ERROR;
- *      myString=(UChar*)malloc(sizeof(UChar) * (myStrlen+1) );
- *      udat_format(dfmt, myDate, myString, myStrlen+1, &pos, &status);
- *  }
- *  printf("date format: %s\n", u_austrcpy(buffer, myString));
- *  buffer[pos.endIndex] = 0;   // NULL terminate the string.
- *  printf("UFieldPosition position equals %s\n", &buffer[pos.beginIndex]);
- * \endcode
- * </pre>
- * To format a date for a different Locale, specify it in the call to
- * udat_open()
- * <pre>
- * \code
- *        UDateFormat* df = udat_open(UDAT_SHORT, UDAT_SHORT, "fr_FR", NULL, -1, NULL, 0, &status);
- * \endcode
- * </pre>
- * You can use a DateFormat API udat_parse() to parse.
- * <pre>
- * \code
- *  UErrorCode status = U_ZERO_ERROR;
- *  int32_t parsepos=0;
- *  UDate myDate = udat_parse(df, myString, u_strlen(myString), &parsepos, &status);
- * \endcode
- * </pre>
- *  You can pass in different options for the arguments for date and time style
- *  to control the length of the result; from SHORT to MEDIUM to LONG to FULL.
- *  The exact result depends on the locale, but generally:
- *  see UDateFormatStyle for more details
- * <ul type=round>
- *   <li>   UDAT_SHORT is completely numeric, such as 12/13/52 or 3:30pm
- *   <li>   UDAT_MEDIUM is longer, such as Jan 12, 1952
- *   <li>   UDAT_LONG is longer, such as January 12, 1952 or 3:30:32pm
- *   <li>   UDAT_FULL is pretty completely specified, such as
- *          Tuesday, April 12, 1952 AD or 3:30:42pm PST.
- * </ul>
- * You can also set the time zone on the format if you wish.
- * <P>
- * You can also use forms of the parse and format methods with Parse Position and
- * UFieldPosition to allow you to
- * <ul type=round>
- *   <li>   Progressively parse through pieces of a string.
- *   <li>   Align any particular field, or find out where it is for selection
- *          on the screen.
- * </ul>
- */
-
-/** A date formatter.
- *  For usage in C programs.
- *  @stable ICU 2.6
- */
-typedef void* UDateFormat;
-
-/** The possible date/time format styles 
- *  @stable ICU 2.6
- */
-typedef enum UDateFormatStyle {
-    /** Full style */
-    UDAT_FULL,
-    /** Long style */
-    UDAT_LONG,
-    /** Medium style */
-    UDAT_MEDIUM,
-    /** Short style */
-    UDAT_SHORT,
-    /** Default style */
-    UDAT_DEFAULT = UDAT_MEDIUM,
-
-    /** Bitfield for relative date */
-    UDAT_RELATIVE = (1 << 7),
-    
-    UDAT_FULL_RELATIVE = UDAT_FULL | UDAT_RELATIVE,
-        
-    UDAT_LONG_RELATIVE = UDAT_LONG | UDAT_RELATIVE,
-    
-    UDAT_MEDIUM_RELATIVE = UDAT_MEDIUM | UDAT_RELATIVE,
-    
-    UDAT_SHORT_RELATIVE = UDAT_SHORT | UDAT_RELATIVE,
-    
-    
-    /** No style */
-    UDAT_NONE = -1,
-    /** for internal API use only */
-    UDAT_IGNORE = -2
-
-} UDateFormatStyle;
-
-
-/**
- * @{
- * Below are a set of pre-defined skeletons.
- *
- * <P>
- * A skeleton 
- * <ol>
- * <li>
- *    only keeps the field pattern letter and ignores all other parts 
- *    in a pattern, such as space, punctuations, and string literals.
- * </li>
- * <li>
- *    hides the order of fields. 
- * </li>
- * <li>
- *    might hide a field's pattern letter length.
- *
- *    For those non-digit calendar fields, the pattern letter length is 
- *    important, such as MMM, MMMM, and MMMMM; EEE and EEEE, 
- *    and the field's pattern letter length is honored.
- *    
- *    For the digit calendar fields,  such as M or MM, d or dd, yy or yyyy, 
- *    the field pattern length is ignored and the best match, which is defined 
- *    in date time patterns, will be returned without honor the field pattern
- *    letter length in skeleton.
- * </li>
- * </ol>
- *
- * @stable ICU 4.0
- */
-
-#define UDAT_MINUTE_SECOND              "ms"
-#define UDAT_HOUR24_MINUTE              "Hm"
-#define UDAT_HOUR24_MINUTE_SECOND       "Hms"      
-#define UDAT_HOUR_MINUTE_SECOND         "hms"
-#define UDAT_STANDALONE_MONTH           "LLLL"
-#define UDAT_ABBR_STANDALONE_MONTH      "LLL"
-#define UDAT_YEAR_QUARTER               "yQQQ"
-#define UDAT_YEAR_ABBR_QUARTER          "yQ"
-
-/** @} */
-
-/**
- * @{
- * Below are a set of pre-defined skeletons that 
- * have pre-defined interval patterns in resource files.
- * Users are encouraged to use them in date interval format factory methods.
- *
- */
-#define UDAT_HOUR_MINUTE                "hm"
-#define UDAT_YEAR                       "y"
-#define UDAT_DAY                        "d"
-#define UDAT_NUM_MONTH_WEEKDAY_DAY      "MEd"
-#define UDAT_YEAR_NUM_MONTH             "yM"              
-#define UDAT_NUM_MONTH_DAY              "Md"
-#define UDAT_YEAR_NUM_MONTH_WEEKDAY_DAY "yMEd"
-#define UDAT_ABBR_MONTH_WEEKDAY_DAY     "MMMEd"
-#define UDAT_YEAR_MONTH                 "yMMMM"
-#define UDAT_YEAR_ABBR_MONTH            "yMMM"
-#define UDAT_MONTH_DAY                  "MMMMd"
-#define UDAT_ABBR_MONTH_DAY             "MMMd" 
-#define UDAT_MONTH_WEEKDAY_DAY          "MMMMEEEEd"
-#define UDAT_YEAR_ABBR_MONTH_WEEKDAY_DAY "yMMMEd" 
-#define UDAT_YEAR_MONTH_WEEKDAY_DAY     "yMMMMEEEEd"
-#define UDAT_YEAR_MONTH_DAY             "yMMMMd"
-#define UDAT_YEAR_ABBR_MONTH_DAY        "yMMMd"
-#define UDAT_YEAR_NUM_MONTH_DAY         "yMd"
-#define UDAT_NUM_MONTH                  "M"
-#define UDAT_ABBR_MONTH                 "MMM"
-#define UDAT_MONTH                      "MMMM"
-#define UDAT_HOUR_MINUTE_GENERIC_TZ     "hmv"
-#define UDAT_HOUR_MINUTE_TZ             "hmz"
-#define UDAT_HOUR                       "h"
-#define UDAT_HOUR_GENERIC_TZ            "hv"
-#define UDAT_HOUR_TZ                    "hz"
-
-/** @} */
-
-
-/**
- * FieldPosition and UFieldPosition selectors for format fields
- * defined by DateFormat and UDateFormat.
- * @stable ICU 3.0
- */
-typedef enum UDateFormatField {
-    /**
-     * FieldPosition and UFieldPosition selector for 'G' field alignment,
-     * corresponding to the UCAL_ERA field.
-     * @stable ICU 3.0
-     */
-    UDAT_ERA_FIELD = 0,
-
-    /**
-     * FieldPosition and UFieldPosition selector for 'y' field alignment,
-     * corresponding to the UCAL_YEAR field.
-     * @stable ICU 3.0
-     */
-    UDAT_YEAR_FIELD = 1,
-
-    /**
-     * FieldPosition and UFieldPosition selector for 'M' field alignment,
-     * corresponding to the UCAL_MONTH field.
-     * @stable ICU 3.0
-     */
-    UDAT_MONTH_FIELD = 2,
-
-    /**
-     * FieldPosition and UFieldPosition selector for 'd' field alignment,
-     * corresponding to the UCAL_DATE field.
-     * @stable ICU 3.0
-     */
-    UDAT_DATE_FIELD = 3,
-
-    /**
-     * FieldPosition and UFieldPosition selector for 'k' field alignment,
-     * corresponding to the UCAL_HOUR_OF_DAY field.
-     * UDAT_HOUR_OF_DAY1_FIELD is used for the one-based 24-hour clock.
-     * For example, 23:59 + 01:00 results in 24:59.
-     * @stable ICU 3.0
-     */
-    UDAT_HOUR_OF_DAY1_FIELD = 4,
-
-    /**
-     * FieldPosition and UFieldPosition selector for 'H' field alignment,
-     * corresponding to the UCAL_HOUR_OF_DAY field.
-     * UDAT_HOUR_OF_DAY0_FIELD is used for the zero-based 24-hour clock.
-     * For example, 23:59 + 01:00 results in 00:59.
-     * @stable ICU 3.0
-     */
-    UDAT_HOUR_OF_DAY0_FIELD = 5,
-
-    /**
-     * FieldPosition and UFieldPosition selector for 'm' field alignment,
-     * corresponding to the UCAL_MINUTE field.
-     * @stable ICU 3.0
-     */
-    UDAT_MINUTE_FIELD = 6,
-
-    /**
-     * FieldPosition and UFieldPosition selector for 's' field alignment,
-     * corresponding to the UCAL_SECOND field.
-     * @stable ICU 3.0
-     */
-    UDAT_SECOND_FIELD = 7,
-
-    /**
-     * FieldPosition and UFieldPosition selector for 'S' field alignment,
-     * corresponding to the UCAL_MILLISECOND field.
-     * @stable ICU 3.0
-     */
-    UDAT_FRACTIONAL_SECOND_FIELD = 8,
-
-    /**
-     * FieldPosition and UFieldPosition selector for 'E' field alignment,
-     * corresponding to the UCAL_DAY_OF_WEEK field.
-     * @stable ICU 3.0
-     */
-    UDAT_DAY_OF_WEEK_FIELD = 9,
-
-    /**
-     * FieldPosition and UFieldPosition selector for 'D' field alignment,
-     * corresponding to the UCAL_DAY_OF_YEAR field.
-     * @stable ICU 3.0
-     */
-    UDAT_DAY_OF_YEAR_FIELD = 10,
-
-    /**
-     * FieldPosition and UFieldPosition selector for 'F' field alignment,
-     * corresponding to the UCAL_DAY_OF_WEEK_IN_MONTH field.
-     * @stable ICU 3.0
-     */
-    UDAT_DAY_OF_WEEK_IN_MONTH_FIELD = 11,
-
-    /**
-     * FieldPosition and UFieldPosition selector for 'w' field alignment,
-     * corresponding to the UCAL_WEEK_OF_YEAR field.
-     * @stable ICU 3.0
-     */
-    UDAT_WEEK_OF_YEAR_FIELD = 12,
-
-    /**
-     * FieldPosition and UFieldPosition selector for 'W' field alignment,
-     * corresponding to the UCAL_WEEK_OF_MONTH field.
-     * @stable ICU 3.0
-     */
-    UDAT_WEEK_OF_MONTH_FIELD = 13,
-
-    /**
-     * FieldPosition and UFieldPosition selector for 'a' field alignment,
-     * corresponding to the UCAL_AM_PM field.
-     * @stable ICU 3.0
-     */
-    UDAT_AM_PM_FIELD = 14,
-
-    /**
-     * FieldPosition and UFieldPosition selector for 'h' field alignment,
-     * corresponding to the UCAL_HOUR field.
-     * UDAT_HOUR1_FIELD is used for the one-based 12-hour clock.
-     * For example, 11:30 PM + 1 hour results in 12:30 AM.
-     * @stable ICU 3.0
-     */
-    UDAT_HOUR1_FIELD = 15,
-
-    /**
-     * FieldPosition and UFieldPosition selector for 'K' field alignment,
-     * corresponding to the UCAL_HOUR field.
-     * UDAT_HOUR0_FIELD is used for the zero-based 12-hour clock.
-     * For example, 11:30 PM + 1 hour results in 00:30 AM.
-     * @stable ICU 3.0
-     */
-    UDAT_HOUR0_FIELD = 16,
-
-    /**
-     * FieldPosition and UFieldPosition selector for 'z' field alignment,
-     * corresponding to the UCAL_ZONE_OFFSET and
-     * UCAL_DST_OFFSET fields.
-     * @stable ICU 3.0
-     */
-    UDAT_TIMEZONE_FIELD = 17,
-
-    /**
-     * FieldPosition and UFieldPosition selector for 'Y' field alignment,
-     * corresponding to the UCAL_YEAR_WOY field.
-     * @stable ICU 3.0
-     */
-    UDAT_YEAR_WOY_FIELD = 18,
-
-    /**
-     * FieldPosition and UFieldPosition selector for 'e' field alignment,
-     * corresponding to the UCAL_DOW_LOCAL field.
-     * @stable ICU 3.0
-     */
-    UDAT_DOW_LOCAL_FIELD = 19,
-
-    /**
-     * FieldPosition and UFieldPosition selector for 'u' field alignment,
-     * corresponding to the UCAL_EXTENDED_YEAR field.
-     * @stable ICU 3.0
-     */
-    UDAT_EXTENDED_YEAR_FIELD = 20,
-
-    /**
-     * FieldPosition and UFieldPosition selector for 'g' field alignment,
-     * corresponding to the UCAL_JULIAN_DAY field.
-     * @stable ICU 3.0
-     */
-    UDAT_JULIAN_DAY_FIELD = 21,
-
-    /**
-     * FieldPosition and UFieldPosition selector for 'A' field alignment,
-     * corresponding to the UCAL_MILLISECONDS_IN_DAY field.
-     * @stable ICU 3.0
-     */
-    UDAT_MILLISECONDS_IN_DAY_FIELD = 22,
-
-    /**
-     * FieldPosition and UFieldPosition selector for 'Z' field alignment,
-     * corresponding to the UCAL_ZONE_OFFSET and
-     * UCAL_DST_OFFSET fields.
-     * @stable ICU 3.0
-     */
-    UDAT_TIMEZONE_RFC_FIELD = 23,
-
-    /**
-     * FieldPosition and UFieldPosition selector for 'v' field alignment,
-     * corresponding to the UCAL_ZONE_OFFSET field.
-     * @stable ICU 3.4
-     */
-    UDAT_TIMEZONE_GENERIC_FIELD = 24,
-    /**
-     * FieldPosition selector for 'c' field alignment,
-     * corresponding to the {@link #UCAL_DATE} field. 
-     * This displays the stand alone day name, if available.
-     * @stable ICU 3.4
-     */
-    UDAT_STANDALONE_DAY_FIELD = 25,
-    
-    /**
-     * FieldPosition selector for 'L' field alignment,
-     * corresponding to the {@link #UCAL_MONTH} field.  
-     * This displays the stand alone month name, if available.
-     * @stable ICU 3.4
-     */
-    UDAT_STANDALONE_MONTH_FIELD = 26,
-
-    /**
-     * FieldPosition selector for "Q" field alignment,
-     * corresponding to quarters. This is implemented
-     * using the {@link #UCAL_MONTH} field. This
-     * displays the quarter.
-     * @stable ICU 3.6
-     */
-    UDAT_QUARTER_FIELD = 27,
-
-    /**
-     * FieldPosition selector for the "q" field alignment,
-     * corresponding to stand-alone quarters. This is
-     * implemented using the {@link #UCAL_MONTH} field.
-     * This displays the stand-alone quarter.
-     * @stable ICU 3.6
-     */
-    UDAT_STANDALONE_QUARTER_FIELD = 28,
-
-    /**
-     * FieldPosition and UFieldPosition selector for 'V' field alignment,
-     * corresponding to the UCAL_ZONE_OFFSET field.
-     * @stable ICU 3.8
-     */
-    UDAT_TIMEZONE_SPECIAL_FIELD = 29,
-
-   /**
-     * Number of FieldPosition and UFieldPosition selectors for 
-     * DateFormat and UDateFormat.
-     * Valid selectors range from 0 to UDAT_FIELD_COUNT-1.
-     * This value is subject to change if new fields are defined
-     * in the future.
-     * @stable ICU 3.0
-     */
-    UDAT_FIELD_COUNT = 30
-
-} UDateFormatField;
-
-/**
- * Open a new UDateFormat for formatting and parsing dates and times.
- * A UDateFormat may be used to format dates in calls to {@link #udat_format },
- * and to parse dates in calls to {@link #udat_parse }.
- * @param timeStyle The style used to format times; one of UDAT_FULL, UDAT_LONG,
- * UDAT_MEDIUM, UDAT_SHORT, UDAT_DEFAULT, or UDAT_NONE (relative time styles
- * are not currently supported)
- * @param dateStyle The style used to format dates; one of UDAT_FULL, UDAT_LONG,
- * UDAT_MEDIUM, UDAT_SHORT, UDAT_DEFAULT, UDAT_FULL_RELATIVE, UDAT_LONG_RELATIVE,
- * UDAT_MEDIUM_RELATIVE, UDAT_SHORT_RELATIVE, or UDAT_NONE
- * @param locale The locale specifying the formatting conventions
- * @param tzID A timezone ID specifying the timezone to use.  If 0, use
- * the default timezone.
- * @param tzIDLength The length of tzID, or -1 if null-terminated.
- * @param pattern A pattern specifying the format to use.
- * @param patternLength The number of characters in the pattern, or -1 if null-terminated.
- * @param status A pointer to an UErrorCode to receive any errors
- * @return A pointer to a UDateFormat to use for formatting dates and times, or 0 if
- * an error occurred.
- * @stable ICU 2.0
- */
-U_STABLE UDateFormat* U_EXPORT2 
-udat_open(UDateFormatStyle  timeStyle,
-          UDateFormatStyle  dateStyle,
-          const char        *locale,
-          const UChar       *tzID,
-          int32_t           tzIDLength,
-          const UChar       *pattern,
-          int32_t           patternLength,
-          UErrorCode        *status);
-
-
-/**
-* Close a UDateFormat.
-* Once closed, a UDateFormat may no longer be used.
-* @param format The formatter to close.
-* @stable ICU 2.0
-*/
-U_STABLE void U_EXPORT2 
-udat_close(UDateFormat* format);
-
-/**
- * Open a copy of a UDateFormat.
- * This function performs a deep copy.
- * @param fmt The format to copy
- * @param status A pointer to an UErrorCode to receive any errors.
- * @return A pointer to a UDateFormat identical to fmt.
- * @stable ICU 2.0
- */
-U_STABLE UDateFormat* U_EXPORT2 
-udat_clone(const UDateFormat *fmt,
-       UErrorCode *status);
-
-/**
-* Format a date using an UDateFormat.
-* The date will be formatted using the conventions specified in {@link #udat_open }
-* @param format The formatter to use
-* @param dateToFormat The date to format
-* @param result A pointer to a buffer to receive the formatted number.
-* @param resultLength The maximum size of result.
-* @param position A pointer to a UFieldPosition.  On input, position->field
-* is read.  On output, position->beginIndex and position->endIndex indicate
-* the beginning and ending indices of field number position->field, if such
-* a field exists.  This parameter may be NULL, in which case no field
-* position data is returned.
-* @param status A pointer to an UErrorCode to receive any errors
-* @return The total buffer size needed; if greater than resultLength, the output was truncated.
-* @see udat_parse
-* @see UFieldPosition
-* @stable ICU 2.0
-*/
-U_STABLE int32_t U_EXPORT2 
-udat_format(    const    UDateFormat*    format,
-                        UDate           dateToFormat,
-                        UChar*          result,
-                        int32_t         resultLength,
-                        UFieldPosition* position,
-                        UErrorCode*     status);
-
-/**
-* Parse a string into an date/time using a UDateFormat.
-* The date will be parsed using the conventions specified in {@link #udat_open }
-* @param format The formatter to use.
-* @param text The text to parse.
-* @param textLength The length of text, or -1 if null-terminated.
-* @param parsePos If not 0, on input a pointer to an integer specifying the offset at which
-* to begin parsing.  If not 0, on output the offset at which parsing ended.
-* @param status A pointer to an UErrorCode to receive any errors
-* @return The value of the parsed date/time
-* @see udat_format
-* @stable ICU 2.0
-*/
-U_STABLE UDate U_EXPORT2 
-udat_parse(    const    UDateFormat*    format,
-            const    UChar*          text,
-                    int32_t         textLength,
-                    int32_t         *parsePos,
-                    UErrorCode      *status);
-
-/**
-* Parse a string into an date/time using a UDateFormat.
-* The date will be parsed using the conventions specified in {@link #udat_open }
-* @param format The formatter to use.
-* @param calendar The calendar in which to store the parsed data.
-* @param text The text to parse.
-* @param textLength The length of text, or -1 if null-terminated.
-* @param parsePos If not 0, on input a pointer to an integer specifying the offset at which
-* to begin parsing.  If not 0, on output the offset at which parsing ended.
-* @param status A pointer to an UErrorCode to receive any errors
-* @see udat_format
-* @stable ICU 2.0
-*/
-U_STABLE void U_EXPORT2 
-udat_parseCalendar(const    UDateFormat*    format,
-                            UCalendar*      calendar,
-                   const    UChar*          text,
-                            int32_t         textLength,
-                            int32_t         *parsePos,
-                            UErrorCode      *status);
-
-/**
-* Determine if an UDateFormat will perform lenient parsing.
-* With lenient parsing, the parser may use heuristics to interpret inputs that do not
-* precisely match the pattern. With strict parsing, inputs must match the pattern.
-* @param fmt The formatter to query
-* @return TRUE if fmt is set to perform lenient parsing, FALSE otherwise.
-* @see udat_setLenient
-* @stable ICU 2.0
-*/
-U_STABLE UBool U_EXPORT2 
-udat_isLenient(const UDateFormat* fmt);
-
-/**
-* Specify whether an UDateFormat will perform lenient parsing.
-* With lenient parsing, the parser may use heuristics to interpret inputs that do not
-* precisely match the pattern. With strict parsing, inputs must match the pattern.
-* @param fmt The formatter to set
-* @param isLenient TRUE if fmt should perform lenient parsing, FALSE otherwise.
-* @see dat_isLenient
-* @stable ICU 2.0
-*/
-U_STABLE void U_EXPORT2 
-udat_setLenient(    UDateFormat*    fmt,
-                    UBool          isLenient);
-
-/**
-* Get the UCalendar associated with an UDateFormat.
-* A UDateFormat uses a UCalendar to convert a raw value to, for example,
-* the day of the week.
-* @param fmt The formatter to query.
-* @return A pointer to the UCalendar used by fmt.
-* @see udat_setCalendar
-* @stable ICU 2.0
-*/
-U_STABLE const UCalendar* U_EXPORT2 
-udat_getCalendar(const UDateFormat* fmt);
-
-/**
-* Set the UCalendar associated with an UDateFormat.
-* A UDateFormat uses a UCalendar to convert a raw value to, for example,
-* the day of the week.
-* @param fmt The formatter to set.
-* @param calendarToSet A pointer to an UCalendar to be used by fmt.
-* @see udat_setCalendar
-* @stable ICU 2.0
-*/
-U_STABLE void U_EXPORT2 
-udat_setCalendar(            UDateFormat*    fmt,
-                    const   UCalendar*      calendarToSet);
-
-/**
-* Get the UNumberFormat associated with an UDateFormat.
-* A UDateFormat uses a UNumberFormat to format numbers within a date,
-* for example the day number.
-* @param fmt The formatter to query.
-* @return A pointer to the UNumberFormat used by fmt to format numbers.
-* @see udat_setNumberFormat
-* @stable ICU 2.0
-*/
-U_STABLE const UNumberFormat* U_EXPORT2 
-udat_getNumberFormat(const UDateFormat* fmt);
-
-/**
-* Set the UNumberFormat associated with an UDateFormat.
-* A UDateFormat uses a UNumberFormat to format numbers within a date,
-* for example the day number.
-* @param fmt The formatter to set.
-* @param numberFormatToSet A pointer to the UNumberFormat to be used by fmt to format numbers.
-* @see udat_getNumberFormat
-* @stable ICU 2.0
-*/
-U_STABLE void U_EXPORT2 
-udat_setNumberFormat(            UDateFormat*    fmt,
-                        const   UNumberFormat*  numberFormatToSet);
-
-/**
-* Get a locale for which date/time formatting patterns are available.
-* A UDateFormat in a locale returned by this function will perform the correct
-* formatting and parsing for the locale.
-* @param localeIndex The index of the desired locale.
-* @return A locale for which date/time formatting patterns are available, or 0 if none.
-* @see udat_countAvailable
-* @stable ICU 2.0
-*/
-U_STABLE const char* U_EXPORT2 
-udat_getAvailable(int32_t localeIndex);
-
-/**
-* Determine how many locales have date/time  formatting patterns available.
-* This function is most useful as determining the loop ending condition for
-* calls to {@link #udat_getAvailable }.
-* @return The number of locales for which date/time formatting patterns are available.
-* @see udat_getAvailable
-* @stable ICU 2.0
-*/
-U_STABLE int32_t U_EXPORT2 
-udat_countAvailable(void);
-
-/**
-* Get the year relative to which all 2-digit years are interpreted.
-* For example, if the 2-digit start year is 2100, the year 99 will be
-* interpreted as 2199.
-* @param fmt The formatter to query.
-* @param status A pointer to an UErrorCode to receive any errors
-* @return The year relative to which all 2-digit years are interpreted.
-* @see udat_Set2DigitYearStart
-* @stable ICU 2.0
-*/
-U_STABLE UDate U_EXPORT2 
-udat_get2DigitYearStart(    const   UDateFormat     *fmt,
-                                    UErrorCode      *status);
-
-/**
-* Set the year relative to which all 2-digit years will be interpreted.
-* For example, if the 2-digit start year is 2100, the year 99 will be
-* interpreted as 2199.
-* @param fmt The formatter to set.
-* @param d The year relative to which all 2-digit years will be interpreted.
-* @param status A pointer to an UErrorCode to receive any errors
-* @see udat_Set2DigitYearStart
-* @stable ICU 2.0
-*/
-U_STABLE void U_EXPORT2 
-udat_set2DigitYearStart(    UDateFormat     *fmt,
-                            UDate           d,
-                            UErrorCode      *status);
-
-/**
-* Extract the pattern from a UDateFormat.
-* The pattern will follow the pattern syntax rules.
-* @param fmt The formatter to query.
-* @param localized TRUE if the pattern should be localized, FALSE otherwise.
-* @param result A pointer to a buffer to receive the pattern.
-* @param resultLength The maximum size of result.
-* @param status A pointer to an UErrorCode to receive any errors
-* @return The total buffer size needed; if greater than resultLength, the output was truncated.
-* @see udat_applyPattern
-* @stable ICU 2.0
-*/
-U_STABLE int32_t U_EXPORT2 
-udat_toPattern(    const   UDateFormat     *fmt,
-                        UBool          localized,
-                        UChar           *result,
-                        int32_t         resultLength,
-                        UErrorCode      *status);
-
-/**
-* Set the pattern used by an UDateFormat.
-* The pattern should follow the pattern syntax rules.
-* @param format The formatter to set.
-* @param localized TRUE if the pattern is localized, FALSE otherwise.
-* @param pattern The new pattern
-* @param patternLength The length of pattern, or -1 if null-terminated.
-* @see udat_toPattern
-* @stable ICU 2.0
-*/
-U_STABLE void U_EXPORT2 
-udat_applyPattern(            UDateFormat     *format,
-                            UBool          localized,
-                    const   UChar           *pattern,
-                            int32_t         patternLength);
-
-/** 
- * The possible types of date format symbols 
- * @stable ICU 2.6
- */
-typedef enum UDateFormatSymbolType {
-    /** The era names, for example AD */
-    UDAT_ERAS,
-    /** The month names, for example February */
-    UDAT_MONTHS,
-    /** The short month names, for example Feb. */
-    UDAT_SHORT_MONTHS,
-    /** The weekday names, for example Monday */
-    UDAT_WEEKDAYS,
-    /** The short weekday names, for example Mon. */
-    UDAT_SHORT_WEEKDAYS,
-    /** The AM/PM names, for example AM */
-    UDAT_AM_PMS,
-    /** The localized characters */
-    UDAT_LOCALIZED_CHARS,
-    /** The long era names, for example Anno Domini */
-    UDAT_ERA_NAMES,
-    /** The narrow month names, for example F */
-    UDAT_NARROW_MONTHS,
-    /** The narrow weekday names, for example N */
-    UDAT_NARROW_WEEKDAYS,
-    /** Standalone context versions of months */
-    UDAT_STANDALONE_MONTHS,
-    UDAT_STANDALONE_SHORT_MONTHS,
-    UDAT_STANDALONE_NARROW_MONTHS,
-    /** Standalone context versions of weekdays */
-    UDAT_STANDALONE_WEEKDAYS,
-    UDAT_STANDALONE_SHORT_WEEKDAYS,
-    UDAT_STANDALONE_NARROW_WEEKDAYS,
-    /** The quarters, for example 1st Quarter */
-    UDAT_QUARTERS,
-    /** The short quarter names, for example Q1 */
-    UDAT_SHORT_QUARTERS,
-    /** Standalone context versions of quarters */
-    UDAT_STANDALONE_QUARTERS,
-    UDAT_STANDALONE_SHORT_QUARTERS
-
-} UDateFormatSymbolType;
-
-struct UDateFormatSymbols;
-/** Date format symbols.
- *  For usage in C programs.
- *  @stable ICU 2.6
- */
-typedef struct UDateFormatSymbols UDateFormatSymbols;
-
-/**
-* Get the symbols associated with an UDateFormat.
-* The symbols are what a UDateFormat uses to represent locale-specific data,
-* for example month or day names.
-* @param fmt The formatter to query.
-* @param type The type of symbols to get.  One of UDAT_ERAS, UDAT_MONTHS, UDAT_SHORT_MONTHS,
-* UDAT_WEEKDAYS, UDAT_SHORT_WEEKDAYS, UDAT_AM_PMS, or UDAT_LOCALIZED_CHARS
-* @param symbolIndex The desired symbol of type type.
-* @param result A pointer to a buffer to receive the pattern.
-* @param resultLength The maximum size of result.
-* @param status A pointer to an UErrorCode to receive any errors
-* @return The total buffer size needed; if greater than resultLength, the output was truncated.
-* @see udat_countSymbols
-* @see udat_setSymbols
-* @stable ICU 2.0
-*/
-U_STABLE int32_t U_EXPORT2 
-udat_getSymbols(const   UDateFormat             *fmt,
-                        UDateFormatSymbolType   type,
-                        int32_t                 symbolIndex,
-                        UChar                   *result,
-                        int32_t                 resultLength,
-                        UErrorCode              *status);
-
-/**
-* Count the number of particular symbols for an UDateFormat.
-* This function is most useful as for detemining the loop termination condition
-* for calls to {@link #udat_getSymbols }.
-* @param fmt The formatter to query.
-* @param type The type of symbols to count.  One of UDAT_ERAS, UDAT_MONTHS, UDAT_SHORT_MONTHS,
-* UDAT_WEEKDAYS, UDAT_SHORT_WEEKDAYS, UDAT_AM_PMS, or UDAT_LOCALIZED_CHARS
-* @return The number of symbols of type type.
-* @see udat_getSymbols
-* @see udat_setSymbols
-* @stable ICU 2.0
-*/
-U_STABLE int32_t U_EXPORT2 
-udat_countSymbols(    const    UDateFormat                *fmt,
-                            UDateFormatSymbolType    type);
-
-/**
-* Set the symbols associated with an UDateFormat.
-* The symbols are what a UDateFormat uses to represent locale-specific data,
-* for example month or day names.
-* @param format The formatter to set
-* @param type The type of symbols to set.  One of UDAT_ERAS, UDAT_MONTHS, UDAT_SHORT_MONTHS,
-* UDAT_WEEKDAYS, UDAT_SHORT_WEEKDAYS, UDAT_AM_PMS, or UDAT_LOCALIZED_CHARS
-* @param symbolIndex The index of the symbol to set of type type.
-* @param value The new value
-* @param valueLength The length of value, or -1 if null-terminated
-* @param status A pointer to an UErrorCode to receive any errors
-* @see udat_getSymbols
-* @see udat_countSymbols
-* @stable ICU 2.0
-*/
-U_STABLE void U_EXPORT2 
-udat_setSymbols(    UDateFormat             *format,
-                    UDateFormatSymbolType   type,
-                    int32_t                 symbolIndex,
-                    UChar                   *value,
-                    int32_t                 valueLength,
-                    UErrorCode              *status);
-
-/**
- * Get the locale for this date format object.
- * You can choose between valid and actual locale.
- * @param fmt The formatter to get the locale from
- * @param type type of the locale we're looking for (valid or actual) 
- * @param status error code for the operation
- * @return the locale name
- * @stable ICU 2.8
- */
-U_STABLE const char* U_EXPORT2
-udat_getLocaleByType(const UDateFormat *fmt,
-                     ULocDataLocaleType type,
-                     UErrorCode* status); 
-
-/**
-* Extract the date pattern from a UDateFormat set for relative date formatting.
-* The pattern will follow the pattern syntax rules.
-* @param fmt The formatter to query.
-* @param result A pointer to a buffer to receive the pattern.
-* @param resultLength The maximum size of result.
-* @param status A pointer to a UErrorCode to receive any errors
-* @return The total buffer size needed; if greater than resultLength, the output was truncated.
-* @see udat_applyPatternRelative
-* @internal ICU 4.2 technology preview
-*/
-U_INTERNAL int32_t U_EXPORT2 
-udat_toPatternRelativeDate(const UDateFormat *fmt,
-                           UChar             *result,
-                           int32_t           resultLength,
-                           UErrorCode        *status);
-
-/**
-* Extract the time pattern from a UDateFormat set for relative date formatting.
-* The pattern will follow the pattern syntax rules.
-* @param fmt The formatter to query.
-* @param result A pointer to a buffer to receive the pattern.
-* @param resultLength The maximum size of result.
-* @param status A pointer to a UErrorCode to receive any errors
-* @return The total buffer size needed; if greater than resultLength, the output was truncated.
-* @see udat_applyPatternRelative
-* @internal ICU 4.2 technology preview
-*/
-U_INTERNAL int32_t U_EXPORT2 
-udat_toPatternRelativeTime(const UDateFormat *fmt,
-                           UChar             *result,
-                           int32_t           resultLength,
-                           UErrorCode        *status);
-
-/**
-* Set the date & time patterns used by a UDateFormat set for relative date formatting.
-* The patterns should follow the pattern syntax rules.
-* @param format The formatter to set.
-* @param datePattern The new date pattern
-* @param datePatternLength The length of datePattern, or -1 if null-terminated.
-* @param timePattern The new time pattern
-* @param timePatternLength The length of timePattern, or -1 if null-terminated.
-* @param status A pointer to a UErrorCode to receive any errors
-* @see udat_toPatternRelativeDate, udat_toPatternRelativeTime
-* @internal ICU 4.2 technology preview
-*/
-U_INTERNAL void U_EXPORT2 
-udat_applyPatternRelative(UDateFormat *format,
-                          const UChar *datePattern,
-                          int32_t     datePatternLength,
-                          const UChar *timePattern,
-                          int32_t     timePatternLength,
-                          UErrorCode  *status);
-
-#endif /* #if !UCONFIG_NO_FORMATTING */
-
-#endif


[37/57] [abbrv] remove couch_collate

Posted by be...@apache.org.
http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/decimfmt.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/decimfmt.h b/apps/couch_collate/platform/osx/icu/unicode/decimfmt.h
deleted file mode 100644
index a584a9c..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/decimfmt.h
+++ /dev/null
@@ -1,1901 +0,0 @@
-/*
-********************************************************************************
-*   Copyright (C) 1997-2009, International Business Machines
-*   Corporation and others.  All Rights Reserved.
-********************************************************************************
-*
-* File DECIMFMT.H
-*
-* Modification History:
-*
-*   Date        Name        Description
-*   02/19/97    aliu        Converted from java.
-*   03/20/97    clhuang     Updated per C++ implementation.
-*   04/03/97    aliu        Rewrote parsing and formatting completely, and
-*                           cleaned up and debugged.  Actually works now.
-*   04/17/97    aliu        Changed DigitCount to int per code review.
-*   07/10/97    helena      Made ParsePosition a class and get rid of the function
-*                           hiding problems.
-*   09/09/97    aliu        Ported over support for exponential formats.
-*    07/20/98    stephen        Changed documentation
-********************************************************************************
-*/
- 
-#ifndef DECIMFMT_H
-#define DECIMFMT_H
- 
-#include "unicode/utypes.h"
-/**
- * \file 
- * \brief C++ API: Formats decimal numbers.
- */
- 
-#if !UCONFIG_NO_FORMATTING
-
-#include "unicode/dcfmtsym.h"
-#include "unicode/numfmt.h"
-#include "unicode/locid.h"
-
-U_NAMESPACE_BEGIN
-
-class DigitList;
-class ChoiceFormat;
-class UnicodeSet;
-
-/**
- * DecimalFormat is a concrete subclass of NumberFormat that formats decimal
- * numbers. It has a variety of features designed to make it possible to parse
- * and format numbers in any locale, including support for Western, Arabic, or
- * Indic digits.  It also supports different flavors of numbers, including
- * integers ("123"), fixed-point numbers ("123.4"), scientific notation
- * ("1.23E4"), percentages ("12%"), and currency amounts ("$123").  All of these
- * flavors can be easily localized.
- *
- * <p>To obtain a NumberFormat for a specific locale (including the default
- * locale) call one of NumberFormat's factory methods such as
- * createInstance(). Do not call the DecimalFormat constructors directly, unless
- * you know what you are doing, since the NumberFormat factory methods may
- * return subclasses other than DecimalFormat.
- *
- * <p><strong>Example Usage</strong>
- *
- * \code
- *     // Normally we would have a GUI with a menu for this
- *     int32_t locCount;
- *     const Locale* locales = NumberFormat::getAvailableLocales(locCount);
- * 
- *     double myNumber = -1234.56;
- *     UErrorCode success = U_ZERO_ERROR;
- *     NumberFormat* form;
- * 
- *     // Print out a number with the localized number, currency and percent
- *     // format for each locale.
- *     UnicodeString countryName;
- *     UnicodeString displayName;
- *     UnicodeString str;
- *     UnicodeString pattern;
- *     Formattable fmtable;
- *     for (int32_t j = 0; j < 3; ++j) {
- *         cout << endl << "FORMAT " << j << endl;
- *         for (int32_t i = 0; i < locCount; ++i) {
- *             if (locales[i].getCountry(countryName).size() == 0) {
- *                 // skip language-only
- *                 continue;
- *             }
- *             switch (j) {
- *             case 0:
- *                 form = NumberFormat::createInstance(locales[i], success ); break;
- *             case 1:
- *                 form = NumberFormat::createCurrencyInstance(locales[i], success ); break;
- *             default:
- *                 form = NumberFormat::createPercentInstance(locales[i], success ); break;
- *             }
- *             if (form) {
- *                 str.remove();
- *                 pattern = ((DecimalFormat*)form)->toPattern(pattern);
- *                 cout << locales[i].getDisplayName(displayName) << ": " << pattern;
- *                 cout << "  ->  " << form->format(myNumber,str) << endl;
- *                 form->parse(form->format(myNumber,str), fmtable, success);
- *                 delete form;  
- *             }
- *         }
- *     }
- * \endcode
- *
- * <p><strong>Patterns</strong>
- *
- * <p>A DecimalFormat consists of a <em>pattern</em> and a set of
- * <em>symbols</em>.  The pattern may be set directly using
- * applyPattern(), or indirectly using other API methods which
- * manipulate aspects of the pattern, such as the minimum number of integer
- * digits.  The symbols are stored in a DecimalFormatSymbols
- * object.  When using the NumberFormat factory methods, the
- * pattern and symbols are read from ICU's locale data.
- * 
- * <p><strong>Special Pattern Characters</strong>
- *
- * <p>Many characters in a pattern are taken literally; they are matched during
- * parsing and output unchanged during formatting.  Special characters, on the
- * other hand, stand for other characters, strings, or classes of characters.
- * For example, the '#' character is replaced by a localized digit.  Often the
- * replacement character is the same as the pattern character; in the U.S. locale,
- * the ',' grouping character is replaced by ','.  However, the replacement is
- * still happening, and if the symbols are modified, the grouping character
- * changes.  Some special characters affect the behavior of the formatter by
- * their presence; for example, if the percent character is seen, then the
- * value is multiplied by 100 before being displayed.
- *
- * <p>To insert a special character in a pattern as a literal, that is, without
- * any special meaning, the character must be quoted.  There are some exceptions to
- * this which are noted below.
- *
- * <p>The characters listed here are used in non-localized patterns.  Localized
- * patterns use the corresponding characters taken from this formatter's
- * DecimalFormatSymbols object instead, and these characters lose
- * their special status.  Two exceptions are the currency sign and quote, which
- * are not localized.
- *
- * <table border=0 cellspacing=3 cellpadding=0>
- *   <tr bgcolor="#ccccff">
- *     <td align=left><strong>Symbol</strong>
- *     <td align=left><strong>Location</strong>
- *     <td align=left><strong>Localized?</strong>
- *     <td align=left><strong>Meaning</strong>
- *   <tr valign=top>
- *     <td><code>0</code>
- *     <td>Number
- *     <td>Yes
- *     <td>Digit
- *   <tr valign=top bgcolor="#eeeeff">
- *     <td><code>1-9</code>
- *     <td>Number
- *     <td>Yes
- *     <td>'1' through '9' indicate rounding.
- *   <tr valign=top>
- *     <td><code>\htmlonly&#x40;\endhtmlonly</code> <!--doxygen doesn't like @-->
- *     <td>Number
- *     <td>No
- *     <td>Significant digit
- *   <tr valign=top bgcolor="#eeeeff">
- *     <td><code>#</code>
- *     <td>Number
- *     <td>Yes
- *     <td>Digit, zero shows as absent
- *   <tr valign=top>
- *     <td><code>.</code>
- *     <td>Number
- *     <td>Yes
- *     <td>Decimal separator or monetary decimal separator
- *   <tr valign=top bgcolor="#eeeeff">
- *     <td><code>-</code>
- *     <td>Number
- *     <td>Yes
- *     <td>Minus sign
- *   <tr valign=top>
- *     <td><code>,</code>
- *     <td>Number
- *     <td>Yes
- *     <td>Grouping separator
- *   <tr valign=top bgcolor="#eeeeff">
- *     <td><code>E</code>
- *     <td>Number
- *     <td>Yes
- *     <td>Separates mantissa and exponent in scientific notation.
- *         <em>Need not be quoted in prefix or suffix.</em>
- *   <tr valign=top>
- *     <td><code>+</code>
- *     <td>Exponent
- *     <td>Yes
- *     <td>Prefix positive exponents with localized plus sign.
- *         <em>Need not be quoted in prefix or suffix.</em>
- *   <tr valign=top bgcolor="#eeeeff">
- *     <td><code>;</code>
- *     <td>Subpattern boundary
- *     <td>Yes
- *     <td>Separates positive and negative subpatterns
- *   <tr valign=top>
- *     <td><code>\%</code>
- *     <td>Prefix or suffix
- *     <td>Yes
- *     <td>Multiply by 100 and show as percentage
- *   <tr valign=top bgcolor="#eeeeff">
- *     <td><code>\\u2030</code>
- *     <td>Prefix or suffix
- *     <td>Yes
- *     <td>Multiply by 1000 and show as per mille
- *   <tr valign=top>
- *     <td><code>\htmlonly&curren;\endhtmlonly</code> (<code>\\u00A4</code>)
- *     <td>Prefix or suffix
- *     <td>No
- *     <td>Currency sign, replaced by currency symbol.  If
- *         doubled, replaced by international currency symbol.
- *         If present in a pattern, the monetary decimal separator
- *         is used instead of the decimal separator.
- *   <tr valign=top bgcolor="#eeeeff">
- *     <td><code>'</code>
- *     <td>Prefix or suffix
- *     <td>No
- *     <td>Used to quote special characters in a prefix or suffix,
- *         for example, <code>"'#'#"</code> formats 123 to
- *         <code>"#123"</code>.  To create a single quote
- *         itself, use two in a row: <code>"# o''clock"</code>.
- *   <tr valign=top>
- *     <td><code>*</code>
- *     <td>Prefix or suffix boundary
- *     <td>Yes
- *     <td>Pad escape, precedes pad character
- * </table>
- *
- * <p>A DecimalFormat pattern contains a postive and negative
- * subpattern, for example, "#,##0.00;(#,##0.00)".  Each subpattern has a
- * prefix, a numeric part, and a suffix.  If there is no explicit negative
- * subpattern, the negative subpattern is the localized minus sign prefixed to the
- * positive subpattern. That is, "0.00" alone is equivalent to "0.00;-0.00".  If there
- * is an explicit negative subpattern, it serves only to specify the negative
- * prefix and suffix; the number of digits, minimal digits, and other
- * characteristics are ignored in the negative subpattern. That means that
- * "#,##0.0#;(#)" has precisely the same result as "#,##0.0#;(#,##0.0#)".
- *
- * <p>The prefixes, suffixes, and various symbols used for infinity, digits,
- * thousands separators, decimal separators, etc. may be set to arbitrary
- * values, and they will appear properly during formatting.  However, care must
- * be taken that the symbols and strings do not conflict, or parsing will be
- * unreliable.  For example, either the positive and negative prefixes or the
- * suffixes must be distinct for parse() to be able
- * to distinguish positive from negative values.  Another example is that the
- * decimal separator and thousands separator should be distinct characters, or
- * parsing will be impossible.
- *
- * <p>The <em>grouping separator</em> is a character that separates clusters of
- * integer digits to make large numbers more legible.  It commonly used for
- * thousands, but in some locales it separates ten-thousands.  The <em>grouping
- * size</em> is the number of digits between the grouping separators, such as 3
- * for "100,000,000" or 4 for "1 0000 0000". There are actually two different
- * grouping sizes: One used for the least significant integer digits, the
- * <em>primary grouping size</em>, and one used for all others, the
- * <em>secondary grouping size</em>.  In most locales these are the same, but
- * sometimes they are different. For example, if the primary grouping interval
- * is 3, and the secondary is 2, then this corresponds to the pattern
- * "#,##,##0", and the number 123456789 is formatted as "12,34,56,789".  If a
- * pattern contains multiple grouping separators, the interval between the last
- * one and the end of the integer defines the primary grouping size, and the
- * interval between the last two defines the secondary grouping size. All others
- * are ignored, so "#,##,###,####" == "###,###,####" == "##,#,###,####".
- *
- * <p>Illegal patterns, such as "#.#.#" or "#.###,###", will cause
- * DecimalFormat to set a failing UErrorCode.
- *
- * <p><strong>Pattern BNF</strong>
- *
- * <pre>
- * pattern    := subpattern (';' subpattern)?
- * subpattern := prefix? number exponent? suffix?
- * number     := (integer ('.' fraction)?) | sigDigits
- * prefix     := '\\u0000'..'\\uFFFD' - specialCharacters
- * suffix     := '\\u0000'..'\\uFFFD' - specialCharacters
- * integer    := '#'* '0'* '0'
- * fraction   := '0'* '#'*
- * sigDigits  := '#'* '@' '@'* '#'*
- * exponent   := 'E' '+'? '0'* '0'
- * padSpec    := '*' padChar
- * padChar    := '\\u0000'..'\\uFFFD' - quote
- * &nbsp;
- * Notation:
- *   X*       0 or more instances of X
- *   X?       0 or 1 instances of X
- *   X|Y      either X or Y
- *   C..D     any character from C up to D, inclusive
- *   S-T      characters in S, except those in T
- * </pre>
- * The first subpattern is for positive numbers. The second (optional)
- * subpattern is for negative numbers.
- * 
- * <p>Not indicated in the BNF syntax above:
- *
- * <ul><li>The grouping separator ',' can occur inside the integer and
- * sigDigits elements, between any two pattern characters of that
- * element, as long as the integer or sigDigits element is not
- * followed by the exponent element.
- *
- * <li>Two grouping intervals are recognized: That between the
- *     decimal point and the first grouping symbol, and that
- *     between the first and second grouping symbols. These
- *     intervals are identical in most locales, but in some
- *     locales they differ. For example, the pattern
- *     &quot;#,##,###&quot; formats the number 123456789 as
- *     &quot;12,34,56,789&quot;.</li>
- * 
- * <li>The pad specifier <code>padSpec</code> may appear before the prefix,
- * after the prefix, before the suffix, after the suffix, or not at all.
- *
- * <li>In place of '0', the digits '1' through '9' may be used to
- * indicate a rounding increment.
- * </ul>
- *
- * <p><strong>Parsing</strong>
- *
- * <p>DecimalFormat parses all Unicode characters that represent
- * decimal digits, as defined by u_charDigitValue().  In addition,
- * DecimalFormat also recognizes as digits the ten consecutive
- * characters starting with the localized zero digit defined in the
- * DecimalFormatSymbols object.  During formatting, the
- * DecimalFormatSymbols-based digits are output.
- *
- * <p>During parsing, grouping separators are ignored.
- *
- * <p>If parse(UnicodeString&,Formattable&,ParsePosition&)
- * fails to parse a string, it leaves the parse position unchanged.
- * The convenience method parse(UnicodeString&,Formattable&,UErrorCode&)
- * indicates parse failure by setting a failing
- * UErrorCode.
- *
- * <p><strong>Formatting</strong>
- *
- * <p>Formatting is guided by several parameters, all of which can be
- * specified either using a pattern or using the API.  The following
- * description applies to formats that do not use <a href="#sci">scientific
- * notation</a> or <a href="#sigdig">significant digits</a>.
- *
- * <ul><li>If the number of actual integer digits exceeds the
- * <em>maximum integer digits</em>, then only the least significant
- * digits are shown.  For example, 1997 is formatted as "97" if the
- * maximum integer digits is set to 2.
- *
- * <li>If the number of actual integer digits is less than the
- * <em>minimum integer digits</em>, then leading zeros are added.  For
- * example, 1997 is formatted as "01997" if the minimum integer digits
- * is set to 5.
- *
- * <li>If the number of actual fraction digits exceeds the <em>maximum
- * fraction digits</em>, then half-even rounding it performed to the
- * maximum fraction digits.  For example, 0.125 is formatted as "0.12"
- * if the maximum fraction digits is 2.  This behavior can be changed
- * by specifying a rounding increment and a rounding mode.
- *
- * <li>If the number of actual fraction digits is less than the
- * <em>minimum fraction digits</em>, then trailing zeros are added.
- * For example, 0.125 is formatted as "0.1250" if the mimimum fraction
- * digits is set to 4.
- *
- * <li>Trailing fractional zeros are not displayed if they occur
- * <em>j</em> positions after the decimal, where <em>j</em> is less
- * than the maximum fraction digits. For example, 0.10004 is
- * formatted as "0.1" if the maximum fraction digits is four or less.
- * </ul>
- *
- * <p><strong>Special Values</strong>
- *
- * <p><code>NaN</code> is represented as a single character, typically
- * <code>\\uFFFD</code>.  This character is determined by the
- * DecimalFormatSymbols object.  This is the only value for which
- * the prefixes and suffixes are not used.
- *
- * <p>Infinity is represented as a single character, typically
- * <code>\\u221E</code>, with the positive or negative prefixes and suffixes
- * applied.  The infinity character is determined by the
- * DecimalFormatSymbols object.
- *
- * <a name="sci"><strong>Scientific Notation</strong></a>
- *
- * <p>Numbers in scientific notation are expressed as the product of a mantissa
- * and a power of ten, for example, 1234 can be expressed as 1.234 x 10<sup>3</sup>. The
- * mantissa is typically in the half-open interval [1.0, 10.0) or sometimes [0.0, 1.0),
- * but it need not be.  DecimalFormat supports arbitrary mantissas.
- * DecimalFormat can be instructed to use scientific
- * notation through the API or through the pattern.  In a pattern, the exponent
- * character immediately followed by one or more digit characters indicates
- * scientific notation.  Example: "0.###E0" formats the number 1234 as
- * "1.234E3".
- *
- * <ul>
- * <li>The number of digit characters after the exponent character gives the
- * minimum exponent digit count.  There is no maximum.  Negative exponents are
- * formatted using the localized minus sign, <em>not</em> the prefix and suffix
- * from the pattern.  This allows patterns such as "0.###E0 m/s".  To prefix
- * positive exponents with a localized plus sign, specify '+' between the
- * exponent and the digits: "0.###E+0" will produce formats "1E+1", "1E+0",
- * "1E-1", etc.  (In localized patterns, use the localized plus sign rather than
- * '+'.)
- *
- * <li>The minimum number of integer digits is achieved by adjusting the
- * exponent.  Example: 0.00123 formatted with "00.###E0" yields "12.3E-4".  This
- * only happens if there is no maximum number of integer digits.  If there is a
- * maximum, then the minimum number of integer digits is fixed at one.
- *
- * <li>The maximum number of integer digits, if present, specifies the exponent
- * grouping.  The most common use of this is to generate <em>engineering
- * notation</em>, in which the exponent is a multiple of three, e.g.,
- * "##0.###E0".  The number 12345 is formatted using "##0.####E0" as "12.345E3".
- *
- * <li>When using scientific notation, the formatter controls the
- * digit counts using significant digits logic.  The maximum number of
- * significant digits limits the total number of integer and fraction
- * digits that will be shown in the mantissa; it does not affect
- * parsing.  For example, 12345 formatted with "##0.##E0" is "12.3E3".
- * See the section on significant digits for more details.
- *
- * <li>The number of significant digits shown is determined as
- * follows: If areSignificantDigitsUsed() returns false, then the
- * minimum number of significant digits shown is one, and the maximum
- * number of significant digits shown is the sum of the <em>minimum
- * integer</em> and <em>maximum fraction</em> digits, and is
- * unaffected by the maximum integer digits.  If this sum is zero,
- * then all significant digits are shown.  If
- * areSignificantDigitsUsed() returns true, then the significant digit
- * counts are specified by getMinimumSignificantDigits() and
- * getMaximumSignificantDigits().  In this case, the number of
- * integer digits is fixed at one, and there is no exponent grouping.
- *
- * <li>Exponential patterns may not contain grouping separators.
- * </ul>
- *
- * <a name="sigdig"><strong>Significant Digits</strong></a>
- *
- * <code>DecimalFormat</code> has two ways of controlling how many
- * digits are shows: (a) significant digits counts, or (b) integer and
- * fraction digit counts.  Integer and fraction digit counts are
- * described above.  When a formatter is using significant digits
- * counts, the number of integer and fraction digits is not specified
- * directly, and the formatter settings for these counts are ignored.
- * Instead, the formatter uses however many integer and fraction
- * digits are required to display the specified number of significant
- * digits.  Examples:
- *
- * <table border=0 cellspacing=3 cellpadding=0>
- *   <tr bgcolor="#ccccff">
- *     <td align=left>Pattern
- *     <td align=left>Minimum significant digits
- *     <td align=left>Maximum significant digits
- *     <td align=left>Number
- *     <td align=left>Output of format()
- *   <tr valign=top>
- *     <td><code>\@\@\@</code>
- *     <td>3
- *     <td>3
- *     <td>12345
- *     <td><code>12300</code>
- *   <tr valign=top bgcolor="#eeeeff">
- *     <td><code>\@\@\@</code>
- *     <td>3
- *     <td>3
- *     <td>0.12345
- *     <td><code>0.123</code>
- *   <tr valign=top>
- *     <td><code>\@\@##</code>
- *     <td>2
- *     <td>4
- *     <td>3.14159
- *     <td><code>3.142</code>
- *   <tr valign=top bgcolor="#eeeeff">
- *     <td><code>\@\@##</code>
- *     <td>2
- *     <td>4
- *     <td>1.23004
- *     <td><code>1.23</code>
- * </table>
- *
- * <ul>
- * <li>Significant digit counts may be expressed using patterns that
- * specify a minimum and maximum number of significant digits.  These
- * are indicated by the <code>'@'</code> and <code>'#'</code>
- * characters.  The minimum number of significant digits is the number
- * of <code>'@'</code> characters.  The maximum number of significant
- * digits is the number of <code>'@'</code> characters plus the number
- * of <code>'#'</code> characters following on the right.  For
- * example, the pattern <code>"@@@"</code> indicates exactly 3
- * significant digits.  The pattern <code>"@##"</code> indicates from
- * 1 to 3 significant digits.  Trailing zero digits to the right of
- * the decimal separator are suppressed after the minimum number of
- * significant digits have been shown.  For example, the pattern
- * <code>"@##"</code> formats the number 0.1203 as
- * <code>"0.12"</code>.
- *
- * <li>If a pattern uses significant digits, it may not contain a
- * decimal separator, nor the <code>'0'</code> pattern character.
- * Patterns such as <code>"@00"</code> or <code>"@.###"</code> are
- * disallowed.
- *
- * <li>Any number of <code>'#'</code> characters may be prepended to
- * the left of the leftmost <code>'@'</code> character.  These have no
- * effect on the minimum and maximum significant digits counts, but
- * may be used to position grouping separators.  For example,
- * <code>"#,#@#"</code> indicates a minimum of one significant digits,
- * a maximum of two significant digits, and a grouping size of three.
- *
- * <li>In order to enable significant digits formatting, use a pattern
- * containing the <code>'@'</code> pattern character.  Alternatively,
- * call setSignificantDigitsUsed(TRUE).
- *
- * <li>In order to disable significant digits formatting, use a
- * pattern that does not contain the <code>'@'</code> pattern
- * character. Alternatively, call setSignificantDigitsUsed(FALSE).
- *
- * <li>The number of significant digits has no effect on parsing.
- *
- * <li>Significant digits may be used together with exponential notation. Such
- * patterns are equivalent to a normal exponential pattern with a minimum and
- * maximum integer digit count of one, a minimum fraction digit count of
- * <code>getMinimumSignificantDigits() - 1</code>, and a maximum fraction digit
- * count of <code>getMaximumSignificantDigits() - 1</code>. For example, the
- * pattern <code>"@@###E0"</code> is equivalent to <code>"0.0###E0"</code>.
- *
- * <li>If signficant digits are in use, then the integer and fraction
- * digit counts, as set via the API, are ignored.  If significant
- * digits are not in use, then the signficant digit counts, as set via
- * the API, are ignored.
- *
- * </ul>
- *
- * <p><strong>Padding</strong>
- *
- * <p>DecimalFormat supports padding the result of
- * format() to a specific width.  Padding may be specified either
- * through the API or through the pattern syntax.  In a pattern the pad escape
- * character, followed by a single pad character, causes padding to be parsed
- * and formatted.  The pad escape character is '*' in unlocalized patterns, and
- * can be localized using DecimalFormatSymbols::setSymbol() with a
- * DecimalFormatSymbols::kPadEscapeSymbol
- * selector.  For example, <code>"$*x#,##0.00"</code> formats 123 to
- * <code>"$xx123.00"</code>, and 1234 to <code>"$1,234.00"</code>.
- *
- * <ul>
- * <li>When padding is in effect, the width of the positive subpattern,
- * including prefix and suffix, determines the format width.  For example, in
- * the pattern <code>"* #0 o''clock"</code>, the format width is 10.
- *
- * <li>The width is counted in 16-bit code units (UChars).
- *
- * <li>Some parameters which usually do not matter have meaning when padding is
- * used, because the pattern width is significant with padding.  In the pattern
- * "* ##,##,#,##0.##", the format width is 14.  The initial characters "##,##,"
- * do not affect the grouping size or maximum integer digits, but they do affect
- * the format width.
- *
- * <li>Padding may be inserted at one of four locations: before the prefix,
- * after the prefix, before the suffix, or after the suffix.  If padding is
- * specified in any other location, applyPattern()
- * sets a failing UErrorCode.  If there is no prefix,
- * before the prefix and after the prefix are equivalent, likewise for the
- * suffix.
- *
- * <li>When specified in a pattern, the 32-bit code point immediately
- * following the pad escape is the pad character. This may be any character,
- * including a special pattern character. That is, the pad escape
- * <em>escapes</em> the following character. If there is no character after
- * the pad escape, then the pattern is illegal.
- *
- * </ul>
- *
- * <p><strong>Rounding</strong>
- *
- * <p>DecimalFormat supports rounding to a specific increment.  For
- * example, 1230 rounded to the nearest 50 is 1250.  1.234 rounded to the
- * nearest 0.65 is 1.3.  The rounding increment may be specified through the API
- * or in a pattern.  To specify a rounding increment in a pattern, include the
- * increment in the pattern itself.  "#,#50" specifies a rounding increment of
- * 50.  "#,##0.05" specifies a rounding increment of 0.05.
- *
- * <ul>
- * <li>Rounding only affects the string produced by formatting.  It does
- * not affect parsing or change any numerical values.
- *
- * <li>A <em>rounding mode</em> determines how values are rounded; see
- * DecimalFormat::ERoundingMode.  Rounding increments specified in
- * patterns use the default mode, DecimalFormat::kRoundHalfEven.
- *
- * <li>Some locales use rounding in their currency formats to reflect the
- * smallest currency denomination.
- *
- * <li>In a pattern, digits '1' through '9' specify rounding, but otherwise
- * behave identically to digit '0'.
- * </ul>
- *
- * <p><strong>Synchronization</strong>
- *
- * <p>DecimalFormat objects are not synchronized.  Multiple
- * threads should not access one formatter concurrently.
- *
- * <p><strong>Subclassing</strong>
- *
- * <p><em>User subclasses are not supported.</em> While clients may write
- * subclasses, such code will not necessarily work and will not be
- * guaranteed to work stably from release to release.
- */
-class U_I18N_API DecimalFormat: public NumberFormat {
-public:
-    /**
-     * Rounding mode.
-     * @stable ICU 2.4
-     */
-    enum ERoundingMode {
-        kRoundCeiling,  /**< Round towards positive infinity */
-        kRoundFloor,    /**< Round towards negative infinity */
-        kRoundDown,     /**< Round towards zero */
-        kRoundUp,       /**< Round away from zero */
-        kRoundHalfEven, /**< Round towards the nearest integer, or
-                             towards the nearest even integer if equidistant */
-        kRoundHalfDown, /**< Round towards the nearest integer, or
-                             towards zero if equidistant */
-        kRoundHalfUp    /**< Round towards the nearest integer, or
-                             away from zero if equidistant */
-        // We don't support ROUND_UNNECESSARY
-    };
-
-    /**
-     * Pad position.
-     * @stable ICU 2.4
-     */
-    enum EPadPosition {
-        kPadBeforePrefix,
-        kPadAfterPrefix,
-        kPadBeforeSuffix,
-        kPadAfterSuffix
-    };
-
-    /**
-     * Create a DecimalFormat using the default pattern and symbols
-     * for the default locale. This is a convenient way to obtain a
-     * DecimalFormat when internationalization is not the main concern.
-     * <P>
-     * To obtain standard formats for a given locale, use the factory methods
-     * on NumberFormat such as createInstance. These factories will
-     * return the most appropriate sub-class of NumberFormat for a given
-     * locale.
-     * @param status    Output param set to success/failure code. If the
-     *                  pattern is invalid this will be set to a failure code.
-     * @stable ICU 2.0
-     */
-    DecimalFormat(UErrorCode& status);
-
-    /**
-     * Create a DecimalFormat from the given pattern and the symbols
-     * for the default locale. This is a convenient way to obtain a
-     * DecimalFormat when internationalization is not the main concern.
-     * <P>
-     * To obtain standard formats for a given locale, use the factory methods
-     * on NumberFormat such as createInstance. These factories will
-     * return the most appropriate sub-class of NumberFormat for a given
-     * locale.
-     * @param pattern   A non-localized pattern string.
-     * @param status    Output param set to success/failure code. If the
-     *                  pattern is invalid this will be set to a failure code.
-     * @stable ICU 2.0
-     */
-    DecimalFormat(const UnicodeString& pattern,
-                  UErrorCode& status);
-
-    /**
-     * Create a DecimalFormat from the given pattern and symbols.
-     * Use this constructor when you need to completely customize the
-     * behavior of the format.
-     * <P>
-     * To obtain standard formats for a given
-     * locale, use the factory methods on NumberFormat such as
-     * createInstance or createCurrencyInstance. If you need only minor adjustments
-     * to a standard format, you can modify the format returned by
-     * a NumberFormat factory method.
-     *
-     * @param pattern           a non-localized pattern string
-     * @param symbolsToAdopt    the set of symbols to be used.  The caller should not
-     *                          delete this object after making this call.
-     * @param status            Output param set to success/failure code. If the
-     *                          pattern is invalid this will be set to a failure code.
-     * @stable ICU 2.0
-     */
-    DecimalFormat(  const UnicodeString& pattern,
-                    DecimalFormatSymbols* symbolsToAdopt,
-                    UErrorCode& status);
-
-    /**
-     * Create a DecimalFormat from the given pattern and symbols.
-     * Use this constructor when you need to completely customize the
-     * behavior of the format.
-     * <P>
-     * To obtain standard formats for a given
-     * locale, use the factory methods on NumberFormat such as
-     * createInstance or createCurrencyInstance. If you need only minor adjustments
-     * to a standard format, you can modify the format returned by
-     * a NumberFormat factory method.
-     *
-     * @param pattern           a non-localized pattern string
-     * @param symbolsToAdopt    the set of symbols to be used.  The caller should not
-     *                          delete this object after making this call.
-     * @param parseError        Output param to receive errors occured during parsing 
-     * @param status            Output param set to success/failure code. If the
-     *                          pattern is invalid this will be set to a failure code.
-     * @stable ICU 2.0
-     */
-    DecimalFormat(  const UnicodeString& pattern,
-                    DecimalFormatSymbols* symbolsToAdopt,
-                    UParseError& parseError,
-                    UErrorCode& status);
-    /**
-     * Create a DecimalFormat from the given pattern and symbols.
-     * Use this constructor when you need to completely customize the
-     * behavior of the format.
-     * <P>
-     * To obtain standard formats for a given
-     * locale, use the factory methods on NumberFormat such as
-     * createInstance or createCurrencyInstance. If you need only minor adjustments
-     * to a standard format, you can modify the format returned by
-     * a NumberFormat factory method.
-     *
-     * @param pattern           a non-localized pattern string
-     * @param symbols   the set of symbols to be used
-     * @param status            Output param set to success/failure code. If the
-     *                          pattern is invalid this will be set to a failure code.
-     * @stable ICU 2.0
-     */
-    DecimalFormat(  const UnicodeString& pattern,
-                    const DecimalFormatSymbols& symbols,
-                    UErrorCode& status);
-
-    /**
-     * Copy constructor.
-     * 
-     * @param source    the DecimalFormat object to be copied from.
-     * @stable ICU 2.0
-     */
-    DecimalFormat(const DecimalFormat& source);
-
-    /**
-     * Assignment operator.
-     *
-     * @param rhs    the DecimalFormat object to be copied.
-     * @stable ICU 2.0
-     */
-    DecimalFormat& operator=(const DecimalFormat& rhs);
-
-    /**
-     * Destructor.
-     * @stable ICU 2.0
-     */
-    virtual ~DecimalFormat();
-
-    /**
-     * Clone this Format object polymorphically. The caller owns the
-     * result and should delete it when done.
-     *
-     * @return    a polymorphic copy of this DecimalFormat.
-     * @stable ICU 2.0
-     */
-    virtual Format* clone(void) const;
-
-    /**
-     * Return true if the given Format objects are semantically equal.
-     * Objects of different subclasses are considered unequal.
-     *
-     * @param other    the object to be compared with.
-     * @return         true if the given Format objects are semantically equal.
-     * @stable ICU 2.0
-     */
-    virtual UBool operator==(const Format& other) const;
-
-    /**
-     * Format a double or long number using base-10 representation.
-     *
-     * @param number    The value to be formatted.
-     * @param appendTo  Output parameter to receive result.
-     *                  Result is appended to existing contents.
-     * @param pos       On input: an alignment field, if desired.
-     *                  On output: the offsets of the alignment field.
-     * @return          Reference to 'appendTo' parameter.
-     * @stable ICU 2.0
-    */
-    virtual UnicodeString& format(double number,
-                                  UnicodeString& appendTo,
-                                  FieldPosition& pos) const;
-    /**
-     * Format a long number using base-10 representation.
-     *
-     * @param number    The value to be formatted.
-     * @param appendTo  Output parameter to receive result.
-     *                  Result is appended to existing contents.
-     * @param pos       On input: an alignment field, if desired.
-     *                  On output: the offsets of the alignment field.
-     * @return          Reference to 'appendTo' parameter.
-     * @stable ICU 2.0
-     */
-    virtual UnicodeString& format(int32_t number,
-                                  UnicodeString& appendTo,
-                                  FieldPosition& pos) const;
-    /**
-     * Format an int64 number using base-10 representation.
-     *
-     * @param number    The value to be formatted.
-     * @param appendTo  Output parameter to receive result.
-     *                  Result is appended to existing contents.
-     * @param pos       On input: an alignment field, if desired.
-     *                  On output: the offsets of the alignment field.
-     * @return          Reference to 'appendTo' parameter.
-     * @stable ICU 2.8
-     */
-    virtual UnicodeString& format(int64_t number,
-                                  UnicodeString& appendTo,
-                                  FieldPosition& pos) const;
-
-    /**
-     * Format a Formattable using base-10 representation.
-     *
-     * @param obj       The value to be formatted.
-     * @param appendTo  Output parameter to receive result.
-     *                  Result is appended to existing contents.
-     * @param pos       On input: an alignment field, if desired.
-     *                  On output: the offsets of the alignment field.
-     * @param status    Error code indicating success or failure.
-     * @return          Reference to 'appendTo' parameter.
-     * @stable ICU 2.0
-     */
-    virtual UnicodeString& format(const Formattable& obj,
-                                  UnicodeString& appendTo,
-                                  FieldPosition& pos,
-                                  UErrorCode& status) const;
-
-    /**
-     * Redeclared NumberFormat method.
-     * Formats an object to produce a string.
-     *
-     * @param obj       The object to format.
-     * @param appendTo  Output parameter to receive result.
-     *                  Result is appended to existing contents.
-     * @param status    Output parameter filled in with success or failure status.
-     * @return          Reference to 'appendTo' parameter.
-     * @stable ICU 2.0
-     */
-    UnicodeString& format(const Formattable& obj,
-                          UnicodeString& appendTo,
-                          UErrorCode& status) const;
-
-    /**
-     * Redeclared NumberFormat method.
-     * Format a double number.
-     *
-     * @param number    The value to be formatted.
-     * @param appendTo  Output parameter to receive result.
-     *                  Result is appended to existing contents.
-     * @return          Reference to 'appendTo' parameter.
-     * @stable ICU 2.0
-     */
-    UnicodeString& format(double number,
-                          UnicodeString& appendTo) const;
-
-    /**
-     * Redeclared NumberFormat method.
-     * Format a long number. These methods call the NumberFormat
-     * pure virtual format() methods with the default FieldPosition.
-     *
-     * @param number    The value to be formatted.
-     * @param appendTo  Output parameter to receive result.
-     *                  Result is appended to existing contents.
-     * @return          Reference to 'appendTo' parameter.
-     * @stable ICU 2.0
-     */
-    UnicodeString& format(int32_t number,
-                          UnicodeString& appendTo) const;
-
-    /**
-     * Redeclared NumberFormat method.
-     * Format an int64 number. These methods call the NumberFormat
-     * pure virtual format() methods with the default FieldPosition.
-     *
-     * @param number    The value to be formatted.
-     * @param appendTo  Output parameter to receive result.
-     *                  Result is appended to existing contents.
-     * @return          Reference to 'appendTo' parameter.
-     * @stable ICU 2.8
-     */
-    UnicodeString& format(int64_t number,
-                          UnicodeString& appendTo) const;
-   /**
-    * Parse the given string using this object's choices. The method
-    * does string comparisons to try to find an optimal match.
-    * If no object can be parsed, index is unchanged, and NULL is
-    * returned.  The result is returned as the most parsimonious
-    * type of Formattable that will accomodate all of the
-    * necessary precision.  For example, if the result is exactly 12,
-    * it will be returned as a long.  However, if it is 1.5, it will
-    * be returned as a double.
-    *
-    * @param text           The text to be parsed.
-    * @param result         Formattable to be set to the parse result.
-    *                       If parse fails, return contents are undefined.
-    * @param parsePosition  The position to start parsing at on input.
-    *                       On output, moved to after the last successfully
-    *                       parse character. On parse failure, does not change.
-    * @see Formattable
-    * @stable ICU 2.0
-    */
-    virtual void parse(const UnicodeString& text,
-                       Formattable& result,
-                       ParsePosition& parsePosition) const;
-
-    // Declare here again to get rid of function hiding problems.
-    /** 
-     * Parse the given string using this object's choices.
-     *
-     * @param text           The text to be parsed.
-     * @param result         Formattable to be set to the parse result.
-     * @param status    Output parameter filled in with success or failure status.
-     * @stable ICU 2.0
-     */
-    virtual void parse(const UnicodeString& text, 
-                       Formattable& result, 
-                       UErrorCode& status) const;
-
-    /**
-     * Parses text from the given string as a currency amount.  Unlike
-     * the parse() method, this method will attempt to parse a generic
-     * currency name, searching for a match of this object's locale's
-     * currency display names, or for a 3-letter ISO currency code.
-     * This method will fail if this format is not a currency format,
-     * that is, if it does not contain the currency pattern symbol
-     * (U+00A4) in its prefix or suffix.
-     *
-     * @param text the string to parse
-     * @param result output parameter to receive result. This will have
-     * its currency set to the parsed ISO currency code.
-     * @param pos input-output position; on input, the position within
-     * text to match; must have 0 <= pos.getIndex() < text.length();
-     * on output, the position after the last matched character. If
-     * the parse fails, the position in unchanged upon output.
-     * @return a reference to result
-     * @internal
-     */
-    virtual Formattable& parseCurrency(const UnicodeString& text,
-                                       Formattable& result,
-                                       ParsePosition& pos) const;
-
-    /**
-     * Returns the decimal format symbols, which is generally not changed
-     * by the programmer or user.
-     * @return desired DecimalFormatSymbols
-     * @see DecimalFormatSymbols
-     * @stable ICU 2.0
-     */
-    virtual const DecimalFormatSymbols* getDecimalFormatSymbols(void) const;
-
-    /**
-     * Sets the decimal format symbols, which is generally not changed
-     * by the programmer or user.
-     * @param symbolsToAdopt DecimalFormatSymbols to be adopted.
-     * @stable ICU 2.0
-     */
-    virtual void adoptDecimalFormatSymbols(DecimalFormatSymbols* symbolsToAdopt);
-
-    /**
-     * Sets the decimal format symbols, which is generally not changed
-     * by the programmer or user.
-     * @param symbols DecimalFormatSymbols.
-     * @stable ICU 2.0
-     */
-    virtual void setDecimalFormatSymbols(const DecimalFormatSymbols& symbols);
-
-
-    /**
-     * Get the positive prefix.
-     *
-     * @param result    Output param which will receive the positive prefix.
-     * @return          A reference to 'result'.
-     * Examples: +123, $123, sFr123
-     * @stable ICU 2.0
-     */
-    UnicodeString& getPositivePrefix(UnicodeString& result) const;
-
-    /**
-     * Set the positive prefix.
-     *
-     * @param newValue    the new value of the the positive prefix to be set.
-     * Examples: +123, $123, sFr123
-     * @stable ICU 2.0
-     */
-    virtual void setPositivePrefix(const UnicodeString& newValue);
-
-    /**
-     * Get the negative prefix.
-     *
-     * @param result    Output param which will receive the negative prefix.
-     * @return          A reference to 'result'.
-     * Examples: -123, ($123) (with negative suffix), sFr-123
-     * @stable ICU 2.0
-     */
-    UnicodeString& getNegativePrefix(UnicodeString& result) const;
-
-    /**
-     * Set the negative prefix.
-     *
-     * @param newValue    the new value of the the negative prefix to be set.
-     * Examples: -123, ($123) (with negative suffix), sFr-123
-     * @stable ICU 2.0
-     */
-    virtual void setNegativePrefix(const UnicodeString& newValue);
-
-    /**
-     * Get the positive suffix.
-     *
-     * @param result    Output param which will receive the positive suffix.
-     * @return          A reference to 'result'.
-     * Example: 123%
-     * @stable ICU 2.0
-     */
-    UnicodeString& getPositiveSuffix(UnicodeString& result) const;
-
-    /**
-     * Set the positive suffix.
-     *
-     * @param newValue    the new value of the positive suffix to be set.
-     * Example: 123%
-     * @stable ICU 2.0
-     */
-    virtual void setPositiveSuffix(const UnicodeString& newValue);
-
-    /**
-     * Get the negative suffix.
-     *
-     * @param result    Output param which will receive the negative suffix.
-     * @return          A reference to 'result'.
-     * Examples: -123%, ($123) (with positive suffixes)
-     * @stable ICU 2.0
-     */
-    UnicodeString& getNegativeSuffix(UnicodeString& result) const;
-
-    /**
-     * Set the negative suffix.
-     *
-     * @param newValue    the new value of the negative suffix to be set.
-     * Examples: 123%
-     * @stable ICU 2.0
-     */
-    virtual void setNegativeSuffix(const UnicodeString& newValue);
-
-    /**
-     * Get the multiplier for use in percent, permill, etc.
-     * For a percentage, set the suffixes to have "%" and the multiplier to be 100.
-     * (For Arabic, use arabic percent symbol).
-     * For a permill, set the suffixes to have "\\u2031" and the multiplier to be 1000.
-     *
-     * @return    the multiplier for use in percent, permill, etc.
-     * Examples: with 100, 1.23 -> "123", and "123" -> 1.23
-     * @stable ICU 2.0
-     */
-    int32_t getMultiplier(void) const;
-
-    /**
-     * Set the multiplier for use in percent, permill, etc.
-     * For a percentage, set the suffixes to have "%" and the multiplier to be 100.
-     * (For Arabic, use arabic percent symbol).
-     * For a permill, set the suffixes to have "\\u2031" and the multiplier to be 1000.
-     *
-     * @param newValue    the new value of the multiplier for use in percent, permill, etc.
-     * Examples: with 100, 1.23 -> "123", and "123" -> 1.23
-     * @stable ICU 2.0
-     */
-    virtual void setMultiplier(int32_t newValue);
-
-    /**
-     * Get the rounding increment.
-     * @return A positive rounding increment, or 0.0 if rounding
-     * is not in effect.
-     * @see #setRoundingIncrement
-     * @see #getRoundingMode
-     * @see #setRoundingMode
-     * @stable ICU 2.0
-     */
-    virtual double getRoundingIncrement(void) const;
-
-    /**
-     * Set the rounding increment.  This method also controls whether
-     * rounding is enabled.
-     * @param newValue A positive rounding increment, or 0.0 to disable rounding.
-     * Negative increments are equivalent to 0.0.
-     * @see #getRoundingIncrement
-     * @see #getRoundingMode
-     * @see #setRoundingMode
-     * @stable ICU 2.0
-     */
-    virtual void setRoundingIncrement(double newValue);
-
-    /**
-     * Get the rounding mode.
-     * @return A rounding mode
-     * @see #setRoundingIncrement
-     * @see #getRoundingIncrement
-     * @see #setRoundingMode
-     * @stable ICU 2.0
-     */
-    virtual ERoundingMode getRoundingMode(void) const;
-
-    /**
-     * Set the rounding mode.  This has no effect unless the rounding
-     * increment is greater than zero.
-     * @param roundingMode A rounding mode
-     * @see #setRoundingIncrement
-     * @see #getRoundingIncrement
-     * @see #getRoundingMode
-     * @stable ICU 2.0
-     */
-    virtual void setRoundingMode(ERoundingMode roundingMode);
-
-    /**
-     * Get the width to which the output of format() is padded.
-     * The width is counted in 16-bit code units.
-     * @return the format width, or zero if no padding is in effect
-     * @see #setFormatWidth
-     * @see #getPadCharacterString
-     * @see #setPadCharacter
-     * @see #getPadPosition
-     * @see #setPadPosition
-     * @stable ICU 2.0
-     */
-    virtual int32_t getFormatWidth(void) const;
-
-    /**
-     * Set the width to which the output of format() is padded.
-     * The width is counted in 16-bit code units.
-     * This method also controls whether padding is enabled.
-     * @param width the width to which to pad the result of
-     * format(), or zero to disable padding.  A negative
-     * width is equivalent to 0.
-     * @see #getFormatWidth
-     * @see #getPadCharacterString
-     * @see #setPadCharacter
-     * @see #getPadPosition
-     * @see #setPadPosition
-     * @stable ICU 2.0
-     */
-    virtual void setFormatWidth(int32_t width);
-
-    /**
-     * Get the pad character used to pad to the format width.  The
-     * default is ' '.
-     * @return a string containing the pad character. This will always
-     * have a length of one 32-bit code point.
-     * @see #setFormatWidth
-     * @see #getFormatWidth
-     * @see #setPadCharacter
-     * @see #getPadPosition
-     * @see #setPadPosition
-     * @stable ICU 2.0
-     */
-    virtual UnicodeString getPadCharacterString() const;
-
-    /**
-     * Set the character used to pad to the format width.  If padding
-     * is not enabled, then this will take effect if padding is later
-     * enabled.
-     * @param padChar a string containing the pad charcter. If the string
-     * has length 0, then the pad characer is set to ' '.  Otherwise
-     * padChar.char32At(0) will be used as the pad character.
-     * @see #setFormatWidth
-     * @see #getFormatWidth
-     * @see #getPadCharacterString
-     * @see #getPadPosition
-     * @see #setPadPosition
-     * @stable ICU 2.0
-     */
-    virtual void setPadCharacter(const UnicodeString &padChar);
-
-    /**
-     * Get the position at which padding will take place.  This is the location
-     * at which padding will be inserted if the result of format()
-     * is shorter than the format width.
-     * @return the pad position, one of kPadBeforePrefix,
-     * kPadAfterPrefix, kPadBeforeSuffix, or
-     * kPadAfterSuffix.
-     * @see #setFormatWidth
-     * @see #getFormatWidth
-     * @see #setPadCharacter
-     * @see #getPadCharacterString
-     * @see #setPadPosition
-     * @see #EPadPosition
-     * @stable ICU 2.0
-     */
-    virtual EPadPosition getPadPosition(void) const;
-
-    /**
-     * Set the position at which padding will take place.  This is the location
-     * at which padding will be inserted if the result of format()
-     * is shorter than the format width.  This has no effect unless padding is
-     * enabled.
-     * @param padPos the pad position, one of kPadBeforePrefix,
-     * kPadAfterPrefix, kPadBeforeSuffix, or
-     * kPadAfterSuffix.
-     * @see #setFormatWidth
-     * @see #getFormatWidth
-     * @see #setPadCharacter
-     * @see #getPadCharacterString
-     * @see #getPadPosition
-     * @see #EPadPosition
-     * @stable ICU 2.0
-     */
-    virtual void setPadPosition(EPadPosition padPos);
-
-    /**
-     * Return whether or not scientific notation is used.
-     * @return TRUE if this object formats and parses scientific notation
-     * @see #setScientificNotation
-     * @see #getMinimumExponentDigits
-     * @see #setMinimumExponentDigits
-     * @see #isExponentSignAlwaysShown
-     * @see #setExponentSignAlwaysShown
-     * @stable ICU 2.0
-     */
-    virtual UBool isScientificNotation(void);
-
-    /**
-     * Set whether or not scientific notation is used. When scientific notation
-     * is used, the effective maximum number of integer digits is <= 8.  If the
-     * maximum number of integer digits is set to more than 8, the effective
-     * maximum will be 1.  This allows this call to generate a 'default' scientific
-     * number format without additional changes.
-     * @param useScientific TRUE if this object formats and parses scientific
-     * notation
-     * @see #isScientificNotation
-     * @see #getMinimumExponentDigits
-     * @see #setMinimumExponentDigits
-     * @see #isExponentSignAlwaysShown
-     * @see #setExponentSignAlwaysShown
-     * @stable ICU 2.0
-     */
-    virtual void setScientificNotation(UBool useScientific);
-
-    /**
-     * Return the minimum exponent digits that will be shown.
-     * @return the minimum exponent digits that will be shown
-     * @see #setScientificNotation
-     * @see #isScientificNotation
-     * @see #setMinimumExponentDigits
-     * @see #isExponentSignAlwaysShown
-     * @see #setExponentSignAlwaysShown
-     * @stable ICU 2.0
-     */
-    virtual int8_t getMinimumExponentDigits(void) const;
-
-    /**
-     * Set the minimum exponent digits that will be shown.  This has no
-     * effect unless scientific notation is in use.
-     * @param minExpDig a value >= 1 indicating the fewest exponent digits
-     * that will be shown.  Values less than 1 will be treated as 1.
-     * @see #setScientificNotation
-     * @see #isScientificNotation
-     * @see #getMinimumExponentDigits
-     * @see #isExponentSignAlwaysShown
-     * @see #setExponentSignAlwaysShown
-     * @stable ICU 2.0
-     */
-    virtual void setMinimumExponentDigits(int8_t minExpDig);
-
-    /**
-     * Return whether the exponent sign is always shown.
-     * @return TRUE if the exponent is always prefixed with either the
-     * localized minus sign or the localized plus sign, false if only negative
-     * exponents are prefixed with the localized minus sign.
-     * @see #setScientificNotation
-     * @see #isScientificNotation
-     * @see #setMinimumExponentDigits
-     * @see #getMinimumExponentDigits
-     * @see #setExponentSignAlwaysShown
-     * @stable ICU 2.0
-     */
-    virtual UBool isExponentSignAlwaysShown(void);
-
-    /**
-     * Set whether the exponent sign is always shown.  This has no effect
-     * unless scientific notation is in use.
-     * @param expSignAlways TRUE if the exponent is always prefixed with either
-     * the localized minus sign or the localized plus sign, false if only
-     * negative exponents are prefixed with the localized minus sign.
-     * @see #setScientificNotation
-     * @see #isScientificNotation
-     * @see #setMinimumExponentDigits
-     * @see #getMinimumExponentDigits
-     * @see #isExponentSignAlwaysShown
-     * @stable ICU 2.0
-     */
-    virtual void setExponentSignAlwaysShown(UBool expSignAlways);
-
-    /**
-     * Return the grouping size. Grouping size is the number of digits between
-     * grouping separators in the integer portion of a number.  For example,
-     * in the number "123,456.78", the grouping size is 3.
-     *
-     * @return    the grouping size.
-     * @see setGroupingSize
-     * @see NumberFormat::isGroupingUsed
-     * @see DecimalFormatSymbols::getGroupingSeparator
-     * @stable ICU 2.0
-     */
-    int32_t getGroupingSize(void) const;
-
-    /**
-     * Set the grouping size. Grouping size is the number of digits between
-     * grouping separators in the integer portion of a number.  For example,
-     * in the number "123,456.78", the grouping size is 3.
-     *
-     * @param newValue    the new value of the grouping size.
-     * @see getGroupingSize
-     * @see NumberFormat::setGroupingUsed
-     * @see DecimalFormatSymbols::setGroupingSeparator
-     * @stable ICU 2.0
-     */
-    virtual void setGroupingSize(int32_t newValue);
-
-    /**
-     * Return the secondary grouping size. In some locales one
-     * grouping interval is used for the least significant integer
-     * digits (the primary grouping size), and another is used for all
-     * others (the secondary grouping size).  A formatter supporting a
-     * secondary grouping size will return a positive integer unequal
-     * to the primary grouping size returned by
-     * getGroupingSize().  For example, if the primary
-     * grouping size is 4, and the secondary grouping size is 2, then
-     * the number 123456789 formats as "1,23,45,6789", and the pattern
-     * appears as "#,##,###0".
-     * @return the secondary grouping size, or a value less than
-     * one if there is none
-     * @see setSecondaryGroupingSize
-     * @see NumberFormat::isGroupingUsed
-     * @see DecimalFormatSymbols::getGroupingSeparator
-     * @stable ICU 2.4
-     */
-    int32_t getSecondaryGroupingSize(void) const;
-
-    /**
-     * Set the secondary grouping size. If set to a value less than 1,
-     * then secondary grouping is turned off, and the primary grouping
-     * size is used for all intervals, not just the least significant.
-     *
-     * @param newValue    the new value of the secondary grouping size.
-     * @see getSecondaryGroupingSize
-     * @see NumberFormat#setGroupingUsed
-     * @see DecimalFormatSymbols::setGroupingSeparator
-     * @stable ICU 2.4
-     */
-    virtual void setSecondaryGroupingSize(int32_t newValue);
-
-    /**
-     * Allows you to get the behavior of the decimal separator with integers.
-     * (The decimal separator will always appear with decimals.)
-     *
-     * @return    TRUE if the decimal separator always appear with decimals.
-     * Example: Decimal ON: 12345 -> 12345.; OFF: 12345 -> 12345
-     * @stable ICU 2.0
-     */
-    UBool isDecimalSeparatorAlwaysShown(void) const;
-
-    /**
-     * Allows you to set the behavior of the decimal separator with integers.
-     * (The decimal separator will always appear with decimals.)
-     *
-     * @param newValue    set TRUE if the decimal separator will always appear with decimals.
-     * Example: Decimal ON: 12345 -> 12345.; OFF: 12345 -> 12345
-     * @stable ICU 2.0
-     */
-    virtual void setDecimalSeparatorAlwaysShown(UBool newValue);
-
-    /**
-     * Synthesizes a pattern string that represents the current state
-     * of this Format object.
-     *
-     * @param result    Output param which will receive the pattern.
-     *                  Previous contents are deleted.
-     * @return          A reference to 'result'.
-     * @see applyPattern
-     * @stable ICU 2.0
-     */
-    virtual UnicodeString& toPattern(UnicodeString& result) const;
-
-    /**
-     * Synthesizes a localized pattern string that represents the current
-     * state of this Format object.
-     *
-     * @param result    Output param which will receive the localized pattern.
-     *                  Previous contents are deleted.
-     * @return          A reference to 'result'.
-     * @see applyPattern
-     * @stable ICU 2.0
-     */
-    virtual UnicodeString& toLocalizedPattern(UnicodeString& result) const;
- 
-    /**
-     * Apply the given pattern to this Format object.  A pattern is a
-     * short-hand specification for the various formatting properties.
-     * These properties can also be changed individually through the
-     * various setter methods.
-     * <P>
-     * There is no limit to integer digits are set
-     * by this routine, since that is the typical end-user desire;
-     * use setMaximumInteger if you want to set a real value.
-     * For negative numbers, use a second pattern, separated by a semicolon
-     * <pre>
-     * .      Example "#,#00.0#" -> 1,234.56
-     * </pre>
-     * This means a minimum of 2 integer digits, 1 fraction digit, and
-     * a maximum of 2 fraction digits.
-     * <pre>
-     * .      Example: "#,#00.0#;(#,#00.0#)" for negatives in parantheses.
-     * </pre>
-     * In negative patterns, the minimum and maximum counts are ignored;
-     * these are presumed to be set in the positive pattern.
-     *
-     * @param pattern    The pattern to be applied.
-     * @param parseError Struct to recieve information on position 
-     *                   of error if an error is encountered
-     * @param status     Output param set to success/failure code on
-     *                   exit. If the pattern is invalid, this will be
-     *                   set to a failure result.
-     * @stable ICU 2.0
-     */
-    virtual void applyPattern(const UnicodeString& pattern,
-                             UParseError& parseError,
-                             UErrorCode& status);
-    /**
-     * Sets the pattern.
-     * @param pattern   The pattern to be applied.
-     * @param status    Output param set to success/failure code on
-     *                  exit. If the pattern is invalid, this will be
-     *                  set to a failure result.
-     * @stable ICU 2.0
-     */  
-    virtual void applyPattern(const UnicodeString& pattern,
-                             UErrorCode& status);
-
-    /**
-     * Apply the given pattern to this Format object.  The pattern
-     * is assumed to be in a localized notation. A pattern is a
-     * short-hand specification for the various formatting properties.
-     * These properties can also be changed individually through the
-     * various setter methods.
-     * <P>
-     * There is no limit to integer digits are set
-     * by this routine, since that is the typical end-user desire;
-     * use setMaximumInteger if you want to set a real value.
-     * For negative numbers, use a second pattern, separated by a semicolon
-     * <pre>
-     * .      Example "#,#00.0#" -> 1,234.56
-     * </pre>
-     * This means a minimum of 2 integer digits, 1 fraction digit, and
-     * a maximum of 2 fraction digits.
-     *
-     * Example: "#,#00.0#;(#,#00.0#)" for negatives in parantheses.
-     *
-     * In negative patterns, the minimum and maximum counts are ignored;
-     * these are presumed to be set in the positive pattern.
-     *
-     * @param pattern   The localized pattern to be applied.
-     * @param parseError Struct to recieve information on position 
-     *                   of error if an error is encountered
-     * @param status    Output param set to success/failure code on
-     *                  exit. If the pattern is invalid, this will be
-     *                  set to a failure result.
-     * @stable ICU 2.0
-     */
-    virtual void applyLocalizedPattern(const UnicodeString& pattern,
-                                       UParseError& parseError,
-                                       UErrorCode& status);
-
-    /**
-     * Apply the given pattern to this Format object.
-     *
-     * @param pattern   The localized pattern to be applied.
-     * @param status    Output param set to success/failure code on
-     *                  exit. If the pattern is invalid, this will be
-     *                  set to a failure result.
-     * @stable ICU 2.0
-     */
-    virtual void applyLocalizedPattern(const UnicodeString& pattern,
-                                       UErrorCode& status);
-
-
-    /**
-     * Sets the maximum number of digits allowed in the integer portion of a
-     * number. This override limits the integer digit count to 309.
-     *
-     * @param newValue    the new value of the maximum number of digits 
-     *                      allowed in the integer portion of a number.
-     * @see NumberFormat#setMaximumIntegerDigits
-     * @stable ICU 2.0
-     */
-    virtual void setMaximumIntegerDigits(int32_t newValue);
-
-    /**
-     * Sets the minimum number of digits allowed in the integer portion of a
-     * number. This override limits the integer digit count to 309.
-     * 
-     * @param newValue    the new value of the minimum number of digits 
-     *                      allowed in the integer portion of a number.
-     * @see NumberFormat#setMinimumIntegerDigits
-     * @stable ICU 2.0
-     */
-    virtual void setMinimumIntegerDigits(int32_t newValue);
-
-    /**
-     * Sets the maximum number of digits allowed in the fraction portion of a
-     * number. This override limits the fraction digit count to 340.
-     *
-     * @param newValue    the new value of the maximum number of digits 
-     *                    allowed in the fraction portion of a number.
-     * @see NumberFormat#setMaximumFractionDigits
-     * @stable ICU 2.0
-     */
-    virtual void setMaximumFractionDigits(int32_t newValue);
-
-    /**
-     * Sets the minimum number of digits allowed in the fraction portion of a
-     * number. This override limits the fraction digit count to 340.
-     *
-     * @param newValue    the new value of the minimum number of digits 
-     *                    allowed in the fraction portion of a number.
-     * @see NumberFormat#setMinimumFractionDigits
-     * @stable ICU 2.0
-     */
-    virtual void setMinimumFractionDigits(int32_t newValue);
-
-    /**
-     * Returns the minimum number of significant digits that will be
-     * displayed. This value has no effect unless areSignificantDigitsUsed()
-     * returns true.
-     * @return the fewest significant digits that will be shown
-     * @stable ICU 3.0
-     */
-    int32_t getMinimumSignificantDigits() const;
-
-    /**
-     * Returns the maximum number of significant digits that will be
-     * displayed. This value has no effect unless areSignificantDigitsUsed()
-     * returns true.
-     * @return the most significant digits that will be shown
-     * @stable ICU 3.0
-     */
-    int32_t getMaximumSignificantDigits() const;
-
-    /**
-     * Sets the minimum number of significant digits that will be
-     * displayed.  If <code>min</code> is less than one then it is set
-     * to one.  If the maximum significant digits count is less than
-     * <code>min</code>, then it is set to <code>min</code>. This
-     * value has no effect unless areSignificantDigits() returns true.
-     * @param min the fewest significant digits to be shown 
-     * @stable ICU 3.0
-     */
-    void setMinimumSignificantDigits(int32_t min);
-
-    /**
-     * Sets the maximum number of significant digits that will be
-     * displayed.  If <code>max</code> is less than one then it is set
-     * to one.  If the minimum significant digits count is greater
-     * than <code>max</code>, then it is set to <code>max</code>.
-     * This value has no effect unless areSignificantDigits() returns
-     * true.
-     * @param max the most significant digits to be shown 
-     * @stable ICU 3.0
-     */
-    void setMaximumSignificantDigits(int32_t max);
-
-    /**
-     * Returns true if significant digits are in use, or false if
-     * integer and fraction digit counts are in use.
-     * @return true if significant digits are in use
-     * @stable ICU 3.0
-     */
-    UBool areSignificantDigitsUsed() const;
-
-    /**
-     * Sets whether significant digits are in use, or integer and
-     * fraction digit counts are in use.
-     * @param useSignificantDigits true to use significant digits, or
-     * false to use integer and fraction digit counts
-     * @stable ICU 3.0
-     */
-    void setSignificantDigitsUsed(UBool useSignificantDigits);
-
- public:
-    /**
-     * Sets the currency used to display currency
-     * amounts.  This takes effect immediately, if this format is a
-     * currency format.  If this format is not a currency format, then
-     * the currency is used if and when this object becomes a
-     * currency format through the application of a new pattern.
-     * @param theCurrency a 3-letter ISO code indicating new currency
-     * to use.  It need not be null-terminated.  May be the empty
-     * string or NULL to indicate no currency.
-     * @param ec input-output error code
-     * @stable ICU 3.0
-     */
-    virtual void setCurrency(const UChar* theCurrency, UErrorCode& ec);
-
-    /**
-     * Sets the currency used to display currency amounts.  See
-     * setCurrency(const UChar*, UErrorCode&).
-     * @deprecated ICU 3.0. Use setCurrency(const UChar*, UErrorCode&).
-     */
-    virtual void setCurrency(const UChar* theCurrency);
-
-    /**
-     * The resource tags we use to retrieve decimal format data from
-     * locale resource bundles.
-     * @deprecated ICU 3.4. This string has no public purpose. Please don't use it.
-     */
-    static const char fgNumberPatterns[];
-
-public:
-
-    /**
-     * Return the class ID for this class.  This is useful only for
-     * comparing to a return value from getDynamicClassID().  For example:
-     * <pre>
-     * .      Base* polymorphic_pointer = createPolymorphicObject();
-     * .      if (polymorphic_pointer->getDynamicClassID() ==
-     * .          Derived::getStaticClassID()) ...
-     * </pre>
-     * @return          The class ID for all objects of this class.
-     * @stable ICU 2.0
-     */
-    static UClassID U_EXPORT2 getStaticClassID(void);
-
-    /**
-     * Returns a unique class ID POLYMORPHICALLY.  Pure virtual override.
-     * This method is to implement a simple version of RTTI, since not all
-     * C++ compilers support genuine RTTI.  Polymorphic operator==() and
-     * clone() methods call this method.
-     *
-     * @return          The class ID for this object. All objects of a
-     *                  given class have the same class ID.  Objects of
-     *                  other classes have different class IDs.
-     * @stable ICU 2.0
-     */
-    virtual UClassID getDynamicClassID(void) const;
-
-private:
-    DecimalFormat(); // default constructor not implemented
-
-    int32_t precision(UBool isIntegral) const;
-
-    /**
-     * Do real work of constructing a new DecimalFormat.
-     */
-    void construct(UErrorCode&               status,
-                   UParseError&             parseErr,
-                   const UnicodeString*     pattern = 0,
-                   DecimalFormatSymbols*    symbolsToAdopt = 0
-                   );
-
-    /**
-     * Does the real work of generating a pattern.
-     *
-     * @param result     Output param which will receive the pattern.
-     *                   Previous contents are deleted.
-     * @param localized  TRUE return localized pattern.
-     * @return           A reference to 'result'.
-     */
-    UnicodeString& toPattern(UnicodeString& result, UBool localized) const;
-
-    /**
-     * Does the real work of applying a pattern.
-     * @param pattern    The pattern to be applied.
-     * @param localized  If true, the pattern is localized; else false.
-     * @param parseError Struct to recieve information on position 
-     *                   of error if an error is encountered
-     * @param status     Output param set to success/failure code on
-     *                   exit. If the pattern is invalid, this will be
-     *                   set to a failure result.
-     */
-    void applyPattern(const UnicodeString& pattern,
-                            UBool localized,
-                            UParseError& parseError,
-                            UErrorCode& status);
-    /**
-     * Do the work of formatting a number, either a double or a long.
-     *
-     * @param appendTo       Output parameter to receive result.
-     *                       Result is appended to existing contents.
-     * @param fieldPosition  On input: an alignment field, if desired.
-     *                       On output: the offsets of the alignment field.
-     * @param digits         the digits to be formatted.
-     * @param isInteger      if TRUE format the digits as Integer.
-     * @return               Reference to 'appendTo' parameter.
-     */
-    UnicodeString& subformat(UnicodeString& appendTo,
-                             FieldPosition& fieldPosition,
-                             DigitList& digits,
-                             UBool         isInteger) const;
-
-    void parse(const UnicodeString& text,
-               Formattable& result,
-               ParsePosition& pos,
-               UBool parseCurrency) const;
-
-    enum {
-        fgStatusInfinite,
-        fgStatusLength      // Leave last in list.
-    } StatusFlags;
-
-    UBool subparse(const UnicodeString& text, ParsePosition& parsePosition,
-                   DigitList& digits, UBool* status,
-                   UChar* currency) const;
-
-    int32_t skipPadding(const UnicodeString& text, int32_t position) const;
-
-    int32_t compareAffix(const UnicodeString& input,
-                         int32_t pos,
-                         UBool isNegative,
-                         UBool isPrefix,
-                         UChar* currency) const;
-    
-    static int32_t compareSimpleAffix(const UnicodeString& affix,
-                                      const UnicodeString& input,
-                                      int32_t pos,
-                                      UBool strict);
-    
-    static int32_t skipRuleWhiteSpace(const UnicodeString& text, int32_t pos);
-    
-    static int32_t skipUWhiteSpace(const UnicodeString& text, int32_t pos);
-    
-    int32_t compareComplexAffix(const UnicodeString& affixPat,
-                                const UnicodeString& input,
-                                int32_t pos,
-                                UChar* currency) const;
-
-    static int32_t match(const UnicodeString& text, int32_t pos, UChar32 ch);
-
-    static int32_t match(const UnicodeString& text, int32_t pos, const UnicodeString& str);
-	
-    static UBool matchSymbol(const UnicodeString &text, int32_t position, int32_t length, const UnicodeString &symbol,
-                             UnicodeSet *sset, UChar32 schar);
-	
-    /**
-     * Get a decimal format symbol.
-     * Returns a const reference to the symbol string.
-     * @internal
-     */
-    inline const UnicodeString &getConstSymbol(DecimalFormatSymbols::ENumberFormatSymbol symbol) const;
-
-    int32_t appendAffix(UnicodeString& buf, double number,
-                        UBool isNegative, UBool isPrefix) const;
-
-    /**
-     * Append an affix to the given UnicodeString, using quotes if
-     * there are special characters.  Single quotes themselves must be
-     * escaped in either case.
-     */
-    void appendAffixPattern(UnicodeString& appendTo, const UnicodeString& affix, 
-                            UBool localized) const;
-
-    void appendAffixPattern(UnicodeString& appendTo,
-                            const UnicodeString* affixPattern,
-                            const UnicodeString& expAffix, UBool localized) const;
-
-    void expandAffix(const UnicodeString& pattern,
-                     UnicodeString& affix,
-                     double number,
-                     UBool doFormat) const;
-
-    void expandAffixes();
-    
-    static double round(double a, ERoundingMode mode, UBool isNegative);
-
-    void addPadding(UnicodeString& appendTo,
-                    FieldPosition& fieldPosition,
-                    int32_t prefixLen, int32_t suffixLen) const;
-
-    UBool isGroupingPosition(int32_t pos) const;
-
-    void setCurrencyForSymbols();
-
-    /**
-     * Constants.
-     */
-    //static const int8_t fgMaxDigit; // The largest digit, in this case 9
-
-    /*transient*/ //DigitList* fDigitList;
-
-    UnicodeString           fPositivePrefix;
-    UnicodeString           fPositiveSuffix;
-    UnicodeString           fNegativePrefix;
-    UnicodeString           fNegativeSuffix;
-    UnicodeString*          fPosPrefixPattern;
-    UnicodeString*          fPosSuffixPattern;
-    UnicodeString*          fNegPrefixPattern;
-    UnicodeString*          fNegSuffixPattern;
-
-    /**
-     * Formatter for ChoiceFormat-based currency names.  If this field
-     * is not null, then delegate to it to format currency symbols.
-     * @since ICU 2.6
-     */
-    ChoiceFormat*           fCurrencyChoice;
-
-    int32_t                 fMultiplier;
-    int32_t                 fGroupingSize;
-    int32_t                 fGroupingSize2;
-    UBool                   fDecimalSeparatorAlwaysShown;
-    /*transient*/ UBool     fIsCurrencyFormat;
-    DecimalFormatSymbols*   fSymbols;
-
-    UBool                   fUseSignificantDigits;
-    int32_t                 fMinSignificantDigits;
-    int32_t                 fMaxSignificantDigits;
-
-    UBool                   fUseExponentialNotation;
-    int8_t                  fMinExponentDigits;
-    UBool                   fExponentSignAlwaysShown;
-
-    /* If fRoundingIncrement is NULL, there is no rounding.  Otherwise, round to
-     * fRoundingIncrement.getDouble().  Since this operation may be expensive,
-     * we cache the result in fRoundingDouble.  All methods that update
-     * fRoundingIncrement also update fRoundingDouble. */
-    DigitList*              fRoundingIncrement;
-    /*transient*/ double    fRoundingDouble;
-    ERoundingMode           fRoundingMode;
-
-    UChar32                 fPad;
-    int32_t                 fFormatWidth;
-    EPadPosition            fPadPosition;
-
-protected:
-
-    /**
-     * Returns the currency in effect for this formatter.  Subclasses
-     * should override this method as needed.  Unlike getCurrency(),
-     * this method should never return "".
-     * @result output parameter for null-terminated result, which must
-     * have a capacity of at least 4
-     * @internal
-     */
-    virtual void getEffectiveCurrency(UChar* result, UErrorCode& ec) const;
-
-  /** number of integer digits 
-   * @stable ICU 2.4
-   */  
-    static const int32_t  kDoubleIntegerDigits;
-  /** number of fraction digits 
-   * @stable ICU 2.4
-   */  
-    static const int32_t  kDoubleFractionDigits;
-
-    /**
-     * When someone turns on scientific mode, we assume that more than this
-     * number of digits is due to flipping from some other mode that didn't
-     * restrict the maximum, and so we force 1 integer digit.  We don't bother
-     * to track and see if someone is using exponential notation with more than
-     * this number, it wouldn't make sense anyway, and this is just to make sure
-     * that someone turning on scientific mode with default settings doesn't
-     * end up with lots of zeroes.
-     * @stable ICU 2.8
-     */
-    static const int32_t  kMaxScientificIntegerDigits;
-};
-
-inline UnicodeString&
-DecimalFormat::format(const Formattable& obj,
-                      UnicodeString& appendTo,
-                      UErrorCode& status) const {
-    // Don't use Format:: - use immediate base class only,
-    // in case immediate base modifies behavior later.
-    return NumberFormat::format(obj, appendTo, status);
-}
-
-inline UnicodeString&
-DecimalFormat::format(double number,
-                      UnicodeString& appendTo) const {
-    FieldPosition pos(0);
-    return format(number, appendTo, pos);
-}
-
-inline UnicodeString&
-DecimalFormat::format(int32_t number,
-                      UnicodeString& appendTo) const {
-    FieldPosition pos(0);
-    return format((int64_t)number, appendTo, pos);
-}
-
-inline const UnicodeString &
-DecimalFormat::getConstSymbol(DecimalFormatSymbols::ENumberFormatSymbol symbol) const {
-    return fSymbols->getConstSymbol(symbol);
-}
-
-U_NAMESPACE_END
-
-#endif /* #if !UCONFIG_NO_FORMATTING */
-
-#endif // _DECIMFMT
-//eof

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/docmain.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/docmain.h b/apps/couch_collate/platform/osx/icu/unicode/docmain.h
deleted file mode 100644
index 973ebea..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/docmain.h
+++ /dev/null
@@ -1,202 +0,0 @@
-/********************************************************************
- * COPYRIGHT: 
- * Copyright (c) 1997-2007, International Business Machines Corporation and
- * others. All Rights Reserved.
- *
- *  FILE NAME: DOCMAIN.h
- *
- *   Date          Name        Description
- *   12/11/2000    Ram        Creation.
- */
-
-/* This file contains documentation for Doxygen and doesnot have
- * any significance with respect to C or C++ API
- */
-
-/*! \mainpage
- *
- * \section API API Reference Usage
- * 
- * <h3>C++ Programmers:</h3>
- * <p>Use <a href="hierarchy.html">Class Hierarchy</a> or <a href="classes.html"> Alphabetical List </a>
- * or <a href="annotated.html"> Compound List</a>
- * to find the class you are interested in. For example, to find BreakIterator,
- * you can go to the <a href="classes.html"> Alphabetical List</a>, then click on
- * "BreakIterator". Once you are at the class, you will find an inheritance
- * chart, a list of the public members, a detailed description of the class,
- * then detailed member descriptions.</p>
- * 
- * <h3>C Programmers:</h3>
- * <p>Use <a href="#Module">Module List</a> or <a href="globals.html">File Members</a>
- * to find a list of all the functions and constants.
- * For example, to find BreakIterator functions you would click on
- * <a href="files.html"> File List</a>,
- * then find "ubrk.h" and click on it. You will find descriptions of Defines,
- * Typedefs, Enumerations, and Functions, with detailed descriptions below.
- * If you want to find a specific function, such as ubrk_next(), then click
- * first on <a href="globals.html"> File Members</a>, then use your browser
- * Find dialog to search for "ubrk_next()".</p>
- *
- *
- * <h3>API References for Previous Releases</h3>
- * <p>The API References for each release of ICU are also available as
- * a zip file from the ICU 
- * <a href="http://icu-project.org/download/">download page</a>.</p>
- *
- * <hr>
- *
- * <h2>Architecture (User's Guide)</h2>
- * <ul>
- *   <li><a href="http://icu-project.org/userguide/">Introduction</a></li>
- *   <li><a href="http://icu-project.org/userguide/i18n.html">Internationalization</a></li>
- *   <li><a href="http://icu-project.org/userguide/design.html">Locale Model</a></li>
- *   <li><a href="http://icu-project.org/userguide/design.html">Multithreading</a></li>
- *   <li><a href="http://icu-project.org/userguide/conversion.html">Conversion</a></li>
- *   <li><a href="http://icu-project.org/userguide/design.html">Error Handling</a></li>
- * </ul>
- *
- * <hr>
- *\htmlonly <h2><a NAME="Module">Module List</a></h2> \endhtmlonly
- * <table border="1" cols="3" align="center">
- *   <tr>
- *     <td><strong>Module Name</strong></td>
- *     <td><strong>C</strong></td>
- *     <td><strong>C++</strong></td>
- *   </tr>
- *   <tr>
- *     <td>Basic Types and Constants</td>
- *     <td>utypes.h</td>
- *     <td>utypes.h</td>
- *   </tr>
- *   <tr>
- *     <td>Strings and Character Iteration</td>
- *     <td>ustring.h, utf.h</td>
- *     <td>UnicodeString, CharacterIterator</td>
- *   </tr>
- *   <tr>
- *     <td>Unicode Character<br>Properties and Names</td>
- *     <td>uchar.h</td>
- *     <td>uchar.h C API</td>
- *   </tr>
- *   <tr>
- *     <td>Codepage Conversion</td>
- *     <td>ucnv.h</td>
- *     <td>ucnv.h C API</td>
- *   </tr>
- *   <tr>
- *     <td>Unicode Text Compression</td>
- *     <td>ucnv.h <br> (encoding name "SCSU" or "BOCU-1")</td>
- *     <td>ucnv.h C API</td>
- *   </tr>
- *   <tr>
- *     <td>Locales </td>
- *     <td>uloc.h</a></td>
- *     <td>Locale</td>
- *   </tr>
- *   <tr>
- *     <td>Resource Bundles</td>
- *     <td>ures.h</td>
- *     <td>ResourceBundle</td>
- *   </tr>
- *   <tr>
- *     <td>Normalization</td>
- *     <td>unorm.h</td>
- *     <td>Normalizer</td>
- *   </tr>
- *   <tr>
- *     <td>Calendars</td>
- *     <td>ucal.h</td>
- *     <td>Calendar</td>
- *   </tr>
- *   <tr>
- *     <td>Date and Time Formatting</td>
- *     <td>udat.h</td>
- *     <td>DateFormat</td>
- *   </tr>
- *   <tr>
- *     <td>Message Formatting</td>
- *     <td>umsg.h</td>
- *     <td>MessageFormat</td>
- *   </tr>
- *   <tr>
- *     <td>Number Formatting</td>
- *     <td>unum.h</td>
- *     <td>NumberFormat</td>
- *   </tr>
- *   <tr>
- *     <td>Number Spellout <br> (Rule Based Number Formatting)</td>
- *     <td>unum.h <br> (use UNUM_SPELLOUT)</td>
- *     <td>RuleBasedNumberFormat</td>
- *   </tr>
- *   <tr>
- *     <td>Text Transformation <br> (Transliteration)</td>
- *     <td>utrans.h</td>
- *     <td>Transliterator</td>
- *   </tr>
- *   <tr>
- *     <td>Bidirectional Algorithm</td>
- *     <td>ubidi.h</td>
- *     <td>ubidi.h C API</td>
- *   </tr>
- *   <tr>
- *     <td>Arabic Shaping</td>
- *     <td>ushape.h</td>
- *     <td>ushape.h C API</td>
- *   </tr>
- *   <tr>
- *     <td>Collation</td>
- *     <td>ucol.h</td>
- *     <td>Collator</td>
- *   </tr>
- *   <tr>
- *     <td>String Searching</td>
- *     <td>usearch.h</td>
- *     <td>StringSearch</td>
- *   </tr>
- *   <tr>
- *     <td>Text Boundary Analysis <br> (Break Iteration)</td>
- *     <td>ubrk.h</td>
- *     <td>BreakIterator</td>
- *   </tr>
- *   <tr>
- *     <td>Unicode Set</td>
- *     <td>uset.h</td>
- *     <td>UnicodeSet</td>
- *   </tr>
- *   <tr>
- *     <td>Regular Expressions</td>
- *     <td>uregex.h</td>
- *     <td>RegexPattern, RegexMatcher</td>
- *   </tr>
- *   <tr>
- *     <td>StringPrep</td>
- *     <td>usprep.h</td>
- *     <td>usprep.h C API</td>
- *   </tr>
- *   <tr>
- *     <td>International Domain Names in Applications</td>
- *     <td>uidna.h</td>
- *     <td>uidna.h C API</td>
- *   </tr>
- *   <tr>
- *     <td>Universal Time Scale</td>
- *     <td>utmscale.h</td>
- *     <td>utmscale.h C API</td>
- *   </tr>
- *   <tr>
- *     <td>Basic Layout Engine Types and Constants</td>
- *     <td>(no C API)</td>
- *     <td>LETypes.h</td>
- *   </tr>
- *   <tr>
- *     <td>Complex Text Layout</td>
- *     <td>(no C API)</td>
- *     <td>LayoutEngine, ParagraphLayout</td>
- *   </tr>
- *   <tr>
- *     <td>ICU I/O</td>
- *     <td>ustdio.h</td>
- *     <td>ustream.h</td>
- *   </tr>
- * </table>
- */


[10/57] [abbrv] remove couch_collate

Posted by be...@apache.org.
http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/unorm.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/unorm.h b/apps/couch_collate/platform/osx/icu/unicode/unorm.h
deleted file mode 100644
index c22b808..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/unorm.h
+++ /dev/null
@@ -1,576 +0,0 @@
-/*
-*******************************************************************************
-* Copyright (c) 1996-2007, International Business Machines Corporation
-*               and others. All Rights Reserved.
-*******************************************************************************
-* File unorm.h
-*
-* Created by: Vladimir Weinstein 12052000
-*
-* Modification history :
-*
-* Date        Name        Description
-* 02/01/01    synwee      Added normalization quickcheck enum and method.
-*/
-#ifndef UNORM_H
-#define UNORM_H
-
-#include "unicode/utypes.h"
-
-#if !UCONFIG_NO_NORMALIZATION
-
-#include "unicode/uiter.h"
-
-/**
- * \file
- * \brief C API: Unicode Normalization 
- *
- * <h2>Unicode normalization API</h2>
- *
- * <code>unorm_normalize</code> transforms Unicode text into an equivalent composed or
- * decomposed form, allowing for easier sorting and searching of text.
- * <code>unorm_normalize</code> supports the standard normalization forms described in
- * <a href="http://www.unicode.org/unicode/reports/tr15/" target="unicode">
- * Unicode Standard Annex #15: Unicode Normalization Forms</a>.
- *
- * Characters with accents or other adornments can be encoded in
- * several different ways in Unicode.  For example, take the character A-acute.
- * In Unicode, this can be encoded as a single character (the
- * "composed" form):
- *
- * \code
- *      00C1    LATIN CAPITAL LETTER A WITH ACUTE
- * \endcode
- *
- * or as two separate characters (the "decomposed" form):
- *
- * \code
- *      0041    LATIN CAPITAL LETTER A
- *      0301    COMBINING ACUTE ACCENT
- * \endcode
- *
- * To a user of your program, however, both of these sequences should be
- * treated as the same "user-level" character "A with acute accent".  When you are searching or
- * comparing text, you must ensure that these two sequences are treated 
- * equivalently.  In addition, you must handle characters with more than one
- * accent.  Sometimes the order of a character's combining accents is
- * significant, while in other cases accent sequences in different orders are
- * really equivalent.
- *
- * Similarly, the string "ffi" can be encoded as three separate letters:
- *
- * \code
- *      0066    LATIN SMALL LETTER F
- *      0066    LATIN SMALL LETTER F
- *      0069    LATIN SMALL LETTER I
- * \endcode
- *
- * or as the single character
- *
- * \code
- *      FB03    LATIN SMALL LIGATURE FFI
- * \endcode
- *
- * The ffi ligature is not a distinct semantic character, and strictly speaking
- * it shouldn't be in Unicode at all, but it was included for compatibility
- * with existing character sets that already provided it.  The Unicode standard
- * identifies such characters by giving them "compatibility" decompositions
- * into the corresponding semantic characters.  When sorting and searching, you
- * will often want to use these mappings.
- *
- * <code>unorm_normalize</code> helps solve these problems by transforming text into the
- * canonical composed and decomposed forms as shown in the first example above.  
- * In addition, you can have it perform compatibility decompositions so that 
- * you can treat compatibility characters the same as their equivalents.
- * Finally, <code>unorm_normalize</code> rearranges accents into the proper canonical
- * order, so that you do not have to worry about accent rearrangement on your
- * own.
- *
- * Form FCD, "Fast C or D", is also designed for collation.
- * It allows to work on strings that are not necessarily normalized
- * with an algorithm (like in collation) that works under "canonical closure", i.e., it treats precomposed
- * characters and their decomposed equivalents the same.
- *
- * It is not a normalization form because it does not provide for uniqueness of representation. Multiple strings
- * may be canonically equivalent (their NFDs are identical) and may all conform to FCD without being identical
- * themselves.
- *
- * The form is defined such that the "raw decomposition", the recursive canonical decomposition of each character,
- * results in a string that is canonically ordered. This means that precomposed characters are allowed for as long
- * as their decompositions do not need canonical reordering.
- *
- * Its advantage for a process like collation is that all NFD and most NFC texts - and many unnormalized texts -
- * already conform to FCD and do not need to be normalized (NFD) for such a process. The FCD quick check will
- * return UNORM_YES for most strings in practice.
- *
- * unorm_normalize(UNORM_FCD) may be implemented with UNORM_NFD.
- *
- * For more details on FCD see the collation design document:
- * http://source.icu-project.org/repos/icu/icuhtml/trunk/design/collation/ICU_collation_design.htm
- *
- * ICU collation performs either NFD or FCD normalization automatically if normalization
- * is turned on for the collator object.
- * Beyond collation and string search, normalized strings may be useful for string equivalence comparisons,
- * transliteration/transcription, unique representations, etc.
- *
- * The W3C generally recommends to exchange texts in NFC.
- * Note also that most legacy character encodings use only precomposed forms and often do not
- * encode any combining marks by themselves. For conversion to such character encodings the
- * Unicode text needs to be normalized to NFC.
- * For more usage examples, see the Unicode Standard Annex.
- */
-
-/**
- * Constants for normalization modes.
- * @stable ICU 2.0
- */
-typedef enum {
-  /** No decomposition/composition. @stable ICU 2.0 */
-  UNORM_NONE = 1, 
-  /** Canonical decomposition. @stable ICU 2.0 */
-  UNORM_NFD = 2,
-  /** Compatibility decomposition. @stable ICU 2.0 */
-  UNORM_NFKD = 3,
-  /** Canonical decomposition followed by canonical composition. @stable ICU 2.0 */
-  UNORM_NFC = 4,
-  /** Default normalization. @stable ICU 2.0 */
-  UNORM_DEFAULT = UNORM_NFC, 
-  /** Compatibility decomposition followed by canonical composition. @stable ICU 2.0 */
-  UNORM_NFKC =5,
-  /** "Fast C or D" form. @stable ICU 2.0 */
-  UNORM_FCD = 6,
-
-  /** One more than the highest normalization mode constant. @stable ICU 2.0 */
-  UNORM_MODE_COUNT
-} UNormalizationMode;
-
-/**
- * Constants for options flags for normalization.
- * Use 0 for default options,
- * including normalization according to the Unicode version
- * that is currently supported by ICU (see u_getUnicodeVersion).
- * @stable ICU 2.6
- */
-enum {
-    /**
-     * Options bit set value to select Unicode 3.2 normalization
-     * (except NormalizationCorrections).
-     * At most one Unicode version can be selected at a time.
-     * @stable ICU 2.6
-     */
-    UNORM_UNICODE_3_2=0x20
-};
-
-/**
- * Lowest-order bit number of unorm_compare() options bits corresponding to
- * normalization options bits.
- *
- * The options parameter for unorm_compare() uses most bits for
- * itself and for various comparison and folding flags.
- * The most significant bits, however, are shifted down and passed on
- * to the normalization implementation.
- * (That is, from unorm_compare(..., options, ...),
- * options>>UNORM_COMPARE_NORM_OPTIONS_SHIFT will be passed on to the
- * internal normalization functions.)
- *
- * @see unorm_compare
- * @stable ICU 2.6
- */
-#define UNORM_COMPARE_NORM_OPTIONS_SHIFT 20
-
-/**
- * Normalize a string.
- * The string will be normalized according the specified normalization mode
- * and options.
- * The source and result buffers must not be the same, nor overlap.
- *
- * @param source The string to normalize.
- * @param sourceLength The length of source, or -1 if NUL-terminated.
- * @param mode The normalization mode; one of UNORM_NONE, 
- *             UNORM_NFD, UNORM_NFC, UNORM_NFKC, UNORM_NFKD, UNORM_DEFAULT.
- * @param options The normalization options, ORed together (0 for no options).
- * @param result A pointer to a buffer to receive the result string.
- *               The result string is NUL-terminated if possible.
- * @param resultLength The maximum size of result.
- * @param status A pointer to a UErrorCode to receive any errors.
- * @return The total buffer size needed; if greater than resultLength,
- *         the output was truncated, and the error code is set to U_BUFFER_OVERFLOW_ERROR.
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2 
-unorm_normalize(const UChar *source, int32_t sourceLength,
-                UNormalizationMode mode, int32_t options,
-                UChar *result, int32_t resultLength,
-                UErrorCode *status);
-#endif
-/**
- * Result values for unorm_quickCheck().
- * For details see Unicode Technical Report 15.
- * @stable ICU 2.0
- */
-typedef enum UNormalizationCheckResult {
-  /** 
-   * Indicates that string is not in the normalized format
-   */
-  UNORM_NO,
-  /** 
-   * Indicates that string is in the normalized format
-   */
-  UNORM_YES,
-  /** 
-   * Indicates that string cannot be determined if it is in the normalized 
-   * format without further thorough checks.
-   */
-  UNORM_MAYBE
-} UNormalizationCheckResult;
-#if !UCONFIG_NO_NORMALIZATION
-/**
- * Performing quick check on a string, to quickly determine if the string is 
- * in a particular normalization format.
- * Three types of result can be returned UNORM_YES, UNORM_NO or
- * UNORM_MAYBE. Result UNORM_YES indicates that the argument
- * string is in the desired normalized format, UNORM_NO determines that
- * argument string is not in the desired normalized format. A 
- * UNORM_MAYBE result indicates that a more thorough check is required, 
- * the user may have to put the string in its normalized form and compare the 
- * results.
- *
- * @param source       string for determining if it is in a normalized format
- * @param sourcelength length of source to test, or -1 if NUL-terminated
- * @param mode         which normalization form to test for
- * @param status       a pointer to a UErrorCode to receive any errors
- * @return UNORM_YES, UNORM_NO or UNORM_MAYBE
- *
- * @see unorm_isNormalized
- * @stable ICU 2.0
- */
-U_STABLE UNormalizationCheckResult U_EXPORT2
-unorm_quickCheck(const UChar *source, int32_t sourcelength,
-                 UNormalizationMode mode,
-                 UErrorCode *status);
-
-/**
- * Performing quick check on a string; same as unorm_quickCheck but
- * takes an extra options parameter like most normalization functions.
- *
- * @param src        String that is to be tested if it is in a normalization format.
- * @param srcLength  Length of source to test, or -1 if NUL-terminated.
- * @param mode       Which normalization form to test for.
- * @param options    The normalization options, ORed together (0 for no options).
- * @param pErrorCode ICU error code in/out parameter.
- *                   Must fulfill U_SUCCESS before the function call.
- * @return UNORM_YES, UNORM_NO or UNORM_MAYBE
- *
- * @see unorm_quickCheck
- * @see unorm_isNormalized
- * @stable ICU 2.6
- */
-U_STABLE UNormalizationCheckResult U_EXPORT2
-unorm_quickCheckWithOptions(const UChar *src, int32_t srcLength, 
-                            UNormalizationMode mode, int32_t options,
-                            UErrorCode *pErrorCode);
-
-/**
- * Test if a string is in a given normalization form.
- * This is semantically equivalent to source.equals(normalize(source, mode)) .
- *
- * Unlike unorm_quickCheck(), this function returns a definitive result,
- * never a "maybe".
- * For NFD, NFKD, and FCD, both functions work exactly the same.
- * For NFC and NFKC where quickCheck may return "maybe", this function will
- * perform further tests to arrive at a TRUE/FALSE result.
- *
- * @param src        String that is to be tested if it is in a normalization format.
- * @param srcLength  Length of source to test, or -1 if NUL-terminated.
- * @param mode       Which normalization form to test for.
- * @param pErrorCode ICU error code in/out parameter.
- *                   Must fulfill U_SUCCESS before the function call.
- * @return Boolean value indicating whether the source string is in the
- *         "mode" normalization form.
- *
- * @see unorm_quickCheck
- * @stable ICU 2.2
- */
-U_STABLE UBool U_EXPORT2
-unorm_isNormalized(const UChar *src, int32_t srcLength,
-                   UNormalizationMode mode,
-                   UErrorCode *pErrorCode);
-
-/**
- * Test if a string is in a given normalization form; same as unorm_isNormalized but
- * takes an extra options parameter like most normalization functions.
- *
- * @param src        String that is to be tested if it is in a normalization format.
- * @param srcLength  Length of source to test, or -1 if NUL-terminated.
- * @param mode       Which normalization form to test for.
- * @param options    The normalization options, ORed together (0 for no options).
- * @param pErrorCode ICU error code in/out parameter.
- *                   Must fulfill U_SUCCESS before the function call.
- * @return Boolean value indicating whether the source string is in the
- *         "mode/options" normalization form.
- *
- * @see unorm_quickCheck
- * @see unorm_isNormalized
- * @stable ICU 2.6
- */
-U_STABLE UBool U_EXPORT2
-unorm_isNormalizedWithOptions(const UChar *src, int32_t srcLength,
-                              UNormalizationMode mode, int32_t options,
-                              UErrorCode *pErrorCode);
-
-/**
- * Iterative normalization forward.
- * This function (together with unorm_previous) is somewhat
- * similar to the C++ Normalizer class (see its non-static functions).
- *
- * Iterative normalization is useful when only a small portion of a longer
- * string/text needs to be processed.
- *
- * For example, the likelihood may be high that processing the first 10% of some
- * text will be sufficient to find certain data.
- * Another example: When one wants to concatenate two normalized strings and get a
- * normalized result, it is much more efficient to normalize just a small part of
- * the result around the concatenation place instead of re-normalizing everything.
- *
- * The input text is an instance of the C character iteration API UCharIterator.
- * It may wrap around a simple string, a CharacterIterator, a Replaceable, or any
- * other kind of text object.
- *
- * If a buffer overflow occurs, then the caller needs to reset the iterator to the
- * old index and call the function again with a larger buffer - if the caller cares
- * for the actual output.
- * Regardless of the output buffer, the iterator will always be moved to the next
- * normalization boundary.
- *
- * This function (like unorm_previous) serves two purposes:
- *
- * 1) To find the next boundary so that the normalization of the part of the text
- * from the current position to that boundary does not affect and is not affected
- * by the part of the text beyond that boundary.
- *
- * 2) To normalize the text up to the boundary.
- *
- * The second step is optional, per the doNormalize parameter.
- * It is omitted for operations like string concatenation, where the two adjacent
- * string ends need to be normalized together.
- * In such a case, the output buffer will just contain a copy of the text up to the
- * boundary.
- *
- * pNeededToNormalize is an output-only parameter. Its output value is only defined
- * if normalization was requested (doNormalize) and successful (especially, no
- * buffer overflow).
- * It is useful for operations like a normalizing transliterator, where one would
- * not want to replace a piece of text if it is not modified.
- *
- * If doNormalize==TRUE and pNeededToNormalize!=NULL then *pNeeded... is set TRUE
- * if the normalization was necessary.
- *
- * If doNormalize==FALSE then *pNeededToNormalize will be set to FALSE.
- *
- * If the buffer overflows, then *pNeededToNormalize will be undefined;
- * essentially, whenever U_FAILURE is true (like in buffer overflows), this result
- * will be undefined.
- *
- * @param src The input text in the form of a C character iterator.
- * @param dest The output buffer; can be NULL if destCapacity==0 for pure preflighting.
- * @param destCapacity The number of UChars that fit into dest.
- * @param mode The normalization mode.
- * @param options The normalization options, ORed together (0 for no options).
- * @param doNormalize Indicates if the source text up to the next boundary
- *                    is to be normalized (TRUE) or just copied (FALSE).
- * @param pNeededToNormalize Output flag indicating if the normalization resulted in
- *                           different text from the input.
- *                           Not defined if an error occurs including buffer overflow.
- *                           Always FALSE if !doNormalize.
- * @param pErrorCode ICU error code in/out parameter.
- *                   Must fulfill U_SUCCESS before the function call.
- * @return Length of output (number of UChars) when successful or buffer overflow.
- *
- * @see unorm_previous
- * @see unorm_normalize
- *
- * @stable ICU 2.1
- */
-U_STABLE int32_t U_EXPORT2
-unorm_next(UCharIterator *src,
-           UChar *dest, int32_t destCapacity,
-           UNormalizationMode mode, int32_t options,
-           UBool doNormalize, UBool *pNeededToNormalize,
-           UErrorCode *pErrorCode);
-
-/**
- * Iterative normalization backward.
- * This function (together with unorm_next) is somewhat
- * similar to the C++ Normalizer class (see its non-static functions).
- * For all details see unorm_next.
- *
- * @param src The input text in the form of a C character iterator.
- * @param dest The output buffer; can be NULL if destCapacity==0 for pure preflighting.
- * @param destCapacity The number of UChars that fit into dest.
- * @param mode The normalization mode.
- * @param options The normalization options, ORed together (0 for no options).
- * @param doNormalize Indicates if the source text up to the next boundary
- *                    is to be normalized (TRUE) or just copied (FALSE).
- * @param pNeededToNormalize Output flag indicating if the normalization resulted in
- *                           different text from the input.
- *                           Not defined if an error occurs including buffer overflow.
- *                           Always FALSE if !doNormalize.
- * @param pErrorCode ICU error code in/out parameter.
- *                   Must fulfill U_SUCCESS before the function call.
- * @return Length of output (number of UChars) when successful or buffer overflow.
- *
- * @see unorm_next
- * @see unorm_normalize
- *
- * @stable ICU 2.1
- */
-U_STABLE int32_t U_EXPORT2
-unorm_previous(UCharIterator *src,
-               UChar *dest, int32_t destCapacity,
-               UNormalizationMode mode, int32_t options,
-               UBool doNormalize, UBool *pNeededToNormalize,
-               UErrorCode *pErrorCode);
-
-/**
- * Concatenate normalized strings, making sure that the result is normalized as well.
- *
- * If both the left and the right strings are in
- * the normalization form according to "mode/options",
- * then the result will be
- *
- * \code
- *     dest=normalize(left+right, mode, options)
- * \endcode
- *
- * With the input strings already being normalized,
- * this function will use unorm_next() and unorm_previous()
- * to find the adjacent end pieces of the input strings.
- * Only the concatenation of these end pieces will be normalized and
- * then concatenated with the remaining parts of the input strings.
- *
- * It is allowed to have dest==left to avoid copying the entire left string.
- *
- * @param left Left source string, may be same as dest.
- * @param leftLength Length of left source string, or -1 if NUL-terminated.
- * @param right Right source string. Must not be the same as dest, nor overlap.
- * @param rightLength Length of right source string, or -1 if NUL-terminated.
- * @param dest The output buffer; can be NULL if destCapacity==0 for pure preflighting.
- * @param destCapacity The number of UChars that fit into dest.
- * @param mode The normalization mode.
- * @param options The normalization options, ORed together (0 for no options).
- * @param pErrorCode ICU error code in/out parameter.
- *                   Must fulfill U_SUCCESS before the function call.
- * @return Length of output (number of UChars) when successful or buffer overflow.
- *
- * @see unorm_normalize
- * @see unorm_next
- * @see unorm_previous
- *
- * @stable ICU 2.1
- */
-U_STABLE int32_t U_EXPORT2
-unorm_concatenate(const UChar *left, int32_t leftLength,
-                  const UChar *right, int32_t rightLength,
-                  UChar *dest, int32_t destCapacity,
-                  UNormalizationMode mode, int32_t options,
-                  UErrorCode *pErrorCode);
-
-/**
- * Option bit for unorm_compare:
- * Both input strings are assumed to fulfill FCD conditions.
- * @stable ICU 2.2
- */
-#define UNORM_INPUT_IS_FCD          0x20000
-
-/**
- * Option bit for unorm_compare:
- * Perform case-insensitive comparison.
- * @stable ICU 2.2
- */
-#define U_COMPARE_IGNORE_CASE       0x10000
-
-#ifndef U_COMPARE_CODE_POINT_ORDER
-/* see also unistr.h and ustring.h */
-/**
- * Option bit for u_strCaseCompare, u_strcasecmp, unorm_compare, etc:
- * Compare strings in code point order instead of code unit order.
- * @stable ICU 2.2
- */
-#define U_COMPARE_CODE_POINT_ORDER  0x8000
-#endif
-
-/**
- * Compare two strings for canonical equivalence.
- * Further options include case-insensitive comparison and
- * code point order (as opposed to code unit order).
- *
- * Canonical equivalence between two strings is defined as their normalized
- * forms (NFD or NFC) being identical.
- * This function compares strings incrementally instead of normalizing
- * (and optionally case-folding) both strings entirely,
- * improving performance significantly.
- *
- * Bulk normalization is only necessary if the strings do not fulfill the FCD
- * conditions. Only in this case, and only if the strings are relatively long,
- * is memory allocated temporarily.
- * For FCD strings and short non-FCD strings there is no memory allocation.
- *
- * Semantically, this is equivalent to
- *   strcmp[CodePointOrder](NFD(foldCase(NFD(s1))), NFD(foldCase(NFD(s2))))
- * where code point order and foldCase are all optional.
- *
- * UAX 21 2.5 Caseless Matching specifies that for a canonical caseless match
- * the case folding must be performed first, then the normalization.
- *
- * @param s1 First source string.
- * @param length1 Length of first source string, or -1 if NUL-terminated.
- *
- * @param s2 Second source string.
- * @param length2 Length of second source string, or -1 if NUL-terminated.
- *
- * @param options A bit set of options:
- *   - U_FOLD_CASE_DEFAULT or 0 is used for default options:
- *     Case-sensitive comparison in code unit order, and the input strings
- *     are quick-checked for FCD.
- *
- *   - UNORM_INPUT_IS_FCD
- *     Set if the caller knows that both s1 and s2 fulfill the FCD conditions.
- *     If not set, the function will quickCheck for FCD
- *     and normalize if necessary.
- *
- *   - U_COMPARE_CODE_POINT_ORDER
- *     Set to choose code point order instead of code unit order
- *     (see u_strCompare for details).
- *
- *   - U_COMPARE_IGNORE_CASE
- *     Set to compare strings case-insensitively using case folding,
- *     instead of case-sensitively.
- *     If set, then the following case folding options are used.
- *
- *   - Options as used with case-insensitive comparisons, currently:
- *
- *   - U_FOLD_CASE_EXCLUDE_SPECIAL_I
- *    (see u_strCaseCompare for details)
- *
- *   - regular normalization options shifted left by UNORM_COMPARE_NORM_OPTIONS_SHIFT
- *
- * @param pErrorCode ICU error code in/out parameter.
- *                   Must fulfill U_SUCCESS before the function call.
- * @return <0 or 0 or >0 as usual for string comparisons
- *
- * @see unorm_normalize
- * @see UNORM_FCD
- * @see u_strCompare
- * @see u_strCaseCompare
- *
- * @stable ICU 2.2
- */
-U_STABLE int32_t U_EXPORT2
-unorm_compare(const UChar *s1, int32_t length1,
-              const UChar *s2, int32_t length2,
-              uint32_t options,
-              UErrorCode *pErrorCode);
-
-#endif /* #if !UCONFIG_NO_NORMALIZATION */
-
-#endif

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/unum.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/unum.h b/apps/couch_collate/platform/osx/icu/unicode/unum.h
deleted file mode 100644
index c5df2bb..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/unum.h
+++ /dev/null
@@ -1,869 +0,0 @@
-/*
-*******************************************************************************
-* Copyright (C) 1997-2008, International Business Machines Corporation and others.
-* All Rights Reserved.
-* Modification History:
-*
-*   Date        Name        Description
-*   06/24/99    helena      Integrated Alan's NF enhancements and Java2 bug fixes
-*******************************************************************************
-*/
-
-#ifndef _UNUM
-#define _UNUM
-
-#include "unicode/utypes.h"
-
-#if !UCONFIG_NO_FORMATTING
-
-#include "unicode/uloc.h"
-#include "unicode/umisc.h"
-#include "unicode/parseerr.h"
-/**
- * \file
- * \brief C API: NumberFormat
- *
- * <h2> Number Format C API </h2>
- *
- * Number Format C API  Provides functions for
- * formatting and parsing a number.  Also provides methods for
- * determining which locales have number formats, and what their names
- * are.
- * <P>
- * UNumberFormat helps you to format and parse numbers for any locale.
- * Your code can be completely independent of the locale conventions
- * for decimal points, thousands-separators, or even the particular
- * decimal digits used, or whether the number format is even decimal.
- * There are different number format styles like decimal, currency,
- * percent and spellout.
- * <P>
- * To format a number for the current Locale, use one of the static
- * factory methods:
- * <pre>
- * \code
- *    UChar myString[20];
- *    double myNumber = 7.0;
- *    UErrorCode status = U_ZERO_ERROR;
- *    UNumberFormat* nf = unum_open(UNUM_DEFAULT, NULL, -1, NULL, NULL, &status);
- *    unum_formatDouble(nf, myNumber, myString, 20, NULL, &status);
- *    printf(" Example 1: %s\n", austrdup(myString) ); //austrdup( a function used to convert UChar* to char*)
- * \endcode
- * </pre>
- * If you are formatting multiple numbers, it is more efficient to get
- * the format and use it multiple times so that the system doesn't
- * have to fetch the information about the local language and country
- * conventions multiple times.
- * <pre>
- * \code
- * uint32_t i, resultlength, reslenneeded;
- * UErrorCode status = U_ZERO_ERROR;
- * UFieldPosition pos;
- * uint32_t a[] = { 123, 3333, -1234567 };
- * const uint32_t a_len = sizeof(a) / sizeof(a[0]);
- * UNumberFormat* nf;
- * UChar* result = NULL;
- *
- * nf = unum_open(UNUM_DEFAULT, NULL, -1, NULL, NULL, &status);
- * for (i = 0; i < a_len; i++) {
- *    resultlength=0;
- *    reslenneeded=unum_format(nf, a[i], NULL, resultlength, &pos, &status);
- *    result = NULL;
- *    if(status==U_BUFFER_OVERFLOW_ERROR){
- *       status=U_ZERO_ERROR;
- *       resultlength=reslenneeded+1;
- *       result=(UChar*)malloc(sizeof(UChar) * resultlength);
- *       unum_format(nf, a[i], result, resultlength, &pos, &status);
- *    }
- *    printf( " Example 2: %s\n", austrdup(result));
- *    free(result);
- * }
- * \endcode
- * </pre>
- * To format a number for a different Locale, specify it in the
- * call to unum_open().
- * <pre>
- * \code
- *     UNumberFormat* nf = unum_open(UNUM_DEFAULT, NULL, -1, "fr_FR", NULL, &success)
- * \endcode
- * </pre>
- * You can use a NumberFormat API unum_parse() to parse.
- * <pre>
- * \code
- *    UErrorCode status = U_ZERO_ERROR;
- *    int32_t pos=0;
- *    int32_t num;
- *    num = unum_parse(nf, str, u_strlen(str), &pos, &status);
- * \endcode
- * </pre>
- * Use UNUM_DECIMAL to get the normal number format for that country.
- * There are other static options available.  Use UNUM_CURRENCY
- * to get the currency number format for that country.  Use UNUM_PERCENT
- * to get a format for displaying percentages. With this format, a
- * fraction from 0.53 is displayed as 53%.
- * <P>
- * Use a pattern to create either a DecimalFormat or a RuleBasedNumberFormat
- * formatter.  The pattern must conform to the syntax defined for those
- * formatters.
- * <P>
- * You can also control the display of numbers with such function as
- * unum_getAttribues() and unum_setAtributes(), which let you set the
- * miminum fraction digits, grouping, etc.
- * @see UNumberFormatAttributes for more details
- * <P>
- * You can also use forms of the parse and format methods with
- * ParsePosition and UFieldPosition to allow you to:
- * <ul type=round>
- *   <li>(a) progressively parse through pieces of a string.
- *   <li>(b) align the decimal point and other areas.
- * </ul>
- * <p>
- * It is also possible to change or set the symbols used for a particular
- * locale like the currency symbol, the grouping seperator , monetary seperator
- * etc by making use of functions unum_setSymbols() and unum_getSymbols().
- */
-
-/** A number formatter.
- *  For usage in C programs.
- *  @stable ICU 2.0
- */
-typedef void* UNumberFormat;
-
-/** The possible number format styles. 
- *  @stable ICU 2.0
- */
-typedef enum UNumberFormatStyle {
-    /**
-     * Decimal format defined by pattern 
-     * @stable ICU 3.0
-     */
-    UNUM_PATTERN_DECIMAL=0,
-    /** Decimal format */
-    UNUM_DECIMAL=1,
-    /** Currency format */
-    UNUM_CURRENCY,
-    /** Percent format */
-    UNUM_PERCENT,
-    /** Scientific format */
-    UNUM_SCIENTIFIC,
-    /** Spellout rule-based format */
-    UNUM_SPELLOUT,
-    /** 
-     * Ordinal rule-based format 
-     * @stable ICU 3.0
-     */
-    UNUM_ORDINAL,
-    /** 
-     * Duration rule-based format 
-     * @stable ICU 3.0
-     */
-    UNUM_DURATION,
-    /** 
-     * Rule-based format defined by pattern 
-     * @stable ICU 3.0
-     */
-    UNUM_PATTERN_RULEBASED,
-    /** Default format */
-    UNUM_DEFAULT = UNUM_DECIMAL,
-    /** (Alias for UNUM_PATTERN_DECIMAL) */
-    UNUM_IGNORE = UNUM_PATTERN_DECIMAL
-} UNumberFormatStyle;
-
-/** The possible number format rounding modes. 
- *  @stable ICU 2.0
- */
-typedef enum UNumberFormatRoundingMode {
-    UNUM_ROUND_CEILING,
-    UNUM_ROUND_FLOOR,
-    UNUM_ROUND_DOWN,
-    UNUM_ROUND_UP,
-    /**
-     * Half-even rounding, misspelled name
-     * @deprecated, ICU 3.8
-     */
-    UNUM_FOUND_HALFEVEN,
-    UNUM_ROUND_HALFDOWN,
-    UNUM_ROUND_HALFUP,
-    /**
-     * Half-even rounding
-     * @stable, ICU 3.8
-     */
-    UNUM_ROUND_HALFEVEN = UNUM_FOUND_HALFEVEN
-} UNumberFormatRoundingMode;
-
-/** The possible number format pad positions. 
- *  @stable ICU 2.0
- */
-typedef enum UNumberFormatPadPosition {
-    UNUM_PAD_BEFORE_PREFIX,
-    UNUM_PAD_AFTER_PREFIX,
-    UNUM_PAD_BEFORE_SUFFIX,
-    UNUM_PAD_AFTER_SUFFIX
-} UNumberFormatPadPosition;
-
-/**
- * Create and return a new UNumberFormat for formatting and parsing
- * numbers.  A UNumberFormat may be used to format numbers by calling
- * {@link #unum_format }, and to parse numbers by calling {@link #unum_parse }.
- * The caller must call {@link #unum_close } when done to release resources
- * used by this object.
- * @param style The type of number format to open: one of
- * UNUM_DECIMAL, UNUM_CURRENCY, UNUM_PERCENT, UNUM_SCIENTIFIC, UNUM_SPELLOUT,
- * UNUM_PATTERN_DECIMAL, UNUM_PATTERN_RULEBASED, or UNUM_DEFAULT.
- * If UNUM_PATTERN_DECIMAL or UNUM_PATTERN_RULEBASED is passed then the
- * number format is opened using the given pattern, which must conform
- * to the syntax described in DecimalFormat or RuleBasedNumberFormat,
- * respectively.
- * @param pattern A pattern specifying the format to use. 
- * This parameter is ignored unless the style is
- * UNUM_PATTERN_DECIMAL or UNUM_PATTERN_RULEBASED.
- * @param patternLength The number of characters in the pattern, or -1
- * if null-terminated. This parameter is ignored unless the style is
- * UNUM_PATTERN.
- * @param locale A locale identifier to use to determine formatting
- * and parsing conventions, or NULL to use the default locale.
- * @param parseErr A pointer to a UParseError struct to receive the
- * details of any parsing errors, or NULL if no parsing error details
- * are desired.
- * @param status A pointer to an input-output UErrorCode.
- * @return A pointer to a newly created UNumberFormat, or NULL if an
- * error occurred.
- * @see unum_close
- * @see DecimalFormat
- * @stable ICU 2.0
- */
-U_STABLE UNumberFormat* U_EXPORT2 
-unum_open(  UNumberFormatStyle    style,
-            const    UChar*    pattern,
-            int32_t            patternLength,
-            const    char*     locale,
-            UParseError*       parseErr,
-            UErrorCode*        status);
-
-
-/**
-* Close a UNumberFormat.
-* Once closed, a UNumberFormat may no longer be used.
-* @param fmt The formatter to close.
-* @stable ICU 2.0
-*/
-U_STABLE void U_EXPORT2 
-unum_close(UNumberFormat* fmt);
-
-/**
- * Open a copy of a UNumberFormat.
- * This function performs a deep copy.
- * @param fmt The format to copy
- * @param status A pointer to an UErrorCode to receive any errors.
- * @return A pointer to a UNumberFormat identical to fmt.
- * @stable ICU 2.0
- */
-U_STABLE UNumberFormat* U_EXPORT2 
-unum_clone(const UNumberFormat *fmt,
-       UErrorCode *status);
-
-/**
-* Format an integer using a UNumberFormat.
-* The integer will be formatted according to the UNumberFormat's locale.
-* @param fmt The formatter to use.
-* @param number The number to format.
-* @param result A pointer to a buffer to receive the formatted number.
-* @param resultLength The maximum size of result.
-* @param pos    A pointer to a UFieldPosition.  On input, position->field
-* is read.  On output, position->beginIndex and position->endIndex indicate
-* the beginning and ending indices of field number position->field, if such
-* a field exists.  This parameter may be NULL, in which case no field
-* @param status A pointer to an UErrorCode to receive any errors
-* @return The total buffer size needed; if greater than resultLength, the output was truncated.
-* @see unum_formatInt64
-* @see unum_formatDouble
-* @see unum_parse
-* @see unum_parseInt64
-* @see unum_parseDouble
-* @see UFieldPosition
-* @stable ICU 2.0
-*/
-U_STABLE int32_t U_EXPORT2 
-unum_format(    const    UNumberFormat*    fmt,
-        int32_t            number,
-        UChar*            result,
-        int32_t            resultLength,
-        UFieldPosition    *pos,
-        UErrorCode*        status);
-
-/**
-* Format an int64 using a UNumberFormat.
-* The int64 will be formatted according to the UNumberFormat's locale.
-* @param fmt The formatter to use.
-* @param number The number to format.
-* @param result A pointer to a buffer to receive the formatted number.
-* @param resultLength The maximum size of result.
-* @param pos    A pointer to a UFieldPosition.  On input, position->field
-* is read.  On output, position->beginIndex and position->endIndex indicate
-* the beginning and ending indices of field number position->field, if such
-* a field exists.  This parameter may be NULL, in which case no field
-* @param status A pointer to an UErrorCode to receive any errors
-* @return The total buffer size needed; if greater than resultLength, the output was truncated.
-* @see unum_format
-* @see unum_formatDouble
-* @see unum_parse
-* @see unum_parseInt64
-* @see unum_parseDouble
-* @see UFieldPosition
-* @stable ICU 2.0
-*/
-U_STABLE int32_t U_EXPORT2 
-unum_formatInt64(const UNumberFormat *fmt,
-        int64_t         number,
-        UChar*          result,
-        int32_t         resultLength,
-        UFieldPosition *pos,
-        UErrorCode*     status);
-
-/**
-* Format a double using a UNumberFormat.
-* The double will be formatted according to the UNumberFormat's locale.
-* @param fmt The formatter to use.
-* @param number The number to format.
-* @param result A pointer to a buffer to receive the formatted number.
-* @param resultLength The maximum size of result.
-* @param pos    A pointer to a UFieldPosition.  On input, position->field
-* is read.  On output, position->beginIndex and position->endIndex indicate
-* the beginning and ending indices of field number position->field, if such
-* a field exists.  This parameter may be NULL, in which case no field
-* @param status A pointer to an UErrorCode to receive any errors
-* @return The total buffer size needed; if greater than resultLength, the output was truncated.
-* @see unum_format
-* @see unum_formatInt64
-* @see unum_parse
-* @see unum_parseInt64
-* @see unum_parseDouble
-* @see UFieldPosition
-* @stable ICU 2.0
-*/
-U_STABLE int32_t U_EXPORT2 
-unum_formatDouble(    const    UNumberFormat*  fmt,
-            double          number,
-            UChar*          result,
-            int32_t         resultLength,
-            UFieldPosition  *pos, /* 0 if ignore */
-            UErrorCode*     status);
-
-/**
- * Format a double currency amount using a UNumberFormat.
- * The double will be formatted according to the UNumberFormat's locale.
- * @param fmt the formatter to use
- * @param number the number to format
- * @param currency the 3-letter null-terminated ISO 4217 currency code
- * @param result a pointer to the buffer to receive the formatted number
- * @param resultLength the maximum number of UChars to write to result
- * @param pos a pointer to a UFieldPosition.  On input,
- * position->field is read.  On output, position->beginIndex and
- * position->endIndex indicate the beginning and ending indices of
- * field number position->field, if such a field exists.  This
- * parameter may be NULL, in which case it is ignored.
- * @param status a pointer to an input-output UErrorCode
- * @return the total buffer size needed; if greater than resultLength,
- * the output was truncated.
- * @see unum_formatDouble
- * @see unum_parseDoubleCurrency
- * @see UFieldPosition
- * @stable ICU 3.0
- */
-U_STABLE int32_t U_EXPORT2 
-unum_formatDoubleCurrency(const UNumberFormat* fmt,
-                          double number,
-                          UChar* currency,
-                          UChar* result,
-                          int32_t resultLength,
-                          UFieldPosition* pos, /* ignored if 0 */
-                          UErrorCode* status);
-
-/**
-* Parse a string into an integer using a UNumberFormat.
-* The string will be parsed according to the UNumberFormat's locale.
-* @param fmt The formatter to use.
-* @param text The text to parse.
-* @param textLength The length of text, or -1 if null-terminated.
-* @param parsePos If not 0, on input a pointer to an integer specifying the offset at which
-* to begin parsing.  If not 0, on output the offset at which parsing ended.
-* @param status A pointer to an UErrorCode to receive any errors
-* @return The value of the parsed integer
-* @see unum_parseInt64
-* @see unum_parseDouble
-* @see unum_format
-* @see unum_formatInt64
-* @see unum_formatDouble
-* @stable ICU 2.0
-*/
-U_STABLE int32_t U_EXPORT2 
-unum_parse(    const   UNumberFormat*  fmt,
-        const   UChar*          text,
-        int32_t         textLength,
-        int32_t         *parsePos /* 0 = start */,
-        UErrorCode      *status);
-
-/**
-* Parse a string into an int64 using a UNumberFormat.
-* The string will be parsed according to the UNumberFormat's locale.
-* @param fmt The formatter to use.
-* @param text The text to parse.
-* @param textLength The length of text, or -1 if null-terminated.
-* @param parsePos If not 0, on input a pointer to an integer specifying the offset at which
-* to begin parsing.  If not 0, on output the offset at which parsing ended.
-* @param status A pointer to an UErrorCode to receive any errors
-* @return The value of the parsed integer
-* @see unum_parse
-* @see unum_parseDouble
-* @see unum_format
-* @see unum_formatInt64
-* @see unum_formatDouble
-* @stable ICU 2.8
-*/
-U_STABLE int64_t U_EXPORT2 
-unum_parseInt64(const UNumberFormat*  fmt,
-        const UChar*  text,
-        int32_t       textLength,
-        int32_t       *parsePos /* 0 = start */,
-        UErrorCode    *status);
-
-/**
-* Parse a string into a double using a UNumberFormat.
-* The string will be parsed according to the UNumberFormat's locale.
-* @param fmt The formatter to use.
-* @param text The text to parse.
-* @param textLength The length of text, or -1 if null-terminated.
-* @param parsePos If not 0, on input a pointer to an integer specifying the offset at which
-* to begin parsing.  If not 0, on output the offset at which parsing ended.
-* @param status A pointer to an UErrorCode to receive any errors
-* @return The value of the parsed double
-* @see unum_parse
-* @see unum_parseInt64
-* @see unum_format
-* @see unum_formatInt64
-* @see unum_formatDouble
-* @stable ICU 2.0
-*/
-U_STABLE double U_EXPORT2 
-unum_parseDouble(    const   UNumberFormat*  fmt,
-            const   UChar*          text,
-            int32_t         textLength,
-            int32_t         *parsePos /* 0 = start */,
-            UErrorCode      *status);
-
-/**
- * Parse a string into a double and a currency using a UNumberFormat.
- * The string will be parsed according to the UNumberFormat's locale.
- * @param fmt the formatter to use
- * @param text the text to parse
- * @param textLength the length of text, or -1 if null-terminated
- * @param parsePos a pointer to an offset index into text at which to
- * begin parsing. On output, *parsePos will point after the last
- * parsed character.  This parameter may be 0, in which case parsing
- * begins at offset 0.
- * @param currency a pointer to the buffer to receive the parsed null-
- * terminated currency.  This buffer must have a capacity of at least
- * 4 UChars.
- * @param status a pointer to an input-output UErrorCode
- * @return the parsed double
- * @see unum_parseDouble
- * @see unum_formatDoubleCurrency
- * @stable ICU 3.0
- */
-U_STABLE double U_EXPORT2
-unum_parseDoubleCurrency(const UNumberFormat* fmt,
-                         const UChar* text,
-                         int32_t textLength,
-                         int32_t* parsePos, /* 0 = start */
-                         UChar* currency,
-                         UErrorCode* status);
-
-/**
- * Set the pattern used by a UNumberFormat.  This can only be used
- * on a DecimalFormat, other formats return U_ILLEGAL_ARGUMENT_ERROR
- * in the status.
- * @param format The formatter to set.
- * @param localized TRUE if the pattern is localized, FALSE otherwise.
- * @param pattern The new pattern
- * @param patternLength The length of pattern, or -1 if null-terminated.
- * @param parseError A pointer to UParseError to recieve information
- * about errors occurred during parsing, or NULL if no parse error
- * information is desired.
- * @param status A pointer to an input-output UErrorCode.
- * @see unum_toPattern
- * @see DecimalFormat
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2 
-unum_applyPattern(          UNumberFormat  *format,
-                            UBool          localized,
-                    const   UChar          *pattern,
-                            int32_t         patternLength,
-                            UParseError    *parseError,
-                            UErrorCode     *status
-                                    );
-
-/**
-* Get a locale for which decimal formatting patterns are available.
-* A UNumberFormat in a locale returned by this function will perform the correct
-* formatting and parsing for the locale.  The results of this call are not
-* valid for rule-based number formats.
-* @param index The index of the desired locale.
-* @return A locale for which number formatting patterns are available, or 0 if none.
-* @see unum_countAvailable
-* @stable ICU 2.0
-*/
-U_STABLE const char* U_EXPORT2 
-unum_getAvailable(int32_t index);
-
-/**
-* Determine how many locales have decimal formatting patterns available.  The
-* results of this call are not valid for rule-based number formats.
-* This function is useful for determining the loop ending condition for
-* calls to {@link #unum_getAvailable }.
-* @return The number of locales for which decimal formatting patterns are available.
-* @see unum_getAvailable
-* @stable ICU 2.0
-*/
-U_STABLE int32_t U_EXPORT2 
-unum_countAvailable(void);
-
-/** The possible UNumberFormat numeric attributes @stable ICU 2.0 */
-typedef enum UNumberFormatAttribute {
-  /** Parse integers only */
-  UNUM_PARSE_INT_ONLY,
-  /** Use grouping separator */
-  UNUM_GROUPING_USED,
-  /** Always show decimal point */
-  UNUM_DECIMAL_ALWAYS_SHOWN,
-  /** Maximum integer digits */
-  UNUM_MAX_INTEGER_DIGITS,
-  /** Minimum integer digits */
-  UNUM_MIN_INTEGER_DIGITS,
-  /** Integer digits */
-  UNUM_INTEGER_DIGITS,
-  /** Maximum fraction digits */
-  UNUM_MAX_FRACTION_DIGITS,
-  /** Minimum fraction digits */
-  UNUM_MIN_FRACTION_DIGITS,
-  /** Fraction digits */
-  UNUM_FRACTION_DIGITS,
-  /** Multiplier */
-  UNUM_MULTIPLIER,
-  /** Grouping size */
-  UNUM_GROUPING_SIZE,
-  /** Rounding Mode */
-  UNUM_ROUNDING_MODE,
-  /** Rounding increment */
-  UNUM_ROUNDING_INCREMENT,
-  /** The width to which the output of <code>format()</code> is padded. */
-  UNUM_FORMAT_WIDTH,
-  /** The position at which padding will take place. */
-  UNUM_PADDING_POSITION,
-  /** Secondary grouping size */
-  UNUM_SECONDARY_GROUPING_SIZE,
-  /** Use significant digits
-   * @stable ICU 3.0 */
-  UNUM_SIGNIFICANT_DIGITS_USED,
-  /** Minimum significant digits
-   * @stable ICU 3.0 */
-  UNUM_MIN_SIGNIFICANT_DIGITS,
-  /** Maximum significant digits
-   * @stable ICU 3.0 */
-  UNUM_MAX_SIGNIFICANT_DIGITS,
-  /** Lenient parse mode used by rule-based formats.
-   * @stable ICU 3.0
-   */
-  UNUM_LENIENT_PARSE
-} UNumberFormatAttribute;
-
-/**
-* Get a numeric attribute associated with a UNumberFormat.
-* An example of a numeric attribute is the number of integer digits a formatter will produce.
-* @param fmt The formatter to query.
-* @param attr The attribute to query; one of UNUM_PARSE_INT_ONLY, UNUM_GROUPING_USED,
-* UNUM_DECIMAL_ALWAYS_SHOWN, UNUM_MAX_INTEGER_DIGITS, UNUM_MIN_INTEGER_DIGITS, UNUM_INTEGER_DIGITS,
-* UNUM_MAX_FRACTION_DIGITS, UNUM_MIN_FRACTION_DIGITS, UNUM_FRACTION_DIGITS, UNUM_MULTIPLIER,
-* UNUM_GROUPING_SIZE, UNUM_ROUNDING_MODE, UNUM_FORMAT_WIDTH, UNUM_PADDING_POSITION, UNUM_SECONDARY_GROUPING_SIZE.
-* @return The value of attr.
-* @see unum_setAttribute
-* @see unum_getDoubleAttribute
-* @see unum_setDoubleAttribute
-* @see unum_getTextAttribute
-* @see unum_setTextAttribute
-* @stable ICU 2.0
-*/
-U_STABLE int32_t U_EXPORT2 
-unum_getAttribute(const UNumberFormat*          fmt,
-          UNumberFormatAttribute  attr);
-
-/**
-* Set a numeric attribute associated with a UNumberFormat.
-* An example of a numeric attribute is the number of integer digits a formatter will produce.  If the
-* formatter does not understand the attribute, the call is ignored.  Rule-based formatters only understand
-* the lenient-parse attribute.
-* @param fmt The formatter to set.
-* @param attr The attribute to set; one of UNUM_PARSE_INT_ONLY, UNUM_GROUPING_USED,
-* UNUM_DECIMAL_ALWAYS_SHOWN, UNUM_MAX_INTEGER_DIGITS, UNUM_MIN_INTEGER_DIGITS, UNUM_INTEGER_DIGITS,
-* UNUM_MAX_FRACTION_DIGITS, UNUM_MIN_FRACTION_DIGITS, UNUM_FRACTION_DIGITS, UNUM_MULTIPLIER,
-* UNUM_GROUPING_SIZE, UNUM_ROUNDING_MODE, UNUM_FORMAT_WIDTH, UNUM_PADDING_POSITION, UNUM_SECONDARY_GROUPING_SIZE,
-* or UNUM_LENIENT_PARSE.
-* @param newValue The new value of attr.
-* @see unum_getAttribute
-* @see unum_getDoubleAttribute
-* @see unum_setDoubleAttribute
-* @see unum_getTextAttribute
-* @see unum_setTextAttribute
-* @stable ICU 2.0
-*/
-U_STABLE void U_EXPORT2 
-unum_setAttribute(    UNumberFormat*          fmt,
-            UNumberFormatAttribute  attr,
-            int32_t                 newValue);
-
-
-/**
-* Get a numeric attribute associated with a UNumberFormat.
-* An example of a numeric attribute is the number of integer digits a formatter will produce.
-* If the formatter does not understand the attribute, -1 is returned.
-* @param fmt The formatter to query.
-* @param attr The attribute to query; e.g. UNUM_ROUNDING_INCREMENT.
-* @return The value of attr.
-* @see unum_getAttribute
-* @see unum_setAttribute
-* @see unum_setDoubleAttribute
-* @see unum_getTextAttribute
-* @see unum_setTextAttribute
-* @stable ICU 2.0
-*/
-U_STABLE double U_EXPORT2 
-unum_getDoubleAttribute(const UNumberFormat*          fmt,
-          UNumberFormatAttribute  attr);
-
-/**
-* Set a numeric attribute associated with a UNumberFormat.
-* An example of a numeric attribute is the number of integer digits a formatter will produce.
-* If the formatter does not understand the attribute, this call is ignored.
-* @param fmt The formatter to set.
-* @param attr The attribute to set; e.g. UNUM_ROUNDING_INCREMENT.
-* @param newValue The new value of attr.
-* @see unum_getAttribute
-* @see unum_setAttribute
-* @see unum_getDoubleAttribute
-* @see unum_getTextAttribute
-* @see unum_setTextAttribute
-* @stable ICU 2.0
-*/
-U_STABLE void U_EXPORT2 
-unum_setDoubleAttribute(    UNumberFormat*          fmt,
-            UNumberFormatAttribute  attr,
-            double                 newValue);
-
-/** The possible UNumberFormat text attributes @stable ICU 2.0*/
-typedef enum UNumberFormatTextAttribute {
-  /** Positive prefix */
-  UNUM_POSITIVE_PREFIX,
-  /** Positive suffix */
-  UNUM_POSITIVE_SUFFIX,
-  /** Negative prefix */
-  UNUM_NEGATIVE_PREFIX,
-  /** Negative suffix */
-  UNUM_NEGATIVE_SUFFIX,
-  /** The character used to pad to the format width. */
-  UNUM_PADDING_CHARACTER,
-  /** The ISO currency code */
-  UNUM_CURRENCY_CODE,
-  /**
-   * The default rule set.  This is only available with rule-based formatters.
-   * @stable ICU 3.0
-   */
-  UNUM_DEFAULT_RULESET,
-  /**
-   * The public rule sets.  This is only available with rule-based formatters.
-   * This is a read-only attribute.  The public rulesets are returned as a
-   * single string, with each ruleset name delimited by ';' (semicolon).
-   * @stable ICU 3.0
-   */
-  UNUM_PUBLIC_RULESETS
-} UNumberFormatTextAttribute;
-
-/**
-* Get a text attribute associated with a UNumberFormat.
-* An example of a text attribute is the suffix for positive numbers.  If the formatter
-* does not understand the attributre, U_UNSUPPORTED_ERROR is returned as the status.
-* Rule-based formatters only understand UNUM_DEFAULT_RULESET and UNUM_PUBLIC_RULESETS.
-* @param fmt The formatter to query.
-* @param tag The attribute to query; one of UNUM_POSITIVE_PREFIX, UNUM_POSITIVE_SUFFIX,
-* UNUM_NEGATIVE_PREFIX, UNUM_NEGATIVE_SUFFIX, UNUM_PADDING_CHARACTER, UNUM_CURRENCY_CODE,
-* UNUM_DEFAULT_RULESET, or UNUM_PUBLIC_RULESETS.
-* @param result A pointer to a buffer to receive the attribute.
-* @param resultLength The maximum size of result.
-* @param status A pointer to an UErrorCode to receive any errors
-* @return The total buffer size needed; if greater than resultLength, the output was truncated.
-* @see unum_setTextAttribute
-* @see unum_getAttribute
-* @see unum_setAttribute
-* @stable ICU 2.0
-*/
-U_STABLE int32_t U_EXPORT2 
-unum_getTextAttribute(    const    UNumberFormat*                    fmt,
-            UNumberFormatTextAttribute      tag,
-            UChar*                            result,
-            int32_t                            resultLength,
-            UErrorCode*                        status);
-
-/**
-* Set a text attribute associated with a UNumberFormat.
-* An example of a text attribute is the suffix for positive numbers.  Rule-based formatters
-* only understand UNUM_DEFAULT_RULESET.
-* @param fmt The formatter to set.
-* @param tag The attribute to set; one of UNUM_POSITIVE_PREFIX, UNUM_POSITIVE_SUFFIX,
-* UNUM_NEGATIVE_PREFIX, UNUM_NEGATIVE_SUFFIX, UNUM_PADDING_CHARACTER, UNUM_CURRENCY_CODE,
-* or UNUM_DEFAULT_RULESET.
-* @param newValue The new value of attr.
-* @param newValueLength The length of newValue, or -1 if null-terminated.
-* @param status A pointer to an UErrorCode to receive any errors
-* @see unum_getTextAttribute
-* @see unum_getAttribute
-* @see unum_setAttribute
-* @stable ICU 2.0
-*/
-U_STABLE void U_EXPORT2 
-unum_setTextAttribute(    UNumberFormat*                    fmt,
-            UNumberFormatTextAttribute      tag,
-            const    UChar*                            newValue,
-            int32_t                            newValueLength,
-            UErrorCode                        *status);
-
-/**
- * Extract the pattern from a UNumberFormat.  The pattern will follow
- * the DecimalFormat pattern syntax.
- * @param fmt The formatter to query.
- * @param isPatternLocalized TRUE if the pattern should be localized,
- * FALSE otherwise.  This is ignored if the formatter is a rule-based
- * formatter.
- * @param result A pointer to a buffer to receive the pattern.
- * @param resultLength The maximum size of result.
- * @param status A pointer to an input-output UErrorCode.
- * @return The total buffer size needed; if greater than resultLength,
- * the output was truncated.
- * @see unum_applyPattern
- * @see DecimalFormat
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2 
-unum_toPattern(    const    UNumberFormat*          fmt,
-        UBool                  isPatternLocalized,
-        UChar*                  result,
-        int32_t                 resultLength,
-        UErrorCode*             status);
-
-
-/**
- * Constants for specifying a number format symbol.
- * @stable ICU 2.0
- */
-typedef enum UNumberFormatSymbol {
-  /** The decimal separator */
-  UNUM_DECIMAL_SEPARATOR_SYMBOL = 0,
-  /** The grouping separator */
-  UNUM_GROUPING_SEPARATOR_SYMBOL = 1,
-  /** The pattern separator */
-  UNUM_PATTERN_SEPARATOR_SYMBOL = 2,
-  /** The percent sign */
-  UNUM_PERCENT_SYMBOL = 3,
-  /** Zero*/
-  UNUM_ZERO_DIGIT_SYMBOL = 4,
-  /** Character representing a digit in the pattern */
-  UNUM_DIGIT_SYMBOL = 5,
-  /** The minus sign */
-  UNUM_MINUS_SIGN_SYMBOL = 6,
-  /** The plus sign */
-  UNUM_PLUS_SIGN_SYMBOL = 7,
-  /** The currency symbol */
-  UNUM_CURRENCY_SYMBOL = 8,
-  /** The international currency symbol */
-  UNUM_INTL_CURRENCY_SYMBOL = 9,
-  /** The monetary separator */
-  UNUM_MONETARY_SEPARATOR_SYMBOL = 10,
-  /** The exponential symbol */
-  UNUM_EXPONENTIAL_SYMBOL = 11,
-  /** Per mill symbol */
-  UNUM_PERMILL_SYMBOL = 12,
-  /** Escape padding character */
-  UNUM_PAD_ESCAPE_SYMBOL = 13,
-  /** Infinity symbol */
-  UNUM_INFINITY_SYMBOL = 14,
-  /** Nan symbol */
-  UNUM_NAN_SYMBOL = 15,
-  /** Significant digit symbol
-   * @stable ICU 3.0 */
-  UNUM_SIGNIFICANT_DIGIT_SYMBOL = 16,
-  /** The monetary grouping separator 
-   * @stable ICU 3.6
-   */
-  UNUM_MONETARY_GROUPING_SEPARATOR_SYMBOL = 17,  
-  /** count symbol constants */
-  UNUM_FORMAT_SYMBOL_COUNT = 18
-} UNumberFormatSymbol;
-
-/**
-* Get a symbol associated with a UNumberFormat.
-* A UNumberFormat uses symbols to represent the special locale-dependent
-* characters in a number, for example the percent sign. This API is not
-* supported for rule-based formatters.
-* @param fmt The formatter to query.
-* @param symbol The UNumberFormatSymbol constant for the symbol to get
-* @param buffer The string buffer that will receive the symbol string;
-*               if it is NULL, then only the length of the symbol is returned
-* @param size The size of the string buffer
-* @param status A pointer to an UErrorCode to receive any errors
-* @return The length of the symbol; the buffer is not modified if
-*         <code>length&gt;=size</code>
-* @see unum_setSymbol
-* @stable ICU 2.0
-*/
-U_STABLE int32_t U_EXPORT2
-unum_getSymbol(const UNumberFormat *fmt,
-               UNumberFormatSymbol symbol,
-               UChar *buffer,
-               int32_t size,
-               UErrorCode *status);
-
-/**
-* Set a symbol associated with a UNumberFormat.
-* A UNumberFormat uses symbols to represent the special locale-dependent
-* characters in a number, for example the percent sign.  This API is not
-* supported for rule-based formatters.
-* @param fmt The formatter to set.
-* @param symbol The UNumberFormatSymbol constant for the symbol to set
-* @param value The string to set the symbol to
-* @param length The length of the string, or -1 for a zero-terminated string
-* @param status A pointer to an UErrorCode to receive any errors.
-* @see unum_getSymbol
-* @stable ICU 2.0
-*/
-U_STABLE void U_EXPORT2
-unum_setSymbol(UNumberFormat *fmt,
-               UNumberFormatSymbol symbol,
-               const UChar *value,
-               int32_t length,
-               UErrorCode *status);
-
-
-/**
- * Get the locale for this number format object.
- * You can choose between valid and actual locale.
- * @param fmt The formatter to get the locale from
- * @param type type of the locale we're looking for (valid or actual) 
- * @param status error code for the operation
- * @return the locale name
- * @stable ICU 2.8
- */
-U_STABLE const char* U_EXPORT2
-unum_getLocaleByType(const UNumberFormat *fmt,
-                     ULocDataLocaleType type,
-                     UErrorCode* status); 
-
-#endif /* #if !UCONFIG_NO_FORMATTING */
-
-#endif

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/uobject.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/uobject.h b/apps/couch_collate/platform/osx/icu/unicode/uobject.h
deleted file mode 100644
index 3d8b96e..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/uobject.h
+++ /dev/null
@@ -1,308 +0,0 @@
-/*
-******************************************************************************
-*
-*   Copyright (C) 2002-2007, International Business Machines
-*   Corporation and others.  All Rights Reserved.
-*
-******************************************************************************
-*   file name:  uobject.h
-*   encoding:   US-ASCII
-*   tab size:   8 (not used)
-*   indentation:4
-*
-*   created on: 2002jun26
-*   created by: Markus W. Scherer
-*/
-
-#ifndef __UOBJECT_H__
-#define __UOBJECT_H__
-
-#include "unicode/utypes.h"
-
-U_NAMESPACE_BEGIN
-
-/**
- * \file
- * \brief C++ API: Common ICU base class UObject.
- */
-
-/**  U_OVERRIDE_CXX_ALLOCATION - Define this to override operator new and
- *                               delete in UMemory. Enabled by default for ICU.
- *
- *         Enabling forces all allocation of ICU object types to use ICU's
- *         memory allocation. On Windows, this allows the ICU DLL to be used by
- *         applications that statically link the C Runtime library, meaning that
- *         the app and ICU will be using different heaps.
- *
- * @stable ICU 2.2
- */                              
-#ifndef U_OVERRIDE_CXX_ALLOCATION
-#define U_OVERRIDE_CXX_ALLOCATION 1
-#endif
-
-/**  U_HAVE_PLACEMENT_NEW - Define this to define the placement new and
- *                          delete in UMemory for STL.
- *
- * @stable ICU 2.6
- */                              
-#ifndef U_HAVE_PLACEMENT_NEW
-#define U_HAVE_PLACEMENT_NEW 1
-#endif
-
-
-/**  U_HAVE_DEBUG_LOCATION_NEW - Define this to define the MFC debug
- * version of the operator new.
- *
- * @stable ICU 3.4
- */                              
-#ifndef U_HAVE_DEBUG_LOCATION_NEW
-#define U_HAVE_DEBUG_LOCATION_NEW 0
-#endif
-
-/**
- * UMemory is the common ICU base class.
- * All other ICU C++ classes are derived from UMemory (starting with ICU 2.4).
- *
- * This is primarily to make it possible and simple to override the
- * C++ memory management by adding new/delete operators to this base class.
- *
- * To override ALL ICU memory management, including that from plain C code,
- * replace the allocation functions declared in cmemory.h
- *
- * UMemory does not contain any virtual functions.
- * Common "boilerplate" functions are defined in UObject.
- *
- * @stable ICU 2.4
- */
-class U_COMMON_API UMemory {
-public:
-
-#if U_OVERRIDE_CXX_ALLOCATION
-    /**
-     * Override for ICU4C C++ memory management.
-     * simple, non-class types are allocated using the macros in common/cmemory.h
-     * (uprv_malloc(), uprv_free(), uprv_realloc());
-     * they or something else could be used here to implement C++ new/delete
-     * for ICU4C C++ classes
-     * @stable ICU 2.4
-     */
-    static void * U_EXPORT2 operator new(size_t size);
-
-    /**
-     * Override for ICU4C C++ memory management.
-     * See new().
-     * @stable ICU 2.4
-     */
-    static void * U_EXPORT2 operator new[](size_t size);
-
-    /**
-     * Override for ICU4C C++ memory management.
-     * simple, non-class types are allocated using the macros in common/cmemory.h
-     * (uprv_malloc(), uprv_free(), uprv_realloc());
-     * they or something else could be used here to implement C++ new/delete
-     * for ICU4C C++ classes
-     * @stable ICU 2.4
-     */
-    static void U_EXPORT2 operator delete(void *p);
-
-    /**
-     * Override for ICU4C C++ memory management.
-     * See delete().
-     * @stable ICU 2.4
-     */
-    static void U_EXPORT2 operator delete[](void *p);
-
-#if U_HAVE_PLACEMENT_NEW
-    /**
-     * Override for ICU4C C++ memory management for STL.
-     * See new().
-     * @stable ICU 2.6
-     */
-    static inline void * U_EXPORT2 operator new(size_t, void *ptr) { return ptr; }
-
-    /**
-     * Override for ICU4C C++ memory management for STL.
-     * See delete().
-     * @stable ICU 2.6
-     */
-    static inline void U_EXPORT2 operator delete(void *, void *) {}
-#endif /* U_HAVE_PLACEMENT_NEW */
-#if U_HAVE_DEBUG_LOCATION_NEW
-    /**
-      * This method overrides the MFC debug version of the operator new
-      * 
-      * @param size   The requested memory size
-      * @param file   The file where the allocation was requested
-      * @param line   The line where the allocation was requested 
-      */ 
-    static void * U_EXPORT2 operator new(size_t size, const char* file, int line);
-    /**
-      * This method provides a matching delete for the MFC debug new
-      * 
-      * @param p      The pointer to the allocated memory
-      * @param file   The file where the allocation was requested
-      * @param line   The line where the allocation was requested 
-      */ 
-    static void U_EXPORT2 operator delete(void* p, const char* file, int line);
-#endif /* U_HAVE_DEBUG_LOCATION_NEW */
-#endif /* U_OVERRIDE_CXX_ALLOCATION */
-
-    /*
-     * Assignment operator not declared. The compiler will provide one
-     * which does nothing since this class does not contain any data members.
-     * API/code coverage may show the assignment operator as present and
-     * untested - ignore.
-     * Subclasses need this assignment operator if they use compiler-provided
-     * assignment operators of their own. An alternative to not declaring one
-     * here would be to declare and empty-implement a protected or public one.
-    UMemory &UMemory::operator=(const UMemory &);
-     */
-};
-
-/**
- * UObject is the common ICU "boilerplate" class.
- * UObject inherits UMemory (starting with ICU 2.4),
- * and all other public ICU C++ classes
- * are derived from UObject (starting with ICU 2.2).
- *
- * UObject contains common virtual functions like for ICU's "poor man's RTTI".
- * It does not contain default implementations of virtual methods
- * like getDynamicClassID to allow derived classes such as Format
- * to declare these as pure virtual.
- *
- * The clone() function is not available in UObject because it is not
- * implemented by all ICU classes.
- * Many ICU services provide a clone() function for their class trees,
- * defined on the service's C++ base class, and all subclasses within that
- * service class tree return a pointer to the service base class
- * (which itself is a subclass of UObject).
- * This is because some compilers do not support covariant (same-as-this)
- * return types; cast to the appropriate subclass if necessary.
- *
- * @stable ICU 2.2
- */
-class U_COMMON_API UObject : public UMemory {
-public:
-    /**
-     * Destructor.
-     *
-     * @stable ICU 2.2
-     */
-    virtual ~UObject();
-
-    /**
-     * ICU4C "poor man's RTTI", returns a UClassID for the actual ICU class.
-     *
-     * @stable ICU 2.2
-     */
-    virtual UClassID getDynamicClassID() const = 0;
-
-protected:
-    // the following functions are protected to prevent instantiation and
-    // direct use of UObject itself
-
-    // default constructor
-    // commented out because UObject is abstract (see getDynamicClassID)
-    // inline UObject() {}
-
-    // copy constructor
-    // commented out because UObject is abstract (see getDynamicClassID)
-    // inline UObject(const UObject &other) {}
-
-#if 0
-    // TODO Sometime in the future. Implement operator==().
-    // (This comment inserted in 2.2)
-    // some or all of the following "boilerplate" functions may be made public
-    // in a future ICU4C release when all subclasses implement them
-
-    // assignment operator
-    // (not virtual, see "Taligent's Guide to Designing Programs" pp.73..74)
-    // commented out because the implementation is the same as a compiler's default
-    // UObject &operator=(const UObject &other) { return *this; }
-
-    // comparison operators
-    virtual inline UBool operator==(const UObject &other) const { return this==&other; }
-    inline UBool operator!=(const UObject &other) const { return !operator==(other); }
-
-    // clone() commented out from the base class:
-    // some compilers do not support co-variant return types
-    // (i.e., subclasses would have to return UObject * as well, instead of SubClass *)
-    // see also UObject class documentation.
-    // virtual UObject *clone() const;
-#endif
-
-    /*
-     * Assignment operator not declared. The compiler will provide one
-     * which does nothing since this class does not contain any data members.
-     * API/code coverage may show the assignment operator as present and
-     * untested - ignore.
-     * Subclasses need this assignment operator if they use compiler-provided
-     * assignment operators of their own. An alternative to not declaring one
-     * here would be to declare and empty-implement a protected or public one.
-    UObject &UObject::operator=(const UObject &);
-     */
-
-// Future implementation for RTTI that support subtyping. [alan]
-// 
-//  public:
-//     /**
-//      * @internal
-//      */
-//     static UClassID getStaticClassID();
-// 
-//     /**
-//      * @internal
-//      */
-//     UBool instanceOf(UClassID type) const;
-};
-
-/**
- * This is a simple macro to add ICU RTTI to an ICU object implementation.
- * This does not go into the header. This should only be used in *.cpp files.
- *
- * @param myClass The name of the class that needs RTTI defined.
- * @internal
- */
-#define UOBJECT_DEFINE_RTTI_IMPLEMENTATION(myClass) \
-    UClassID U_EXPORT2 myClass::getStaticClassID() { \
-        static char classID = 0; \
-        return (UClassID)&classID; \
-    } \
-    UClassID myClass::getDynamicClassID() const \
-    { return myClass::getStaticClassID(); }
-
-
-/**
- * This macro adds ICU RTTI to an ICU abstract class implementation.
- * This macro should be invoked in *.cpp files.  The corresponding
- * header should declare getStaticClassID.
- *
- * @param myClass The name of the class that needs RTTI defined.
- * @internal
- */
-#define UOBJECT_DEFINE_ABSTRACT_RTTI_IMPLEMENTATION(myClass) \
-    UClassID U_EXPORT2 myClass::getStaticClassID() { \
-        static char classID = 0; \
-        return (UClassID)&classID; \
-    }
-
-// /**
-//  * This macro adds ICU RTTI to an ICU concrete class implementation.
-//  * This macro should be invoked in *.cpp files.  The corresponding
-//  * header should declare getDynamicClassID and getStaticClassID.
-//  *
-//  * @param myClass The name of the class that needs RTTI defined.
-//  * @param myParent The name of the myClass's parent.
-//  * @internal
-//  */
-/*#define UOBJECT_DEFINE_RTTI_IMPLEMENTATION(myClass, myParent) \
-    UOBJECT_DEFINE_ABSTRACT_RTTI_IMPLEMENTATION(myClass, myParent) \
-    UClassID myClass::getDynamicClassID() const { \
-        return myClass::getStaticClassID(); \
-    }
-*/
-
-
-U_NAMESPACE_END
-
-#endif

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/uobslete.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/uobslete.h b/apps/couch_collate/platform/osx/icu/unicode/uobslete.h
deleted file mode 100644
index 91be243..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/uobslete.h
+++ /dev/null
@@ -1,32 +0,0 @@
-/*
-*******************************************************************************
-*   Copyright (C) 2004-2008, International Business Machines
-*   Corporation and others.  All Rights Reserved.
-*******************************************************************************
-*
-*   file name:  
-*   encoding:   US-ASCII
-*   tab size:   8 (not used)
-*   indentation:4
-*
-*   Created by: genheaders.pl, a perl script written by Ram Viswanadha
-*
-*  Contains data for commenting out APIs.
-*  Gets included by umachine.h
-*
-*  THIS FILE IS MACHINE-GENERATED, DON'T PLAY WITH IT IF YOU DON'T KNOW WHAT
-*  YOU ARE DOING, OTHERWISE VERY BAD THINGS WILL HAPPEN!
-*/
-
-#ifndef UOBSLETE_H
-#define UOBSLETE_H
-
-#ifdef U_HIDE_OBSOLETE_API
-
-#    if U_DISABLE_RENAMING
-#    else
-#    endif /* U_DISABLE_RENAMING */
-
-#endif /* U_HIDE_OBSOLETE_API */
-#endif /* UOBSLETE_H */
-

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/urbtok.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/urbtok.h b/apps/couch_collate/platform/osx/icu/unicode/urbtok.h
deleted file mode 100644
index 936ddde..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/urbtok.h
+++ /dev/null
@@ -1,126 +0,0 @@
-/*
-******************************************************************************
-* Copyright (C) 2006-2008 Apple Inc. All Rights Reserved.
-******************************************************************************
-*/
-
-#ifndef URBTOK_H
-#define URBTOK_H
-
-#include "unicode/utypes.h"
-
-#if !UCONFIG_NO_BREAK_ITERATION
-
-#include "unicode/utext.h"
-#include "unicode/ubrk.h"
-#include "unicode/parseerr.h"
-
-
-typedef struct RuleBasedTokenRange {
-    signed long location;
-    signed long length;
-} RuleBasedTokenRange;
-
-/**
- * Open a new UBreakIterator for tokenizing text using specified breaking rules.
- * The rule syntax is ... (TBD)
- * @param rules A set of rules specifying the text breaking conventions.
- * @param rulesLength The number of characters in rules, or -1 if null-terminated.
- * @param parseErr   Receives position and context information for any syntax errors
- *                   detected while parsing the rules.
- * @param status A UErrorCode to receive any errors.
- * @return A UBreakIterator for the specified rules.
- * @see ubrk_open
- * @internal
- */
-U_INTERNAL UBreakIterator* U_EXPORT2
-urbtok_openRules(const UChar     *rules,
-               int32_t         rulesLength,
-               UParseError     *parseErr,
-               UErrorCode      *status);
-
-/**
- * Open a new UBreakIterator for tokenizing text using specified breaking rules.
- * @param rules A set of rules specifying the text breaking conventions. The binary rules
- *              must be at least 32-bit aligned. Note: This version makes a copy of the
- *				rules, so after calling this function the caller can close or release
- *				the rules that were passed to this function. The copy created by this
- *				call will be freed when ubrk_close() is called on the UBreakIterator*.
- * @param status A UErrorCode to receive any errors.
- * @return A UBreakIterator for the specified rules.
- * @see ubrk_open
- * @internal
- */
-U_INTERNAL UBreakIterator* U_EXPORT2
-urbtok_openBinaryRules(const uint8_t *rules,
-               UErrorCode      *status);
-
-/**
- * Open a new UBreakIterator for tokenizing text using specified breaking rules.
- * @param rules A set of rules specifying the text breaking conventions. The binary rules
- *              must be at least 32-bit aligned. Note: This version does NOT make a copy
- *				of the rules, so after calling this function the caller must not close or
- *				release the rules passed to this function until after they are finished
- *				with this UBreakIterator* (and any others created using the same rules)
-  *				and have called ubrk_close() to close the UBreakIterator* (and any others
- *				using the same rules).
- * @param status A UErrorCode to receive any errors.
- * @return A UBreakIterator for the specified rules.
- * @see ubrk_open
- * @internal
- */
-U_INTERNAL UBreakIterator* U_EXPORT2
-urbtok_openBinaryRulesNoCopy(const uint8_t *rules,
-               UErrorCode      *status);
-
-/**
- * Get the (native-endian) binary break rules for this tokenizer.
- * @param bi The tokenizer to use.
- * @param buffer The output buffer for the rules. You can pass 0 to get the required size.
- * @param buffSize The size of the output buffer.
- * @param status A UErrorCode to receive any errors.
- * @return The actual size of the binary rules, whether they fit the buffer or not.
- * @internal
- */
-U_INTERNAL uint32_t U_EXPORT2
-urbtok_getBinaryRules(UBreakIterator      *bi,
-                uint8_t             *buffer,
-                uint32_t            buffSize,
-                UErrorCode          *status);
-
-/**
- * Tokenize text using a rule-based tokenizer.
- * @param bi The tokenizer to use.
- * @param maxTokens The maximum number of tokens to return.
- * @param outTokens An array of RuleBasedTokenRange to fill in with the tokens.
- * @param outTokenFlags An (optional) array of uint32_t to fill in with token flags.
- * @return The number of tokens returned, 0 if done.
- * @internal
- */
-U_INTERNAL int32_t U_EXPORT2
-urbtok_tokenize(UBreakIterator      *bi,
-               int32_t              maxTokens,
-               RuleBasedTokenRange  *outTokens,
-               unsigned long        *outTokenFlags);
-
-/**
- * Swap the endianness of a set of binary break rules.
- * @param rules A set of rules which need swapping.
- * @param buffer The output buffer for the swapped rules, which must be the same
- *               size as the input rules buffer.
- * @param inIsBigEndian UBool indicating whether the input is big-endian
- * @param outIsBigEndian UBool indicating whether the output should be big-endian
- * @param status A UErrorCode to receive any errors.
- * @internal
- */
-U_INTERNAL void U_EXPORT2
-urbtok_swapBinaryRules(const uint8_t *rules,
-               uint8_t          *buffer,
-               UBool            inIsBigEndian,
-               UBool            outIsBigEndian,
-               UErrorCode       *status);
-
-
-#endif /* #if !UCONFIG_NO_BREAK_ITERATION */
-
-#endif


[11/57] [abbrv] remove couch_collate

Posted by be...@apache.org.
http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/unistr.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/unistr.h b/apps/couch_collate/platform/osx/icu/unicode/unistr.h
deleted file mode 100644
index 9a96bdc..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/unistr.h
+++ /dev/null
@@ -1,4230 +0,0 @@
-/*
-**********************************************************************
-*   Copyright (C) 1998-2008, International Business Machines
-*   Corporation and others.  All Rights Reserved.
-**********************************************************************
-*
-* File unistr.h
-*
-* Modification History:
-*
-*   Date        Name        Description
-*   09/25/98    stephen     Creation.
-*   11/11/98    stephen     Changed per 11/9 code review.
-*   04/20/99    stephen     Overhauled per 4/16 code review.
-*   11/18/99    aliu        Made to inherit from Replaceable.  Added method
-*                           handleReplaceBetween(); other methods unchanged.
-*   06/25/01    grhoten     Remove dependency on iostream.
-******************************************************************************
-*/
-
-#ifndef UNISTR_H
-#define UNISTR_H
-
-/**
- * \file 
- * \brief C++ API: Unicode String 
- */
-
-#include "unicode/rep.h"
-
-struct UConverter;          // unicode/ucnv.h
-class  StringThreadTest;
-
-#ifndef U_COMPARE_CODE_POINT_ORDER
-/* see also ustring.h and unorm.h */
-/**
- * Option bit for u_strCaseCompare, u_strcasecmp, unorm_compare, etc:
- * Compare strings in code point order instead of code unit order.
- * @stable ICU 2.2
- */
-#define U_COMPARE_CODE_POINT_ORDER  0x8000
-#endif
-
-#ifndef USTRING_H
-/**
- * \ingroup ustring_ustrlen
- */
-U_STABLE int32_t U_EXPORT2
-u_strlen(const UChar *s);
-#endif
-
-U_NAMESPACE_BEGIN
-
-class Locale;               // unicode/locid.h
-class StringCharacterIterator;
-class BreakIterator;        // unicode/brkiter.h
-
-/* The <iostream> include has been moved to unicode/ustream.h */
-
-/**
- * Constant to be used in the UnicodeString(char *, int32_t, EInvariant) constructor
- * which constructs a Unicode string from an invariant-character char * string.
- * About invariant characters see utypes.h.
- * This constructor has no runtime dependency on conversion code and is
- * therefore recommended over ones taking a charset name string
- * (where the empty string "" indicates invariant-character conversion).
- *
- * @stable ICU 3.2
- */
-#define US_INV U_NAMESPACE_QUALIFIER UnicodeString::kInvariant
-
-/**
- * Unicode String literals in C++.
- * Dependent on the platform properties, different UnicodeString
- * constructors should be used to create a UnicodeString object from
- * a string literal.
- * The macros are defined for maximum performance.
- * They work only for strings that contain "invariant characters", i.e.,
- * only latin letters, digits, and some punctuation.
- * See utypes.h for details.
- *
- * The string parameter must be a C string literal.
- * The length of the string, not including the terminating
- * <code>NUL</code>, must be specified as a constant.
- * The U_STRING_DECL macro should be invoked exactly once for one
- * such string variable before it is used.
- * @stable ICU 2.0
- */
-#if defined(U_DECLARE_UTF16)
-#   define UNICODE_STRING(cs, _length) U_NAMESPACE_QUALIFIER UnicodeString(TRUE, (const UChar *)U_DECLARE_UTF16(cs), _length)
-#elif U_SIZEOF_WCHAR_T==U_SIZEOF_UCHAR && (U_CHARSET_FAMILY==U_ASCII_FAMILY || (U_SIZEOF_UCHAR == 2 && defined(U_WCHAR_IS_UTF16)))
-#   define UNICODE_STRING(cs, _length) U_NAMESPACE_QUALIFIER UnicodeString(TRUE, (const UChar *)L ## cs, _length)
-#elif U_SIZEOF_UCHAR==1 && U_CHARSET_FAMILY==U_ASCII_FAMILY
-#   define UNICODE_STRING(cs, _length) U_NAMESPACE_QUALIFIER UnicodeString(TRUE, (const UChar *)cs, _length)
-#else
-#   define UNICODE_STRING(cs, _length) U_NAMESPACE_QUALIFIER UnicodeString(cs, _length, US_INV)
-#endif
-
-/**
- * Unicode String literals in C++.
- * Dependent on the platform properties, different UnicodeString
- * constructors should be used to create a UnicodeString object from
- * a string literal.
- * The macros are defined for improved performance.
- * They work only for strings that contain "invariant characters", i.e.,
- * only latin letters, digits, and some punctuation.
- * See utypes.h for details.
- *
- * The string parameter must be a C string literal.
- * @stable ICU 2.0
- */
-#define UNICODE_STRING_SIMPLE(cs) UNICODE_STRING(cs, -1)
-
-/**
- * UnicodeString is a string class that stores Unicode characters directly and provides
- * similar functionality as the Java String and StringBuffer classes.
- * It is a concrete implementation of the abstract class Replaceable (for transliteration).
- *
- * The UnicodeString class is not suitable for subclassing.
- *
- * <p>For an overview of Unicode strings in C and C++ see the
- * <a href="http://icu-project.org/userguide/strings.html">User Guide Strings chapter</a>.</p>
- *
- * <p>In ICU, a Unicode string consists of 16-bit Unicode <em>code units</em>.
- * A Unicode character may be stored with either one code unit
- * (the most common case) or with a matched pair of special code units
- * ("surrogates"). The data type for code units is UChar. 
- * For single-character handling, a Unicode character code <em>point</em> is a value
- * in the range 0..0x10ffff. ICU uses the UChar32 type for code points.</p>
- *
- * <p>Indexes and offsets into and lengths of strings always count code units, not code points.
- * This is the same as with multi-byte char* strings in traditional string handling.
- * Operations on partial strings typically do not test for code point boundaries.
- * If necessary, the user needs to take care of such boundaries by testing for the code unit
- * values or by using functions like
- * UnicodeString::getChar32Start() and UnicodeString::getChar32Limit()
- * (or, in C, the equivalent macros U16_SET_CP_START() and U16_SET_CP_LIMIT(), see utf.h).</p>
- *
- * UnicodeString methods are more lenient with regard to input parameter values
- * than other ICU APIs. In particular:
- * - If indexes are out of bounds for a UnicodeString object
- *   (<0 or >length()) then they are "pinned" to the nearest boundary.
- * - If primitive string pointer values (e.g., const UChar * or char *)
- *   for input strings are NULL, then those input string parameters are treated
- *   as if they pointed to an empty string.
- *   However, this is <em>not</em> the case for char * parameters for charset names
- *   or other IDs.
- * - Most UnicodeString methods do not take a UErrorCode parameter because
- *   there are usually very few opportunities for failure other than a shortage
- *   of memory, error codes in low-level C++ string methods would be inconvenient,
- *   and the error code as the last parameter (ICU convention) would prevent
- *   the use of default parameter values.
- *   Instead, such methods set the UnicodeString into a "bogus" state
- *   (see isBogus()) if an error occurs.
- *
- * In string comparisons, two UnicodeString objects that are both "bogus"
- * compare equal (to be transitive and prevent endless loops in sorting),
- * and a "bogus" string compares less than any non-"bogus" one.
- *
- * Const UnicodeString methods are thread-safe. Multiple threads can use
- * const methods on the same UnicodeString object simultaneously,
- * but non-const methods must not be called concurrently (in multiple threads)
- * with any other (const or non-const) methods.
- *
- * Similarly, const UnicodeString & parameters are thread-safe.
- * One object may be passed in as such a parameter concurrently in multiple threads.
- * This includes the const UnicodeString & parameters for
- * copy construction, assignment, and cloning.
- *
- * <p>UnicodeString uses several storage methods.
- * String contents can be stored inside the UnicodeString object itself,
- * in an allocated and shared buffer, or in an outside buffer that is "aliased".
- * Most of this is done transparently, but careful aliasing in particular provides
- * significant performance improvements.
- * Also, the internal buffer is accessible via special functions.
- * For details see the
- * <a href="http://icu-project.org/userguide/strings.html">User Guide Strings chapter</a>.</p>
- *
- * @see utf.h
- * @see CharacterIterator
- * @stable ICU 2.0
- */
-class U_COMMON_API UnicodeString : public Replaceable
-{
-public:
-
-  /**
-   * Constant to be used in the UnicodeString(char *, int32_t, EInvariant) constructor
-   * which constructs a Unicode string from an invariant-character char * string.
-   * Use the macro US_INV instead of the full qualification for this value.
-   *
-   * @see US_INV
-   * @stable ICU 3.2
-   */
-  enum EInvariant {
-    /**
-     * @see EInvariant
-     * @stable ICU 3.2
-     */
-    kInvariant
-  };
-
-  //========================================
-  // Read-only operations
-  //========================================
-
-  /* Comparison - bitwise only - for international comparison use collation */
-
-  /**
-   * Equality operator. Performs only bitwise comparison.
-   * @param text The UnicodeString to compare to this one.
-   * @return TRUE if <TT>text</TT> contains the same characters as this one,
-   * FALSE otherwise.
-   * @stable ICU 2.0
-   */
-  inline UBool operator== (const UnicodeString& text) const;
-
-  /**
-   * Inequality operator. Performs only bitwise comparison.
-   * @param text The UnicodeString to compare to this one.
-   * @return FALSE if <TT>text</TT> contains the same characters as this one,
-   * TRUE otherwise.
-   * @stable ICU 2.0
-   */
-  inline UBool operator!= (const UnicodeString& text) const;
-
-  /**
-   * Greater than operator. Performs only bitwise comparison.
-   * @param text The UnicodeString to compare to this one.
-   * @return TRUE if the characters in this are bitwise
-   * greater than the characters in <code>text</code>, FALSE otherwise
-   * @stable ICU 2.0
-   */
-  inline UBool operator> (const UnicodeString& text) const;
-
-  /**
-   * Less than operator. Performs only bitwise comparison.
-   * @param text The UnicodeString to compare to this one.
-   * @return TRUE if the characters in this are bitwise
-   * less than the characters in <code>text</code>, FALSE otherwise
-   * @stable ICU 2.0
-   */
-  inline UBool operator< (const UnicodeString& text) const;
-
-  /**
-   * Greater than or equal operator. Performs only bitwise comparison.
-   * @param text The UnicodeString to compare to this one.
-   * @return TRUE if the characters in this are bitwise
-   * greater than or equal to the characters in <code>text</code>, FALSE otherwise
-   * @stable ICU 2.0
-   */
-  inline UBool operator>= (const UnicodeString& text) const;
-
-  /**
-   * Less than or equal operator. Performs only bitwise comparison.
-   * @param text The UnicodeString to compare to this one.
-   * @return TRUE if the characters in this are bitwise
-   * less than or equal to the characters in <code>text</code>, FALSE otherwise
-   * @stable ICU 2.0
-   */
-  inline UBool operator<= (const UnicodeString& text) const;
-
-  /**
-   * Compare the characters bitwise in this UnicodeString to
-   * the characters in <code>text</code>.
-   * @param text The UnicodeString to compare to this one.
-   * @return The result of bitwise character comparison: 0 if this
-   * contains the same characters as <code>text</code>, -1 if the characters in
-   * this are bitwise less than the characters in <code>text</code>, +1 if the
-   * characters in this are bitwise greater than the characters
-   * in <code>text</code>.
-   * @stable ICU 2.0
-   */
-  inline int8_t compare(const UnicodeString& text) const;
-
-  /**
-   * Compare the characters bitwise in the range
-   * [<TT>start</TT>, <TT>start + length</TT>) with the characters
-   * in <TT>text</TT>
-   * @param start the offset at which the compare operation begins
-   * @param length the number of characters of text to compare.
-   * @param text the other text to be compared against this string.
-   * @return The result of bitwise character comparison: 0 if this
-   * contains the same characters as <code>text</code>, -1 if the characters in
-   * this are bitwise less than the characters in <code>text</code>, +1 if the
-   * characters in this are bitwise greater than the characters
-   * in <code>text</code>.
-   * @stable ICU 2.0
-   */
-  inline int8_t compare(int32_t start,
-         int32_t length,
-         const UnicodeString& text) const;
-
-  /**
-   * Compare the characters bitwise in the range
-   * [<TT>start</TT>, <TT>start + length</TT>) with the characters
-   * in <TT>srcText</TT> in the range
-   * [<TT>srcStart</TT>, <TT>srcStart + srcLength</TT>).
-   * @param start the offset at which the compare operation begins
-   * @param length the number of characters in this to compare.
-   * @param srcText the text to be compared
-   * @param srcStart the offset into <TT>srcText</TT> to start comparison
-   * @param srcLength the number of characters in <TT>src</TT> to compare
-   * @return The result of bitwise character comparison: 0 if this
-   * contains the same characters as <code>srcText</code>, -1 if the characters in
-   * this are bitwise less than the characters in <code>srcText</code>, +1 if the
-   * characters in this are bitwise greater than the characters
-   * in <code>srcText</code>.
-   * @stable ICU 2.0
-   */
-   inline int8_t compare(int32_t start,
-         int32_t length,
-         const UnicodeString& srcText,
-         int32_t srcStart,
-         int32_t srcLength) const;
-
-  /**
-   * Compare the characters bitwise in this UnicodeString with the first
-   * <TT>srcLength</TT> characters in <TT>srcChars</TT>.
-   * @param srcChars The characters to compare to this UnicodeString.
-   * @param srcLength the number of characters in <TT>srcChars</TT> to compare
-   * @return The result of bitwise character comparison: 0 if this
-   * contains the same characters as <code>srcChars</code>, -1 if the characters in
-   * this are bitwise less than the characters in <code>srcChars</code>, +1 if the
-   * characters in this are bitwise greater than the characters
-   * in <code>srcChars</code>.
-   * @stable ICU 2.0
-   */
-  inline int8_t compare(const UChar *srcChars,
-         int32_t srcLength) const;
-
-  /**
-   * Compare the characters bitwise in the range
-   * [<TT>start</TT>, <TT>start + length</TT>) with the first
-   * <TT>length</TT> characters in <TT>srcChars</TT>
-   * @param start the offset at which the compare operation begins
-   * @param length the number of characters to compare.
-   * @param srcChars the characters to be compared
-   * @return The result of bitwise character comparison: 0 if this
-   * contains the same characters as <code>srcChars</code>, -1 if the characters in
-   * this are bitwise less than the characters in <code>srcChars</code>, +1 if the
-   * characters in this are bitwise greater than the characters
-   * in <code>srcChars</code>.
-   * @stable ICU 2.0
-   */
-  inline int8_t compare(int32_t start,
-         int32_t length,
-         const UChar *srcChars) const;
-
-  /**
-   * Compare the characters bitwise in the range
-   * [<TT>start</TT>, <TT>start + length</TT>) with the characters
-   * in <TT>srcChars</TT> in the range
-   * [<TT>srcStart</TT>, <TT>srcStart + srcLength</TT>).
-   * @param start the offset at which the compare operation begins
-   * @param length the number of characters in this to compare
-   * @param srcChars the characters to be compared
-   * @param srcStart the offset into <TT>srcChars</TT> to start comparison
-   * @param srcLength the number of characters in <TT>srcChars</TT> to compare
-   * @return The result of bitwise character comparison: 0 if this
-   * contains the same characters as <code>srcChars</code>, -1 if the characters in
-   * this are bitwise less than the characters in <code>srcChars</code>, +1 if the
-   * characters in this are bitwise greater than the characters
-   * in <code>srcChars</code>.
-   * @stable ICU 2.0
-   */
-  inline int8_t compare(int32_t start,
-         int32_t length,
-         const UChar *srcChars,
-         int32_t srcStart,
-         int32_t srcLength) const;
-
-  /**
-   * Compare the characters bitwise in the range
-   * [<TT>start</TT>, <TT>limit</TT>) with the characters
-   * in <TT>srcText</TT> in the range
-   * [<TT>srcStart</TT>, <TT>srcLimit</TT>).
-   * @param start the offset at which the compare operation begins
-   * @param limit the offset immediately following the compare operation
-   * @param srcText the text to be compared
-   * @param srcStart the offset into <TT>srcText</TT> to start comparison
-   * @param srcLimit the offset into <TT>srcText</TT> to limit comparison
-   * @return The result of bitwise character comparison: 0 if this
-   * contains the same characters as <code>srcText</code>, -1 if the characters in
-   * this are bitwise less than the characters in <code>srcText</code>, +1 if the
-   * characters in this are bitwise greater than the characters
-   * in <code>srcText</code>.
-   * @stable ICU 2.0
-   */
-  inline int8_t compareBetween(int32_t start,
-            int32_t limit,
-            const UnicodeString& srcText,
-            int32_t srcStart,
-            int32_t srcLimit) const;
-
-  /**
-   * Compare two Unicode strings in code point order.
-   * The result may be different from the results of compare(), operator<, etc.
-   * if supplementary characters are present:
-   *
-   * In UTF-16, supplementary characters (with code points U+10000 and above) are
-   * stored with pairs of surrogate code units. These have values from 0xd800 to 0xdfff,
-   * which means that they compare as less than some other BMP characters like U+feff.
-   * This function compares Unicode strings in code point order.
-   * If either of the UTF-16 strings is malformed (i.e., it contains unpaired surrogates), then the result is not defined.
-   *
-   * @param text Another string to compare this one to.
-   * @return a negative/zero/positive integer corresponding to whether
-   * this string is less than/equal to/greater than the second one
-   * in code point order
-   * @stable ICU 2.0
-   */
-  inline int8_t compareCodePointOrder(const UnicodeString& text) const;
-
-  /**
-   * Compare two Unicode strings in code point order.
-   * The result may be different from the results of compare(), operator<, etc.
-   * if supplementary characters are present:
-   *
-   * In UTF-16, supplementary characters (with code points U+10000 and above) are
-   * stored with pairs of surrogate code units. These have values from 0xd800 to 0xdfff,
-   * which means that they compare as less than some other BMP characters like U+feff.
-   * This function compares Unicode strings in code point order.
-   * If either of the UTF-16 strings is malformed (i.e., it contains unpaired surrogates), then the result is not defined.
-   *
-   * @param start The start offset in this string at which the compare operation begins.
-   * @param length The number of code units from this string to compare.
-   * @param srcText Another string to compare this one to.
-   * @return a negative/zero/positive integer corresponding to whether
-   * this string is less than/equal to/greater than the second one
-   * in code point order
-   * @stable ICU 2.0
-   */
-  inline int8_t compareCodePointOrder(int32_t start,
-                                      int32_t length,
-                                      const UnicodeString& srcText) const;
-
-  /**
-   * Compare two Unicode strings in code point order.
-   * The result may be different from the results of compare(), operator<, etc.
-   * if supplementary characters are present:
-   *
-   * In UTF-16, supplementary characters (with code points U+10000 and above) are
-   * stored with pairs of surrogate code units. These have values from 0xd800 to 0xdfff,
-   * which means that they compare as less than some other BMP characters like U+feff.
-   * This function compares Unicode strings in code point order.
-   * If either of the UTF-16 strings is malformed (i.e., it contains unpaired surrogates), then the result is not defined.
-   *
-   * @param start The start offset in this string at which the compare operation begins.
-   * @param length The number of code units from this string to compare.
-   * @param srcText Another string to compare this one to.
-   * @param srcStart The start offset in that string at which the compare operation begins.
-   * @param srcLength The number of code units from that string to compare.
-   * @return a negative/zero/positive integer corresponding to whether
-   * this string is less than/equal to/greater than the second one
-   * in code point order
-   * @stable ICU 2.0
-   */
-   inline int8_t compareCodePointOrder(int32_t start,
-                                       int32_t length,
-                                       const UnicodeString& srcText,
-                                       int32_t srcStart,
-                                       int32_t srcLength) const;
-
-  /**
-   * Compare two Unicode strings in code point order.
-   * The result may be different from the results of compare(), operator<, etc.
-   * if supplementary characters are present:
-   *
-   * In UTF-16, supplementary characters (with code points U+10000 and above) are
-   * stored with pairs of surrogate code units. These have values from 0xd800 to 0xdfff,
-   * which means that they compare as less than some other BMP characters like U+feff.
-   * This function compares Unicode strings in code point order.
-   * If either of the UTF-16 strings is malformed (i.e., it contains unpaired surrogates), then the result is not defined.
-   *
-   * @param srcChars A pointer to another string to compare this one to.
-   * @param srcLength The number of code units from that string to compare.
-   * @return a negative/zero/positive integer corresponding to whether
-   * this string is less than/equal to/greater than the second one
-   * in code point order
-   * @stable ICU 2.0
-   */
-  inline int8_t compareCodePointOrder(const UChar *srcChars,
-                                      int32_t srcLength) const;
-
-  /**
-   * Compare two Unicode strings in code point order.
-   * The result may be different from the results of compare(), operator<, etc.
-   * if supplementary characters are present:
-   *
-   * In UTF-16, supplementary characters (with code points U+10000 and above) are
-   * stored with pairs of surrogate code units. These have values from 0xd800 to 0xdfff,
-   * which means that they compare as less than some other BMP characters like U+feff.
-   * This function compares Unicode strings in code point order.
-   * If either of the UTF-16 strings is malformed (i.e., it contains unpaired surrogates), then the result is not defined.
-   *
-   * @param start The start offset in this string at which the compare operation begins.
-   * @param length The number of code units from this string to compare.
-   * @param srcChars A pointer to another string to compare this one to.
-   * @return a negative/zero/positive integer corresponding to whether
-   * this string is less than/equal to/greater than the second one
-   * in code point order
-   * @stable ICU 2.0
-   */
-  inline int8_t compareCodePointOrder(int32_t start,
-                                      int32_t length,
-                                      const UChar *srcChars) const;
-
-  /**
-   * Compare two Unicode strings in code point order.
-   * The result may be different from the results of compare(), operator<, etc.
-   * if supplementary characters are present:
-   *
-   * In UTF-16, supplementary characters (with code points U+10000 and above) are
-   * stored with pairs of surrogate code units. These have values from 0xd800 to 0xdfff,
-   * which means that they compare as less than some other BMP characters like U+feff.
-   * This function compares Unicode strings in code point order.
-   * If either of the UTF-16 strings is malformed (i.e., it contains unpaired surrogates), then the result is not defined.
-   *
-   * @param start The start offset in this string at which the compare operation begins.
-   * @param length The number of code units from this string to compare.
-   * @param srcChars A pointer to another string to compare this one to.
-   * @param srcStart The start offset in that string at which the compare operation begins.
-   * @param srcLength The number of code units from that string to compare.
-   * @return a negative/zero/positive integer corresponding to whether
-   * this string is less than/equal to/greater than the second one
-   * in code point order
-   * @stable ICU 2.0
-   */
-  inline int8_t compareCodePointOrder(int32_t start,
-                                      int32_t length,
-                                      const UChar *srcChars,
-                                      int32_t srcStart,
-                                      int32_t srcLength) const;
-
-  /**
-   * Compare two Unicode strings in code point order.
-   * The result may be different from the results of compare(), operator<, etc.
-   * if supplementary characters are present:
-   *
-   * In UTF-16, supplementary characters (with code points U+10000 and above) are
-   * stored with pairs of surrogate code units. These have values from 0xd800 to 0xdfff,
-   * which means that they compare as less than some other BMP characters like U+feff.
-   * This function compares Unicode strings in code point order.
-   * If either of the UTF-16 strings is malformed (i.e., it contains unpaired surrogates), then the result is not defined.
-   *
-   * @param start The start offset in this string at which the compare operation begins.
-   * @param limit The offset after the last code unit from this string to compare.
-   * @param srcText Another string to compare this one to.
-   * @param srcStart The start offset in that string at which the compare operation begins.
-   * @param srcLimit The offset after the last code unit from that string to compare.
-   * @return a negative/zero/positive integer corresponding to whether
-   * this string is less than/equal to/greater than the second one
-   * in code point order
-   * @stable ICU 2.0
-   */
-  inline int8_t compareCodePointOrderBetween(int32_t start,
-                                             int32_t limit,
-                                             const UnicodeString& srcText,
-                                             int32_t srcStart,
-                                             int32_t srcLimit) const;
-
-  /**
-   * Compare two strings case-insensitively using full case folding.
-   * This is equivalent to this->foldCase(options).compare(text.foldCase(options)).
-   *
-   * @param text Another string to compare this one to.
-   * @param options A bit set of options:
-   *   - U_FOLD_CASE_DEFAULT or 0 is used for default options:
-   *     Comparison in code unit order with default case folding.
-   *
-   *   - U_COMPARE_CODE_POINT_ORDER
-   *     Set to choose code point order instead of code unit order
-   *     (see u_strCompare for details).
-   *
-   *   - U_FOLD_CASE_EXCLUDE_SPECIAL_I
-   *
-   * @return A negative, zero, or positive integer indicating the comparison result.
-   * @stable ICU 2.0
-   */
-  inline int8_t caseCompare(const UnicodeString& text, uint32_t options) const;
-
-  /**
-   * Compare two strings case-insensitively using full case folding.
-   * This is equivalent to this->foldCase(options).compare(srcText.foldCase(options)).
-   *
-   * @param start The start offset in this string at which the compare operation begins.
-   * @param length The number of code units from this string to compare.
-   * @param srcText Another string to compare this one to.
-   * @param options A bit set of options:
-   *   - U_FOLD_CASE_DEFAULT or 0 is used for default options:
-   *     Comparison in code unit order with default case folding.
-   *
-   *   - U_COMPARE_CODE_POINT_ORDER
-   *     Set to choose code point order instead of code unit order
-   *     (see u_strCompare for details).
-   *
-   *   - U_FOLD_CASE_EXCLUDE_SPECIAL_I
-   *
-   * @return A negative, zero, or positive integer indicating the comparison result.
-   * @stable ICU 2.0
-   */
-  inline int8_t caseCompare(int32_t start,
-         int32_t length,
-         const UnicodeString& srcText,
-         uint32_t options) const;
-
-  /**
-   * Compare two strings case-insensitively using full case folding.
-   * This is equivalent to this->foldCase(options).compare(srcText.foldCase(options)).
-   *
-   * @param start The start offset in this string at which the compare operation begins.
-   * @param length The number of code units from this string to compare.
-   * @param srcText Another string to compare this one to.
-   * @param srcStart The start offset in that string at which the compare operation begins.
-   * @param srcLength The number of code units from that string to compare.
-   * @param options A bit set of options:
-   *   - U_FOLD_CASE_DEFAULT or 0 is used for default options:
-   *     Comparison in code unit order with default case folding.
-   *
-   *   - U_COMPARE_CODE_POINT_ORDER
-   *     Set to choose code point order instead of code unit order
-   *     (see u_strCompare for details).
-   *
-   *   - U_FOLD_CASE_EXCLUDE_SPECIAL_I
-   *
-   * @return A negative, zero, or positive integer indicating the comparison result.
-   * @stable ICU 2.0
-   */
-  inline int8_t caseCompare(int32_t start,
-         int32_t length,
-         const UnicodeString& srcText,
-         int32_t srcStart,
-         int32_t srcLength,
-         uint32_t options) const;
-
-  /**
-   * Compare two strings case-insensitively using full case folding.
-   * This is equivalent to this->foldCase(options).compare(srcChars.foldCase(options)).
-   *
-   * @param srcChars A pointer to another string to compare this one to.
-   * @param srcLength The number of code units from that string to compare.
-   * @param options A bit set of options:
-   *   - U_FOLD_CASE_DEFAULT or 0 is used for default options:
-   *     Comparison in code unit order with default case folding.
-   *
-   *   - U_COMPARE_CODE_POINT_ORDER
-   *     Set to choose code point order instead of code unit order
-   *     (see u_strCompare for details).
-   *
-   *   - U_FOLD_CASE_EXCLUDE_SPECIAL_I
-   *
-   * @return A negative, zero, or positive integer indicating the comparison result.
-   * @stable ICU 2.0
-   */
-  inline int8_t caseCompare(const UChar *srcChars,
-         int32_t srcLength,
-         uint32_t options) const;
-
-  /**
-   * Compare two strings case-insensitively using full case folding.
-   * This is equivalent to this->foldCase(options).compare(srcChars.foldCase(options)).
-   *
-   * @param start The start offset in this string at which the compare operation begins.
-   * @param length The number of code units from this string to compare.
-   * @param srcChars A pointer to another string to compare this one to.
-   * @param options A bit set of options:
-   *   - U_FOLD_CASE_DEFAULT or 0 is used for default options:
-   *     Comparison in code unit order with default case folding.
-   *
-   *   - U_COMPARE_CODE_POINT_ORDER
-   *     Set to choose code point order instead of code unit order
-   *     (see u_strCompare for details).
-   *
-   *   - U_FOLD_CASE_EXCLUDE_SPECIAL_I
-   *
-   * @return A negative, zero, or positive integer indicating the comparison result.
-   * @stable ICU 2.0
-   */
-  inline int8_t caseCompare(int32_t start,
-         int32_t length,
-         const UChar *srcChars,
-         uint32_t options) const;
-
-  /**
-   * Compare two strings case-insensitively using full case folding.
-   * This is equivalent to this->foldCase(options).compare(srcChars.foldCase(options)).
-   *
-   * @param start The start offset in this string at which the compare operation begins.
-   * @param length The number of code units from this string to compare.
-   * @param srcChars A pointer to another string to compare this one to.
-   * @param srcStart The start offset in that string at which the compare operation begins.
-   * @param srcLength The number of code units from that string to compare.
-   * @param options A bit set of options:
-   *   - U_FOLD_CASE_DEFAULT or 0 is used for default options:
-   *     Comparison in code unit order with default case folding.
-   *
-   *   - U_COMPARE_CODE_POINT_ORDER
-   *     Set to choose code point order instead of code unit order
-   *     (see u_strCompare for details).
-   *
-   *   - U_FOLD_CASE_EXCLUDE_SPECIAL_I
-   *
-   * @return A negative, zero, or positive integer indicating the comparison result.
-   * @stable ICU 2.0
-   */
-  inline int8_t caseCompare(int32_t start,
-         int32_t length,
-         const UChar *srcChars,
-         int32_t srcStart,
-         int32_t srcLength,
-         uint32_t options) const;
-
-  /**
-   * Compare two strings case-insensitively using full case folding.
-   * This is equivalent to this->foldCase(options).compareBetween(text.foldCase(options)).
-   *
-   * @param start The start offset in this string at which the compare operation begins.
-   * @param limit The offset after the last code unit from this string to compare.
-   * @param srcText Another string to compare this one to.
-   * @param srcStart The start offset in that string at which the compare operation begins.
-   * @param srcLimit The offset after the last code unit from that string to compare.
-   * @param options A bit set of options:
-   *   - U_FOLD_CASE_DEFAULT or 0 is used for default options:
-   *     Comparison in code unit order with default case folding.
-   *
-   *   - U_COMPARE_CODE_POINT_ORDER
-   *     Set to choose code point order instead of code unit order
-   *     (see u_strCompare for details).
-   *
-   *   - U_FOLD_CASE_EXCLUDE_SPECIAL_I
-   *
-   * @return A negative, zero, or positive integer indicating the comparison result.
-   * @stable ICU 2.0
-   */
-  inline int8_t caseCompareBetween(int32_t start,
-            int32_t limit,
-            const UnicodeString& srcText,
-            int32_t srcStart,
-            int32_t srcLimit,
-            uint32_t options) const;
-
-  /**
-   * Determine if this starts with the characters in <TT>text</TT>
-   * @param text The text to match.
-   * @return TRUE if this starts with the characters in <TT>text</TT>,
-   * FALSE otherwise
-   * @stable ICU 2.0
-   */
-  inline UBool startsWith(const UnicodeString& text) const;
-
-  /**
-   * Determine if this starts with the characters in <TT>srcText</TT>
-   * in the range [<TT>srcStart</TT>, <TT>srcStart + srcLength</TT>).
-   * @param srcText The text to match.
-   * @param srcStart the offset into <TT>srcText</TT> to start matching
-   * @param srcLength the number of characters in <TT>srcText</TT> to match
-   * @return TRUE if this starts with the characters in <TT>text</TT>,
-   * FALSE otherwise
-   * @stable ICU 2.0
-   */
-  inline UBool startsWith(const UnicodeString& srcText,
-            int32_t srcStart,
-            int32_t srcLength) const;
-
-  /**
-   * Determine if this starts with the characters in <TT>srcChars</TT>
-   * @param srcChars The characters to match.
-   * @param srcLength the number of characters in <TT>srcChars</TT>
-   * @return TRUE if this starts with the characters in <TT>srcChars</TT>,
-   * FALSE otherwise
-   * @stable ICU 2.0
-   */
-  inline UBool startsWith(const UChar *srcChars,
-            int32_t srcLength) const;
-
-  /**
-   * Determine if this ends with the characters in <TT>srcChars</TT>
-   * in the range  [<TT>srcStart</TT>, <TT>srcStart + srcLength</TT>).
-   * @param srcChars The characters to match.
-   * @param srcStart the offset into <TT>srcText</TT> to start matching
-   * @param srcLength the number of characters in <TT>srcChars</TT> to match
-   * @return TRUE if this ends with the characters in <TT>srcChars</TT>, FALSE otherwise
-   * @stable ICU 2.0
-   */
-  inline UBool startsWith(const UChar *srcChars,
-            int32_t srcStart,
-            int32_t srcLength) const;
-
-  /**
-   * Determine if this ends with the characters in <TT>text</TT>
-   * @param text The text to match.
-   * @return TRUE if this ends with the characters in <TT>text</TT>,
-   * FALSE otherwise
-   * @stable ICU 2.0
-   */
-  inline UBool endsWith(const UnicodeString& text) const;
-
-  /**
-   * Determine if this ends with the characters in <TT>srcText</TT>
-   * in the range [<TT>srcStart</TT>, <TT>srcStart + srcLength</TT>).
-   * @param srcText The text to match.
-   * @param srcStart the offset into <TT>srcText</TT> to start matching
-   * @param srcLength the number of characters in <TT>srcText</TT> to match
-   * @return TRUE if this ends with the characters in <TT>text</TT>,
-   * FALSE otherwise
-   * @stable ICU 2.0
-   */
-  inline UBool endsWith(const UnicodeString& srcText,
-          int32_t srcStart,
-          int32_t srcLength) const;
-
-  /**
-   * Determine if this ends with the characters in <TT>srcChars</TT>
-   * @param srcChars The characters to match.
-   * @param srcLength the number of characters in <TT>srcChars</TT>
-   * @return TRUE if this ends with the characters in <TT>srcChars</TT>,
-   * FALSE otherwise
-   * @stable ICU 2.0
-   */
-  inline UBool endsWith(const UChar *srcChars,
-          int32_t srcLength) const;
-
-  /**
-   * Determine if this ends with the characters in <TT>srcChars</TT>
-   * in the range  [<TT>srcStart</TT>, <TT>srcStart + srcLength</TT>).
-   * @param srcChars The characters to match.
-   * @param srcStart the offset into <TT>srcText</TT> to start matching
-   * @param srcLength the number of characters in <TT>srcChars</TT> to match
-   * @return TRUE if this ends with the characters in <TT>srcChars</TT>,
-   * FALSE otherwise
-   * @stable ICU 2.0
-   */
-  inline UBool endsWith(const UChar *srcChars,
-          int32_t srcStart,
-          int32_t srcLength) const;
-
-
-  /* Searching - bitwise only */
-
-  /**
-   * Locate in this the first occurrence of the characters in <TT>text</TT>,
-   * using bitwise comparison.
-   * @param text The text to search for.
-   * @return The offset into this of the start of <TT>text</TT>,
-   * or -1 if not found.
-   * @stable ICU 2.0
-   */
-  inline int32_t indexOf(const UnicodeString& text) const;
-
-  /**
-   * Locate in this the first occurrence of the characters in <TT>text</TT>
-   * starting at offset <TT>start</TT>, using bitwise comparison.
-   * @param text The text to search for.
-   * @param start The offset at which searching will start.
-   * @return The offset into this of the start of <TT>text</TT>,
-   * or -1 if not found.
-   * @stable ICU 2.0
-   */
-  inline int32_t indexOf(const UnicodeString& text,
-              int32_t start) const;
-
-  /**
-   * Locate in this the first occurrence in the range
-   * [<TT>start</TT>, <TT>start + length</TT>) of the characters
-   * in <TT>text</TT>, using bitwise comparison.
-   * @param text The text to search for.
-   * @param start The offset at which searching will start.
-   * @param length The number of characters to search
-   * @return The offset into this of the start of <TT>text</TT>,
-   * or -1 if not found.
-   * @stable ICU 2.0
-   */
-  inline int32_t indexOf(const UnicodeString& text,
-              int32_t start,
-              int32_t length) const;
-
-  /**
-   * Locate in this the first occurrence in the range
-   * [<TT>start</TT>, <TT>start + length</TT>) of the characters
-   *  in <TT>srcText</TT> in the range
-   * [<TT>srcStart</TT>, <TT>srcStart + srcLength</TT>),
-   * using bitwise comparison.
-   * @param srcText The text to search for.
-   * @param srcStart the offset into <TT>srcText</TT> at which
-   * to start matching
-   * @param srcLength the number of characters in <TT>srcText</TT> to match
-   * @param start the offset into this at which to start matching
-   * @param length the number of characters in this to search
-   * @return The offset into this of the start of <TT>text</TT>,
-   * or -1 if not found.
-   * @stable ICU 2.0
-   */
-  inline int32_t indexOf(const UnicodeString& srcText,
-              int32_t srcStart,
-              int32_t srcLength,
-              int32_t start,
-              int32_t length) const;
-
-  /**
-   * Locate in this the first occurrence of the characters in
-   * <TT>srcChars</TT>
-   * starting at offset <TT>start</TT>, using bitwise comparison.
-   * @param srcChars The text to search for.
-   * @param srcLength the number of characters in <TT>srcChars</TT> to match
-   * @param start the offset into this at which to start matching
-   * @return The offset into this of the start of <TT>text</TT>,
-   * or -1 if not found.
-   * @stable ICU 2.0
-   */
-  inline int32_t indexOf(const UChar *srcChars,
-              int32_t srcLength,
-              int32_t start) const;
-
-  /**
-   * Locate in this the first occurrence in the range
-   * [<TT>start</TT>, <TT>start + length</TT>) of the characters
-   * in <TT>srcChars</TT>, using bitwise comparison.
-   * @param srcChars The text to search for.
-   * @param srcLength the number of characters in <TT>srcChars</TT>
-   * @param start The offset at which searching will start.
-   * @param length The number of characters to search
-   * @return The offset into this of the start of <TT>srcChars</TT>,
-   * or -1 if not found.
-   * @stable ICU 2.0
-   */
-  inline int32_t indexOf(const UChar *srcChars,
-              int32_t srcLength,
-              int32_t start,
-              int32_t length) const;
-
-  /**
-   * Locate in this the first occurrence in the range
-   * [<TT>start</TT>, <TT>start + length</TT>) of the characters
-   * in <TT>srcChars</TT> in the range
-   * [<TT>srcStart</TT>, <TT>srcStart + srcLength</TT>),
-   * using bitwise comparison.
-   * @param srcChars The text to search for.
-   * @param srcStart the offset into <TT>srcChars</TT> at which
-   * to start matching
-   * @param srcLength the number of characters in <TT>srcChars</TT> to match
-   * @param start the offset into this at which to start matching
-   * @param length the number of characters in this to search
-   * @return The offset into this of the start of <TT>text</TT>,
-   * or -1 if not found.
-   * @stable ICU 2.0
-   */
-  int32_t indexOf(const UChar *srcChars,
-              int32_t srcStart,
-              int32_t srcLength,
-              int32_t start,
-              int32_t length) const;
-
-  /**
-   * Locate in this the first occurrence of the BMP code point <code>c</code>,
-   * using bitwise comparison.
-   * @param c The code unit to search for.
-   * @return The offset into this of <TT>c</TT>, or -1 if not found.
-   * @stable ICU 2.0
-   */
-  inline int32_t indexOf(UChar c) const;
-
-  /**
-   * Locate in this the first occurrence of the code point <TT>c</TT>,
-   * using bitwise comparison.
-   *
-   * @param c The code point to search for.
-   * @return The offset into this of <TT>c</TT>, or -1 if not found.
-   * @stable ICU 2.0
-   */
-  inline int32_t indexOf(UChar32 c) const;
-
-  /**
-   * Locate in this the first occurrence of the BMP code point <code>c</code>,
-   * starting at offset <TT>start</TT>, using bitwise comparison.
-   * @param c The code unit to search for.
-   * @param start The offset at which searching will start.
-   * @return The offset into this of <TT>c</TT>, or -1 if not found.
-   * @stable ICU 2.0
-   */
-  inline int32_t indexOf(UChar c,
-              int32_t start) const;
-
-  /**
-   * Locate in this the first occurrence of the code point <TT>c</TT>
-   * starting at offset <TT>start</TT>, using bitwise comparison.
-   *
-   * @param c The code point to search for.
-   * @param start The offset at which searching will start.
-   * @return The offset into this of <TT>c</TT>, or -1 if not found.
-   * @stable ICU 2.0
-   */
-  inline int32_t indexOf(UChar32 c,
-              int32_t start) const;
-
-  /**
-   * Locate in this the first occurrence of the BMP code point <code>c</code>
-   * in the range [<TT>start</TT>, <TT>start + length</TT>),
-   * using bitwise comparison.
-   * @param c The code unit to search for.
-   * @param start the offset into this at which to start matching
-   * @param length the number of characters in this to search
-   * @return The offset into this of <TT>c</TT>, or -1 if not found.
-   * @stable ICU 2.0
-   */
-  inline int32_t indexOf(UChar c,
-              int32_t start,
-              int32_t length) const;
-
-  /**
-   * Locate in this the first occurrence of the code point <TT>c</TT>
-   * in the range [<TT>start</TT>, <TT>start + length</TT>),
-   * using bitwise comparison.
-   *
-   * @param c The code point to search for.
-   * @param start the offset into this at which to start matching
-   * @param length the number of characters in this to search
-   * @return The offset into this of <TT>c</TT>, or -1 if not found.
-   * @stable ICU 2.0
-   */
-  inline int32_t indexOf(UChar32 c,
-              int32_t start,
-              int32_t length) const;
-
-  /**
-   * Locate in this the last occurrence of the characters in <TT>text</TT>,
-   * using bitwise comparison.
-   * @param text The text to search for.
-   * @return The offset into this of the start of <TT>text</TT>,
-   * or -1 if not found.
-   * @stable ICU 2.0
-   */
-  inline int32_t lastIndexOf(const UnicodeString& text) const;
-
-  /**
-   * Locate in this the last occurrence of the characters in <TT>text</TT>
-   * starting at offset <TT>start</TT>, using bitwise comparison.
-   * @param text The text to search for.
-   * @param start The offset at which searching will start.
-   * @return The offset into this of the start of <TT>text</TT>,
-   * or -1 if not found.
-   * @stable ICU 2.0
-   */
-  inline int32_t lastIndexOf(const UnicodeString& text,
-              int32_t start) const;
-
-  /**
-   * Locate in this the last occurrence in the range
-   * [<TT>start</TT>, <TT>start + length</TT>) of the characters
-   * in <TT>text</TT>, using bitwise comparison.
-   * @param text The text to search for.
-   * @param start The offset at which searching will start.
-   * @param length The number of characters to search
-   * @return The offset into this of the start of <TT>text</TT>,
-   * or -1 if not found.
-   * @stable ICU 2.0
-   */
-  inline int32_t lastIndexOf(const UnicodeString& text,
-              int32_t start,
-              int32_t length) const;
-
-  /**
-   * Locate in this the last occurrence in the range
-   * [<TT>start</TT>, <TT>start + length</TT>) of the characters
-   * in <TT>srcText</TT> in the range
-   * [<TT>srcStart</TT>, <TT>srcStart + srcLength</TT>),
-   * using bitwise comparison.
-   * @param srcText The text to search for.
-   * @param srcStart the offset into <TT>srcText</TT> at which
-   * to start matching
-   * @param srcLength the number of characters in <TT>srcText</TT> to match
-   * @param start the offset into this at which to start matching
-   * @param length the number of characters in this to search
-   * @return The offset into this of the start of <TT>text</TT>,
-   * or -1 if not found.
-   * @stable ICU 2.0
-   */
-  inline int32_t lastIndexOf(const UnicodeString& srcText,
-              int32_t srcStart,
-              int32_t srcLength,
-              int32_t start,
-              int32_t length) const;
-
-  /**
-   * Locate in this the last occurrence of the characters in <TT>srcChars</TT>
-   * starting at offset <TT>start</TT>, using bitwise comparison.
-   * @param srcChars The text to search for.
-   * @param srcLength the number of characters in <TT>srcChars</TT> to match
-   * @param start the offset into this at which to start matching
-   * @return The offset into this of the start of <TT>text</TT>,
-   * or -1 if not found.
-   * @stable ICU 2.0
-   */
-  inline int32_t lastIndexOf(const UChar *srcChars,
-              int32_t srcLength,
-              int32_t start) const;
-
-  /**
-   * Locate in this the last occurrence in the range
-   * [<TT>start</TT>, <TT>start + length</TT>) of the characters
-   * in <TT>srcChars</TT>, using bitwise comparison.
-   * @param srcChars The text to search for.
-   * @param srcLength the number of characters in <TT>srcChars</TT>
-   * @param start The offset at which searching will start.
-   * @param length The number of characters to search
-   * @return The offset into this of the start of <TT>srcChars</TT>,
-   * or -1 if not found.
-   * @stable ICU 2.0
-   */
-  inline int32_t lastIndexOf(const UChar *srcChars,
-              int32_t srcLength,
-              int32_t start,
-              int32_t length) const;
-
-  /**
-   * Locate in this the last occurrence in the range
-   * [<TT>start</TT>, <TT>start + length</TT>) of the characters
-   * in <TT>srcChars</TT> in the range
-   * [<TT>srcStart</TT>, <TT>srcStart + srcLength</TT>),
-   * using bitwise comparison.
-   * @param srcChars The text to search for.
-   * @param srcStart the offset into <TT>srcChars</TT> at which
-   * to start matching
-   * @param srcLength the number of characters in <TT>srcChars</TT> to match
-   * @param start the offset into this at which to start matching
-   * @param length the number of characters in this to search
-   * @return The offset into this of the start of <TT>text</TT>,
-   * or -1 if not found.
-   * @stable ICU 2.0
-   */
-  int32_t lastIndexOf(const UChar *srcChars,
-              int32_t srcStart,
-              int32_t srcLength,
-              int32_t start,
-              int32_t length) const;
-
-  /**
-   * Locate in this the last occurrence of the BMP code point <code>c</code>,
-   * using bitwise comparison.
-   * @param c The code unit to search for.
-   * @return The offset into this of <TT>c</TT>, or -1 if not found.
-   * @stable ICU 2.0
-   */
-  inline int32_t lastIndexOf(UChar c) const;
-
-  /**
-   * Locate in this the last occurrence of the code point <TT>c</TT>,
-   * using bitwise comparison.
-   *
-   * @param c The code point to search for.
-   * @return The offset into this of <TT>c</TT>, or -1 if not found.
-   * @stable ICU 2.0
-   */
-  inline int32_t lastIndexOf(UChar32 c) const;
-
-  /**
-   * Locate in this the last occurrence of the BMP code point <code>c</code>
-   * starting at offset <TT>start</TT>, using bitwise comparison.
-   * @param c The code unit to search for.
-   * @param start The offset at which searching will start.
-   * @return The offset into this of <TT>c</TT>, or -1 if not found.
-   * @stable ICU 2.0
-   */
-  inline int32_t lastIndexOf(UChar c,
-              int32_t start) const;
-
-  /**
-   * Locate in this the last occurrence of the code point <TT>c</TT>
-   * starting at offset <TT>start</TT>, using bitwise comparison.
-   *
-   * @param c The code point to search for.
-   * @param start The offset at which searching will start.
-   * @return The offset into this of <TT>c</TT>, or -1 if not found.
-   * @stable ICU 2.0
-   */
-  inline int32_t lastIndexOf(UChar32 c,
-              int32_t start) const;
-
-  /**
-   * Locate in this the last occurrence of the BMP code point <code>c</code>
-   * in the range [<TT>start</TT>, <TT>start + length</TT>),
-   * using bitwise comparison.
-   * @param c The code unit to search for.
-   * @param start the offset into this at which to start matching
-   * @param length the number of characters in this to search
-   * @return The offset into this of <TT>c</TT>, or -1 if not found.
-   * @stable ICU 2.0
-   */
-  inline int32_t lastIndexOf(UChar c,
-              int32_t start,
-              int32_t length) const;
-
-  /**
-   * Locate in this the last occurrence of the code point <TT>c</TT>
-   * in the range [<TT>start</TT>, <TT>start + length</TT>),
-   * using bitwise comparison.
-   *
-   * @param c The code point to search for.
-   * @param start the offset into this at which to start matching
-   * @param length the number of characters in this to search
-   * @return The offset into this of <TT>c</TT>, or -1 if not found.
-   * @stable ICU 2.0
-   */
-  inline int32_t lastIndexOf(UChar32 c,
-              int32_t start,
-              int32_t length) const;
-
-
-  /* Character access */
-
-  /**
-   * Return the code unit at offset <tt>offset</tt>.
-   * If the offset is not valid (0..length()-1) then U+ffff is returned.
-   * @param offset a valid offset into the text
-   * @return the code unit at offset <tt>offset</tt>
-   *         or 0xffff if the offset is not valid for this string
-   * @stable ICU 2.0
-   */
-  inline UChar charAt(int32_t offset) const;
-
-  /**
-   * Return the code unit at offset <tt>offset</tt>.
-   * If the offset is not valid (0..length()-1) then U+ffff is returned.
-   * @param offset a valid offset into the text
-   * @return the code unit at offset <tt>offset</tt>
-   * @stable ICU 2.0
-   */
-  inline UChar operator[] (int32_t offset) const;
-
-  /**
-   * Return the code point that contains the code unit
-   * at offset <tt>offset</tt>.
-   * If the offset is not valid (0..length()-1) then U+ffff is returned.
-   * @param offset a valid offset into the text
-   * that indicates the text offset of any of the code units
-   * that will be assembled into a code point (21-bit value) and returned
-   * @return the code point of text at <tt>offset</tt>
-   *         or 0xffff if the offset is not valid for this string
-   * @stable ICU 2.0
-   */
-  inline UChar32 char32At(int32_t offset) const;
-
-  /**
-   * Adjust a random-access offset so that
-   * it points to the beginning of a Unicode character.
-   * The offset that is passed in points to
-   * any code unit of a code point,
-   * while the returned offset will point to the first code unit
-   * of the same code point.
-   * In UTF-16, if the input offset points to a second surrogate
-   * of a surrogate pair, then the returned offset will point
-   * to the first surrogate.
-   * @param offset a valid offset into one code point of the text
-   * @return offset of the first code unit of the same code point
-   * @see U16_SET_CP_START
-   * @stable ICU 2.0
-   */
-  inline int32_t getChar32Start(int32_t offset) const;
-
-  /**
-   * Adjust a random-access offset so that
-   * it points behind a Unicode character.
-   * The offset that is passed in points behind
-   * any code unit of a code point,
-   * while the returned offset will point behind the last code unit
-   * of the same code point.
-   * In UTF-16, if the input offset points behind the first surrogate
-   * (i.e., to the second surrogate)
-   * of a surrogate pair, then the returned offset will point
-   * behind the second surrogate (i.e., to the first surrogate).
-   * @param offset a valid offset after any code unit of a code point of the text
-   * @return offset of the first code unit after the same code point
-   * @see U16_SET_CP_LIMIT
-   * @stable ICU 2.0
-   */
-  inline int32_t getChar32Limit(int32_t offset) const;
-
-  /**
-   * Move the code unit index along the string by delta code points.
-   * Interpret the input index as a code unit-based offset into the string,
-   * move the index forward or backward by delta code points, and
-   * return the resulting index.
-   * The input index should point to the first code unit of a code point,
-   * if there is more than one.
-   *
-   * Both input and output indexes are code unit-based as for all
-   * string indexes/offsets in ICU (and other libraries, like MBCS char*).
-   * If delta<0 then the index is moved backward (toward the start of the string).
-   * If delta>0 then the index is moved forward (toward the end of the string).
-   *
-   * This behaves like CharacterIterator::move32(delta, kCurrent).
-   *
-   * Behavior for out-of-bounds indexes:
-   * <code>moveIndex32</code> pins the input index to 0..length(), i.e.,
-   * if the input index<0 then it is pinned to 0;
-   * if it is index>length() then it is pinned to length().
-   * Afterwards, the index is moved by <code>delta</code> code points
-   * forward or backward,
-   * but no further backward than to 0 and no further forward than to length().
-   * The resulting index return value will be in between 0 and length(), inclusively.
-   *
-   * Examples:
-   * <pre>
-   * // s has code points 'a' U+10000 'b' U+10ffff U+2029
-   * UnicodeString s=UNICODE_STRING("a\\U00010000b\\U0010ffff\\u2029", 31).unescape();
-   *
-   * // initial index: position of U+10000
-   * int32_t index=1;
-   *
-   * // the following examples will all result in index==4, position of U+10ffff
-   *
-   * // skip 2 code points from some position in the string
-   * index=s.moveIndex32(index, 2); // skips U+10000 and 'b'
-   *
-   * // go to the 3rd code point from the start of s (0-based)
-   * index=s.moveIndex32(0, 3); // skips 'a', U+10000, and 'b'
-   *
-   * // go to the next-to-last code point of s
-   * index=s.moveIndex32(s.length(), -2); // backward-skips U+2029 and U+10ffff
-   * </pre>
-   *
-   * @param index input code unit index
-   * @param delta (signed) code point count to move the index forward or backward
-   *        in the string
-   * @return the resulting code unit index
-   * @stable ICU 2.0
-   */
-  int32_t moveIndex32(int32_t index, int32_t delta) const;
-
-  /* Substring extraction */
-
-  /**
-   * Copy the characters in the range
-   * [<tt>start</tt>, <tt>start + length</tt>) into the array <tt>dst</tt>,
-   * beginning at <tt>dstStart</tt>.
-   * If the string aliases to <code>dst</code> itself as an external buffer,
-   * then extract() will not copy the contents.
-   *
-   * @param start offset of first character which will be copied into the array
-   * @param length the number of characters to extract
-   * @param dst array in which to copy characters.  The length of <tt>dst</tt>
-   * must be at least (<tt>dstStart + length</tt>).
-   * @param dstStart the offset in <TT>dst</TT> where the first character
-   * will be extracted
-   * @stable ICU 2.0
-   */
-  inline void extract(int32_t start,
-           int32_t length,
-           UChar *dst,
-           int32_t dstStart = 0) const;
-
-  /**
-   * Copy the contents of the string into dest.
-   * This is a convenience function that
-   * checks if there is enough space in dest,
-   * extracts the entire string if possible,
-   * and NUL-terminates dest if possible.
-   *
-   * If the string fits into dest but cannot be NUL-terminated
-   * (length()==destCapacity) then the error code is set to U_STRING_NOT_TERMINATED_WARNING.
-   * If the string itself does not fit into dest
-   * (length()>destCapacity) then the error code is set to U_BUFFER_OVERFLOW_ERROR.
-   *
-   * If the string aliases to <code>dest</code> itself as an external buffer,
-   * then extract() will not copy the contents.
-   *
-   * @param dest Destination string buffer.
-   * @param destCapacity Number of UChars available at dest.
-   * @param errorCode ICU error code.
-   * @return length()
-   * @stable ICU 2.0
-   */
-  int32_t
-  extract(UChar *dest, int32_t destCapacity,
-          UErrorCode &errorCode) const;
-
-  /**
-   * Copy the characters in the range
-   * [<tt>start</tt>, <tt>start + length</tt>) into the  UnicodeString
-   * <tt>target</tt>.
-   * @param start offset of first character which will be copied
-   * @param length the number of characters to extract
-   * @param target UnicodeString into which to copy characters.
-   * @return A reference to <TT>target</TT>
-   * @stable ICU 2.0
-   */
-  inline void extract(int32_t start,
-           int32_t length,
-           UnicodeString& target) const;
-
-  /**
-   * Copy the characters in the range [<tt>start</tt>, <tt>limit</tt>)
-   * into the array <tt>dst</tt>, beginning at <tt>dstStart</tt>.
-   * @param start offset of first character which will be copied into the array
-   * @param limit offset immediately following the last character to be copied
-   * @param dst array in which to copy characters.  The length of <tt>dst</tt>
-   * must be at least (<tt>dstStart + (limit - start)</tt>).
-   * @param dstStart the offset in <TT>dst</TT> where the first character
-   * will be extracted
-   * @stable ICU 2.0
-   */
-  inline void extractBetween(int32_t start,
-              int32_t limit,
-              UChar *dst,
-              int32_t dstStart = 0) const;
-
-  /**
-   * Copy the characters in the range [<tt>start</tt>, <tt>limit</tt>)
-   * into the UnicodeString <tt>target</tt>.  Replaceable API.
-   * @param start offset of first character which will be copied
-   * @param limit offset immediately following the last character to be copied
-   * @param target UnicodeString into which to copy characters.
-   * @return A reference to <TT>target</TT>
-   * @stable ICU 2.0
-   */
-  virtual void extractBetween(int32_t start,
-              int32_t limit,
-              UnicodeString& target) const;
-
-  /**
-   * Copy the characters in the range 
-   * [<tt>start</TT>, <tt>start + length</TT>) into an array of characters.
-   * All characters must be invariant (see utypes.h).
-   * Use US_INV as the last, signature-distinguishing parameter.
-   *
-   * This function does not write any more than <code>targetLength</code>
-   * characters but returns the length of the entire output string
-   * so that one can allocate a larger buffer and call the function again
-   * if necessary.
-   * The output string is NUL-terminated if possible.
-   *
-   * @param start offset of first character which will be copied
-   * @param startLength the number of characters to extract
-   * @param target the target buffer for extraction, can be NULL
-   *               if targetLength is 0
-   * @param targetCapacity the length of the target buffer
-   * @param inv Signature-distinguishing paramater, use US_INV.
-   * @return the output string length, not including the terminating NUL
-   * @stable ICU 3.2
-   */
-  int32_t extract(int32_t start,
-           int32_t startLength,
-           char *target,
-           int32_t targetCapacity,
-           enum EInvariant inv) const;
-
-#if !UCONFIG_NO_CONVERSION
-
-  /**
-   * Copy the characters in the range
-   * [<tt>start</TT>, <tt>start + length</TT>) into an array of characters
-   * in a specified codepage.
-   * The output string is NUL-terminated.
-   *
-   * Recommendation: For invariant-character strings use
-   * extract(int32_t start, int32_t length, char *target, int32_t targetCapacity, enum EInvariant inv) const
-   * because it avoids object code dependencies of UnicodeString on
-   * the conversion code.
-   *
-   * @param start offset of first character which will be copied
-   * @param startLength the number of characters to extract
-   * @param target the target buffer for extraction
-   * @param codepage the desired codepage for the characters.  0 has
-   * the special meaning of the default codepage
-   * If <code>codepage</code> is an empty string (<code>""</code>),
-   * then a simple conversion is performed on the codepage-invariant
-   * subset ("invariant characters") of the platform encoding. See utypes.h.
-   * If <TT>target</TT> is NULL, then the number of bytes required for
-   * <TT>target</TT> is returned. It is assumed that the target is big enough
-   * to fit all of the characters.
-   * @return the output string length, not including the terminating NUL
-   * @stable ICU 2.0
-   */
-  inline int32_t extract(int32_t start,
-                 int32_t startLength,
-                 char *target,
-                 const char *codepage = 0) const;
-
-  /**
-   * Copy the characters in the range
-   * [<tt>start</TT>, <tt>start + length</TT>) into an array of characters
-   * in a specified codepage.
-   * This function does not write any more than <code>targetLength</code>
-   * characters but returns the length of the entire output string
-   * so that one can allocate a larger buffer and call the function again
-   * if necessary.
-   * The output string is NUL-terminated if possible.
-   *
-   * Recommendation: For invariant-character strings use
-   * extract(int32_t start, int32_t length, char *target, int32_t targetCapacity, enum EInvariant inv) const
-   * because it avoids object code dependencies of UnicodeString on
-   * the conversion code.
-   *
-   * @param start offset of first character which will be copied
-   * @param startLength the number of characters to extract
-   * @param target the target buffer for extraction
-   * @param targetLength the length of the target buffer
-   * @param codepage the desired codepage for the characters.  0 has
-   * the special meaning of the default codepage
-   * If <code>codepage</code> is an empty string (<code>""</code>),
-   * then a simple conversion is performed on the codepage-invariant
-   * subset ("invariant characters") of the platform encoding. See utypes.h.
-   * If <TT>target</TT> is NULL, then the number of bytes required for
-   * <TT>target</TT> is returned.
-   * @return the output string length, not including the terminating NUL
-   * @stable ICU 2.0
-   */
-  int32_t extract(int32_t start,
-           int32_t startLength,
-           char *target,
-           uint32_t targetLength,
-           const char *codepage = 0) const;
-
-  /**
-   * Convert the UnicodeString into a codepage string using an existing UConverter.
-   * The output string is NUL-terminated if possible.
-   *
-   * This function avoids the overhead of opening and closing a converter if
-   * multiple strings are extracted.
-   *
-   * @param dest destination string buffer, can be NULL if destCapacity==0
-   * @param destCapacity the number of chars available at dest
-   * @param cnv the converter object to be used (ucnv_resetFromUnicode() will be called),
-   *        or NULL for the default converter
-   * @param errorCode normal ICU error code
-   * @return the length of the output string, not counting the terminating NUL;
-   *         if the length is greater than destCapacity, then the string will not fit
-   *         and a buffer of the indicated length would need to be passed in
-   * @stable ICU 2.0
-   */
-  int32_t extract(char *dest, int32_t destCapacity,
-                  UConverter *cnv,
-                  UErrorCode &errorCode) const;
-
-#endif
-
-  /* Length operations */
-
-  /**
-   * Return the length of the UnicodeString object.
-   * The length is the number of UChar code units are in the UnicodeString.
-   * If you want the number of code points, please use countChar32().
-   * @return the length of the UnicodeString object
-   * @see countChar32
-   * @stable ICU 2.0
-   */
-  inline int32_t length(void) const;
-
-  /**
-   * Count Unicode code points in the length UChar code units of the string.
-   * A code point may occupy either one or two UChar code units.
-   * Counting code points involves reading all code units.
-   *
-   * This functions is basically the inverse of moveIndex32().
-   *
-   * @param start the index of the first code unit to check
-   * @param length the number of UChar code units to check
-   * @return the number of code points in the specified code units
-   * @see length
-   * @stable ICU 2.0
-   */
-  int32_t
-  countChar32(int32_t start=0, int32_t length=INT32_MAX) const;
-
-  /**
-   * Check if the length UChar code units of the string
-   * contain more Unicode code points than a certain number.
-   * This is more efficient than counting all code points in this part of the string
-   * and comparing that number with a threshold.
-   * This function may not need to scan the string at all if the length
-   * falls within a certain range, and
-   * never needs to count more than 'number+1' code points.
-   * Logically equivalent to (countChar32(start, length)>number).
-   * A Unicode code point may occupy either one or two UChar code units.
-   *
-   * @param start the index of the first code unit to check (0 for the entire string)
-   * @param length the number of UChar code units to check
-   *               (use INT32_MAX for the entire string; remember that start/length
-   *                values are pinned)
-   * @param number The number of code points in the (sub)string is compared against
-   *               the 'number' parameter.
-   * @return Boolean value for whether the string contains more Unicode code points
-   *         than 'number'. Same as (u_countChar32(s, length)>number).
-   * @see countChar32
-   * @see u_strHasMoreChar32Than
-   * @stable ICU 2.4
-   */
-  UBool
-  hasMoreChar32Than(int32_t start, int32_t length, int32_t number) const;
-
-  /**
-   * Determine if this string is empty.
-   * @return TRUE if this string contains 0 characters, FALSE otherwise.
-   * @stable ICU 2.0
-   */
-  inline UBool isEmpty(void) const;
-
-  /**
-   * Return the capacity of the internal buffer of the UnicodeString object.
-   * This is useful together with the getBuffer functions.
-   * See there for details.
-   *
-   * @return the number of UChars available in the internal buffer
-   * @see getBuffer
-   * @stable ICU 2.0
-   */
-  inline int32_t getCapacity(void) const;
-
-  /* Other operations */
-
-  /**
-   * Generate a hash code for this object.
-   * @return The hash code of this UnicodeString.
-   * @stable ICU 2.0
-   */
-  inline int32_t hashCode(void) const;
-
-  /**
-   * Determine if this object contains a valid string.
-   * A bogus string has no value. It is different from an empty string.
-   * It can be used to indicate that no string value is available.
-   * getBuffer() and getTerminatedBuffer() return NULL, and
-   * length() returns 0.
-   *
-   * @return TRUE if the string is valid, FALSE otherwise
-   * @see setToBogus()
-   * @stable ICU 2.0
-   */
-  inline UBool isBogus(void) const;
-
-
-  //========================================
-  // Write operations
-  //========================================
-
-  /* Assignment operations */
-
-  /**
-   * Assignment operator.  Replace the characters in this UnicodeString
-   * with the characters from <TT>srcText</TT>.
-   * @param srcText The text containing the characters to replace
-   * @return a reference to this
-   * @stable ICU 2.0
-   */
-  UnicodeString &operator=(const UnicodeString &srcText);
-
-  /**
-   * Almost the same as the assignment operator.
-   * Replace the characters in this UnicodeString
-   * with the characters from <code>srcText</code>.
-   *
-   * This function works the same for all strings except for ones that
-   * are readonly aliases.
-   * Starting with ICU 2.4, the assignment operator and the copy constructor
-   * allocate a new buffer and copy the buffer contents even for readonly aliases.
-   * This function implements the old, more efficient but less safe behavior
-   * of making this string also a readonly alias to the same buffer.
-   * The fastCopyFrom function must be used only if it is known that the lifetime of
-   * this UnicodeString is at least as long as the lifetime of the aliased buffer
-   * including its contents, for example for strings from resource bundles
-   * or aliases to string contents.
-   *
-   * @param src The text containing the characters to replace.
-   * @return a reference to this
-   * @stable ICU 2.4
-   */
-  UnicodeString &fastCopyFrom(const UnicodeString &src);
-
-  /**
-   * Assignment operator.  Replace the characters in this UnicodeString
-   * with the code unit <TT>ch</TT>.
-   * @param ch the code unit to replace
-   * @return a reference to this
-   * @stable ICU 2.0
-   */
-  inline UnicodeString& operator= (UChar ch);
-
-  /**
-   * Assignment operator.  Replace the characters in this UnicodeString
-   * with the code point <TT>ch</TT>.
-   * @param ch the code point to replace
-   * @return a reference to this
-   * @stable ICU 2.0
-   */
-  inline UnicodeString& operator= (UChar32 ch);
-
-  /**
-   * Set the text in the UnicodeString object to the characters
-   * in <TT>srcText</TT> in the range
-   * [<TT>srcStart</TT>, <TT>srcText.length()</TT>).
-   * <TT>srcText</TT> is not modified.
-   * @param srcText the source for the new characters
-   * @param srcStart the offset into <TT>srcText</TT> where new characters
-   * will be obtained
-   * @return a reference to this
-   * @stable ICU 2.2
-   */
-  inline UnicodeString& setTo(const UnicodeString& srcText,
-               int32_t srcStart);
-
-  /**
-   * Set the text in the UnicodeString object to the characters
-   * in <TT>srcText</TT> in the range
-   * [<TT>srcStart</TT>, <TT>srcStart + srcLength</TT>).
-   * <TT>srcText</TT> is not modified.
-   * @param srcText the source for the new characters
-   * @param srcStart the offset into <TT>srcText</TT> where new characters
-   * will be obtained
-   * @param srcLength the number of characters in <TT>srcText</TT> in the
-   * replace string.
-   * @return a reference to this
-   * @stable ICU 2.0
-   */
-  inline UnicodeString& setTo(const UnicodeString& srcText,
-               int32_t srcStart,
-               int32_t srcLength);
-
-  /**
-   * Set the text in the UnicodeString object to the characters in
-   * <TT>srcText</TT>.
-   * <TT>srcText</TT> is not modified.
-   * @param srcText the source for the new characters
-   * @return a reference to this
-   * @stable ICU 2.0
-   */
-  inline UnicodeString& setTo(const UnicodeString& srcText);
-
-  /**
-   * Set the characters in the UnicodeString object to the characters
-   * in <TT>srcChars</TT>. <TT>srcChars</TT> is not modified.
-   * @param srcChars the source for the new characters
-   * @param srcLength the number of Unicode characters in srcChars.
-   * @return a reference to this
-   * @stable ICU 2.0
-   */
-  inline UnicodeString& setTo(const UChar *srcChars,
-               int32_t srcLength);
-
-  /**
-   * Set the characters in the UnicodeString object to the code unit
-   * <TT>srcChar</TT>.
-   * @param srcChar the code unit which becomes the UnicodeString's character
-   * content
-   * @return a reference to this
-   * @stable ICU 2.0
-   */
-  UnicodeString& setTo(UChar srcChar);
-
-  /**
-   * Set the characters in the UnicodeString object to the code point
-   * <TT>srcChar</TT>.
-   * @param srcChar the code point which becomes the UnicodeString's character
-   * content
-   * @return a reference to this
-   * @stable ICU 2.0
-   */
-  UnicodeString& setTo(UChar32 srcChar);
-
-  /**
-   * Aliasing setTo() function, analogous to the readonly-aliasing UChar* constructor.
-   * The text will be used for the UnicodeString object, but
-   * it will not be released when the UnicodeString is destroyed.
-   * This has copy-on-write semantics:
-   * When the string is modified, then the buffer is first copied into
-   * newly allocated memory.
-   * The aliased buffer is never modified.
-   * In an assignment to another UnicodeString, the text will be aliased again,
-   * so that both strings then alias the same readonly-text.
-   *
-   * @param isTerminated specifies if <code>text</code> is <code>NUL</code>-terminated.
-   *                     This must be true if <code>textLength==-1</code>.
-   * @param text The characters to alias for the UnicodeString.
-   * @param textLength The number of Unicode characters in <code>text</code> to alias.
-   *                   If -1, then this constructor will determine the length
-   *                   by calling <code>u_strlen()</code>.
-   * @return a reference to this
-   * @stable ICU 2.0
-   */
-  UnicodeString &setTo(UBool isTerminated,
-                       const UChar *text,
-                       int32_t textLength);
-
-  /**
-   * Aliasing setTo() function, analogous to the writable-aliasing UChar* constructor.
-   * The text will be used for the UnicodeString object, but
-   * it will not be released when the UnicodeString is destroyed.
-   * This has write-through semantics:
-   * For as long as the capacity of the buffer is sufficient, write operations
-   * will directly affect the buffer. When more capacity is necessary, then
-   * a new buffer will be allocated and the contents copied as with regularly
-   * constructed strings.
-   * In an assignment to another UnicodeString, the buffer will be copied.
-   * The extract(UChar *dst) function detects whether the dst pointer is the same
-   * as the string buffer itself and will in this case not copy the contents.
-   *
-   * @param buffer The characters to alias for the UnicodeString.
-   * @param buffLength The number of Unicode characters in <code>buffer</code> to alias.
-   * @param buffCapacity The size of <code>buffer</code> in UChars.
-   * @return a reference to this
-   * @stable ICU 2.0
-   */
-  UnicodeString &setTo(UChar *buffer,
-                       int32_t buffLength,
-                       int32_t buffCapacity);
-
-  /**
-   * Make this UnicodeString object invalid.
-   * The string will test TRUE with isBogus().
-   *
-   * A bogus string has no value. It is different from an empty string.
-   * It can be used to indicate that no string value is available.
-   * getBuffer() and getTerminatedBuffer() return NULL, and
-   * length() returns 0.
-   *
-   * This utility function is used throughout the UnicodeString
-   * implementation to indicate that a UnicodeString operation failed,
-   * and may be used in other functions,
-   * especially but not exclusively when such functions do not
-   * take a UErrorCode for simplicity.
-   *
-   * The following methods, and no others, will clear a string object's bogus flag:
-   * - remove()
-   * - remove(0, INT32_MAX)
-   * - truncate(0)
-   * - operator=() (assignment operator)
-   * - setTo(...)
-   *
-   * The simplest ways to turn a bogus string into an empty one
-   * is to use the remove() function.
-   * Examples for other functions that are equivalent to "set to empty string":
-   * \code
-   * if(s.isBogus()) {
-   *   s.remove();           // set to an empty string (remove all), or
-   *   s.remove(0, INT32_MAX); // set to an empty string (remove all), or
-   *   s.truncate(0);        // set to an empty string (complete truncation), or
-   *   s=UnicodeString();    // assign an empty string, or
-   *   s.setTo((UChar32)-1); // set to a pseudo code point that is out of range, or
-   *   static const UChar nul=0;
-   *   s.setTo(&nul, 0);     // set to an empty C Unicode string
-   * }
-   * \endcode
-   *
-   * @see isBogus()
-   * @stable ICU 2.0
-   */
-  void setToBogus();
-
-  /**
-   * Set the character at the specified offset to the specified character.
-   * @param offset A valid offset into the text of the character to set
-   * @param ch The new character
-   * @return A reference to this
-   * @stable ICU 2.0
-   */
-  UnicodeString& setCharAt(int32_t offset,
-               UChar ch);
-
-
-  /* Append operations */
-
-  /**
-   * Append operator. Append the code unit <TT>ch</TT> to the UnicodeString
-   * object.
-   * @param ch the code unit to be appended
-   * @return a reference to this
-   * @stable ICU 2.0
-   */
- inline  UnicodeString& operator+= (UChar ch);
-
-  /**
-   * Append operator. Append the code point <TT>ch</TT> to the UnicodeString
-   * object.
-   * @param ch the code point to be appended
-   * @return a reference to this
-   * @stable ICU 2.0
-   */
- inline  UnicodeString& operator+= (UChar32 ch);
-
-  /**
-   * Append operator. Append the characters in <TT>srcText</TT> to the
-   * UnicodeString object at offset <TT>start</TT>. <TT>srcText</TT> is
-   * not modified.
-   * @param srcText the source for the new characters
-   * @return a reference to this
-   * @stable ICU 2.0
-   */
-  inline UnicodeString& operator+= (const UnicodeString& srcText);
-
-  /**
-   * Append the characters
-   * in <TT>srcText</TT> in the range
-   * [<TT>srcStart</TT>, <TT>srcStart + srcLength</TT>) to the
-   * UnicodeString object at offset <TT>start</TT>. <TT>srcText</TT>
-   * is not modified.
-   * @param srcText the source for the new characters
-   * @param srcStart the offset into <TT>srcText</TT> where new characters
-   * will be obtained
-   * @param srcLength the number of characters in <TT>srcText</TT> in
-   * the append string
-   * @return a reference to this
-   * @stable ICU 2.0
-   */
-  inline UnicodeString& append(const UnicodeString& srcText,
-            int32_t srcStart,
-            int32_t srcLength);
-
-  /**
-   * Append the characters in <TT>srcText</TT> to the UnicodeString object at
-   * offset <TT>start</TT>. <TT>srcText</TT> is not modified.
-   * @param srcText the source for the new characters
-   * @return a reference to this
-   * @stable ICU 2.0
-   */
-  inline UnicodeString& append(const UnicodeString& srcText);
-
-  /**
-   * Append the characters in <TT>srcChars</TT> in the range
-   * [<TT>srcStart</TT>, <TT>srcStart + srcLength</TT>) to the UnicodeString
-   * object at offset
-   * <TT>start</TT>. <TT>srcChars</TT> is not modified.
-   * @param srcChars the source for the new characters
-   * @param srcStart the offset into <TT>srcChars</TT> where new characters
-   * will be obtained
-   * @param srcLength the number of characters in <TT>srcChars</TT> in
-   * the append string
-   * @return a reference to this
-   * @stable ICU 2.0
-   */
-  inline UnicodeString& append(const UChar *srcChars,
-            int32_t srcStart,
-            int32_t srcLength);
-
-  /**
-   * Append the characters in <TT>srcChars</TT> to the UnicodeString object
-   * at offset <TT>start</TT>. <TT>srcChars</TT> is not modified.
-   * @param srcChars the source for the new characters
-   * @param srcLength the number of Unicode characters in <TT>srcChars</TT>
-   * @return a reference to this
-   * @stable ICU 2.0
-   */
-  inline UnicodeString& append(const UChar *srcChars,
-            int32_t srcLength);
-
-  /**
-   * Append the code unit <TT>srcChar</TT> to the UnicodeString object.
-   * @param srcChar the code unit to append
-   * @return a reference to this
-   * @stable ICU 2.0
-   */
-  inline UnicodeString& append(UChar srcChar);
-
-  /**
-   * Append the code point <TT>srcChar</TT> to the UnicodeString object.
-   * @param srcChar the code point to append
-   * @return a reference to this
-   * @stable ICU 2.0
-   */
-  inline UnicodeString& append(UChar32 srcChar);
-
-
-  /* Insert operations */
-
-  /**
-   * Insert the characters in <TT>srcText</TT> in the range
-   * [<TT>srcStart</TT>, <TT>srcStart + srcLength</TT>) into the UnicodeString
-   * object at offset <TT>start</TT>. <TT>srcText</TT> is not modified.
-   * @param start the offset where the insertion begins
-   * @param srcText the source for the new characters
-   * @param srcStart the offset into <TT>srcText</TT> where new characters
-   * will be obtained
-   * @param srcLength the number of characters in <TT>srcText</TT> in
-   * the insert string
-   * @return a reference to this
-   * @stable ICU 2.0
-   */
-  inline UnicodeString& insert(int32_t start,
-            const UnicodeString& srcText,
-            int32_t srcStart,
-            int32_t srcLength);
-
-  /**
-   * Insert the characters in <TT>srcText</TT> into the UnicodeString object
-   * at offset <TT>start</TT>. <TT>srcText</TT> is not modified.
-   * @param start the offset where the insertion begins
-   * @param srcText the source for the new characters
-   * @return a reference to this
-   * @stable ICU 2.0
-   */
-  inline UnicodeString& insert(int32_t start,
-            const UnicodeString& srcText);
-
-  /**
-   * Insert the characters in <TT>srcChars</TT> in the range
-   * [<TT>srcStart</TT>, <TT>srcStart + srcLength</TT>) into the UnicodeString
-   *  object at offset <TT>start</TT>. <TT>srcChars</TT> is not modified.
-   * @param start the offset at which the insertion begins
-   * @param srcChars the source for the new characters
-   * @param srcStart the offset into <TT>srcChars</TT> where new characters
-   * will be obtained
-   * @param srcLength the number of characters in <TT>srcChars</TT>
-   * in the insert string
-   * @return a reference to this
-   * @stable ICU 2.0
-   */
-  inline UnicodeString& insert(int32_t start,
-            const UChar *srcChars,
-            int32_t srcStart,
-            int32_t srcLength);
-
-  /**
-   * Insert the characters in <TT>srcChars</TT> into the UnicodeString object
-   * at offset <TT>start</TT>. <TT>srcChars</TT> is not modified.
-   * @param start the offset where the insertion begins
-   * @param srcChars the source for the new characters
-   * @param srcLength the number of Unicode characters in srcChars.
-   * @return a reference to this
-   * @stable ICU 2.0
-   */
-  inline UnicodeString& insert(int32_t start,
-            const UChar *srcChars,
-            int32_t srcLength);
-
-  /**
-   * Insert the code unit <TT>srcChar</TT> into the UnicodeString object at
-   * offset <TT>start</TT>.
-   * @param start the offset at which the insertion occurs
-   * @param srcChar the code unit to insert
-   * @return a reference to this
-   * @stable ICU 2.0
-   */
-  inline UnicodeString& insert(int32_t start,
-            UChar srcChar);
-
-  /**
-   * Insert the code point <TT>srcChar</TT> into the UnicodeString object at
-   * offset <TT>start</TT>.
-   * @param start the offset at which the insertion occurs
-   * @param srcChar the code point to insert
-   * @return a reference to this
-   * @stable ICU 2.0
-   */
-  inline UnicodeString& insert(int32_t start,
-            UChar32 srcChar);
-
-
-  /* Replace operations */
-
-  /**
-   * Replace the characters in the range
-   * [<TT>start</TT>, <TT>start + length</TT>) with the characters in
-   * <TT>srcText</TT> in the range
-   * [<TT>srcStart</TT>, <TT>srcStart + srcLength</TT>).
-   * <TT>srcText</TT> is not modified.
-   * @param start the offset at which the replace operation begins
-   * @param length the number of characters to replace. The character at
-   * <TT>start + length</TT> is not modified.
-   * @param srcText the source for the new characters
-   * @param srcStart the offset into <TT>srcText</TT> where new characters
-   * will be obtained
-   * @param srcLength the number of characters in <TT>srcText</TT> in
-   * the replace string
-   * @return a reference to this
-   * @stable ICU 2.0
-   */
-  UnicodeString& replace(int32_t start,
-             int32_t length,
-             const UnicodeString& srcText,
-             int32_t srcStart,
-             int32_t srcLength);
-
-  /**
-   * Replace the characters in the range
-   * [<TT>start</TT>, <TT>start + length</TT>)
-   * with the characters in <TT>srcText</TT>.  <TT>srcText</TT> is
-   *  not modified.
-   * @param start the offset at which the replace operation begins
-   * @param length the number of characters to replace. The character at
-   * <TT>start + length</TT> is not modified.
-   * @param srcText the source for the new characters
-   * @return a reference to this
-   * @stable ICU 2.0
-   */
-  UnicodeString& replace(int32_t start,
-             int32_t length,
-             const UnicodeString& srcText);
-
-  /**
-   * Replace the characters in the range
-   * [<TT>start</TT>, <TT>start + length</TT>) with the characters in
-   * <TT>srcChars</TT> in the range
-   * [<TT>srcStart</TT>, <TT>srcStart + srcLength</TT>). <TT>srcChars</TT>
-   * is not modified.
-   * @param start the offset at which the replace operation begins
-   * @param length the number of characters to replace.  The character at
-   * <TT>start + length</TT> is not modified.
-   * @param srcChars the source for the new characters
-   * @param srcStart the offset into <TT>srcChars</TT> where new characters
-   * will be obtained
-   * @param srcLength the number of characters in <TT>srcChars</TT>
-   * in the replace string
-   * @return a reference to this
-   * @stable ICU 2.0
-   */
-  UnicodeString& replace(int32_t start,
-             int32_t length,
-             const UChar *srcChars,
-             int32_t srcStart,
-             int32_t srcLength);
-
-  /**
-   * Replace the characters in the range
-   * [<TT>start</TT>, <TT>start + length</TT>) with the characters in
-   * <TT>srcChars</TT>.  <TT>srcChars</TT> is not modified.
-   * @param start the offset at which the replace operation begins
-   * @param length number of characters to replace.  The character at
-   * <TT>start + length</TT> is not modified.
-   * @param srcChars the source for the new characters
-   * @param srcLength the number of Unicode characters in srcChars
-   * @return a reference to this
-   * @stable ICU 2.0
-   */
-  inline UnicodeString& replace(int32_t start,
-             int32_t length,
-             const UChar *srcChars,
-             int32_t srcLength);
-
-  /**
-   * Replace the characters in the range
-   * [<TT>start</TT>, <TT>start + length</TT>) with the code unit
-   * <TT>srcChar</TT>.
-   * @param start the offset at which the replace operation begins
-   * @param length the number of characters to replace.  The character at
-   * <TT>start + length</TT> is not modified.
-   * @param srcChar the new code unit
-   * @return a reference to this
-   * @stable ICU 2.0
-   */
-  inline UnicodeString& replace(int32_t start,
-             int32_t length,
-             UChar srcChar);
-
-  /**
-   * Replace the characters in the range
-   * [<TT>start</TT>, <TT>start + length</TT>) with the code point
-   *

<TRUNCATED>

[07/57] [abbrv] remove couch_collate

Posted by be...@apache.org.
http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/urep.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/urep.h b/apps/couch_collate/platform/osx/icu/unicode/urep.h
deleted file mode 100644
index 57b547c..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/urep.h
+++ /dev/null
@@ -1,155 +0,0 @@
-/*
-******************************************************************************
-*   Copyright (C) 1997-2005, International Business Machines
-*   Corporation and others.  All Rights Reserved.
-******************************************************************************
-*   Date        Name        Description
-*   06/23/00    aliu        Creation.
-******************************************************************************
-*/
-
-#ifndef __UREP_H
-#define __UREP_H
-
-#include "unicode/utypes.h"
-
-U_CDECL_BEGIN
-
-/********************************************************************
- * General Notes
- ********************************************************************
- * TODO
- * Add usage scenario
- * Add test code
- * Talk about pinning
- * Talk about "can truncate result if out of memory"
- */
-
-/********************************************************************
- * Data Structures
- ********************************************************************/
-/**
- * \file
- * \brief C API: Callbacks for UReplacebale
- */
-/**
- * An opaque replaceable text object.  This will be manipulated only
- * through the caller-supplied UReplaceableFunctor struct.  Related
- * to the C++ class Replaceable.
- * This is currently only used in the Transliterator C API, see utrans.h .
- * @stable ICU 2.0
- */
-typedef void* UReplaceable;
-
-/**
- * A set of function pointers that transliterators use to manipulate a
- * UReplaceable.  The caller should supply the required functions to
- * manipulate their text appropriately.  Related to the C++ class
- * Replaceable.
- * @stable ICU 2.0
- */
-typedef struct UReplaceableCallbacks {
-
-    /**
-     * Function pointer that returns the number of UChar code units in
-     * this text.
-     *
-     * @param rep A pointer to "this" UReplaceable object.
-     * @return The length of the text.
-     * @stable ICU 2.0
-     */
-    int32_t (*length)(const UReplaceable* rep);
-
-    /**
-     * Function pointer that returns a UChar code units at the given
-     * offset into this text; 0 <= offset < n, where n is the value
-     * returned by (*length)(rep).  See unistr.h for a description of
-     * charAt() vs. char32At().
-     *
-     * @param rep A pointer to "this" UReplaceable object.
-     * @param offset The index at which to fetch the UChar (code unit).
-     * @return The UChar (code unit) at offset, or U+FFFF if the offset is out of bounds.
-     * @stable ICU 2.0
-     */
-    UChar   (*charAt)(const UReplaceable* rep,
-                      int32_t offset);
-
-    /**
-     * Function pointer that returns a UChar32 code point at the given
-     * offset into this text.  See unistr.h for a description of
-     * charAt() vs. char32At().
-     *
-     * @param rep A pointer to "this" UReplaceable object.
-     * @param offset The index at which to fetch the UChar32 (code point).
-     * @return The UChar32 (code point) at offset, or U+FFFF if the offset is out of bounds.
-     * @stable ICU 2.0
-     */
-    UChar32 (*char32At)(const UReplaceable* rep,
-                        int32_t offset);
-    
-    /**
-     * Function pointer that replaces text between start and limit in
-     * this text with the given text.  Attributes (out of band info)
-     * should be retained.
-     *
-     * @param rep A pointer to "this" UReplaceable object.
-     * @param start the starting index of the text to be replaced,
-     * inclusive.
-     * @param limit the ending index of the text to be replaced,
-     * exclusive.
-     * @param text the new text to replace the UChars from
-     * start..limit-1.
-     * @param textLength the number of UChars at text, or -1 if text
-     * is null-terminated.
-     * @stable ICU 2.0
-     */
-    void    (*replace)(UReplaceable* rep,
-                       int32_t start,
-                       int32_t limit,
-                       const UChar* text,
-                       int32_t textLength);
-    
-    /**
-     * Function pointer that copies the characters in the range
-     * [<tt>start</tt>, <tt>limit</tt>) into the array <tt>dst</tt>.
-     *
-     * @param rep A pointer to "this" UReplaceable object.
-     * @param start offset of first character which will be copied
-     * into the array
-     * @param limit offset immediately following the last character to
-     * be copied
-     * @param dst array in which to copy characters.  The length of
-     * <tt>dst</tt> must be at least <tt>(limit - start)</tt>.
-     * @stable ICU 2.1
-     */
-    void    (*extract)(UReplaceable* rep,
-                       int32_t start,
-                       int32_t limit,
-                       UChar* dst);
-
-    /**
-     * Function pointer that copies text between start and limit in
-     * this text to another index in the text.  Attributes (out of
-     * band info) should be retained.  After this call, there will be
-     * (at least) two copies of the characters originally located at
-     * start..limit-1.
-     *
-     * @param rep A pointer to "this" UReplaceable object.
-     * @param start the starting index of the text to be copied,
-     * inclusive.
-     * @param limit the ending index of the text to be copied,
-     * exclusive.
-     * @param dest the index at which the copy of the UChars should be
-     * inserted.
-     * @stable ICU 2.0
-     */
-    void    (*copy)(UReplaceable* rep,
-                    int32_t start,
-                    int32_t limit,
-                    int32_t dest);    
-
-} UReplaceableCallbacks;
-
-U_CDECL_END
-
-#endif

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/ures.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/ures.h b/apps/couch_collate/platform/osx/icu/unicode/ures.h
deleted file mode 100644
index 9cc2e89..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/ures.h
+++ /dev/null
@@ -1,871 +0,0 @@
-/*
-**********************************************************************
-*   Copyright (C) 1997-2007, International Business Machines
-*   Corporation and others.  All Rights Reserved.
-**********************************************************************
-*
-* File URES.H (formerly CRESBUND.H)
-*
-* Modification History:
-*
-*   Date        Name        Description
-*   04/01/97    aliu        Creation.
-*   02/22/99    damiba      overhaul.
-*   04/04/99    helena      Fixed internal header inclusion.
-*   04/15/99    Madhu       Updated Javadoc  
-*   06/14/99    stephen     Removed functions taking a filename suffix.
-*   07/20/99    stephen     Language-independent ypedef to void*
-*   11/09/99    weiv        Added ures_getLocale()
-*   06/24/02    weiv        Added support for resource sharing
-******************************************************************************
-*/
-
-#ifndef URES_H
-#define URES_H
-
-#include "unicode/utypes.h"
-#include "unicode/uloc.h"
-
-/**
- * \file
- * \brief C API: Resource Bundle 
- *
- * <h2>C API: Resource Bundle</h2>
- *
- * C API representing a collection of resource information pertaining to a given
- * locale. A resource bundle provides a way of accessing locale- specific information in
- * a data file. You create a resource bundle that manages the resources for a given
- * locale and then ask it for individual resources.
- * <P>
- * Resource bundles in ICU4C are currently defined using text files which conform to the following
- * <a href="http://source.icu-project.org/repos/icu/icuhtml/trunk/design/bnf_rb.txt">BNF definition</a>.
- * More on resource bundle concepts and syntax can be found in the 
- * <a href="http://icu-project.org/userguide/ResourceManagement.html">Users Guide</a>.
- * <P>
- */
-
-/**
- * UResourceBundle is an opaque type for handles for resource bundles in C APIs.
- * @stable ICU 2.0
- */
-struct UResourceBundle;
-
-/**
- * @stable ICU 2.0
- */
-typedef struct UResourceBundle UResourceBundle;
-
-/**
- * Numeric constants for types of resource items.
- * @see ures_getType
- * @stable ICU 2.0
- */
-typedef enum {
-    /** Resource type constant for "no resource". @stable ICU 2.6 */
-    URES_NONE=-1,
-
-    /** Resource type constant for 16-bit Unicode strings. @stable ICU 2.6 */
-    URES_STRING=0,
-
-    /** Resource type constant for binary data. @stable ICU 2.6 */
-    URES_BINARY=1,
-
-    /** Resource type constant for tables of key-value pairs. @stable ICU 2.6 */
-    URES_TABLE=2,
-
-    /**
-     * Resource type constant for aliases;
-     * internally stores a string which identifies the actual resource
-     * storing the data (can be in a different resource bundle).
-     * Resolved internally before delivering the actual resource through the API.
-     * @stable ICU 2.6
-     */
-    URES_ALIAS=3,
-
-#ifndef U_HIDE_INTERNAL_API
-
-    /**
-     * Internal use only.
-     * Alternative resource type constant for tables of key-value pairs.
-     * Never returned by ures_getType().
-     * @internal
-     */
-    URES_TABLE32=4,
-
-#endif /* U_HIDE_INTERNAL_API */
-
-    /**
-     * Resource type constant for a single 28-bit integer, interpreted as
-     * signed or unsigned by the ures_getInt() or ures_getUInt() function.
-     * @see ures_getInt
-     * @see ures_getUInt
-     * @stable ICU 2.6
-     */
-    URES_INT=7,
-
-    /** Resource type constant for arrays of resources. @stable ICU 2.6 */
-    URES_ARRAY=8,
-
-    /**
-     * Resource type constant for vectors of 32-bit integers.
-     * @see ures_getIntVector
-     * @stable ICU 2.6
-     */
-    URES_INT_VECTOR = 14,
-#ifndef U_HIDE_DEPRECATED_API
-    /** @deprecated ICU 2.6 Use the URES_ constant instead. */
-    RES_NONE=URES_NONE,
-    /** @deprecated ICU 2.6 Use the URES_ constant instead. */
-    RES_STRING=URES_STRING,
-    /** @deprecated ICU 2.6 Use the URES_ constant instead. */
-    RES_BINARY=URES_BINARY,
-    /** @deprecated ICU 2.6 Use the URES_ constant instead. */
-    RES_TABLE=URES_TABLE,
-    /** @deprecated ICU 2.6 Use the URES_ constant instead. */
-    RES_ALIAS=URES_ALIAS,
-    /** @deprecated ICU 2.6 Use the URES_ constant instead. */
-    RES_INT=URES_INT,
-    /** @deprecated ICU 2.6 Use the URES_ constant instead. */
-    RES_ARRAY=URES_ARRAY,
-    /** @deprecated ICU 2.6 Use the URES_ constant instead. */
-    RES_INT_VECTOR=URES_INT_VECTOR,
-    /** @deprecated ICU 2.6 Not used. */
-    RES_RESERVED=15, 
-#endif /* U_HIDE_DEPRECATED_API */
-
-    URES_LIMIT = 16
-} UResType;
-
-/*
- * Functions to create and destroy resource bundles.
- */
-
-/**
- * Opens a UResourceBundle, from which users can extract strings by using
- * their corresponding keys.
- * Note that the caller is responsible of calling <TT>ures_close</TT> on each succesfully
- * opened resource bundle.
- * @param packageName   The packageName and locale together point to an ICU udata object, 
- *                      as defined by <code> udata_open( packageName, "res", locale, err) </code> 
- *                      or equivalent.  Typically, packageName will refer to a (.dat) file, or to
- *                      a package registered with udata_setAppData(). Using a full file or directory
- *                      pathname for packageName is deprecated. If NULL, ICU data will be used.
- * @param locale  specifies the locale for which we want to open the resource
- *                if NULL, the default locale will be used. If strlen(locale) == 0
- *                root locale will be used.
- *                
- * @param status  fills in the outgoing error code.
- * The UErrorCode err parameter is used to return status information to the user. To
- * check whether the construction succeeded or not, you should check the value of
- * U_SUCCESS(err). If you wish more detailed information, you can check for
- * informational status results which still indicate success. U_USING_FALLBACK_WARNING
- * indicates that a fall back locale was used. For example, 'de_CH' was requested,
- * but nothing was found there, so 'de' was used. U_USING_DEFAULT_WARNING indicates that
- * the default locale data or root locale data was used; neither the requested locale 
- * nor any of its fall back locales could be found. Please see the users guide for more 
- * information on this topic.
- * @return      a newly allocated resource bundle.
- * @see ures_close
- * @stable ICU 2.0
- */
-U_STABLE UResourceBundle*  U_EXPORT2 
-ures_open(const char*    packageName,
-          const char*  locale, 
-          UErrorCode*     status);
-
-
-/** This function does not care what kind of localeID is passed in. It simply opens a bundle with 
- *  that name. Fallback mechanism is disabled for the new bundle. If the requested bundle contains
- *  an %%ALIAS directive, the results are undefined.
- * @param packageName   The packageName and locale together point to an ICU udata object, 
- *                      as defined by <code> udata_open( packageName, "res", locale, err) </code> 
- *                      or equivalent.  Typically, packageName will refer to a (.dat) file, or to
- *                      a package registered with udata_setAppData(). Using a full file or directory
- *                      pathname for packageName is deprecated. If NULL, ICU data will be used.
- * @param locale  specifies the locale for which we want to open the resource
- *                if NULL, the default locale will be used. If strlen(locale) == 0
- *                root locale will be used.
- *                
- * @param status fills in the outgoing error code. Either U_ZERO_ERROR or U_MISSING_RESOURCE_ERROR
- * @return      a newly allocated resource bundle or NULL if it doesn't exist.
- * @see ures_close
- * @stable ICU 2.0
- */
-U_STABLE UResourceBundle* U_EXPORT2 
-ures_openDirect(const char* packageName, 
-                const char* locale, 
-                UErrorCode* status);
-
-/**
- * Same as ures_open() but takes a const UChar *path.
- * This path will be converted to char * using the default converter,
- * then ures_open() is called.
- *
- * @param packageName   The packageName and locale together point to an ICU udata object, 
- *                      as defined by <code> udata_open( packageName, "res", locale, err) </code> 
- *                      or equivalent.  Typically, packageName will refer to a (.dat) file, or to
- *                      a package registered with udata_setAppData(). Using a full file or directory
- *                      pathname for packageName is deprecated. If NULL, ICU data will be used.
- * @param locale  specifies the locale for which we want to open the resource
- *                if NULL, the default locale will be used. If strlen(locale) == 0
- *                root locale will be used.
- * @param status  fills in the outgoing error code.
- * @return      a newly allocated resource bundle.
- * @see ures_open
- * @stable ICU 2.0
- */
-U_STABLE UResourceBundle* U_EXPORT2 
-ures_openU(const UChar* packageName, 
-           const char* locale, 
-           UErrorCode* status);
-
-/**
- * Returns the number of strings/arrays in resource bundles.
- * Better to use ures_getSize, as this function will be deprecated. 
- *
- *@param resourceBundle resource bundle containing the desired strings
- *@param resourceKey key tagging the resource
- *@param err fills in the outgoing error code
- *                could be <TT>U_MISSING_RESOURCE_ERROR</TT> if the key is not found
- *                could be a non-failing error 
- *                e.g.: <TT>U_USING_FALLBACK_WARNING</TT>,<TT>U_USING_FALLBACK_WARNING </TT>
- *@return: for    <STRONG>Arrays</STRONG>: returns the number of resources in the array
- *                <STRONG>Tables</STRONG>: returns the number of resources in the table
- *                <STRONG>single string</STRONG>: returns 1
- *@see ures_getSize
- * @deprecated ICU 2.8 User ures_getSize instead
- */
-U_DEPRECATED int32_t U_EXPORT2 
-ures_countArrayItems(const UResourceBundle* resourceBundle,
-                     const char* resourceKey,
-                     UErrorCode* err);
-/**
- * Close a resource bundle, all pointers returned from the various ures_getXXX calls
- * on this particular bundle should be considered invalid henceforth.
- *
- * @param resourceBundle a pointer to a resourceBundle struct. Can be NULL.
- * @see ures_open
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2 
-ures_close(UResourceBundle* resourceBundle);
-
-/**
- * Return the version number associated with this ResourceBundle as a string. Please
- * use ures_getVersion as this function is going to be deprecated.
- *
- * @param resourceBundle The resource bundle for which the version is checked.
- * @return  A version number string as specified in the resource bundle or its parent.
- *          The caller does not own this string.
- * @see ures_getVersion
- * @deprecated ICU 2.8 Use ures_getVersion instead.
- */
-U_DEPRECATED const char* U_EXPORT2 
-ures_getVersionNumber(const UResourceBundle*   resourceBundle);
-
-/**
- * Return the version number associated with this ResourceBundle as an 
- * UVersionInfo array.
- *
- * @param resB The resource bundle for which the version is checked.
- * @param versionInfo A UVersionInfo array that is filled with the version number
- *                    as specified in the resource bundle or its parent.
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2 
-ures_getVersion(const UResourceBundle* resB, 
-                UVersionInfo versionInfo);
-
-/**
- * Return the name of the Locale associated with this ResourceBundle. This API allows
- * you to query for the real locale of the resource. For example, if you requested 
- * "en_US_CALIFORNIA" and only "en_US" bundle exists, "en_US" will be returned. 
- * For subresources, the locale where this resource comes from will be returned.
- * If fallback has occured, getLocale will reflect this.
- *
- * @param resourceBundle resource bundle in question
- * @param status just for catching illegal arguments
- * @return  A Locale name
- * @deprecated ICU 2.8 Use ures_getLocaleByType instead.
- */
-U_DEPRECATED const char* U_EXPORT2 
-ures_getLocale(const UResourceBundle* resourceBundle, 
-               UErrorCode* status);
-
-
-/**
- * Return the name of the Locale associated with this ResourceBundle. 
- * You can choose between requested, valid and real locale.
- *
- * @param resourceBundle resource bundle in question
- * @param type You can choose between requested, valid and actual
- *             locale. For description see the definition of
- *             ULocDataLocaleType in uloc.h
- * @param status just for catching illegal arguments
- * @return  A Locale name
- * @stable ICU 2.8
- */
-U_STABLE const char* U_EXPORT2 
-ures_getLocaleByType(const UResourceBundle* resourceBundle, 
-                     ULocDataLocaleType type, 
-                     UErrorCode* status);
-
-
-/**
- * Same as ures_open() but uses the fill-in parameter instead of allocating
- * a bundle, if r!=NULL.
- * TODO need to revisit usefulness of this function
- *      and usage model for fillIn parameters without knowing sizeof(UResourceBundle)
- * @param r The resourcebundle to open
- * @param packageName   The packageName and locale together point to an ICU udata object, 
- *                      as defined by <code> udata_open( packageName, "res", locale, err) </code> 
- *                      or equivalent.  Typically, packageName will refer to a (.dat) file, or to
- *                      a package registered with udata_setAppData(). Using a full file or directory
- *                      pathname for packageName is deprecated. If NULL, ICU data will be used.
- * @param localeID specifies the locale for which we want to open the resource
- * @param status The error code
- * @return a newly allocated resource bundle or NULL if it doesn't exist.
- * @internal
- */
-U_INTERNAL void U_EXPORT2 
-ures_openFillIn(UResourceBundle *r, 
-                const char* packageName,
-                const char* localeID, 
-                UErrorCode* status);
-
-/**
- * Returns a string from a string resource type
- *
- * @param resourceBundle a string resource
- * @param len    fills in the length of resulting string
- * @param status fills in the outgoing error code
- *                could be <TT>U_MISSING_RESOURCE_ERROR</TT> if the key is not found
- *                Always check the value of status. Don't count on returning NULL.
- *                could be a non-failing error 
- *                e.g.: <TT>U_USING_FALLBACK_WARNING</TT>,<TT>U_USING_DEFAULT_WARNING </TT>
- * @return a pointer to a zero-terminated UChar array which lives in a memory mapped/DLL file.
- * @see ures_getBinary
- * @see ures_getIntVector
- * @see ures_getInt
- * @see ures_getUInt
- * @stable ICU 2.0
- */
-U_STABLE const UChar* U_EXPORT2 
-ures_getString(const UResourceBundle* resourceBundle, 
-               int32_t* len, 
-               UErrorCode* status);
-
-/**
- * Returns a UTF-8 string from a string resource.
- * The UTF-8 string may be returnable directly as a pointer, or
- * it may need to be copied, or transformed from UTF-16 using u_strToUTF8()
- * or equivalent.
- *
- * If forceCopy==TRUE, then the string is always written to the dest buffer
- * and dest is returned.
- *
- * If forceCopy==FALSE, then the string is returned as a pointer if possible,
- * without needing a dest buffer (it can be NULL). If the string needs to be
- * copied or transformed, then it may be placed into dest at an arbitrary offset.
- *
- * If the string is to be written to dest, then U_BUFFER_OVERFLOW_ERROR and
- * U_STRING_NOT_TERMINATED_WARNING are set if appropriate, as usual.
- *
- * If the string is transformed from UTF-16, then a conversion error may occur
- * if an unpaired surrogate is encountered. If the function is successful, then
- * the output UTF-8 string is always well-formed.
- *
- * @param resB Resource bundle.
- * @param dest Destination buffer. Can be NULL only if capacity=*length==0.
- * @param length Input: Capacity of destination buffer.
- *               Output: Actual length of the UTF-8 string, not counting the
- *               terminating NUL, even in case of U_BUFFER_OVERFLOW_ERROR.
- *               Can be NULL, meaning capacity=0 and the string length is not
- *               returned to the caller.
- * @param forceCopy If TRUE, then the output string will always be written to
- *                  dest, with U_BUFFER_OVERFLOW_ERROR and
- *                  U_STRING_NOT_TERMINATED_WARNING set if appropriate.
- *                  If FALSE, then the dest buffer may or may not contain a
- *                  copy of the string. dest may or may not be modified.
- *                  If a copy needs to be written, then the UErrorCode parameter
- *                  indicates overflow etc. as usual.
- * @param status Pointer to a standard ICU error code. Its input value must
- *               pass the U_SUCCESS() test, or else the function returns
- *               immediately. Check for U_FAILURE() on output or use with
- *               function chaining. (See User Guide for details.)
- * @return The pointer to the UTF-8 string. It may be dest, or at some offset
- *         from dest (only if !forceCopy), or in unrelated memory.
- *         Always NUL-terminated unless the string was written to dest and
- *         length==capacity (in which case U_STRING_NOT_TERMINATED_WARNING is set).
- *
- * @see ures_getString
- * @see u_strToUTF8
- * @stable ICU 3.6
- */
-U_STABLE const char * U_EXPORT2
-ures_getUTF8String(const UResourceBundle *resB,
-                   char *dest, int32_t *length,
-                   UBool forceCopy,
-                   UErrorCode *status);
-
-/**
- * Returns a binary data from a binary resource. 
- *
- * @param resourceBundle a string resource
- * @param len    fills in the length of resulting byte chunk
- * @param status fills in the outgoing error code
- *                could be <TT>U_MISSING_RESOURCE_ERROR</TT> if the key is not found
- *                Always check the value of status. Don't count on returning NULL.
- *                could be a non-failing error 
- *                e.g.: <TT>U_USING_FALLBACK_WARNING</TT>,<TT>U_USING_DEFAULT_WARNING </TT>
- * @return a pointer to a chuck of unsigned bytes which live in a memory mapped/DLL file.
- * @see ures_getString
- * @see ures_getIntVector
- * @see ures_getInt
- * @see ures_getUInt
- * @stable ICU 2.0
- */
-U_STABLE const uint8_t* U_EXPORT2 
-ures_getBinary(const UResourceBundle* resourceBundle, 
-               int32_t* len, 
-               UErrorCode* status);
-
-/**
- * Returns a 32 bit integer array from a resource. 
- *
- * @param resourceBundle an int vector resource
- * @param len    fills in the length of resulting byte chunk
- * @param status fills in the outgoing error code
- *                could be <TT>U_MISSING_RESOURCE_ERROR</TT> if the key is not found
- *                Always check the value of status. Don't count on returning NULL.
- *                could be a non-failing error 
- *                e.g.: <TT>U_USING_FALLBACK_WARNING</TT>,<TT>U_USING_DEFAULT_WARNING </TT>
- * @return a pointer to a chunk of unsigned bytes which live in a memory mapped/DLL file.
- * @see ures_getBinary
- * @see ures_getString
- * @see ures_getInt
- * @see ures_getUInt
- * @stable ICU 2.0
- */
-U_STABLE const int32_t* U_EXPORT2 
-ures_getIntVector(const UResourceBundle* resourceBundle, 
-                  int32_t* len, 
-                  UErrorCode* status);
-
-/**
- * Returns an unsigned integer from a resource. 
- * This integer is originally 28 bits.
- *
- * @param resourceBundle a string resource
- * @param status fills in the outgoing error code
- *                could be <TT>U_MISSING_RESOURCE_ERROR</TT> if the key is not found
- *                could be a non-failing error 
- *                e.g.: <TT>U_USING_FALLBACK_WARNING</TT>,<TT>U_USING_DEFAULT_WARNING </TT>
- * @return an integer value
- * @see ures_getInt
- * @see ures_getIntVector
- * @see ures_getBinary
- * @see ures_getString
- * @stable ICU 2.0
- */
-U_STABLE uint32_t U_EXPORT2 
-ures_getUInt(const UResourceBundle* resourceBundle, 
-             UErrorCode *status);
-
-/**
- * Returns a signed integer from a resource. 
- * This integer is originally 28 bit and the sign gets propagated.
- *
- * @param resourceBundle a string resource
- * @param status  fills in the outgoing error code
- *                could be <TT>U_MISSING_RESOURCE_ERROR</TT> if the key is not found
- *                could be a non-failing error 
- *                e.g.: <TT>U_USING_FALLBACK_WARNING</TT>,<TT>U_USING_DEFAULT_WARNING </TT>
- * @return an integer value
- * @see ures_getUInt
- * @see ures_getIntVector
- * @see ures_getBinary
- * @see ures_getString
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2 
-ures_getInt(const UResourceBundle* resourceBundle, 
-            UErrorCode *status);
-
-/**
- * Returns the size of a resource. Size for scalar types is always 1, 
- * and for vector/table types is the number of child resources.
- * @warning Integer array is treated as a scalar type. There are no 
- *          APIs to access individual members of an integer array. It
- *          is always returned as a whole.
- * @param resourceBundle a resource
- * @return number of resources in a given resource.
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2 
-ures_getSize(const UResourceBundle *resourceBundle);
-
-/**
- * Returns the type of a resource. Available types are defined in enum UResType
- *
- * @param resourceBundle a resource
- * @return type of the given resource.
- * @see UResType
- * @stable ICU 2.0
- */
-U_STABLE UResType U_EXPORT2 
-ures_getType(const UResourceBundle *resourceBundle);
-
-/**
- * Returns the key associated with a given resource. Not all the resources have a key - only 
- * those that are members of a table.
- *
- * @param resourceBundle a resource
- * @return a key associated to this resource, or NULL if it doesn't have a key
- * @stable ICU 2.0
- */
-U_STABLE const char * U_EXPORT2 
-ures_getKey(const UResourceBundle *resourceBundle);
-
-/* ITERATION API 
-    This API provides means for iterating through a resource
-*/
-
-/**
- * Resets the internal context of a resource so that iteration starts from the first element.
- *
- * @param resourceBundle a resource
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2 
-ures_resetIterator(UResourceBundle *resourceBundle);
-
-/**
- * Checks whether the given resource has another element to iterate over.
- *
- * @param resourceBundle a resource
- * @return TRUE if there are more elements, FALSE if there is no more elements
- * @stable ICU 2.0
- */
-U_STABLE UBool U_EXPORT2 
-ures_hasNext(const UResourceBundle *resourceBundle);
-
-/**
- * Returns the next resource in a given resource or NULL if there are no more resources 
- * to iterate over. Features a fill-in parameter. 
- *
- * @param resourceBundle    a resource
- * @param fillIn            if NULL a new UResourceBundle struct is allocated and must be closed by the caller.
- *                          Alternatively, you can supply a struct to be filled by this function.
- * @param status            fills in the outgoing error code. You may still get a non NULL result even if an
- *                          error occured. Check status instead.
- * @return                  a pointer to a UResourceBundle struct. If fill in param was NULL, caller must close it
- * @stable ICU 2.0
- */
-U_STABLE UResourceBundle* U_EXPORT2 
-ures_getNextResource(UResourceBundle *resourceBundle, 
-                     UResourceBundle *fillIn, 
-                     UErrorCode *status);
-
-/**
- * Returns the next string in a given resource or NULL if there are no more resources 
- * to iterate over. 
- *
- * @param resourceBundle    a resource
- * @param len               fill in length of the string
- * @param key               fill in for key associated with this string. NULL if no key
- * @param status            fills in the outgoing error code. If an error occured, we may return NULL, but don't
- *                          count on it. Check status instead!
- * @return a pointer to a zero-terminated UChar array which lives in a memory mapped/DLL file.
- * @stable ICU 2.0
- */
-U_STABLE const UChar* U_EXPORT2 
-ures_getNextString(UResourceBundle *resourceBundle, 
-                   int32_t* len, 
-                   const char ** key, 
-                   UErrorCode *status);
-
-/**
- * Returns the resource in a given resource at the specified index. Features a fill-in parameter. 
- *
- * @param resourceBundle    the resource bundle from which to get a sub-resource
- * @param indexR            an index to the wanted resource.
- * @param fillIn            if NULL a new UResourceBundle struct is allocated and must be closed by the caller.
- *                          Alternatively, you can supply a struct to be filled by this function.
- * @param status            fills in the outgoing error code. Don't count on NULL being returned if an error has
- *                          occured. Check status instead.
- * @return                  a pointer to a UResourceBundle struct. If fill in param was NULL, caller must close it
- * @stable ICU 2.0
- */
-U_STABLE UResourceBundle* U_EXPORT2 
-ures_getByIndex(const UResourceBundle *resourceBundle, 
-                int32_t indexR, 
-                UResourceBundle *fillIn, 
-                UErrorCode *status);
-
-/**
- * Returns the string in a given resource at the specified index.
- *
- * @param resourceBundle    a resource
- * @param indexS            an index to the wanted string.
- * @param len               fill in length of the string
- * @param status            fills in the outgoing error code. If an error occured, we may return NULL, but don't
- *                          count on it. Check status instead!
- * @return                  a pointer to a zero-terminated UChar array which lives in a memory mapped/DLL file.
- * @stable ICU 2.0
- */
-U_STABLE const UChar* U_EXPORT2 
-ures_getStringByIndex(const UResourceBundle *resourceBundle, 
-                      int32_t indexS, 
-                      int32_t* len, 
-                      UErrorCode *status);
-
-/**
- * Returns a UTF-8 string from a resource at the specified index.
- * The UTF-8 string may be returnable directly as a pointer, or
- * it may need to be copied, or transformed from UTF-16 using u_strToUTF8()
- * or equivalent.
- *
- * If forceCopy==TRUE, then the string is always written to the dest buffer
- * and dest is returned.
- *
- * If forceCopy==FALSE, then the string is returned as a pointer if possible,
- * without needing a dest buffer (it can be NULL). If the string needs to be
- * copied or transformed, then it may be placed into dest at an arbitrary offset.
- *
- * If the string is to be written to dest, then U_BUFFER_OVERFLOW_ERROR and
- * U_STRING_NOT_TERMINATED_WARNING are set if appropriate, as usual.
- *
- * If the string is transformed from UTF-16, then a conversion error may occur
- * if an unpaired surrogate is encountered. If the function is successful, then
- * the output UTF-8 string is always well-formed.
- *
- * @param resB Resource bundle.
- * @param index An index to the wanted string.
- * @param dest Destination buffer. Can be NULL only if capacity=*length==0.
- * @param pLength Input: Capacity of destination buffer.
- *               Output: Actual length of the UTF-8 string, not counting the
- *               terminating NUL, even in case of U_BUFFER_OVERFLOW_ERROR.
- *               Can be NULL, meaning capacity=0 and the string length is not
- *               returned to the caller.
- * @param forceCopy If TRUE, then the output string will always be written to
- *                  dest, with U_BUFFER_OVERFLOW_ERROR and
- *                  U_STRING_NOT_TERMINATED_WARNING set if appropriate.
- *                  If FALSE, then the dest buffer may or may not contain a
- *                  copy of the string. dest may or may not be modified.
- *                  If a copy needs to be written, then the UErrorCode parameter
- *                  indicates overflow etc. as usual.
- * @param status Pointer to a standard ICU error code. Its input value must
- *               pass the U_SUCCESS() test, or else the function returns
- *               immediately. Check for U_FAILURE() on output or use with
- *               function chaining. (See User Guide for details.)
- * @return The pointer to the UTF-8 string. It may be dest, or at some offset
- *         from dest (only if !forceCopy), or in unrelated memory.
- *         Always NUL-terminated unless the string was written to dest and
- *         length==capacity (in which case U_STRING_NOT_TERMINATED_WARNING is set).
- *
- * @see ures_getStringByIndex
- * @see u_strToUTF8
- * @stable ICU 3.6
- */
-U_STABLE const char * U_EXPORT2
-ures_getUTF8StringByIndex(const UResourceBundle *resB,
-                          int32_t index,
-                          char *dest, int32_t *pLength,
-                          UBool forceCopy,
-                          UErrorCode *status);
-
-/**
- * Returns a resource in a given resource that has a given key. This procedure works only with table
- * resources. Features a fill-in parameter. 
- *
- * @param resourceBundle    a resource
- * @param key               a key associated with the wanted resource
- * @param fillIn            if NULL a new UResourceBundle struct is allocated and must be closed by the caller.
- *                          Alternatively, you can supply a struct to be filled by this function.
- * @param status            fills in the outgoing error code.
- * @return                  a pointer to a UResourceBundle struct. If fill in param was NULL, caller must close it
- * @stable ICU 2.0
- */
-U_STABLE UResourceBundle* U_EXPORT2 
-ures_getByKey(const UResourceBundle *resourceBundle, 
-              const char* key, 
-              UResourceBundle *fillIn, 
-              UErrorCode *status);
-
-/**
- * Returns a string in a given resource that has a given key. This procedure works only with table
- * resources. 
- *
- * @param resB              a resource
- * @param key               a key associated with the wanted string
- * @param len               fill in length of the string
- * @param status            fills in the outgoing error code. If an error occured, we may return NULL, but don't
- *                          count on it. Check status instead!
- * @return                  a pointer to a zero-terminated UChar array which lives in a memory mapped/DLL file.
- * @stable ICU 2.0
- */
-U_STABLE const UChar* U_EXPORT2 
-ures_getStringByKey(const UResourceBundle *resB, 
-                    const char* key, 
-                    int32_t* len, 
-                    UErrorCode *status);
-
-/**
- * Returns a UTF-8 string from a resource and a key.
- * This function works only with table resources.
- *
- * The UTF-8 string may be returnable directly as a pointer, or
- * it may need to be copied, or transformed from UTF-16 using u_strToUTF8()
- * or equivalent.
- *
- * If forceCopy==TRUE, then the string is always written to the dest buffer
- * and dest is returned.
- *
- * If forceCopy==FALSE, then the string is returned as a pointer if possible,
- * without needing a dest buffer (it can be NULL). If the string needs to be
- * copied or transformed, then it may be placed into dest at an arbitrary offset.
- *
- * If the string is to be written to dest, then U_BUFFER_OVERFLOW_ERROR and
- * U_STRING_NOT_TERMINATED_WARNING are set if appropriate, as usual.
- *
- * If the string is transformed from UTF-16, then a conversion error may occur
- * if an unpaired surrogate is encountered. If the function is successful, then
- * the output UTF-8 string is always well-formed.
- *
- * @param resB Resource bundle.
- * @param key  A key associated with the wanted resource
- * @param dest Destination buffer. Can be NULL only if capacity=*length==0.
- * @param pLength Input: Capacity of destination buffer.
- *               Output: Actual length of the UTF-8 string, not counting the
- *               terminating NUL, even in case of U_BUFFER_OVERFLOW_ERROR.
- *               Can be NULL, meaning capacity=0 and the string length is not
- *               returned to the caller.
- * @param forceCopy If TRUE, then the output string will always be written to
- *                  dest, with U_BUFFER_OVERFLOW_ERROR and
- *                  U_STRING_NOT_TERMINATED_WARNING set if appropriate.
- *                  If FALSE, then the dest buffer may or may not contain a
- *                  copy of the string. dest may or may not be modified.
- *                  If a copy needs to be written, then the UErrorCode parameter
- *                  indicates overflow etc. as usual.
- * @param status Pointer to a standard ICU error code. Its input value must
- *               pass the U_SUCCESS() test, or else the function returns
- *               immediately. Check for U_FAILURE() on output or use with
- *               function chaining. (See User Guide for details.)
- * @return The pointer to the UTF-8 string. It may be dest, or at some offset
- *         from dest (only if !forceCopy), or in unrelated memory.
- *         Always NUL-terminated unless the string was written to dest and
- *         length==capacity (in which case U_STRING_NOT_TERMINATED_WARNING is set).
- *
- * @see ures_getStringByKey
- * @see u_strToUTF8
- * @stable ICU 3.6
- */
-U_STABLE const char * U_EXPORT2
-ures_getUTF8StringByKey(const UResourceBundle *resB,
-                        const char *key,
-                        char *dest, int32_t *pLength,
-                        UBool forceCopy,
-                        UErrorCode *status);
-
-#ifdef XP_CPLUSPLUS
-#include "unicode/unistr.h"
-
-U_NAMESPACE_BEGIN
-/**
- * returns a string from a string resource type
- *
- * @param resB    a resource
- * @param status: fills in the outgoing error code
- *                could be <TT>U_MISSING_RESOURCE_ERROR</TT> if the key is not found
- *                could be a non-failing error 
- *                e.g.: <TT>U_USING_FALLBACK_WARNING</TT>,<TT>U_USING_DEFAULT_WARNING </TT>
- * @return        a UnicodeString object. If there is an error, string is bogus
- * @stable ICU 2.0
- */
-inline UnicodeString 
-ures_getUnicodeString(const UResourceBundle *resB, 
-                      UErrorCode* status) 
-{
-    int32_t len = 0;
-    const UChar *r = ures_getString(resB, &len, status);
-    return UnicodeString(TRUE, r, len);
-}
-
-/**
- * Returns the next string in a resource or NULL if there are no more resources 
- * to iterate over. 
- *
- * @param resB              a resource
- * @param key               fill in for key associated with this string
- * @param status            fills in the outgoing error code
- * @return an UnicodeString object.
- * @stable ICU 2.0
- */
-inline UnicodeString 
-ures_getNextUnicodeString(UResourceBundle *resB, 
-                          const char ** key, 
-                          UErrorCode* status) 
-{
-    int32_t len = 0;
-    const UChar* r = ures_getNextString(resB, &len, key, status);
-    return UnicodeString(TRUE, r, len);
-}
-
-/**
- * Returns the string in a given resource at the specified index.
- *
- * @param resB              a resource
- * @param index             an index to the wanted string.
- * @param status            fills in the outgoing error code
- * @return                  an UnicodeString object. If there is an error, string is bogus
- * @stable ICU 2.0
- */
-inline UnicodeString 
-ures_getUnicodeStringByIndex(const UResourceBundle *resB, 
-                             int32_t indexS, 
-                             UErrorCode* status) 
-{
-    int32_t len = 0;
-    const UChar* r = ures_getStringByIndex(resB, indexS, &len, status);
-    return UnicodeString(TRUE, r, len);
-}
-
-/**
- * Returns a string in a resource that has a given key. This procedure works only with table
- * resources. 
- *
- * @param resB              a resource
- * @param key               a key associated with the wanted string
- * @param status            fills in the outgoing error code
- * @return                  an UnicodeString object. If there is an error, string is bogus
- * @stable ICU 2.0
- */
-inline UnicodeString 
-ures_getUnicodeStringByKey(const UResourceBundle *resB, 
-                           const char* key, 
-                           UErrorCode* status) 
-{
-    int32_t len = 0;
-    const UChar* r = ures_getStringByKey(resB, key, &len, status);
-    return UnicodeString(TRUE, r, len);
-}
-
-U_NAMESPACE_END
-
-#endif
-
-/**
- * Create a string enumerator, owned by the caller, of all locales located within 
- * the specified resource tree.
- * @param packageName name of the tree, such as (NULL) or U_ICUDATA_ALIAS or  or "ICUDATA-coll"
- * This call is similar to uloc_getAvailable().
- * @param status error code
- * @stable ICU 3.2
- */
-U_STABLE UEnumeration* U_EXPORT2
-ures_openAvailableLocales(const char *packageName, UErrorCode *status);
-
-
-#endif /*_URES*/
-/*eof*/

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/uscript.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/uscript.h b/apps/couch_collate/platform/osx/icu/unicode/uscript.h
deleted file mode 100644
index c915d8d..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/uscript.h
+++ /dev/null
@@ -1,254 +0,0 @@
-/*
- **********************************************************************
- *   Copyright (C) 1997-2008, International Business Machines
- *   Corporation and others.  All Rights Reserved.
- **********************************************************************
- *
- * File USCRIPT.H
- *
- * Modification History:
- *
- *   Date        Name        Description
- *   07/06/2001    Ram         Creation.
- ******************************************************************************
- */
-
-#ifndef USCRIPT_H
-#define USCRIPT_H
-#include "unicode/utypes.h"
-
-/**
- * \file
- * \brief C API: Unicode Script Information
- */
- 
-/**
- * Constants for ISO 15924 script codes.
- *
- * Many of these script codes - those from Unicode's ScriptNames.txt -
- * are character property values for Unicode's Script property.
- * See UAX #24 Script Names (http://www.unicode.org/reports/tr24/).
- *
- * Starting with ICU 3.6, constants for most ISO 15924 script codes
- * are included (currently excluding private-use codes Qaaa..Qabx).
- * For scripts for which there are codes in ISO 15924 but which are not
- * used in the Unicode Character Database (UCD), there are no Unicode characters
- * associated with those scripts.
- *
- * For example, there are no characters that have a UCD script code of
- * Hans or Hant. All Han ideographs have the Hani script code.
- * The Hans and Hant script codes are used with CLDR data.
- *
- * ISO 15924 script codes are included for use with CLDR and similar.
- *
- * @stable ICU 2.2
- */
-typedef enum UScriptCode {
-      USCRIPT_INVALID_CODE = -1,
-      USCRIPT_COMMON       =  0 , /* Zyyy */
-      USCRIPT_INHERITED    =  1,  /* Qaai */
-      USCRIPT_ARABIC       =  2,  /* Arab */
-      USCRIPT_ARMENIAN     =  3,  /* Armn */
-      USCRIPT_BENGALI      =  4,  /* Beng */
-      USCRIPT_BOPOMOFO     =  5,  /* Bopo */
-      USCRIPT_CHEROKEE     =  6,  /* Cher */
-      USCRIPT_COPTIC       =  7,  /* Copt */
-      USCRIPT_CYRILLIC     =  8,  /* Cyrl */
-      USCRIPT_DESERET      =  9,  /* Dsrt */
-      USCRIPT_DEVANAGARI   = 10,  /* Deva */
-      USCRIPT_ETHIOPIC     = 11,  /* Ethi */
-      USCRIPT_GEORGIAN     = 12,  /* Geor */
-      USCRIPT_GOTHIC       = 13,  /* Goth */
-      USCRIPT_GREEK        = 14,  /* Grek */
-      USCRIPT_GUJARATI     = 15,  /* Gujr */
-      USCRIPT_GURMUKHI     = 16,  /* Guru */
-      USCRIPT_HAN          = 17,  /* Hani */
-      USCRIPT_HANGUL       = 18,  /* Hang */
-      USCRIPT_HEBREW       = 19,  /* Hebr */
-      USCRIPT_HIRAGANA     = 20,  /* Hira */
-      USCRIPT_KANNADA      = 21,  /* Knda */
-      USCRIPT_KATAKANA     = 22,  /* Kana */
-      USCRIPT_KHMER        = 23,  /* Khmr */
-      USCRIPT_LAO          = 24,  /* Laoo */
-      USCRIPT_LATIN        = 25,  /* Latn */
-      USCRIPT_MALAYALAM    = 26,  /* Mlym */
-      USCRIPT_MONGOLIAN    = 27,  /* Mong */
-      USCRIPT_MYANMAR      = 28,  /* Mymr */
-      USCRIPT_OGHAM        = 29,  /* Ogam */
-      USCRIPT_OLD_ITALIC   = 30,  /* Ital */
-      USCRIPT_ORIYA        = 31,  /* Orya */
-      USCRIPT_RUNIC        = 32,  /* Runr */
-      USCRIPT_SINHALA      = 33,  /* Sinh */
-      USCRIPT_SYRIAC       = 34,  /* Syrc */
-      USCRIPT_TAMIL        = 35,  /* Taml */
-      USCRIPT_TELUGU       = 36,  /* Telu */
-      USCRIPT_THAANA       = 37,  /* Thaa */
-      USCRIPT_THAI         = 38,  /* Thai */
-      USCRIPT_TIBETAN      = 39,  /* Tibt */
-      /** Canadian_Aboriginal script. @stable ICU 2.6 */
-      USCRIPT_CANADIAN_ABORIGINAL = 40,  /* Cans */
-      /** Canadian_Aboriginal script (alias). @stable ICU 2.2 */
-      USCRIPT_UCAS         = USCRIPT_CANADIAN_ABORIGINAL,
-      USCRIPT_YI           = 41,  /* Yiii */
-      USCRIPT_TAGALOG      = 42,  /* Tglg */
-      USCRIPT_HANUNOO      = 43,  /* Hano */
-      USCRIPT_BUHID        = 44,  /* Buhd */
-      USCRIPT_TAGBANWA     = 45,  /* Tagb */
-
-      /* New scripts in Unicode 4 @stable ICU 2.6 */
-      USCRIPT_BRAILLE      = 46,  /* Brai */
-      USCRIPT_CYPRIOT      = 47,  /* Cprt */
-      USCRIPT_LIMBU        = 48,  /* Limb */
-      USCRIPT_LINEAR_B     = 49,  /* Linb */
-      USCRIPT_OSMANYA      = 50,  /* Osma */
-      USCRIPT_SHAVIAN      = 51,  /* Shaw */
-      USCRIPT_TAI_LE       = 52,  /* Tale */
-      USCRIPT_UGARITIC     = 53,  /* Ugar */
-
-      /** New script code in Unicode 4.0.1 @stable ICU 3.0 */
-      USCRIPT_KATAKANA_OR_HIRAGANA = 54,/*Hrkt */
-      
-      /* New scripts in Unicode 4.1 @stable ICU 3.4 */
-      USCRIPT_BUGINESE      = 55, /* Bugi */
-      USCRIPT_GLAGOLITIC    = 56, /* Glag */
-      USCRIPT_KHAROSHTHI    = 57, /* Khar */
-      USCRIPT_SYLOTI_NAGRI  = 58, /* Sylo */
-      USCRIPT_NEW_TAI_LUE   = 59, /* Talu */
-      USCRIPT_TIFINAGH      = 60, /* Tfng */
-      USCRIPT_OLD_PERSIAN   = 61, /* Xpeo */
-
-      /* New script codes from ISO 15924 @stable ICU 3.6 */
-      USCRIPT_BALINESE                      = 62, /* Bali */
-      USCRIPT_BATAK                         = 63, /* Batk */
-      USCRIPT_BLISSYMBOLS                   = 64, /* Blis */
-      USCRIPT_BRAHMI                        = 65, /* Brah */
-      USCRIPT_CHAM                          = 66, /* Cham */
-      USCRIPT_CIRTH                         = 67, /* Cirt */
-      USCRIPT_OLD_CHURCH_SLAVONIC_CYRILLIC  = 68, /* Cyrs */
-      USCRIPT_DEMOTIC_EGYPTIAN              = 69, /* Egyd */
-      USCRIPT_HIERATIC_EGYPTIAN             = 70, /* Egyh */
-      USCRIPT_EGYPTIAN_HIEROGLYPHS          = 71, /* Egyp */
-      USCRIPT_KHUTSURI                      = 72, /* Geok */
-      USCRIPT_SIMPLIFIED_HAN                = 73, /* Hans */
-      USCRIPT_TRADITIONAL_HAN               = 74, /* Hant */
-      USCRIPT_PAHAWH_HMONG                  = 75, /* Hmng */
-      USCRIPT_OLD_HUNGARIAN                 = 76, /* Hung */
-      USCRIPT_HARAPPAN_INDUS                = 77, /* Inds */
-      USCRIPT_JAVANESE                      = 78, /* Java */
-      USCRIPT_KAYAH_LI                      = 79, /* Kali */
-      USCRIPT_LATIN_FRAKTUR                 = 80, /* Latf */
-      USCRIPT_LATIN_GAELIC                  = 81, /* Latg */
-      USCRIPT_LEPCHA                        = 82, /* Lepc */
-      USCRIPT_LINEAR_A                      = 83, /* Lina */
-      USCRIPT_MANDAEAN                      = 84, /* Mand */
-      USCRIPT_MAYAN_HIEROGLYPHS             = 85, /* Maya */
-      USCRIPT_MEROITIC                      = 86, /* Mero */
-      USCRIPT_NKO                           = 87, /* Nkoo */
-      USCRIPT_ORKHON                        = 88, /* Orkh */
-      USCRIPT_OLD_PERMIC                    = 89, /* Perm */
-      USCRIPT_PHAGS_PA                      = 90, /* Phag */
-      USCRIPT_PHOENICIAN                    = 91, /* Phnx */
-      USCRIPT_PHONETIC_POLLARD              = 92, /* Plrd */
-      USCRIPT_RONGORONGO                    = 93, /* Roro */
-      USCRIPT_SARATI                        = 94, /* Sara */
-      USCRIPT_ESTRANGELO_SYRIAC             = 95, /* Syre */
-      USCRIPT_WESTERN_SYRIAC                = 96, /* Syrj */
-      USCRIPT_EASTERN_SYRIAC                = 97, /* Syrn */
-      USCRIPT_TENGWAR                       = 98, /* Teng */
-      USCRIPT_VAI                           = 99, /* Vaii */
-      USCRIPT_VISIBLE_SPEECH                = 100, /* Visp */
-      USCRIPT_CUNEIFORM                     = 101,/* Xsux */
-      USCRIPT_UNWRITTEN_LANGUAGES           = 102,/* Zxxx */
-      USCRIPT_UNKNOWN                       = 103,/* Zzzz */ /* Unknown="Code for uncoded script", for unassigned code points */
-
-      /* New script codes from ISO 15924 @stable ICU 4.0 */
-      USCRIPT_CARIAN                        = 104,/* Cari */
-      USCRIPT_JAPANESE                      = 105,/* Jpan */
-      USCRIPT_LANNA                         = 106,/* Lana */
-      USCRIPT_LYCIAN                        = 107,/* Lyci */
-      USCRIPT_LYDIAN                        = 108,/* Lydi */
-      USCRIPT_OL_CHIKI                      = 109,/* Olck */
-      USCRIPT_REJANG                        = 110,/* Rjng */
-      USCRIPT_SAURASHTRA                    = 111,/* Saur */
-      USCRIPT_SIGN_WRITING                  = 112,/* Sgnw */
-      USCRIPT_SUNDANESE                     = 113,/* Sund */
-      USCRIPT_MOON                          = 114,/* Moon */
-      USCRIPT_MEITEI_MAYEK                  = 115,/* Mtei */
-
-      /* New script codes from ISO 15924 @draft ICU 4.0 */
-      USCRIPT_IMPERIAL_ARAMAIC              = 116,/* Armi */
-      USCRIPT_AVESTAN                       = 117,/* Avst */
-      USCRIPT_CHAKMA                        = 118,/* Cakm */
-      USCRIPT_KOREAN                        = 119,/* Kore */
-      USCRIPT_KAITHI                        = 120,/* Kthi */
-      USCRIPT_MANICHAEAN                    = 121,/* Mani */
-      USCRIPT_INSCRIPTIONAL_PAHLAVI         = 122,/* Phli */
-      USCRIPT_PSALTER_PAHLAVI               = 123,/* Phlp */
-      USCRIPT_BOOK_PAHLAVI                  = 124,/* Phlv */
-      USCRIPT_INSCRIPTIONAL_PARTHIAN        = 125,/* Prti */
-      USCRIPT_SAMARITAN                     = 126,/* Samr */
-      USCRIPT_TAI_VIET                      = 127,/* Tavt */
-      USCRIPT_MATHEMATICAL_NOTATION         = 128,/* Zmth */
-      USCRIPT_SYMBOLS                       = 129,/* Zsym */
-
-      /* Private use codes from Qaaa - Qabx are not supported*/
-      USCRIPT_CODE_LIMIT    = 130
-} UScriptCode;
-
-/**
- * Gets script codes associated with the given locale or ISO 15924 abbreviation or name. 
- * Fills in USCRIPT_MALAYALAM given "Malayam" OR "Mlym".
- * Fills in USCRIPT_LATIN given "en" OR "en_US" 
- * If required capacity is greater than capacity of the destination buffer then the error code
- * is set to U_BUFFER_OVERFLOW_ERROR and the required capacity is returned
- *
- * <p>Note: To search by short or long script alias only, use
- * u_getPropertyValueEnum(UCHAR_SCRIPT, alias) instead.  This does
- * a fast lookup with no access of the locale data.
- * @param nameOrAbbrOrLocale name of the script, as given in
- * PropertyValueAliases.txt, or ISO 15924 code or locale
- * @param fillIn the UScriptCode buffer to fill in the script code
- * @param capacity the capacity (size) fo UScriptCode buffer passed in.
- * @param err the error status code.
- * @return The number of script codes filled in the buffer passed in 
- * @stable ICU 2.4
- */
-U_STABLE int32_t  U_EXPORT2 
-uscript_getCode(const char* nameOrAbbrOrLocale,UScriptCode* fillIn,int32_t capacity,UErrorCode *err);
-
-/**
- * Gets a script name associated with the given script code. 
- * Returns  "Malayam" given USCRIPT_MALAYALAM
- * @param scriptCode UScriptCode enum
- * @return script long name as given in
- * PropertyValueAliases.txt, or NULL if scriptCode is invalid
- * @stable ICU 2.4
- */
-U_STABLE const char*  U_EXPORT2 
-uscript_getName(UScriptCode scriptCode);
-
-/**
- * Gets a script name associated with the given script code. 
- * Returns  "Mlym" given USCRIPT_MALAYALAM
- * @param scriptCode UScriptCode enum
- * @return script abbreviated name as given in
- * PropertyValueAliases.txt, or NULL if scriptCode is invalid
- * @stable ICU 2.4
- */
-U_STABLE const char*  U_EXPORT2 
-uscript_getShortName(UScriptCode scriptCode);
-
-/** 
- * Gets the script code associated with the given codepoint.
- * Returns USCRIPT_MALAYALAM given 0x0D02 
- * @param codepoint UChar32 codepoint
- * @param err the error status code.
- * @return The UScriptCode, or 0 if codepoint is invalid 
- * @stable ICU 2.4
- */
-U_STABLE UScriptCode  U_EXPORT2 
-uscript_getScript(UChar32 codepoint, UErrorCode *err);
-
-#endif
-
-


[02/57] [abbrv] remove couch_collate

Posted by be...@apache.org.
http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/utrace.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/utrace.h b/apps/couch_collate/platform/osx/icu/unicode/utrace.h
deleted file mode 100644
index 3c8be9f..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/utrace.h
+++ /dev/null
@@ -1,358 +0,0 @@
-/*
-*******************************************************************************
-*
-*   Copyright (C) 2003-2006, International Business Machines
-*   Corporation and others.  All Rights Reserved.
-*
-*******************************************************************************
-*   file name:  utrace.h
-*   encoding:   US-ASCII
-*   tab size:   8 (not used)
-*   indentation:4
-*
-*   created on: 2003aug06
-*   created by: Markus W. Scherer
-*
-*   Definitions for ICU tracing/logging.
-*
-*/
-
-#ifndef __UTRACE_H__
-#define __UTRACE_H__
-
-#include <stdarg.h>
-#include "unicode/utypes.h"
-
-/**
- * \file
- * \brief C API:  Definitions for ICU tracing/logging. 
- *
- * This provides API for debugging the internals of ICU without the use of
- * a traditional debugger.
- *
- * By default, tracing is disabled in ICU. If you need to debug ICU with 
- * tracing, please compile ICU with the --enable-tracing configure option.
- */
- 
-U_CDECL_BEGIN
-
-/**
- * Trace severity levels.  Higher levels increase the verbosity of the trace output.
- * @see utrace_setLevel
- * @stable ICU 2.8
- */
-typedef enum UTraceLevel {
-    /** Disable all tracing  @stable ICU 2.8*/
-    UTRACE_OFF=-1,
-    /** Trace error conditions only  @stable ICU 2.8*/
-    UTRACE_ERROR=0,
-    /** Trace errors and warnings  @stable ICU 2.8*/
-    UTRACE_WARNING=3,
-    /** Trace opens and closes of ICU services  @stable ICU 2.8*/
-    UTRACE_OPEN_CLOSE=5,
-    /** Trace an intermediate number of ICU operations  @stable ICU 2.8*/
-    UTRACE_INFO=7,
-    /** Trace the maximum number of ICU operations  @stable ICU 2.8*/
-    UTRACE_VERBOSE=9
-} UTraceLevel;
-
-/**
- *  These are the ICU functions that will be traced when tracing is enabled.
- *  @stable ICU 2.8
- */
-typedef enum UTraceFunctionNumber {
-    UTRACE_FUNCTION_START=0,
-    UTRACE_U_INIT=UTRACE_FUNCTION_START,
-    UTRACE_U_CLEANUP,
-    UTRACE_FUNCTION_LIMIT,
-
-    UTRACE_CONVERSION_START=0x1000,
-    UTRACE_UCNV_OPEN=UTRACE_CONVERSION_START,
-    UTRACE_UCNV_OPEN_PACKAGE,
-    UTRACE_UCNV_OPEN_ALGORITHMIC,
-    UTRACE_UCNV_CLONE,
-    UTRACE_UCNV_CLOSE,
-    UTRACE_UCNV_FLUSH_CACHE,
-    UTRACE_UCNV_LOAD,
-    UTRACE_UCNV_UNLOAD,
-    UTRACE_CONVERSION_LIMIT,
-
-    UTRACE_COLLATION_START=0x2000,
-    UTRACE_UCOL_OPEN=UTRACE_COLLATION_START,
-    UTRACE_UCOL_CLOSE,
-    UTRACE_UCOL_STRCOLL,
-    UTRACE_UCOL_GET_SORTKEY,
-    UTRACE_UCOL_GETLOCALE,
-    UTRACE_UCOL_NEXTSORTKEYPART,
-    UTRACE_UCOL_STRCOLLITER,
-    UTRACE_UCOL_OPEN_FROM_SHORT_STRING,
-    UTRACE_COLLATION_LIMIT
-} UTraceFunctionNumber;
-
-/**
- * Setter for the trace level.
- * @param traceLevel A UTraceLevel value.
- * @stable ICU 2.8
- */
-U_STABLE void U_EXPORT2
-utrace_setLevel(int32_t traceLevel);
-
-/**
- * Getter for the trace level.
- * @return The UTraceLevel value being used by ICU.
- * @stable ICU 2.8
- */
-U_STABLE int32_t U_EXPORT2
-utrace_getLevel(void);
-
-/* Trace function pointers types  ----------------------------- */
-
-/**
-  *  Type signature for the trace function to be called when entering a function.
-  *  @param context value supplied at the time the trace functions are set.
-  *  @param fnNumber Enum value indicating the ICU function being entered.
-  *  @stable ICU 2.8
-  */
-typedef void U_CALLCONV
-UTraceEntry(const void *context, int32_t fnNumber);
-
-/**
-  *  Type signature for the trace function to be called when exiting from a function.
-  *  @param context value supplied at the time the trace functions are set.
-  *  @param fnNumber Enum value indicating the ICU function being exited.
-  *  @param fmt     A formatting string that describes the number and types
-  *                 of arguments included with the variable args.  The fmt
-  *                 string has the same form as the utrace_vformat format
-  *                 string.
-  *  @param args    A variable arguments list.  Contents are described by
-  *                 the fmt parameter.
-  *  @see   utrace_vformat
-  *  @stable ICU 2.8
-  */
-typedef void U_CALLCONV
-UTraceExit(const void *context, int32_t fnNumber, 
-           const char *fmt, va_list args);
-
-/**
-  *  Type signature for the trace function to be called from within an ICU function
-  *  to display data or messages.
-  *  @param context  value supplied at the time the trace functions are set.
-  *  @param fnNumber Enum value indicating the ICU function being exited.
-  *  @param level    The current tracing level
-  *  @param fmt      A format string describing the tracing data that is supplied
-  *                  as variable args
-  *  @param args     The data being traced, passed as variable args.
-  *  @stable ICU 2.8
-  */
-typedef void U_CALLCONV
-UTraceData(const void *context, int32_t fnNumber, int32_t level,
-           const char *fmt, va_list args);
-
-/**
-  *  Set ICU Tracing functions.  Installs application-provided tracing
-  *  functions into ICU.  After doing this, subsequent ICU operations
-  *  will call back to the installed functions, providing a trace
-  *  of the use of ICU.  Passing a NULL pointer for a tracing function
-  *  is allowed, and inhibits tracing action at points where that function
-  *  would be called.
-  *  <p>
-  *  Tracing and Threads:  Tracing functions are global to a process, and
-  *  will be called in response to ICU operations performed by any
-  *  thread.  If tracing of an individual thread is desired, the
-  *  tracing functions must themselves filter by checking that the
-  *  current thread is the desired thread.
-  *
-  *  @param context an uninterpretted pointer.  Whatever is passed in
-  *                 here will in turn be passed to each of the tracing
-  *                 functions UTraceEntry, UTraceExit and UTraceData.
-  *                 ICU does not use or alter this pointer.
-  *  @param e       Callback function to be called on entry to a 
-  *                 a traced ICU function.
-  *  @param x       Callback function to be called on exit from a
-  *                 traced ICU function.
-  *  @param d       Callback function to be called from within a 
-  *                 traced ICU function, for the purpose of providing
-  *                 data to the trace.
-  *
-  *  @stable ICU 2.8
-  */
-U_STABLE void U_EXPORT2
-utrace_setFunctions(const void *context,
-                    UTraceEntry *e, UTraceExit *x, UTraceData *d);
-
-/**
-  * Get the currently installed ICU tracing functions.   Note that a null function
-  *   pointer will be returned if no trace function has been set.
-  *
-  * @param context  The currently installed tracing context.
-  * @param e        The currently installed UTraceEntry function.
-  * @param x        The currently installed UTraceExit function.
-  * @param d        The currently installed UTraceData function.
-  * @stable ICU 2.8
-  */
-U_STABLE void U_EXPORT2
-utrace_getFunctions(const void **context,
-                    UTraceEntry **e, UTraceExit **x, UTraceData **d);
-
-
-
-/*
- *
- * ICU trace format string syntax
- *
- * Format Strings are passed to UTraceData functions, and define the
- * number and types of the trace data being passed on each call.
- *
- * The UTraceData function, which is supplied by the application,
- * not by ICU, can either forward the trace data (passed via
- * varargs) and the format string back to ICU for formatting into
- * a displayable string, or it can interpret the format itself,
- * and do as it wishes with the trace data.
- *
- *
- * Goals for the format string
- * - basic data output
- * - easy to use for trace programmer
- * - sufficient provision for data types for trace output readability
- * - well-defined types and binary portable APIs
- *
- * Non-goals
- * - printf compatibility
- * - fancy formatting
- * - argument reordering and other internationalization features
- *
- * ICU trace format strings contain plain text with argument inserts,
- * much like standard printf format strings.
- * Each insert begins with a '%', then optionally contains a 'v',
- * then exactly one type character.
- * Two '%' in a row represent a '%' instead of an insert.
- * The trace format strings need not have \n at the end.
- *
- *
- * Types
- * -----
- *
- * Type characters:
- * - c A char character in the default codepage.
- * - s A NUL-terminated char * string in the default codepage.
- * - S A UChar * string.  Requires two params, (ptr, length).  Length=-1 for nul term.
- * - b A byte (8-bit integer).
- * - h A 16-bit integer.  Also a 16 bit Unicode code unit.
- * - d A 32-bit integer.  Also a 20 bit Unicode code point value. 
- * - l A 64-bit integer.
- * - p A data pointer.
- *
- * Vectors
- * -------
- *
- * If the 'v' is not specified, then one item of the specified type
- * is passed in.
- * If the 'v' (for "vector") is specified, then a vector of items of the
- * specified type is passed in, via a pointer to the first item
- * and an int32_t value for the length of the vector.
- * Length==-1 means zero or NUL termination.  Works for vectors of all types.
- *
- * Note:  %vS is a vector of (UChar *) strings.  The strings must
- *        be nul terminated as there is no way to provide a
- *        separate length parameter for each string.  The length
- *        parameter (required for all vectors) is the number of
- *        strings, not the length of the strings.
- *
- * Examples
- * --------
- *
- * These examples show the parameters that will be passed to an application's
- *   UTraceData() function for various formats.
- *
- * - the precise formatting is up to the application!
- * - the examples use type casts for arguments only to _show_ the types of
- *   arguments without needing variable declarations in the examples;
- *   the type casts will not be necessary in actual code
- *
- * UTraceDataFunc(context, fnNumber, level,
- *              "There is a character %c in the string %s.",   // Format String 
- *              (char)c, (const char *)s);                     // varargs parameters
- * ->   There is a character 0x42 'B' in the string "Bravo".
- *
- * UTraceDataFunc(context, fnNumber, level,
- *              "Vector of bytes %vb vector of chars %vc",
- *              (const uint8_t *)bytes, (int32_t)bytesLength,
- *              (const char *)chars, (int32_t)charsLength);
- * ->  Vector of bytes
- *      42 63 64 3f [4]
- *     vector of chars
- *      "Bcd?"[4]
- *
- * UTraceDataFunc(context, fnNumber, level,
- *              "An int32_t %d and a whole bunch of them %vd",
- *              (int32_t)-5, (const int32_t *)ints, (int32_t)intsLength);
- * ->   An int32_t 0xfffffffb and a whole bunch of them
- *      fffffffb 00000005 0000010a [3]
- *
- */
-
-
-
-/**
-  *  Trace output Formatter.  An application's UTraceData tracing functions may call
-  *                 back to this function to format the trace output in a
-  *                 human readable form.  Note that a UTraceData function may choose
-  *                 to not format the data;  it could, for example, save it in
-  *                 in the raw form it was received (more compact), leaving
-  *                 formatting for a later trace analyis tool.
-  *  @param outBuf  pointer to a buffer to receive the formatted output.  Output
-  *                 will be nul terminated if there is space in the buffer -
-  *                 if the length of the requested output < the output buffer size.
-  *  @param capacity  Length of the output buffer.
-  *  @param indent  Number of spaces to indent the output.  Intended to allow
-  *                 data displayed from nested functions to be indented for readability.
-  *  @param fmt     Format specification for the data to output
-  *  @param args    Data to be formatted.
-  *  @return        Length of formatted output, including the terminating NUL.
-  *                 If buffer capacity is insufficient, the required capacity is returned. 
-  *  @stable ICU 2.8
-  */
-U_STABLE int32_t U_EXPORT2
-utrace_vformat(char *outBuf, int32_t capacity,
-              int32_t indent, const char *fmt,  va_list args);
-
-/**
-  *  Trace output Formatter.  An application's UTraceData tracing functions may call
-  *                 this function to format any additional trace data, beyond that
-  *                 provided by default, in human readable form with the same
-  *                 formatting conventions used by utrace_vformat().
-  *  @param outBuf  pointer to a buffer to receive the formatted output.  Output
-  *                 will be nul terminated if there is space in the buffer -
-  *                 if the length of the requested output < the output buffer size.
-  *  @param capacity  Length of the output buffer.
-  *  @param indent  Number of spaces to indent the output.  Intended to allow
-  *                 data displayed from nested functions to be indented for readability.
-  *  @param fmt     Format specification for the data to output
-  *  @param ...     Data to be formatted.
-  *  @return        Length of formatted output, including the terminating NUL.
-  *                 If buffer capacity is insufficient, the required capacity is returned. 
-  *  @stable ICU 2.8
-  */
-U_STABLE int32_t U_EXPORT2
-utrace_format(char *outBuf, int32_t capacity,
-              int32_t indent, const char *fmt,  ...);
-
-
-
-/* Trace function numbers --------------------------------------------------- */
-
-/**
- * Get the name of a function from its trace function number.
- *
- * @param fnNumber The trace number for an ICU function.
- * @return The name string for the function.
- *
- * @see UTraceFunctionNumber
- * @stable ICU 2.8
- */
-U_STABLE const char * U_EXPORT2
-utrace_functionName(int32_t fnNumber);
-
-U_CDECL_END
-
-#endif

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/utrans.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/utrans.h b/apps/couch_collate/platform/osx/icu/unicode/utrans.h
deleted file mode 100644
index a460a34..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/utrans.h
+++ /dev/null
@@ -1,583 +0,0 @@
-/*
-*******************************************************************************
-*   Copyright (C) 1997-2005, International Business Machines
-*   Corporation and others.  All Rights Reserved.
-*******************************************************************************
-*   Date        Name        Description
-*   06/21/00    aliu        Creation.
-*******************************************************************************
-*/
-
-#ifndef UTRANS_H
-#define UTRANS_H
-
-#include "unicode/utypes.h"
-
-#if !UCONFIG_NO_TRANSLITERATION
-
-#include "unicode/urep.h"
-#include "unicode/parseerr.h"
-#include "unicode/uenum.h"
-
-/********************************************************************
- * General Notes
- ********************************************************************
- */
-/**
- * \file
- * \brief C API: Transliterator
- *
- * <h2> Transliteration </h2>
- * The data structures and functions described in this header provide
- * transliteration services.  Transliteration services are implemented
- * as C++ classes.  The comments and documentation in this header
- * assume the reader is familiar with the C++ headers translit.h and
- * associated documentation.
- *
- * A significant but incomplete subset of the C++ transliteration
- * services are available to C code through this header.  In order to
- * access more complex transliteration services, refer to the C++
- * headers and documentation.
- *
- * There are two sets of functions for working with transliterator IDs:
- *
- * An old, deprecated set uses char * IDs, which works for true and pure
- * identifiers that these APIs were designed for,
- * for example "Cyrillic-Latin".
- * It does not work when the ID contains filters ("[:Script=Cyrl:]")
- * or even a complete set of rules because then the ID string contains more
- * than just "invariant" characters (see utypes.h).
- *
- * A new set of functions replaces the old ones and uses UChar * IDs,
- * paralleling the UnicodeString IDs in the C++ API. (New in ICU 2.8.)
- */
-
-/********************************************************************
- * Data Structures
- ********************************************************************/
-
-/**
- * An opaque transliterator for use in C.  Open with utrans_openxxx()
- * and close with utrans_close() when done.  Equivalent to the C++ class
- * Transliterator and its subclasses.
- * @see Transliterator
- * @stable ICU 2.0
- */
-typedef void* UTransliterator;
-
-/**
- * Direction constant indicating the direction in a transliterator,
- * e.g., the forward or reverse rules of a RuleBasedTransliterator.
- * Specified when a transliterator is opened.  An "A-B" transliterator
- * transliterates A to B when operating in the forward direction, and
- * B to A when operating in the reverse direction.
- * @stable ICU 2.0
- */
-typedef enum UTransDirection {
-    
-    /**
-     * UTRANS_FORWARD means from &lt;source&gt; to &lt;target&gt; for a
-     * transliterator with ID &lt;source&gt;-&lt;target&gt;.  For a transliterator
-     * opened using a rule, it means forward direction rules, e.g.,
-     * "A > B".
-     */
-    UTRANS_FORWARD,
-
-    /**
-     * UTRANS_REVERSE means from &lt;target&gt; to &lt;source&gt; for a
-     * transliterator with ID &lt;source&gt;-&lt;target&gt;.  For a transliterator
-     * opened using a rule, it means reverse direction rules, e.g.,
-     * "A < B".
-     */
-    UTRANS_REVERSE
-
-} UTransDirection;
-
-/**
- * Position structure for utrans_transIncremental() incremental
- * transliteration.  This structure defines two substrings of the text
- * being transliterated.  The first region, [contextStart,
- * contextLimit), defines what characters the transliterator will read
- * as context.  The second region, [start, limit), defines what
- * characters will actually be transliterated.  The second region
- * should be a subset of the first.
- *
- * <p>After a transliteration operation, some of the indices in this
- * structure will be modified.  See the field descriptions for
- * details.
- *
- * <p>contextStart <= start <= limit <= contextLimit
- *
- * <p>Note: All index values in this structure must be at code point
- * boundaries.  That is, none of them may occur between two code units
- * of a surrogate pair.  If any index does split a surrogate pair,
- * results are unspecified.
- *
- * @stable ICU 2.0
- */
-typedef struct UTransPosition {
-
-    /**
-     * Beginning index, inclusive, of the context to be considered for
-     * a transliteration operation.  The transliterator will ignore
-     * anything before this index.  INPUT/OUTPUT parameter: This parameter
-     * is updated by a transliteration operation to reflect the maximum
-     * amount of antecontext needed by a transliterator.
-     * @stable ICU 2.4
-     */
-    int32_t contextStart;
-    
-    /**
-     * Ending index, exclusive, of the context to be considered for a
-     * transliteration operation.  The transliterator will ignore
-     * anything at or after this index.  INPUT/OUTPUT parameter: This
-     * parameter is updated to reflect changes in the length of the
-     * text, but points to the same logical position in the text.
-     * @stable ICU 2.4
-     */
-    int32_t contextLimit;
-    
-    /**
-     * Beginning index, inclusive, of the text to be transliteratd.
-     * INPUT/OUTPUT parameter: This parameter is advanced past
-     * characters that have already been transliterated by a
-     * transliteration operation.
-     * @stable ICU 2.4
-     */
-    int32_t start;
-    
-    /**
-     * Ending index, exclusive, of the text to be transliteratd.
-     * INPUT/OUTPUT parameter: This parameter is updated to reflect
-     * changes in the length of the text, but points to the same
-     * logical position in the text.
-     * @stable ICU 2.4
-     */
-    int32_t limit;
-
-} UTransPosition;
-
-/********************************************************************
- * General API
- ********************************************************************/
-
-/**
- * Open a custom transliterator, given a custom rules string 
- * OR 
- * a system transliterator, given its ID.  
- * Any non-NULL result from this function should later be closed with
- * utrans_close().
- *
- * @param id a valid transliterator ID
- * @param idLength the length of the ID string, or -1 if NUL-terminated
- * @param dir the desired direction
- * @param rules the transliterator rules.  See the C++ header rbt.h for
- *              rules syntax. If NULL then a system transliterator matching
- *              the ID is returned.
- * @param rulesLength the length of the rules, or -1 if the rules
- *                    are NUL-terminated.
- * @param parseError a pointer to a UParseError struct to receive the details
- *                   of any parsing errors. This parameter may be NULL if no
- *                   parsing error details are desired.
- * @param pErrorCode a pointer to the UErrorCode
- * @return a transliterator pointer that may be passed to other
- *         utrans_xxx() functions, or NULL if the open call fails.
- * @stable ICU 2.8
- */
-U_STABLE UTransliterator* U_EXPORT2
-utrans_openU(const UChar *id,
-             int32_t idLength,
-             UTransDirection dir,
-             const UChar *rules,
-             int32_t rulesLength,
-             UParseError *parseError,
-             UErrorCode *pErrorCode);
-
-/**
- * Open an inverse of an existing transliterator.  For this to work,
- * the inverse must be registered with the system.  For example, if
- * the Transliterator "A-B" is opened, and then its inverse is opened,
- * the result is the Transliterator "B-A", if such a transliterator is
- * registered with the system.  Otherwise the result is NULL and a
- * failing UErrorCode is set.  Any non-NULL result from this function
- * should later be closed with utrans_close().
- *
- * @param trans the transliterator to open the inverse of.
- * @param status a pointer to the UErrorCode
- * @return a pointer to a newly-opened transliterator that is the
- * inverse of trans, or NULL if the open call fails.
- * @stable ICU 2.0
- */
-U_STABLE UTransliterator* U_EXPORT2 
-utrans_openInverse(const UTransliterator* trans,
-                   UErrorCode* status);
-
-/**
- * Create a copy of a transliterator.  Any non-NULL result from this
- * function should later be closed with utrans_close().
- *
- * @param trans the transliterator to be copied.
- * @param status a pointer to the UErrorCode
- * @return a transliterator pointer that may be passed to other
- * utrans_xxx() functions, or NULL if the clone call fails.
- * @stable ICU 2.0
- */
-U_STABLE UTransliterator* U_EXPORT2 
-utrans_clone(const UTransliterator* trans,
-             UErrorCode* status);
-
-/**
- * Close a transliterator.  Any non-NULL pointer returned by
- * utrans_openXxx() or utrans_clone() should eventually be closed.
- * @param trans the transliterator to be closed.
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2 
-utrans_close(UTransliterator* trans);
-
-/**
- * Return the programmatic identifier for this transliterator.
- * If this identifier is passed to utrans_openU(), it will open
- * a transliterator equivalent to this one, if the ID has been
- * registered.
- *
- * @param trans the transliterator to return the ID of.
- * @param resultLength pointer to an output variable receiving the length
- *        of the ID string; can be NULL
- * @return the NUL-terminated ID string. This pointer remains
- * valid until utrans_close() is called on this transliterator.
- *
- * @stable ICU 2.8
- */
-U_STABLE const UChar * U_EXPORT2
-utrans_getUnicodeID(const UTransliterator *trans,
-                    int32_t *resultLength);
-
-/**
- * Register an open transliterator with the system.  When
- * utrans_open() is called with an ID string that is equal to that
- * returned by utrans_getID(adoptedTrans,...), then
- * utrans_clone(adoptedTrans,...) is returned.
- *
- * <p>NOTE: After this call the system owns the adoptedTrans and will
- * close it.  The user must not call utrans_close() on adoptedTrans.
- *
- * @param adoptedTrans a transliterator, typically the result of
- * utrans_openRules(), to be registered with the system.
- * @param status a pointer to the UErrorCode
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2 
-utrans_register(UTransliterator* adoptedTrans,
-                UErrorCode* status);
-
-/**
- * Unregister a transliterator from the system.  After this call the
- * system will no longer recognize the given ID when passed to
- * utrans_open(). If the ID is invalid then nothing is done.
- *
- * @param id an ID to unregister
- * @param idLength the length of id, or -1 if id is zero-terminated
- * @stable ICU 2.8
- */
-U_STABLE void U_EXPORT2
-utrans_unregisterID(const UChar* id, int32_t idLength);
-
-/**
- * Set the filter used by a transliterator.  A filter can be used to
- * make the transliterator pass certain characters through untouched.
- * The filter is expressed using a UnicodeSet pattern.  If the
- * filterPattern is NULL or the empty string, then the transliterator
- * will be reset to use no filter.
- *
- * @param trans the transliterator
- * @param filterPattern a pattern string, in the form accepted by
- * UnicodeSet, specifying which characters to apply the
- * transliteration to.  May be NULL or the empty string to indicate no
- * filter.
- * @param filterPatternLen the length of filterPattern, or -1 if
- * filterPattern is zero-terminated
- * @param status a pointer to the UErrorCode
- * @see UnicodeSet
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2 
-utrans_setFilter(UTransliterator* trans,
-                 const UChar* filterPattern,
-                 int32_t filterPatternLen,
-                 UErrorCode* status);
-
-/**
- * Return the number of system transliterators.
- * It is recommended to use utrans_openIDs() instead.
- *
- * @return the number of system transliterators.
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2 
-utrans_countAvailableIDs(void);
-
-/**
- * Return a UEnumeration for the available transliterators.
- *
- * @param pErrorCode Pointer to the UErrorCode in/out parameter.
- * @return UEnumeration for the available transliterators.
- *         Close with uenum_close().
- *
- * @stable ICU 2.8
- */
-U_STABLE UEnumeration * U_EXPORT2
-utrans_openIDs(UErrorCode *pErrorCode);
-
-/********************************************************************
- * Transliteration API
- ********************************************************************/
-
-/**
- * Transliterate a segment of a UReplaceable string.  The string is
- * passed in as a UReplaceable pointer rep and a UReplaceableCallbacks
- * function pointer struct repFunc.  Functions in the repFunc struct
- * will be called in order to modify the rep string.
- *
- * @param trans the transliterator
- * @param rep a pointer to the string.  This will be passed to the
- * repFunc functions.
- * @param repFunc a set of function pointers that will be used to
- * modify the string pointed to by rep.
- * @param start the beginning index, inclusive; <code>0 <= start <=
- * limit</code>.
- * @param limit pointer to the ending index, exclusive; <code>start <=
- * limit <= repFunc->length(rep)</code>.  Upon return, *limit will
- * contain the new limit index.  The text previously occupying
- * <code>[start, limit)</code> has been transliterated, possibly to a
- * string of a different length, at <code>[start,
- * </code><em>new-limit</em><code>)</code>, where <em>new-limit</em>
- * is the return value.
- * @param status a pointer to the UErrorCode
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2 
-utrans_trans(const UTransliterator* trans,
-             UReplaceable* rep,
-             UReplaceableCallbacks* repFunc,
-             int32_t start,
-             int32_t* limit,
-             UErrorCode* status);
-
-/**
- * Transliterate the portion of the UReplaceable text buffer that can
- * be transliterated unambiguosly.  This method is typically called
- * after new text has been inserted, e.g. as a result of a keyboard
- * event.  The transliterator will try to transliterate characters of
- * <code>rep</code> between <code>index.cursor</code> and
- * <code>index.limit</code>.  Characters before
- * <code>index.cursor</code> will not be changed.
- *
- * <p>Upon return, values in <code>index</code> will be updated.
- * <code>index.start</code> will be advanced to the first
- * character that future calls to this method will read.
- * <code>index.cursor</code> and <code>index.limit</code> will
- * be adjusted to delimit the range of text that future calls to
- * this method may change.
- *
- * <p>Typical usage of this method begins with an initial call
- * with <code>index.start</code> and <code>index.limit</code>
- * set to indicate the portion of <code>text</code> to be
- * transliterated, and <code>index.cursor == index.start</code>.
- * Thereafter, <code>index</code> can be used without
- * modification in future calls, provided that all changes to
- * <code>text</code> are made via this method.
- *
- * <p>This method assumes that future calls may be made that will
- * insert new text into the buffer.  As a result, it only performs
- * unambiguous transliterations.  After the last call to this method,
- * there may be untransliterated text that is waiting for more input
- * to resolve an ambiguity.  In order to perform these pending
- * transliterations, clients should call utrans_trans() with a start
- * of index.start and a limit of index.end after the last call to this
- * method has been made.
- *
- * @param trans the transliterator
- * @param rep a pointer to the string.  This will be passed to the
- * repFunc functions.
- * @param repFunc a set of function pointers that will be used to
- * modify the string pointed to by rep.
- * @param pos a struct containing the start and limit indices of the
- * text to be read and the text to be transliterated
- * @param status a pointer to the UErrorCode
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2 
-utrans_transIncremental(const UTransliterator* trans,
-                        UReplaceable* rep,
-                        UReplaceableCallbacks* repFunc,
-                        UTransPosition* pos,
-                        UErrorCode* status);
-
-/**
- * Transliterate a segment of a UChar* string.  The string is passed
- * in in a UChar* buffer.  The string is modified in place.  If the
- * result is longer than textCapacity, it is truncated.  The actual
- * length of the result is returned in *textLength, if textLength is
- * non-NULL. *textLength may be greater than textCapacity, but only
- * textCapacity UChars will be written to *text, including the zero
- * terminator.
- *
- * @param trans the transliterator
- * @param text a pointer to a buffer containing the text to be
- * transliterated on input and the result text on output.
- * @param textLength a pointer to the length of the string in text.
- * If the length is -1 then the string is assumed to be
- * zero-terminated.  Upon return, the new length is stored in
- * *textLength.  If textLength is NULL then the string is assumed to
- * be zero-terminated.
- * @param textCapacity a pointer to the length of the text buffer.
- * Upon return, 
- * @param start the beginning index, inclusive; <code>0 <= start <=
- * limit</code>.
- * @param limit pointer to the ending index, exclusive; <code>start <=
- * limit <= repFunc->length(rep)</code>.  Upon return, *limit will
- * contain the new limit index.  The text previously occupying
- * <code>[start, limit)</code> has been transliterated, possibly to a
- * string of a different length, at <code>[start,
- * </code><em>new-limit</em><code>)</code>, where <em>new-limit</em>
- * is the return value.
- * @param status a pointer to the UErrorCode
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2 
-utrans_transUChars(const UTransliterator* trans,
-                   UChar* text,
-                   int32_t* textLength,
-                   int32_t textCapacity,
-                   int32_t start,
-                   int32_t* limit,
-                   UErrorCode* status);
-
-/**
- * Transliterate the portion of the UChar* text buffer that can be
- * transliterated unambiguosly.  See utrans_transIncremental().  The
- * string is passed in in a UChar* buffer.  The string is modified in
- * place.  If the result is longer than textCapacity, it is truncated.
- * The actual length of the result is returned in *textLength, if
- * textLength is non-NULL. *textLength may be greater than
- * textCapacity, but only textCapacity UChars will be written to
- * *text, including the zero terminator.  See utrans_transIncremental()
- * for usage details.
- *
- * @param trans the transliterator
- * @param text a pointer to a buffer containing the text to be
- * transliterated on input and the result text on output.
- * @param textLength a pointer to the length of the string in text.
- * If the length is -1 then the string is assumed to be
- * zero-terminated.  Upon return, the new length is stored in
- * *textLength.  If textLength is NULL then the string is assumed to
- * be zero-terminated.
- * @param textCapacity the length of the text buffer
- * @param pos a struct containing the start and limit indices of the
- * text to be read and the text to be transliterated
- * @param status a pointer to the UErrorCode
- * @see utrans_transIncremental
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2 
-utrans_transIncrementalUChars(const UTransliterator* trans,
-                              UChar* text,
-                              int32_t* textLength,
-                              int32_t textCapacity,
-                              UTransPosition* pos,
-                              UErrorCode* status);
-
-/* deprecated API ----------------------------------------------------------- */
-
-/* see utrans.h documentation for why these functions are deprecated */
-
-/**
- * Deprecated, use utrans_openU() instead.
- * Open a custom transliterator, given a custom rules string 
- * OR 
- * a system transliterator, given its ID.  
- * Any non-NULL result from this function should later be closed with
- * utrans_close().
- *
- * @param id a valid ID, as returned by utrans_getAvailableID()
- * @param dir the desired direction
- * @param rules the transliterator rules.  See the C++ header rbt.h
- * for rules syntax. If NULL then a system transliterator matching 
- * the ID is returned.
- * @param rulesLength the length of the rules, or -1 if the rules
- * are zero-terminated.
- * @param parseError a pointer to a UParseError struct to receive the
- * details of any parsing errors. This parameter may be NULL if no
- * parsing error details are desired.
- * @param status a pointer to the UErrorCode
- * @return a transliterator pointer that may be passed to other
- * utrans_xxx() functions, or NULL if the open call fails.
- * @deprecated ICU 2.8 Use utrans_openU() instead, see utrans.h
- */
-U_DEPRECATED UTransliterator* U_EXPORT2 
-utrans_open(const char* id,
-            UTransDirection dir,
-            const UChar* rules,         /* may be Null */
-            int32_t rulesLength,        /* -1 if null-terminated */ 
-            UParseError* parseError,    /* may be Null */
-            UErrorCode* status);
-
-/**
- * Deprecated, use utrans_getUnicodeID() instead.
- * Return the programmatic identifier for this transliterator.
- * If this identifier is passed to utrans_open(), it will open
- * a transliterator equivalent to this one, if the ID has been
- * registered.
- * @param trans the transliterator to return the ID of.
- * @param buf the buffer in which to receive the ID.  This may be
- * NULL, in which case no characters are copied.
- * @param bufCapacity the capacity of the buffer.  Ignored if buf is
- * NULL.
- * @return the actual length of the ID, not including
- * zero-termination.  This may be greater than bufCapacity.
- * @deprecated ICU 2.8 Use utrans_getUnicodeID() instead, see utrans.h
- */
-U_DEPRECATED int32_t U_EXPORT2 
-utrans_getID(const UTransliterator* trans,
-             char* buf,
-             int32_t bufCapacity);
-
-/**
- * Deprecated, use utrans_unregisterID() instead.
- * Unregister a transliterator from the system.  After this call the
- * system will no longer recognize the given ID when passed to
- * utrans_open().  If the id is invalid then nothing is done.
- *
- * @param id a zero-terminated ID
- * @deprecated ICU 2.8 Use utrans_unregisterID() instead, see utrans.h
- */
-U_DEPRECATED void U_EXPORT2 
-utrans_unregister(const char* id);
-
-/**
- * Deprecated, use utrans_openIDs() instead.
- * Return the ID of the index-th system transliterator.  The result
- * is placed in the given buffer.  If the given buffer is too small,
- * the initial substring is copied to buf.  The result in buf is
- * always zero-terminated.
- *
- * @param index the number of the transliterator to return.  Must
- * satisfy 0 <= index < utrans_countAvailableIDs().  If index is out
- * of range then it is treated as if it were 0.
- * @param buf the buffer in which to receive the ID.  This may be
- * NULL, in which case no characters are copied.
- * @param bufCapacity the capacity of the buffer.  Ignored if buf is
- * NULL.
- * @return the actual length of the index-th ID, not including
- * zero-termination.  This may be greater than bufCapacity.
- * @deprecated ICU 2.8 Use utrans_openIDs() instead, see utrans.h
- */
-U_DEPRECATED int32_t U_EXPORT2 
-utrans_getAvailableID(int32_t index,
-                      char* buf,
-                      int32_t bufCapacity);
-
-#endif /* #if !UCONFIG_NO_TRANSLITERATION */
-
-#endif

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/utypes.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/utypes.h b/apps/couch_collate/platform/osx/icu/unicode/utypes.h
deleted file mode 100644
index 12977ed..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/utypes.h
+++ /dev/null
@@ -1,801 +0,0 @@
-/*
-**********************************************************************
-*   Copyright (C) 1996-2008, International Business Machines
-*   Corporation and others.  All Rights Reserved.
-**********************************************************************
-*
-*  FILE NAME : UTYPES.H (formerly ptypes.h)
-*
-*   Date        Name        Description
-*   12/11/96    helena      Creation.
-*   02/27/97    aliu        Added typedefs for UClassID, int8, int16, int32,
-*                           uint8, uint16, and uint32.
-*   04/01/97    aliu        Added XP_CPLUSPLUS and modified to work under C as
-*                            well as C++.
-*                           Modified to use memcpy() for uprv_arrayCopy() fns.
-*   04/14/97    aliu        Added TPlatformUtilities.
-*   05/07/97    aliu        Added import/export specifiers (replacing the old
-*                           broken EXT_CLASS).  Added version number for our
-*                           code.  Cleaned up header.
-*    6/20/97    helena      Java class name change.
-*   08/11/98    stephen     UErrorCode changed from typedef to enum
-*   08/12/98    erm         Changed T_ANALYTIC_PACKAGE_VERSION to 3
-*   08/14/98    stephen     Added uprv_arrayCopy() for int8_t, int16_t, int32_t
-*   12/09/98    jfitz       Added BUFFER_OVERFLOW_ERROR (bug 1100066)
-*   04/20/99    stephen     Cleaned up & reworked for autoconf.
-*                           Renamed to utypes.h.
-*   05/05/99    stephen     Changed to use <inttypes.h>
-*   12/07/99    helena      Moved copyright notice string from ucnv_bld.h here.
-*******************************************************************************
-*/
-
-#ifndef UTYPES_H
-#define UTYPES_H
-
-
-#include "unicode/umachine.h"
-#include "unicode/utf.h"
-#include "unicode/uversion.h"
-#include "unicode/uconfig.h"
-
-#if !U_DEFAULT_SHOW_DRAFT && !defined(U_SHOW_DRAFT_API)
-#define U_HIDE_DRAFT_API 1
-#endif
-
-#ifdef U_HIDE_DRAFT_API
-#include "unicode/udraft.h"
-#endif
-
-#ifdef U_HIDE_DEPRECATED_API
-#include "unicode/udeprctd.h"
-#endif
-
-#ifdef U_HIDE_DEPRECATED_API
-#include "unicode/uobslete.h"
-#endif
-
-#ifdef U_HIDE_INTERNAL_API
-#include "unicode/uintrnal.h"
-#endif
-
-#ifdef U_HIDE_SYSTEM_API
-#include "unicode/usystem.h"
-#endif
-
-/*!
- * \file
- * \brief Basic definitions for ICU, for both C and C++ APIs
- *
- * This file defines basic types, constants, and enumerations directly or
- * indirectly by including other header files, especially utf.h for the
- * basic character and string definitions and umachine.h for consistent
- * integer and other types.
- */
-
-/*===========================================================================*/
-/* char Character set family                                                 */
-/*===========================================================================*/
-
-/**
- * U_CHARSET_FAMILY is equal to this value when the platform is an ASCII based platform.
- * @stable ICU 2.0
- */
-#define U_ASCII_FAMILY 0
-
-/**
- * U_CHARSET_FAMILY is equal to this value when the platform is an EBCDIC based platform.
- * @stable ICU 2.0
- */
-#define U_EBCDIC_FAMILY 1
-
-/**
- * \def U_CHARSET_FAMILY
- *
- * <p>These definitions allow to specify the encoding of text
- * in the char data type as defined by the platform and the compiler.
- * It is enough to determine the code point values of "invariant characters",
- * which are the ones shared by all encodings that are in use
- * on a given platform.</p>
- *
- * <p>Those "invariant characters" should be all the uppercase and lowercase
- * latin letters, the digits, the space, and "basic punctuation".
- * Also, '\\n', '\\r', '\\t' should be available.</p>
- *
- * <p>The list of "invariant characters" is:<br>
- * \code
- *    A-Z  a-z  0-9  SPACE  "  %  &amp;  '  (  )  *  +  ,  -  .  /  :  ;  <  =  >  ?  _
- * \endcode
- * <br>
- * (52 letters + 10 numbers + 20 punc/sym/space = 82 total)</p>
- *
- * <p>This matches the IBM Syntactic Character Set (CS 640).</p>
- *
- * <p>In other words, all the graphic characters in 7-bit ASCII should
- * be safely accessible except the following:</p>
- *
- * \code
- *    '\' <backslash>
- *    '[' <left bracket>
- *    ']' <right bracket>
- *    '{' <left brace>
- *    '}' <right brace>
- *    '^' <circumflex>
- *    '~' <tilde>
- *    '!' <exclamation mark>
- *    '#' <number sign>
- *    '|' <vertical line>
- *    '$' <dollar sign>
- *    '@' <commercial at>
- *    '`' <grave accent>
- * \endcode
- * @stable ICU 2.0
- */
-
-#ifndef U_CHARSET_FAMILY
-#   define U_CHARSET_FAMILY 0
-#endif
-
-/*===========================================================================*/
-/* ICUDATA naming scheme                                                     */
-/*===========================================================================*/
-
-/**
- * \def U_ICUDATA_TYPE_LETTER
- *
- * This is a platform-dependent string containing one letter:
- * - b for big-endian, ASCII-family platforms
- * - l for little-endian, ASCII-family platforms
- * - e for big-endian, EBCDIC-family platforms
- * This letter is part of the common data file name.
- * @stable ICU 2.0
- */
-
-/**
- * \def U_ICUDATA_TYPE_LITLETTER
- * The non-string form of U_ICUDATA_TYPE_LETTER
- * @stable ICU 2.0
- */
-#if U_CHARSET_FAMILY
-#   if U_IS_BIG_ENDIAN
-   /* EBCDIC - should always be BE */
-#     define U_ICUDATA_TYPE_LETTER "e"
-#     define U_ICUDATA_TYPE_LITLETTER e
-#   else
-#     error "Don't know what to do with little endian EBCDIC!"
-#     define U_ICUDATA_TYPE_LETTER "x"
-#     define U_ICUDATA_TYPE_LITLETTER x
-#   endif
-#else
-#   if U_IS_BIG_ENDIAN
-      /* Big-endian ASCII */
-#     define U_ICUDATA_TYPE_LETTER "b"
-#     define U_ICUDATA_TYPE_LITLETTER b
-#   else
-      /* Little-endian ASCII */
-#     define U_ICUDATA_TYPE_LETTER "l"
-#     define U_ICUDATA_TYPE_LITLETTER l
-#   endif
-#endif
-
-/**
- * A single string literal containing the icudata stub name. i.e. 'icudt18e' for
- * ICU 1.8.x on EBCDIC, etc..
- * @stable ICU 2.0
- */
-#define U_ICUDATA_NAME    "icudt" U_ICU_VERSION_SHORT U_ICUDATA_TYPE_LETTER
-
-
-/**
- *  U_ICU_ENTRY_POINT is the name of the DLL entry point to the ICU data library.
- *    Defined as a literal, not a string.
- *    Tricky Preprocessor use - ## operator replaces macro paramters with the literal string
- *                              from the corresponding macro invocation, _before_ other macro substitutions.
- *                              Need a nested \#defines to get the actual version numbers rather than
- *                              the literal text U_ICU_VERSION_MAJOR_NUM into the name.
- *                              The net result will be something of the form
- *                                  \#define U_ICU_ENTRY_POINT icudt19_dat
- * @stable ICU 2.4
- */
-#define U_ICUDATA_ENTRY_POINT  U_DEF2_ICUDATA_ENTRY_POINT(U_ICU_VERSION_MAJOR_NUM, U_ICU_VERSION_MINOR_NUM)
-
-/**
- * Do not use.
- * @internal
- */
-#define U_DEF2_ICUDATA_ENTRY_POINT(major, minor) U_DEF_ICUDATA_ENTRY_POINT(major, minor)
-/**
- * Do not use.
- * @internal
- */
-#define U_DEF_ICUDATA_ENTRY_POINT(major, minor) icudt##major##minor##_dat
-
-/**
- * \def U_CALLCONV
- * Similar to U_CDECL_BEGIN/U_CDECL_END, this qualifier is necessary
- * in callback function typedefs to make sure that the calling convention
- * is compatible.
- *
- * This is only used for non-ICU-API functions.
- * When a function is a public ICU API,
- * you must use the U_CAPI and U_EXPORT2 qualifiers.
- * @stable ICU 2.0
- */
-#if defined(OS390) && (__COMPILER_VER__ < 0x41020000) && defined(XP_CPLUSPLUS)
-#    define U_CALLCONV __cdecl
-#else
-#    define U_CALLCONV U_EXPORT2
-#endif
-
-/**
- * \def NULL
- * Define NULL if necessary, to 0 for C++ and to ((void *)0) for C.
- * @stable ICU 2.0
- */
-#ifndef NULL
-#ifdef XP_CPLUSPLUS
-#define NULL    0
-#else
-#define NULL    ((void *)0)
-#endif
-#endif
-
-/*===========================================================================*/
-/* Calendar/TimeZone data types                                              */
-/*===========================================================================*/
-
-/**
- * Date and Time data type.
- * This is a primitive data type that holds the date and time
- * as the number of milliseconds since 1970-jan-01, 00:00 UTC.
- * UTC leap seconds are ignored.
- * @stable ICU 2.0
- */
-typedef double UDate;
-
-/** The number of milliseconds per second @stable ICU 2.0 */
-#define U_MILLIS_PER_SECOND        (1000)
-/** The number of milliseconds per minute @stable ICU 2.0 */
-#define U_MILLIS_PER_MINUTE       (60000)
-/** The number of milliseconds per hour @stable ICU 2.0 */
-#define U_MILLIS_PER_HOUR       (3600000)
-/** The number of milliseconds per day @stable ICU 2.0 */
-#define U_MILLIS_PER_DAY       (86400000)
-
-
-/*===========================================================================*/
-/* UClassID-based RTTI */
-/*===========================================================================*/
-
-/**
- * UClassID is used to identify classes without using RTTI, since RTTI
- * is not yet supported by all C++ compilers.  Each class hierarchy which needs
- * to implement polymorphic clone() or operator==() defines two methods,
- * described in detail below.  UClassID values can be compared using
- * operator==(). Nothing else should be done with them.
- *
- * \par
- * getDynamicClassID() is declared in the base class of the hierarchy as
- * a pure virtual.  Each concrete subclass implements it in the same way:
- *
- * \code
- *      class Base {
- *      public:
- *          virtual UClassID getDynamicClassID() const = 0;
- *      }
- *
- *      class Derived {
- *      public:
- *          virtual UClassID getDynamicClassID() const
- *            { return Derived::getStaticClassID(); }
- *      }
- * \endcode
- *
- * Each concrete class implements getStaticClassID() as well, which allows
- * clients to test for a specific type.
- *
- * \code
- *      class Derived {
- *      public:
- *          static UClassID U_EXPORT2 getStaticClassID();
- *      private:
- *          static char fgClassID;
- *      }
- *
- *      // In Derived.cpp:
- *      UClassID Derived::getStaticClassID()
- *        { return (UClassID)&Derived::fgClassID; }
- *      char Derived::fgClassID = 0; // Value is irrelevant
- * \endcode
- * @stable ICU 2.0
- */
-typedef void* UClassID;
-
-/*===========================================================================*/
-/* Shared library/DLL import-export API control                              */
-/*===========================================================================*/
-
-/*
- * Control of symbol import/export.
- * ICU is separated into three libraries.
- */
-
-/*
- * \def U_COMBINED_IMPLEMENTATION
- * Set to export library symbols from inside the ICU library
- * when all of ICU is in a single library.
- * This can be set as a compiler option while building ICU, and it
- * needs to be the first one tested to override U_COMMON_API, U_I18N_API, etc.
- * @stable ICU 2.0
- */
-
-/**
- * \def U_DATA_API
- * Set to export library symbols from inside the stubdata library,
- * and to import them from outside.
- * @stable ICU 3.0
- */
-
-/**
- * \def U_COMMON_API
- * Set to export library symbols from inside the common library,
- * and to import them from outside.
- * @stable ICU 2.0
- */
-
-/**
- * \def U_I18N_API
- * Set to export library symbols from inside the i18n library,
- * and to import them from outside.
- * @stable ICU 2.0
- */
-
-/**
- * \def U_LAYOUT_API
- * Set to export library symbols from inside the layout engine library,
- * and to import them from outside.
- * @stable ICU 2.0
- */
-
-/**
- * \def U_LAYOUTEX_API
- * Set to export library symbols from inside the layout extensions library,
- * and to import them from outside.
- * @stable ICU 2.6
- */
-
-/**
- * \def U_IO_API
- * Set to export library symbols from inside the ustdio library,
- * and to import them from outside.
- * @stable ICU 2.0
- */
-
-/**
- * \def U_TOOLUTIL_API
- * Set to export library symbols from inside the toolutil library,
- * and to import them from outside.
- * @stable ICU 3.4
- */
-
-#if defined(U_COMBINED_IMPLEMENTATION)
-#define U_DATA_API     U_EXPORT
-#define U_COMMON_API   U_EXPORT
-#define U_I18N_API     U_EXPORT
-#define U_LAYOUT_API   U_EXPORT
-#define U_LAYOUTEX_API U_EXPORT
-#define U_IO_API       U_EXPORT
-#define U_TOOLUTIL_API U_EXPORT
-#elif defined(U_STATIC_IMPLEMENTATION)
-#define U_DATA_API
-#define U_COMMON_API
-#define U_I18N_API
-#define U_LAYOUT_API
-#define U_LAYOUTEX_API
-#define U_IO_API
-#define U_TOOLUTIL_API
-#elif defined(U_COMMON_IMPLEMENTATION)
-#define U_DATA_API     U_IMPORT
-#define U_COMMON_API   U_EXPORT
-#define U_I18N_API     U_IMPORT
-#define U_LAYOUT_API   U_IMPORT
-#define U_LAYOUTEX_API U_IMPORT
-#define U_IO_API       U_IMPORT
-#define U_TOOLUTIL_API U_IMPORT
-#elif defined(U_I18N_IMPLEMENTATION)
-#define U_DATA_API     U_IMPORT
-#define U_COMMON_API   U_IMPORT
-#define U_I18N_API     U_EXPORT
-#define U_LAYOUT_API   U_IMPORT
-#define U_LAYOUTEX_API U_IMPORT
-#define U_IO_API       U_IMPORT
-#define U_TOOLUTIL_API U_IMPORT
-#elif defined(U_LAYOUT_IMPLEMENTATION)
-#define U_DATA_API     U_IMPORT
-#define U_COMMON_API   U_IMPORT
-#define U_I18N_API     U_IMPORT
-#define U_LAYOUT_API   U_EXPORT
-#define U_LAYOUTEX_API U_IMPORT
-#define U_IO_API       U_IMPORT
-#define U_TOOLUTIL_API U_IMPORT
-#elif defined(U_LAYOUTEX_IMPLEMENTATION)
-#define U_DATA_API     U_IMPORT
-#define U_COMMON_API   U_IMPORT
-#define U_I18N_API     U_IMPORT
-#define U_LAYOUT_API   U_IMPORT
-#define U_LAYOUTEX_API U_EXPORT
-#define U_IO_API       U_IMPORT
-#define U_TOOLUTIL_API U_IMPORT
-#elif defined(U_IO_IMPLEMENTATION)
-#define U_DATA_API     U_IMPORT
-#define U_COMMON_API   U_IMPORT
-#define U_I18N_API     U_IMPORT
-#define U_LAYOUT_API   U_IMPORT
-#define U_LAYOUTEX_API U_IMPORT
-#define U_IO_API       U_EXPORT
-#define U_TOOLUTIL_API U_IMPORT
-#elif defined(U_TOOLUTIL_IMPLEMENTATION)
-#define U_DATA_API     U_IMPORT
-#define U_COMMON_API   U_IMPORT
-#define U_I18N_API     U_IMPORT
-#define U_LAYOUT_API   U_IMPORT
-#define U_LAYOUTEX_API U_IMPORT
-#define U_IO_API       U_IMPORT
-#define U_TOOLUTIL_API U_EXPORT
-#else
-#define U_DATA_API     U_IMPORT
-#define U_COMMON_API   U_IMPORT
-#define U_I18N_API     U_IMPORT
-#define U_LAYOUT_API   U_IMPORT
-#define U_LAYOUTEX_API U_IMPORT
-#define U_IO_API       U_IMPORT
-#define U_TOOLUTIL_API U_IMPORT
-#endif
-
-/**
- * \def U_STANDARD_CPP_NAMESPACE
- * Control of C++ Namespace
- * @stable ICU 2.0
- */
-#ifdef __cplusplus
-#define U_STANDARD_CPP_NAMESPACE        ::
-#else
-#define U_STANDARD_CPP_NAMESPACE
-#endif
-
-
-/*===========================================================================*/
-/* Global delete operator                                                    */
-/*===========================================================================*/
-
-/*
- * The ICU4C library must not use the global new and delete operators.
- * These operators here are defined to enable testing for this.
- * See Jitterbug 2581 for details of why this is necessary.
- *
- * Verification that ICU4C's memory usage is correct, i.e.,
- * that global new/delete are not used:
- *
- * a) Check for imports of global new/delete (see uobject.cpp for details)
- * b) Verify that new is never imported.
- * c) Verify that delete is only imported from object code for interface/mixin classes.
- * d) Add global delete and delete[] only for the ICU4C library itself
- *    and define them in a way that crashes or otherwise easily shows a problem.
- *
- * The following implements d).
- * The operator implementations crash; this is intentional and used for library debugging.
- *
- * Note: This is currently only done on Windows because
- * some Linux/Unix compilers have problems with defining global new/delete.
- * On Windows, U_WINDOWS is defined, and it is _MSC_VER>=1200 for MSVC 6.0 and higher.
- */
-#if defined(XP_CPLUSPLUS) && defined(U_WINDOWS) && U_DEBUG && U_OVERRIDE_CXX_ALLOCATION && (_MSC_VER>=1200) && !defined(U_STATIC_IMPLEMENTATION) && (defined(U_COMMON_IMPLEMENTATION) || defined(U_I18N_IMPLEMENTATION) || defined(U_IO_IMPLEMENTATION) || defined(U_LAYOUT_IMPLEMENTATION) || defined(U_LAYOUTEX_IMPLEMENTATION))
-
-#ifndef U_HIDE_INTERNAL_API
-/**
- * Global operator new, defined only inside ICU4C, must not be used.
- * Crashes intentionally.
- * @internal
- */
-inline void *
-operator new(size_t /*size*/) {
-    char *q=NULL;
-    *q=5; /* break it */
-    return q;
-}
-
-#ifdef _Ret_bytecap_
-/* This is only needed to suppress a Visual C++ 2008 warning for operator new[]. */
-_Ret_bytecap_(_Size)
-#endif
-/**
- * Global operator new[], defined only inside ICU4C, must not be used.
- * Crashes intentionally.
- * @internal
- */
-inline void *
-operator new[](size_t /*size*/) {
-    char *q=NULL;
-    *q=5; /* break it */
-    return q;
-}
-
-/**
- * Global operator delete, defined only inside ICU4C, must not be used.
- * Crashes intentionally.
- * @internal
- */
-inline void
-operator delete(void * /*p*/) {
-    char *q=NULL;
-    *q=5; /* break it */
-}
-
-/**
- * Global operator delete[], defined only inside ICU4C, must not be used.
- * Crashes intentionally.
- * @internal
- */
-inline void
-operator delete[](void * /*p*/) {
-    char *q=NULL;
-    *q=5; /* break it */
-}
-
-#endif /* U_HIDE_INTERNAL_API */
-#endif
-
-/*===========================================================================*/
-/* UErrorCode */
-/*===========================================================================*/
-
-/**
- * Error code to replace exception handling, so that the code is compatible with all C++ compilers,
- * and to use the same mechanism for C and C++.
- *
- * \par
- * ICU functions that take a reference (C++) or a pointer (C) to a UErrorCode
- * first test if(U_FAILURE(errorCode)) { return immediately; }
- * so that in a chain of such functions the first one that sets an error code
- * causes the following ones to not perform any operations.
- *
- * \par
- * Error codes should be tested using U_FAILURE() and U_SUCCESS().
- * @stable ICU 2.0
- */
-typedef enum UErrorCode {
-    /* The ordering of U_ERROR_INFO_START Vs U_USING_FALLBACK_WARNING looks weird
-     * and is that way because VC++ debugger displays first encountered constant,
-     * which is not the what the code is used for
-     */
-
-    U_USING_FALLBACK_WARNING  = -128,   /**< A resource bundle lookup returned a fallback result (not an error) */
-
-    U_ERROR_WARNING_START     = -128,   /**< Start of information results (semantically successful) */
-
-    U_USING_DEFAULT_WARNING   = -127,   /**< A resource bundle lookup returned a result from the root locale (not an error) */
-
-    U_SAFECLONE_ALLOCATED_WARNING = -126, /**< A SafeClone operation required allocating memory (informational only) */
-
-    U_STATE_OLD_WARNING       = -125,   /**< ICU has to use compatibility layer to construct the service. Expect performance/memory usage degradation. Consider upgrading */
-
-    U_STRING_NOT_TERMINATED_WARNING = -124,/**< An output string could not be NUL-terminated because output length==destCapacity. */
-
-    U_SORT_KEY_TOO_SHORT_WARNING = -123, /**< Number of levels requested in getBound is higher than the number of levels in the sort key */
-
-    U_AMBIGUOUS_ALIAS_WARNING = -122,   /**< This converter alias can go to different converter implementations */
-
-    U_DIFFERENT_UCA_VERSION = -121,     /**< ucol_open encountered a mismatch between UCA version and collator image version, so the collator was constructed from rules. No impact to further function */
-
-    U_ERROR_WARNING_LIMIT,              /**< This must always be the last warning value to indicate the limit for UErrorCode warnings (last warning code +1) */
-
-
-    U_ZERO_ERROR              =  0,     /**< No error, no warning. */
-
-    U_ILLEGAL_ARGUMENT_ERROR  =  1,     /**< Start of codes indicating failure */
-    U_MISSING_RESOURCE_ERROR  =  2,     /**< The requested resource cannot be found */
-    U_INVALID_FORMAT_ERROR    =  3,     /**< Data format is not what is expected */
-    U_FILE_ACCESS_ERROR       =  4,     /**< The requested file cannot be found */
-    U_INTERNAL_PROGRAM_ERROR  =  5,     /**< Indicates a bug in the library code */
-    U_MESSAGE_PARSE_ERROR     =  6,     /**< Unable to parse a message (message format) */
-    U_MEMORY_ALLOCATION_ERROR =  7,     /**< Memory allocation error */
-    U_INDEX_OUTOFBOUNDS_ERROR =  8,     /**< Trying to access the index that is out of bounds */
-    U_PARSE_ERROR             =  9,     /**< Equivalent to Java ParseException */
-    U_INVALID_CHAR_FOUND      = 10,     /**< Character conversion: Unmappable input sequence. In other APIs: Invalid character. */
-    U_TRUNCATED_CHAR_FOUND    = 11,     /**< Character conversion: Incomplete input sequence. */
-    U_ILLEGAL_CHAR_FOUND      = 12,     /**< Character conversion: Illegal input sequence/combination of input units. */
-    U_INVALID_TABLE_FORMAT    = 13,     /**< Conversion table file found, but corrupted */
-    U_INVALID_TABLE_FILE      = 14,     /**< Conversion table file not found */
-    U_BUFFER_OVERFLOW_ERROR   = 15,     /**< A result would not fit in the supplied buffer */
-    U_UNSUPPORTED_ERROR       = 16,     /**< Requested operation not supported in current context */
-    U_RESOURCE_TYPE_MISMATCH  = 17,     /**< an operation is requested over a resource that does not support it */
-    U_ILLEGAL_ESCAPE_SEQUENCE = 18,     /**< ISO-2022 illlegal escape sequence */
-    U_UNSUPPORTED_ESCAPE_SEQUENCE = 19, /**< ISO-2022 unsupported escape sequence */
-    U_NO_SPACE_AVAILABLE      = 20,     /**< No space available for in-buffer expansion for Arabic shaping */
-    U_CE_NOT_FOUND_ERROR      = 21,     /**< Currently used only while setting variable top, but can be used generally */
-    U_PRIMARY_TOO_LONG_ERROR  = 22,     /**< User tried to set variable top to a primary that is longer than two bytes */
-    U_STATE_TOO_OLD_ERROR     = 23,     /**< ICU cannot construct a service from this state, as it is no longer supported */
-    U_TOO_MANY_ALIASES_ERROR  = 24,     /**< There are too many aliases in the path to the requested resource.
-                                             It is very possible that a circular alias definition has occured */
-    U_ENUM_OUT_OF_SYNC_ERROR  = 25,     /**< UEnumeration out of sync with underlying collection */
-    U_INVARIANT_CONVERSION_ERROR = 26,  /**< Unable to convert a UChar* string to char* with the invariant converter. */
-    U_INVALID_STATE_ERROR     = 27,     /**< Requested operation can not be completed with ICU in its current state */
-    U_COLLATOR_VERSION_MISMATCH = 28,   /**< Collator version is not compatible with the base version */
-    U_USELESS_COLLATOR_ERROR  = 29,     /**< Collator is options only and no base is specified */
-    U_NO_WRITE_PERMISSION     = 30,     /**< Attempt to modify read-only or constant data. */
-
-    U_STANDARD_ERROR_LIMIT,             /**< This must always be the last value to indicate the limit for standard errors */
-    /*
-     * the error code range 0x10000 0x10100 are reserved for Transliterator
-     */
-    U_BAD_VARIABLE_DEFINITION=0x10000,/**< Missing '$' or duplicate variable name */
-    U_PARSE_ERROR_START = 0x10000,    /**< Start of Transliterator errors */
-    U_MALFORMED_RULE,                 /**< Elements of a rule are misplaced */
-    U_MALFORMED_SET,                  /**< A UnicodeSet pattern is invalid*/
-    U_MALFORMED_SYMBOL_REFERENCE,     /**< UNUSED as of ICU 2.4 */
-    U_MALFORMED_UNICODE_ESCAPE,       /**< A Unicode escape pattern is invalid*/
-    U_MALFORMED_VARIABLE_DEFINITION,  /**< A variable definition is invalid */
-    U_MALFORMED_VARIABLE_REFERENCE,   /**< A variable reference is invalid */
-    U_MISMATCHED_SEGMENT_DELIMITERS,  /**< UNUSED as of ICU 2.4 */
-    U_MISPLACED_ANCHOR_START,         /**< A start anchor appears at an illegal position */
-    U_MISPLACED_CURSOR_OFFSET,        /**< A cursor offset occurs at an illegal position */
-    U_MISPLACED_QUANTIFIER,           /**< A quantifier appears after a segment close delimiter */
-    U_MISSING_OPERATOR,               /**< A rule contains no operator */
-    U_MISSING_SEGMENT_CLOSE,          /**< UNUSED as of ICU 2.4 */
-    U_MULTIPLE_ANTE_CONTEXTS,         /**< More than one ante context */
-    U_MULTIPLE_CURSORS,               /**< More than one cursor */
-    U_MULTIPLE_POST_CONTEXTS,         /**< More than one post context */
-    U_TRAILING_BACKSLASH,             /**< A dangling backslash */
-    U_UNDEFINED_SEGMENT_REFERENCE,    /**< A segment reference does not correspond to a defined segment */
-    U_UNDEFINED_VARIABLE,             /**< A variable reference does not correspond to a defined variable */
-    U_UNQUOTED_SPECIAL,               /**< A special character was not quoted or escaped */
-    U_UNTERMINATED_QUOTE,             /**< A closing single quote is missing */
-    U_RULE_MASK_ERROR,                /**< A rule is hidden by an earlier more general rule */
-    U_MISPLACED_COMPOUND_FILTER,      /**< A compound filter is in an invalid location */
-    U_MULTIPLE_COMPOUND_FILTERS,      /**< More than one compound filter */
-    U_INVALID_RBT_SYNTAX,             /**< A "::id" rule was passed to the RuleBasedTransliterator parser */
-    U_INVALID_PROPERTY_PATTERN,       /**< UNUSED as of ICU 2.4 */
-    U_MALFORMED_PRAGMA,               /**< A 'use' pragma is invlalid */
-    U_UNCLOSED_SEGMENT,               /**< A closing ')' is missing */
-    U_ILLEGAL_CHAR_IN_SEGMENT,        /**< UNUSED as of ICU 2.4 */
-    U_VARIABLE_RANGE_EXHAUSTED,       /**< Too many stand-ins generated for the given variable range */
-    U_VARIABLE_RANGE_OVERLAP,         /**< The variable range overlaps characters used in rules */
-    U_ILLEGAL_CHARACTER,              /**< A special character is outside its allowed context */
-    U_INTERNAL_TRANSLITERATOR_ERROR,  /**< Internal transliterator system error */
-    U_INVALID_ID,                     /**< A "::id" rule specifies an unknown transliterator */
-    U_INVALID_FUNCTION,               /**< A "&fn()" rule specifies an unknown transliterator */
-    U_PARSE_ERROR_LIMIT,              /**< The limit for Transliterator errors */
-
-    /*
-     * the error code range 0x10100 0x10200 are reserved for formatting API parsing error
-     */
-    U_UNEXPECTED_TOKEN=0x10100,       /**< Syntax error in format pattern */
-    U_FMT_PARSE_ERROR_START=0x10100,  /**< Start of format library errors */
-    U_MULTIPLE_DECIMAL_SEPARATORS,    /**< More than one decimal separator in number pattern */
-    U_MULTIPLE_DECIMAL_SEPERATORS = U_MULTIPLE_DECIMAL_SEPARATORS, /**< Typo: kept for backward compatibility. Use U_MULTIPLE_DECIMAL_SEPARATORS */
-    U_MULTIPLE_EXPONENTIAL_SYMBOLS,   /**< More than one exponent symbol in number pattern */
-    U_MALFORMED_EXPONENTIAL_PATTERN,  /**< Grouping symbol in exponent pattern */
-    U_MULTIPLE_PERCENT_SYMBOLS,       /**< More than one percent symbol in number pattern */
-    U_MULTIPLE_PERMILL_SYMBOLS,       /**< More than one permill symbol in number pattern */
-    U_MULTIPLE_PAD_SPECIFIERS,        /**< More than one pad symbol in number pattern */
-    U_PATTERN_SYNTAX_ERROR,           /**< Syntax error in format pattern */
-    U_ILLEGAL_PAD_POSITION,           /**< Pad symbol misplaced in number pattern */
-    U_UNMATCHED_BRACES,               /**< Braces do not match in message pattern */
-    U_UNSUPPORTED_PROPERTY,           /**< UNUSED as of ICU 2.4 */
-    U_UNSUPPORTED_ATTRIBUTE,          /**< UNUSED as of ICU 2.4 */
-    U_ARGUMENT_TYPE_MISMATCH,         /**< Argument name and argument index mismatch in MessageFormat functions */
-    U_DUPLICATE_KEYWORD,              /**< Duplicate keyword in PluralFormat */
-    U_UNDEFINED_KEYWORD,              /**< Undefined Pluarl keyword */
-    U_DEFAULT_KEYWORD_MISSING,        /**< Missing DEFAULT rule in plural rules */
-    U_FMT_PARSE_ERROR_LIMIT,          /**< The limit for format library errors */
-
-    /*
-     * the error code range 0x10200 0x102ff are reserved for Break Iterator related error
-     */
-    U_BRK_INTERNAL_ERROR=0x10200,          /**< An internal error (bug) was detected.             */
-    U_BRK_ERROR_START=0x10200,             /**< Start of codes indicating Break Iterator failures */
-    U_BRK_HEX_DIGITS_EXPECTED,             /**< Hex digits expected as part of a escaped char in a rule. */
-    U_BRK_SEMICOLON_EXPECTED,              /**< Missing ';' at the end of a RBBI rule.            */
-    U_BRK_RULE_SYNTAX,                     /**< Syntax error in RBBI rule.                        */
-    U_BRK_UNCLOSED_SET,                    /**< UnicodeSet witing an RBBI rule missing a closing ']'.  */
-    U_BRK_ASSIGN_ERROR,                    /**< Syntax error in RBBI rule assignment statement.   */
-    U_BRK_VARIABLE_REDFINITION,            /**< RBBI rule $Variable redefined.                    */
-    U_BRK_MISMATCHED_PAREN,                /**< Mis-matched parentheses in an RBBI rule.          */
-    U_BRK_NEW_LINE_IN_QUOTED_STRING,       /**< Missing closing quote in an RBBI rule.            */
-    U_BRK_UNDEFINED_VARIABLE,              /**< Use of an undefined $Variable in an RBBI rule.    */
-    U_BRK_INIT_ERROR,                      /**< Initialization failure.  Probable missing ICU Data. */
-    U_BRK_RULE_EMPTY_SET,                  /**< Rule contains an empty Unicode Set.               */
-    U_BRK_UNRECOGNIZED_OPTION,             /**< !!option in RBBI rules not recognized.            */
-    U_BRK_MALFORMED_RULE_TAG,              /**< The {nnn} tag on a rule is mal formed             */
-    U_BRK_ERROR_LIMIT,                     /**< This must always be the last value to indicate the limit for Break Iterator failures */
-
-    /*
-     * The error codes in the range 0x10300-0x103ff are reserved for regular expression related errrs
-     */
-    U_REGEX_INTERNAL_ERROR=0x10300,       /**< An internal error (bug) was detected.              */
-    U_REGEX_ERROR_START=0x10300,          /**< Start of codes indicating Regexp failures          */
-    U_REGEX_RULE_SYNTAX,                  /**< Syntax error in regexp pattern.                    */
-    U_REGEX_INVALID_STATE,                /**< RegexMatcher in invalid state for requested operation */
-    U_REGEX_BAD_ESCAPE_SEQUENCE,          /**< Unrecognized backslash escape sequence in pattern  */
-    U_REGEX_PROPERTY_SYNTAX,              /**< Incorrect Unicode property                         */
-    U_REGEX_UNIMPLEMENTED,                /**< Use of regexp feature that is not yet implemented. */
-    U_REGEX_MISMATCHED_PAREN,             /**< Incorrectly nested parentheses in regexp pattern.  */
-    U_REGEX_NUMBER_TOO_BIG,               /**< Decimal number is too large.                       */
-    U_REGEX_BAD_INTERVAL,                 /**< Error in {min,max} interval                        */
-    U_REGEX_MAX_LT_MIN,                   /**< In {min,max}, max is less than min.                */
-    U_REGEX_INVALID_BACK_REF,             /**< Back-reference to a non-existent capture group.    */
-    U_REGEX_INVALID_FLAG,                 /**< Invalid value for match mode flags.                */
-    U_REGEX_LOOK_BEHIND_LIMIT,            /**< Look-Behind pattern matches must have a bounded maximum length.    */
-    U_REGEX_SET_CONTAINS_STRING,          /**< Regexps cannot have UnicodeSets containing strings.*/
-    U_REGEX_OCTAL_TOO_BIG,                /**< Octal character constants must be <= 0377.         */
-    U_REGEX_MISSING_CLOSE_BRACKET,        /**< Missing closing bracket on a bracket expression.   */
-    U_REGEX_INVALID_RANGE,                /**< In a character range [x-y], x is greater than y.   */
-    U_REGEX_STACK_OVERFLOW,               /**< Regular expression backtrack stack overflow.       */
-    U_REGEX_TIME_OUT,                     /**< Maximum allowed match time exceeded                */
-    U_REGEX_STOPPED_BY_CALLER,            /**< Matching operation aborted by user callback fn.    */
-    U_REGEX_ERROR_LIMIT,                  /**< This must always be the last value to indicate the limit for regexp errors */
-
-    /*
-     * The error code in the range 0x10400-0x104ff are reserved for IDNA related error codes
-     */
-    U_IDNA_PROHIBITED_ERROR=0x10400,
-    U_IDNA_ERROR_START=0x10400,
-    U_IDNA_UNASSIGNED_ERROR,
-    U_IDNA_CHECK_BIDI_ERROR,
-    U_IDNA_STD3_ASCII_RULES_ERROR,
-    U_IDNA_ACE_PREFIX_ERROR,
-    U_IDNA_VERIFICATION_ERROR,
-    U_IDNA_LABEL_TOO_LONG_ERROR,
-    U_IDNA_ZERO_LENGTH_LABEL_ERROR,
-    U_IDNA_DOMAIN_NAME_TOO_LONG_ERROR,
-    U_IDNA_ERROR_LIMIT,
-    /*
-     * Aliases for StringPrep
-     */
-    U_STRINGPREP_PROHIBITED_ERROR = U_IDNA_PROHIBITED_ERROR,
-    U_STRINGPREP_UNASSIGNED_ERROR = U_IDNA_UNASSIGNED_ERROR,
-    U_STRINGPREP_CHECK_BIDI_ERROR = U_IDNA_CHECK_BIDI_ERROR,
-
-
-    U_ERROR_LIMIT=U_IDNA_ERROR_LIMIT      /**< This must always be the last value to indicate the limit for UErrorCode (last error code +1) */
-} UErrorCode;
-
-/* Use the following to determine if an UErrorCode represents */
-/* operational success or failure. */
-
-#ifdef XP_CPLUSPLUS
-    /**
-     * Does the error code indicate success?
-     * @stable ICU 2.0
-     */
-    static
-    inline UBool U_SUCCESS(UErrorCode code) { return (UBool)(code<=U_ZERO_ERROR); }
-    /**
-     * Does the error code indicate a failure?
-     * @stable ICU 2.0
-     */
-    static
-    inline UBool U_FAILURE(UErrorCode code) { return (UBool)(code>U_ZERO_ERROR); }
-#else
-    /**
-     * Does the error code indicate success?
-     * @stable ICU 2.0
-     */
-#   define U_SUCCESS(x) ((x)<=U_ZERO_ERROR)
-    /**
-     * Does the error code indicate a failure?
-     * @stable ICU 2.0
-     */
-#   define U_FAILURE(x) ((x)>U_ZERO_ERROR)
-#endif
-
-/**
- * Return a string for a UErrorCode value.
- * The string will be the same as the name of the error code constant
- * in the UErrorCode enum above.
- * @stable ICU 2.0
- */
-U_STABLE const char * U_EXPORT2
-u_errorName(UErrorCode code);
-
-
-#endif /* _UTYPES */

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/uversion.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/uversion.h b/apps/couch_collate/platform/osx/icu/unicode/uversion.h
deleted file mode 100644
index 5bf7fda..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/uversion.h
+++ /dev/null
@@ -1,275 +0,0 @@
-/*
-*******************************************************************************
-*   Copyright (C) 2000-2008, International Business Machines
-*   Corporation and others.  All Rights Reserved.
-*******************************************************************************
-*
-*   file name:  uversion.h
-*   encoding:   US-ASCII
-*   tab size:   8 (not used)
-*   indentation:4
-*
-*   Created by: Vladimir Weinstein
-*
-*  Contains all the important version numbers for ICU. 
-*  Gets included by utypes.h and Windows .rc files
-*/
-
-/**
- * \file
- * \brief C API: Contains all the important version numbers for ICU. 
- */
-/*===========================================================================*/
-/* Main ICU version information                                              */
-/*===========================================================================*/
-
-#ifndef UVERSION_H
-#define UVERSION_H
-
-/**
- * IMPORTANT: When updating version, the following things need to be done:
- * source/common/unicode/uversion.h - this file: update major, minor,
- *        patchlevel, suffix, version, short version constants, namespace,
- *                                                             and copyright
- * source/common/common.vcproj - update 'Output file name' on the link tab so
- *                   that it contains the new major/minor combination
- * source/i18n/i18n.vcproj - same as for the common.vcproj
- * source/layout/layout.vcproj - same as for the common.vcproj
- * source/layoutex/layoutex.vcproj - same
- * source/stubdata/stubdata.vcproj - same as for the common.vcproj
- * source/io/io.vcproj - same as for the common.vcproj
- * source/data/makedata.mak - change U_ICUDATA_NAME so that it contains
- *                            the new major/minor combination
- * source/tools/genren/genren.pl - use this script according to the README
- *                    in that folder                                         
- */
-
-#include "unicode/umachine.h"
-
-/** The standard copyright notice that gets compiled into each library. 
- *  This value will change in the subsequent releases of ICU
- *  @stable ICU 2.4
- */
-#define U_COPYRIGHT_STRING \
-  " Copyright (C) 2008, International Business Machines Corporation and others. All Rights Reserved. "
-
-/** Maximum length of the copyright string.
- *  @stable ICU 2.4
- */
-#define U_COPYRIGHT_STRING_LENGTH  128
-
-/** The current ICU major version as an integer. 
- *  This value will change in the subsequent releases of ICU
- *  @stable ICU 2.4
- */
-#define U_ICU_VERSION_MAJOR_NUM 4
-
-/** The current ICU minor version as an integer. 
- *  This value will change in the subsequent releases of ICU
- *  @stable ICU 2.6
- */
-#define U_ICU_VERSION_MINOR_NUM 0
-
-/** The current ICU patchlevel version as an integer.  
- *  This value will change in the subsequent releases of ICU
- *  @stable ICU 2.4
- */
-#define U_ICU_VERSION_PATCHLEVEL_NUM 0
-
-/** The current ICU build level version as an integer.  
- *  This value is for use by ICU clients. It defaults to 0.
- *  @draft ICU 4.0
- */
-#ifndef U_ICU_VERSION_BUILDLEVEL_NUM
-#define U_ICU_VERSION_BUILDLEVEL_NUM 0
-#endif
-
-/** Glued version suffix for renamers 
- *  This value will change in the subsequent releases of ICU
- *  @stable ICU 2.6
- */
-#define U_ICU_VERSION_SUFFIX _4_0
-
-/** The current ICU library version as a dotted-decimal string. The patchlevel
- *  only appears in this string if it non-zero. 
- *  This value will change in the subsequent releases of ICU
- *  @stable ICU 2.4
- */
-#define U_ICU_VERSION "4.0"
-
-/** The current ICU library major/minor version as a string without dots, for library name suffixes. 
- *  This value will change in the subsequent releases of ICU
- *  @stable ICU 2.6
- */
-#define U_ICU_VERSION_SHORT "40"
-
-/** An ICU version consists of up to 4 numbers from 0..255.
- *  @stable ICU 2.4
- */
-#define U_MAX_VERSION_LENGTH 4
-
-/** In a string, ICU version fields are delimited by dots.
- *  @stable ICU 2.4
- */
-#define U_VERSION_DELIMITER '.'
-
-/** The maximum length of an ICU version string.
- *  @stable ICU 2.4
- */
-#define U_MAX_VERSION_STRING_LENGTH 20
-
-/** The binary form of a version on ICU APIs is an array of 4 uint8_t.
- *  @stable ICU 2.4
- */
-typedef uint8_t UVersionInfo[U_MAX_VERSION_LENGTH];
-
-/*===========================================================================*/
-/* C++ namespace if supported. Versioned unless versioning is disabled.      */
-/*===========================================================================*/
-
-/**
- * \def U_NAMESPACE_BEGIN
- * This is used to begin a declaration of a public ICU C++ API.
- * If the compiler doesn't support namespaces, this does nothing.
- * @stable ICU 2.4
- */
-
-/**
- * \def U_NAMESPACE_END
- * This is used to end a declaration of a public ICU C++ API 
- * If the compiler doesn't support namespaces, this does nothing.
- * @stable ICU 2.4
- */
-
-/**
- * \def U_NAMESPACE_USE
- * This is used to specify that the rest of the code uses the
- * public ICU C++ API namespace.
- * If the compiler doesn't support namespaces, this does nothing.
- * @stable ICU 2.4
- */
-
-/**
- * \def U_NAMESPACE_QUALIFIER
- * This is used to qualify that a function or class is part of
- * the public ICU C++ API namespace.
- * If the compiler doesn't support namespaces, this does nothing.
- * @stable ICU 2.4
- */
-
-/* Define namespace symbols if the compiler supports it. */
-#if U_HAVE_NAMESPACE && defined(XP_CPLUSPLUS)
-#   if U_DISABLE_RENAMING
-#       define U_ICU_NAMESPACE icu
-        namespace U_ICU_NAMESPACE { }
-#   else
-#       define U_ICU_NAMESPACE icu_4_0
-        namespace U_ICU_NAMESPACE { }
-        namespace icu = U_ICU_NAMESPACE;
-#   endif
-
-#   define U_NAMESPACE_BEGIN namespace U_ICU_NAMESPACE {
-#   define U_NAMESPACE_END  }
-#   define U_NAMESPACE_USE using namespace U_ICU_NAMESPACE;
-#   define U_NAMESPACE_QUALIFIER U_ICU_NAMESPACE::
-
-#   ifndef U_USING_ICU_NAMESPACE
-#       define U_USING_ICU_NAMESPACE 1
-#   endif
-#   if U_USING_ICU_NAMESPACE
-        U_NAMESPACE_USE
-#   endif
-#else
-#   define U_NAMESPACE_BEGIN
-#   define U_NAMESPACE_END
-#   define U_NAMESPACE_USE
-#   define U_NAMESPACE_QUALIFIER
-#endif
-
-
-/*===========================================================================*/
-/* General version helper functions. Definitions in putil.c                  */
-/*===========================================================================*/
-
-/**
- * Parse a string with dotted-decimal version information and
- * fill in a UVersionInfo structure with the result.
- * Definition of this function lives in putil.c
- *
- * @param versionArray The destination structure for the version information.
- * @param versionString A string with dotted-decimal version information,
- *                      with up to four non-negative number fields with
- *                      values of up to 255 each.
- * @stable ICU 2.4
- */
-U_STABLE void U_EXPORT2
-u_versionFromString(UVersionInfo versionArray, const char *versionString);
-
-/**
- * Write a string with dotted-decimal version information according
- * to the input UVersionInfo.
- * Definition of this function lives in putil.c
- *
- * @param versionArray The version information to be written as a string.
- * @param versionString A string buffer that will be filled in with
- *                      a string corresponding to the numeric version
- *                      information in versionArray.
- *                      The buffer size must be at least U_MAX_VERSION_STRING_LENGTH.
- * @stable ICU 2.4
- */
-U_STABLE void U_EXPORT2
-u_versionToString(UVersionInfo versionArray, char *versionString);
-
-/**
- * Gets the ICU release version.  The version array stores the version information
- * for ICU.  For example, release "1.3.31.2" is then represented as 0x01031F02.
- * Definition of this function lives in putil.c
- *
- * @param versionArray the version # information, the result will be filled in
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2
-u_getVersion(UVersionInfo versionArray);
-
-
-/*===========================================================================
- * ICU collation framework version information                               
- * Version info that can be obtained from a collator is affected by these    
- * numbers in a secret and magic way. Please use collator version as whole
- *===========================================================================
- */
-
-/** Collation runtime version (sort key generator, strcoll). 
- * If the version is different, sortkeys for the same string could be different 
- * version 2 was in ICU 1.8.1. changed is: compression intervals, French secondary 
- * compression, generating quad level always when strength is quad or more 
- * version 4 - ICU 2.2 - tracking UCA changes, ignore completely ignorables 
- * in contractions, ignore primary ignorables after shifted 
- * version 5 - ICU 2.8 - changed implicit generation code
- * version 6 - ICU 3.4 - with the UCA 4.1, Thai tag is no longer generated or used
- * This value may change in the subsequent releases of ICU
- * @stable ICU 2.4
- */
-#define UCOL_RUNTIME_VERSION 6
-
-/** Builder code version. When this is different, same tailoring might result
- * in assigning different collation elements to code points                  
- * version 2 was in ICU 1.8.1. added support for prefixes, tweaked canonical 
- * closure. However, the tailorings should probably get same CEs assigned    
- * version 5 - ICU 2.2 - fixed some bugs, renamed some indirect values.      
- * version 6 - ICU 2.8 - fixed bug in builder that allowed 0xFF in primary values
- * version 7 - ICU 3.4 - with the UCA 4.1 Thai tag is no longer processed, complete ignorables
- *                       now break contractions
- * Backward compatible with the old rules. 
- * This value may change in the subsequent releases of ICU
- * @stable ICU 2.4
- */
-#define UCOL_BUILDER_VERSION 7
-
-/** This is the version of the tailorings 
- *  This value may change in the subsequent releases of ICU
- *  @stable ICU 2.4
- */
-#define UCOL_TAILORINGS_VERSION 1
-
-#endif


[04/57] [abbrv] remove couch_collate

Posted by be...@apache.org.
http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/utext.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/utext.h b/apps/couch_collate/platform/osx/icu/unicode/utext.h
deleted file mode 100644
index 866b850..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/utext.h
+++ /dev/null
@@ -1,1562 +0,0 @@
-/*
-*******************************************************************************
-*
-*   Copyright (C) 2004-2008, International Business Machines
-*   Corporation and others.  All Rights Reserved.
-*
-*******************************************************************************
-*   file name:  utext.h
-*   encoding:   US-ASCII
-*   tab size:   8 (not used)
-*   indentation:4
-*
-*   created on: 2004oct06
-*   created by: Markus W. Scherer
-*/
-
-#ifndef __UTEXT_H__
-#define __UTEXT_H__
-
-/**
- * \file
- * \brief C API: Abstract Unicode Text API
- *
- * The Text Access API provides a means to allow text that is stored in alternative
- * formats to work with ICU services.  ICU normally operates on text that is
- * stored in UTF-16 format, in (UChar *) arrays for the C APIs or as type
- * UnicodeString for C++ APIs.
- *
- * ICU Text Access allows other formats, such as UTF-8 or non-contiguous
- * UTF-16 strings, to be placed in a UText wrapper and then passed to ICU services.
- *
- * There are three general classes of usage for UText:
- *
- *     Application Level Use.  This is the simplest usage - applications would
- *     use one of the utext_open() functions on their input text, and pass
- *     the resulting UText to the desired ICU service.
- *
- *     Second is usage in ICU Services, such as break iteration, that will need to
- *     operate on input presented to them as a UText.  These implementations
- *     will need to use the iteration and related UText functions to gain
- *     access to the actual text.
- *
- *     The third class of UText users are "text providers."  These are the
- *     UText implementations for the various text storage formats.  An application
- *     or system with a unique text storage format can implement a set of
- *     UText provider functions for that format, which will then allow
- *     ICU services to operate on that format.
- *
- *
- * <em>Iterating over text</em>
- *
- * Here is sample code for a forward iteration over the contents of a UText
- *
- * \code
- *    UChar32  c;
- *    UText    *ut = whatever();
- *
- *    for (c=utext_next32From(ut, 0); c>=0; c=utext_next32(ut)) {
- *       // do whatever with the codepoint c here.
- *    }
- * \endcode
- *
- * And here is similar code to iterate in the reverse direction, from the end
- * of the text towards the beginning.
- *
- * \code
- *    UChar32  c;
- *    UText    *ut = whatever();
- *    int      textLength = utext_nativeLength(ut);
- *    for (c=utext_previous32From(ut, textLength); c>=0; c=utext_previous32(ut)) {
- *       // do whatever with the codepoint c here.
- *    }
- * \endcode
- *
- * <em>Characters and Indexing</em>
- *
- * Indexing into text by UText functions is nearly always in terms of the native
- * indexing of the underlying text storage.  The storage format could be UTF-8
- * or UTF-32, for example.  When coding to the UText access API, no assumptions
- * can be made regarding the size of characters, or how far an index
- * may move when iterating between characters.
- *
- * All indices supplied to UText functions are pinned to the length of the
- * text.  An out-of-bounds index is not considered to be an error, but is
- * adjusted to be in the range  0 <= index <= length of input text.
- *
- *
- * When an index position is returned from a UText function, it will be
- * a native index to the underlying text.  In the case of multi-unit characters,
- * it will  always refer to the first position of the character,
- * never to the interior.  This is essentially the same thing as saying that
- * a returned index will always point to a boundary between characters.
- *
- * When a native index is supplied to a UText function, all indices that
- * refer to any part of a multi-unit character representation are considered
- * to be equivalent.  In the case of multi-unit characters, an incoming index
- * will be logically normalized to refer to the start of the character.
- * 
- * It is possible to test whether a native index is on a code point boundary
- * by doing a utext_setNativeIndex() followed by a utext_getNativeIndex().
- * If the index is returned unchanged, it was on a code point boundary.  If
- * an adjusted index is returned, the original index referred to the
- * interior of a character.
- *
- * <em>Conventions for calling UText functions</em>
- *
- * Most UText access functions have as their first parameter a (UText *) pointer,
- * which specifies the UText to be used.  Unless otherwise noted, the
- * pointer must refer to a valid, open UText.  Attempting to
- * use a closed UText or passing a NULL pointer is a programming error and
- * will produce undefined results or NULL pointer exceptions.
- * 
- * The UText_Open family of functions can either open an existing (closed)
- * UText, or heap allocate a new UText.  Here is sample code for creating
- * a stack-allocated UText.
- *
- * \code
- *    char     *s = whatever();  // A utf-8 string 
- *    U_ErrorCode status = U_ZERO_ERROR;
- *    UText    ut = UTEXT_INITIALIZER;
- *    utext_openUTF8(ut, s, -1, &status);
- *    if (U_FAILURE(status)) {
- *        // error handling
- *    } else {
- *        // work with the UText
- *    }
- * \endcode
- *
- * Any existing UText passed to an open function _must_ have been initialized, 
- * either by the UTEXT_INITIALIZER, or by having been originally heap-allocated
- * by an open function.  Passing NULL will cause the open function to
- * heap-allocate and fully initialize a new UText.
- *
- */
-
-
-
-#include "unicode/utypes.h"
-#ifdef XP_CPLUSPLUS
-#include "unicode/rep.h"
-#include "unicode/unistr.h"
-#include "unicode/chariter.h"
-#endif
-
-
-U_CDECL_BEGIN
-
-struct UText;
-typedef struct UText UText; /**< C typedef for struct UText. @stable ICU 3.6 */
-
-
-/***************************************************************************************
- *
- *   C Functions for creating UText wrappers around various kinds of text strings.
- *
- ****************************************************************************************/
-
-
-/**
-  * Close function for UText instances.
-  * Cleans up, releases any resources being held by an open UText.
-  * <p>
-  *   If the UText was originally allocated by one of the utext_open functions,
-  *   the storage associated with the utext will also be freed.
-  *   If the UText storage originated with the application, as it would with
-  *   a local or static instance, the storage will not be deleted.
-  *
-  *   An open UText can be reset to refer to new string by using one of the utext_open()
-  *   functions without first closing the UText.  
-  *
-  * @param ut  The UText to be closed.
-  * @return    NULL if the UText struct was deleted by the close.  If the UText struct
-  *            was originally provided by the caller to the open function, it is
-  *            returned by this function, and may be safely used again in
-  *            a subsequent utext_open.
-  *
-  * @stable ICU 3.4
-  */
-U_STABLE UText * U_EXPORT2
-utext_close(UText *ut);
-
-
-/**
- * Open a read-only UText implementation for UTF-8 strings.
- * 
- * \htmlonly
- * Any invalid UTF-8 in the input will be handled in this way:
- * a sequence of bytes that has the form of a truncated, but otherwise valid,
- * UTF-8 sequence will be replaced by a single unicode replacement character, \uFFFD. 
- * Any other illegal bytes will each be replaced by a \uFFFD.
- * \endhtmlonly
- * 
- * @param ut     Pointer to a UText struct.  If NULL, a new UText will be created.
- *               If non-NULL, must refer to an initialized UText struct, which will then
- *               be reset to reference the specified UTF-8 string.
- * @param s      A UTF-8 string.  Must not be NULL.
- * @param length The length of the UTF-8 string in bytes, or -1 if the string is
- *               zero terminated.
- * @param status Errors are returned here.
- * @return       A pointer to the UText.  If a pre-allocated UText was provided, it
- *               will always be used and returned.
- * @stable ICU 3.4
- */
-U_STABLE UText * U_EXPORT2
-utext_openUTF8(UText *ut, const char *s, int64_t length, UErrorCode *status);
-
-
-/**
- * Open a read-only UText for UChar * string.
- * 
- * @param ut     Pointer to a UText struct.  If NULL, a new UText will be created.
- *               If non-NULL, must refer to an initialized UText struct, which will then
- *               be reset to reference the specified UChar string.
- * @param s      A UChar (UTF-16) string
- * @param length The number of UChars in the input string, or -1 if the string is
- *               zero terminated.
- * @param status Errors are returned here.
- * @return       A pointer to the UText.  If a pre-allocated UText was provided, it
- *               will always be used and returned.
- * @stable ICU 3.4
- */
-U_STABLE UText * U_EXPORT2
-utext_openUChars(UText *ut, const UChar *s, int64_t length, UErrorCode *status);
-
-
-#ifdef XP_CPLUSPLUS
-/**
- * Open a writable UText for a non-const UnicodeString. 
- * 
- * @param ut      Pointer to a UText struct.  If NULL, a new UText will be created.
- *                 If non-NULL, must refer to an initialized UText struct, which will then
- *                 be reset to reference the specified input string.
- * @param s       A UnicodeString.
- * @param status Errors are returned here.
- * @return        Pointer to the UText.  If a UText was supplied as input, this
- *                 will always be used and returned.
- * @stable ICU 3.4
- */
-U_STABLE UText * U_EXPORT2
-utext_openUnicodeString(UText *ut, U_NAMESPACE_QUALIFIER UnicodeString *s, UErrorCode *status);
-
-
-/**
- * Open a UText for a const UnicodeString.   The resulting UText will not be writable.
- * 
- * @param ut    Pointer to a UText struct.  If NULL, a new UText will be created.
- *               If non-NULL, must refer to an initialized UText struct, which will then
- *               be reset to reference the specified input string.
- * @param s      A const UnicodeString to be wrapped.
- * @param status Errors are returned here.
- * @return       Pointer to the UText.  If a UText was supplied as input, this
- *               will always be used and returned.
- * @stable ICU 3.4
- */
-U_STABLE UText * U_EXPORT2
-utext_openConstUnicodeString(UText *ut, const U_NAMESPACE_QUALIFIER UnicodeString *s, UErrorCode *status);
-
-
-/**
- * Open a writable UText implementation for an ICU Replaceable object.
- * @param ut    Pointer to a UText struct.  If NULL, a new UText will be created.
- *               If non-NULL, must refer to an already existing UText, which will then
- *               be reset to reference the specified replaceable text.
- * @param rep    A Replaceable text object.
- * @param status Errors are returned here.
- * @return       Pointer to the UText.  If a UText was supplied as input, this
- *               will always be used and returned.
- * @see Replaceable
- * @stable ICU 3.4
- */
-U_STABLE UText * U_EXPORT2
-utext_openReplaceable(UText *ut, U_NAMESPACE_QUALIFIER Replaceable *rep, UErrorCode *status);
-
-/**
- * Open a  UText implementation over an ICU CharacterIterator.
- * @param ut    Pointer to a UText struct.  If NULL, a new UText will be created.
- *               If non-NULL, must refer to an already existing UText, which will then
- *               be reset to reference the specified replaceable text.
- * @param ci     A Character Iterator.
- * @param status Errors are returned here.
- * @return       Pointer to the UText.  If a UText was supplied as input, this
- *               will always be used and returned.
- * @see Replaceable
- * @stable ICU 3.4
- */
-U_STABLE UText * U_EXPORT2
-utext_openCharacterIterator(UText *ut, U_NAMESPACE_QUALIFIER CharacterIterator *ic, UErrorCode *status);
-
-#endif
-
-
-/**
-  *  Clone a UText.  This is much like opening a UText where the source text is itself
-  *  another UText.
-  *
-  *  A deep clone will copy both the UText data structures and the underlying text.
-  *  The original and cloned UText will operate completely independently; modifications
-  *  made to the text in one will not affect the other.  Text providers are not
-  *  required to support deep clones.  The user of clone() must check the status return
-  *  and be prepared to handle failures.
-  *
-  *  The standard UText implementations for UTF8, UChar *, UnicodeString and
-  *  Replaceable all support deep cloning.
-  *
-  *  The UText returned from a deep clone will be writable, assuming that the text
-  *  provider is able to support writing, even if the source UText had been made
-  *  non-writable by means of UText_freeze().
-  *
-  *  A shallow clone replicates only the UText data structures; it does not make
-  *  a copy of the underlying text.  Shallow clones can be used as an efficient way to 
-  *  have multiple iterators active in a single text string that is not being
-  *  modified.
-  *
-  *  A shallow clone operation will not fail, barring truly exceptional conditions such
-  *  as memory allocation failures.
-  *
-  *  Shallow UText clones should be avoided if the UText functions that modify the
-  *  text are expected to be used, either on the original or the cloned UText.
-  *  Any such modifications  can cause unpredictable behavior.  Read Only
-  *  shallow clones provide some protection against errors of this type by
-  *  disabling text modification via the cloned UText.
-  *
-  *  A shallow clone made with the readOnly parameter == FALSE will preserve the 
-  *  utext_isWritable() state of the source object.  Note, however, that
-  *  write operations must be avoided while more than one UText exists that refer
-  *  to the same underlying text.
-  *
-  *  A UText and its clone may be safely concurrently accessed by separate threads.
-  *  This is true for read access only with shallow clones, and for both read and
-  *  write access with deep clones.
-  *  It is the responsibility of the Text Provider to ensure that this thread safety
-  *  constraint is met.
-  *
-  *  @param dest   A UText struct to be filled in with the result of the clone operation,
-  *                or NULL if the clone function should heap-allocate a new UText struct.
-  *                If non-NULL, must refer to an already existing UText, which will then
-  *                be reset to become the clone.
-  *  @param src    The UText to be cloned.
-  *  @param deep   TRUE to request a deep clone, FALSE for a shallow clone.
-  *  @param readOnly TRUE to request that the cloned UText have read only access to the 
-  *                underlying text.  
-
-  *  @param status Errors are returned here.  For deep clones, U_UNSUPPORTED_ERROR
-  *                will be returned if the text provider is unable to clone the
-  *                original text.
-  *  @return       The newly created clone, or NULL if the clone operation failed.
-  *  @stable ICU 3.4
-  */
-U_STABLE UText * U_EXPORT2
-utext_clone(UText *dest, const UText *src, UBool deep, UBool readOnly, UErrorCode *status);
-
-
-/**
-  *  Compare two UText objects for equality.
-  *  UTexts are equal if they are iterating over the same text, and
-  *    have the same iteration position within the text.
-  *    If either or both of the parameters are NULL, the comparison is FALSE.
-  *
-  *  @param a   The first of the two UTexts to compare.
-  *  @param b   The other UText to be compared.
-  *  @return    TRUE if the two UTexts are equal.
-  *  @stable ICU 3.6
-  */
-U_STABLE UBool U_EXPORT2
-utext_equals(const UText *a, const UText *b);
-
-
-/*****************************************************************************
- *
- *   Functions to work with the text represeted by a UText wrapper
- *
- *****************************************************************************/
-
-/**
-  * Get the length of the text.  Depending on the characteristics
-  * of the underlying text representation, this may be expensive.  
-  * @see  utext_isLengthExpensive()
-  *
-  *
-  * @param ut  the text to be accessed.
-  * @return the length of the text, expressed in native units.
-  *
-  * @stable ICU 3.4
-  */
-U_STABLE int64_t U_EXPORT2
-utext_nativeLength(UText *ut);
-
-/**
- *  Return TRUE if calculating the length of the text could be expensive.
- *  Finding the length of NUL terminated strings is considered to be expensive.
- *
- *  Note that the value of this function may change
- *  as the result of other operations on a UText.
- *  Once the length of a string has been discovered, it will no longer
- *  be expensive to report it.
- *
- * @param ut the text to be accessed.
- * @return TRUE if determining the length of the text could be time consuming.
- * @stable ICU 3.4
- */
-U_STABLE UBool U_EXPORT2
-utext_isLengthExpensive(const UText *ut);
-
-/**
- * Returns the code point at the requested index,
- * or U_SENTINEL (-1) if it is out of bounds.
- *
- * If the specified index points to the interior of a multi-unit
- * character - one of the trail bytes of a UTF-8 sequence, for example -
- * the complete code point will be returned.
- *
- * The iteration position will be set to the start of the returned code point.
- *
- * This function is roughly equivalent to the the sequence
- *    utext_setNativeIndex(index);
- *    utext_current32();
- * (There is a subtle difference if the index is out of bounds by being less than zero - 
- * utext_setNativeIndex(negative value) sets the index to zero, after which utext_current()
- * will return the char at zero.  utext_char32At(negative index), on the other hand, will
- * return the U_SENTINEL value of -1.)
- * 
- * @param ut the text to be accessed
- * @param nativeIndex the native index of the character to be accessed.  If the index points
- *        to other than the first unit of a multi-unit character, it will be adjusted
- *        to the start of the character.
- * @return the code point at the specified index.
- * @stable ICU 3.4
- */
-U_STABLE UChar32 U_EXPORT2
-utext_char32At(UText *ut, int64_t nativeIndex);
-
-
-/**
- *
- * Get the code point at the current iteration position,
- * or U_SENTINEL (-1) if the iteration has reached the end of
- * the input text.
- *
- * @param ut the text to be accessed.
- * @return the Unicode code point at the current iterator position.
- * @stable ICU 3.4
- */
-U_STABLE UChar32 U_EXPORT2
-utext_current32(UText *ut);
-
-
-/**
- * Get the code point at the current iteration position of the UText, and
- * advance the position to the first index following the character.
- *
- * If the position is at the end of the text (the index following
- * the last character, which is also the length of the text), 
- * return U_SENTINEL (-1) and do not advance the index. 
- *
- * This is a post-increment operation.
- *
- * An inline macro version of this function, UTEXT_NEXT32(), 
- * is available for performance critical use.
- *
- * @param ut the text to be accessed.
- * @return the Unicode code point at the iteration position.
- * @see UTEXT_NEXT32
- * @stable ICU 3.4
- */
-U_STABLE UChar32 U_EXPORT2
-utext_next32(UText *ut);
-
-
-/**
- *  Move the iterator position to the character (code point) whose
- *  index precedes the current position, and return that character.
- *  This is a pre-decrement operation.
- *
- *  If the initial position is at the start of the text (index of 0) 
- *  return U_SENTINEL (-1), and leave the position unchanged.
- *
- *  An inline macro version of this function, UTEXT_PREVIOUS32(), 
- *  is available for performance critical use.
- *
- *  @param ut the text to be accessed.
- *  @return the previous UChar32 code point, or U_SENTINEL (-1) 
- *          if the iteration has reached the start of the text.
- *  @see UTEXT_PREVIOUS32
- *  @stable ICU 3.4
- */
-U_STABLE UChar32 U_EXPORT2
-utext_previous32(UText *ut);
-
-
-/**
-  * Set the iteration index and return the code point at that index. 
-  * Leave the iteration index at the start of the following code point.
-  *
-  * This function is the most efficient and convenient way to
-  * begin a forward iteration.  The results are identical to the those
-  * from the sequence
-  * \code
-  *    utext_setIndex();
-  *    utext_next32();
-  * \endcode
-  *
-  *  @param ut the text to be accessed.
-  *  @param nativeIndex Iteration index, in the native units of the text provider.
-  *  @return Code point which starts at or before index,
-  *         or U_SENTINEL (-1) if it is out of bounds.
-  * @stable ICU 3.4
-  */
-U_STABLE UChar32 U_EXPORT2
-utext_next32From(UText *ut, int64_t nativeIndex);
-
-
-
-/**
-  * Set the iteration index, and return the code point preceding the
-  * one specified by the initial index.  Leave the iteration position
-  * at the start of the returned code point.
-  *
-  * This function is the most efficient and convenient way to
-  * begin a backwards iteration.
-  *
-  * @param ut the text to be accessed.
-  * @param nativeIndex Iteration index in the native units of the text provider.
-  * @return Code point preceding the one at the initial index,
-  *         or U_SENTINEL (-1) if it is out of bounds.
-  *
-  * @stable ICU 3.4
-  */
-U_STABLE UChar32 U_EXPORT2
-utext_previous32From(UText *ut, int64_t nativeIndex);
-
-/**
-  * Get the current iterator position, which can range from 0 to 
-  * the length of the text.
-  * The position is a native index into the input text, in whatever format it
-  * may have (possibly UTF-8 for example), and may not always be the same as
-  * the corresponding UChar (UTF-16) index.
-  * The returned position will always be aligned to a code point boundary. 
-  *
-  * @param ut the text to be accessed.
-  * @return the current index position, in the native units of the text provider.
-  * @stable ICU 3.4
-  */
-U_STABLE int64_t U_EXPORT2
-utext_getNativeIndex(const UText *ut);
-
-/**
- * Set the current iteration position to the nearest code point
- * boundary at or preceding the specified index.
- * The index is in the native units of the original input text.
- * If the index is out of range, it will be pinned to be within
- * the range of the input text.
- * <p>
- * It will usually be more efficient to begin an iteration
- * using the functions utext_next32From() or utext_previous32From()
- * rather than setIndex().
- * <p>
- * Moving the index position to an adjacent character is best done
- * with utext_next32(), utext_previous32() or utext_moveIndex32().
- * Attempting to do direct arithmetic on the index position is
- * complicated by the fact that the size (in native units) of a
- * character depends on the underlying representation of the character
- * (UTF-8, UTF-16, UTF-32, arbitrary codepage), and is not
- * easily knowable.
- *
- * @param ut the text to be accessed.
- * @param nativeIndex the native unit index of the new iteration position.
- * @stable ICU 3.4
- */
-U_STABLE void U_EXPORT2
-utext_setNativeIndex(UText *ut, int64_t nativeIndex);
-
-/**
- * Move the iterator postion by delta code points.  The number of code points
- * is a signed number; a negative delta will move the iterator backwards,
- * towards the start of the text.
- * <p>
- * The index is moved by <code>delta</code> code points
- * forward or backward, but no further backward than to 0 and
- * no further forward than to utext_nativeLength().
- * The resulting index value will be in between 0 and length, inclusive.
- *
- * @param ut the text to be accessed.
- * @param delta the signed number of code points to move the iteration position.
- * @return TRUE if the position could be moved the requested number of positions while
- *              staying within the range [0 - text length].
- * @stable ICU 3.4
- */
-U_STABLE UBool U_EXPORT2
-utext_moveIndex32(UText *ut, int32_t delta);
-
-/**
- * Get the native index of the character preceeding the current position.
- * If the iteration position is already at the start of the text, zero
- * is returned.
- * The value returned is the same as that obtained from the following sequence,
- * but without the side effect of changing the iteration position.
- *   
- * \code
- *    UText  *ut = whatever;
- *      ...
- *    utext_previous(ut)
- *    utext_getNativeIndex(ut);
- * \endcode
- *
- * This function is most useful during forwards iteration, where it will get the
- *   native index of the character most recently returned from utext_next().
- *
- * @param ut the text to be accessed
- * @return the native index of the character preceeding the current index position,
- *         or zero if the current position is at the start of the text.
- * @stable ICU 3.6
- */
-U_STABLE int64_t U_EXPORT2
-utext_getPreviousNativeIndex(UText *ut); 
-
-
-/**
- *
- * Extract text from a UText into a UChar buffer.  The range of text to be extracted
- * is specified in the native indices of the UText provider.  These may not necessarily
- * be UTF-16 indices.
- * <p>
- * The size (number of 16 bit UChars) of the data to be extracted is returned.  The
- * full number of UChars is returned, even when the extracted text is truncated
- * because the specified buffer size is too small.
- * <p>
- * The extracted string will (if you are a user) / must (if you are a text provider)
- * be NUL-terminated if there is sufficient space in the destination buffer.  This
- * terminating NUL is not included in the returned length.
- * <p>
- * The iteration index is left at the position following the last extracted character.
- *
- * @param  ut    the UText from which to extract data.
- * @param  nativeStart the native index of the first character to extract.\
- *               If the specified index is out of range,
- *               it will be pinned to to be within 0 <= index <= textLength
- * @param  nativeLimit the native string index of the position following the last
- *               character to extract.  If the specified index is out of range,
- *               it will be pinned to to be within 0 <= index <= textLength.
- *               nativeLimit must be >= nativeStart.
- * @param  dest  the UChar (UTF-16) buffer into which the extracted text is placed
- * @param  destCapacity  The size, in UChars, of the destination buffer.  May be zero
- *               for precomputing the required size.
- * @param  status receives any error status.
- *         U_BUFFER_OVERFLOW_ERROR: the extracted text was truncated because the 
- *         buffer was too small.  Returns number of UChars for preflighting.
- * @return Number of UChars in the data to be extracted.  Does not include a trailing NUL.
- *
- * @stable ICU 3.4
- */
-U_STABLE int32_t U_EXPORT2
-utext_extract(UText *ut,
-             int64_t nativeStart, int64_t nativeLimit,
-             UChar *dest, int32_t destCapacity,
-             UErrorCode *status);
-
-
-/************************************************************************************
- *
- *  #define inline versions of selected performance-critical text access functions
- *          Caution:  do not use auto increment++ or decrement-- expressions
- *                    as parameters to these macros.
- *
- *          For most use, where there is no extreme performance constraint, the
- *          normal, non-inline functions are a better choice.  The resulting code
- *          will be smaller, and, if the need ever arises, easier to debug.
- *
- *          These are implemented as #defines rather than real functions
- *          because there is no fully portable way to do inline functions in plain C.
- *
- ************************************************************************************/
-
-/**
- * inline version of utext_next32(), for performance-critical situations.
- *
- * Get the code point at the current iteration position of the UText, and
- * advance the position to the first index following the character.
- * This is a post-increment operation.
- * Returns U_SENTINEL (-1) if the position is at the end of the
- * text.
- *
- * @stable ICU 3.4
- */
-#define UTEXT_NEXT32(ut)  \
-    ((ut)->chunkOffset < (ut)->chunkLength && ((ut)->chunkContents)[(ut)->chunkOffset]<0xd800 ? \
-    ((ut)->chunkContents)[((ut)->chunkOffset)++] : utext_next32(ut))
-
-/**
- * inline version of utext_previous32(), for performance-critical situations.
- *
- *  Move the iterator position to the character (code point) whose
- *  index precedes the current position, and return that character.
- *  This is a pre-decrement operation.
- *  Returns U_SENTINEL (-1) if the position is at the start of the  text.
- *
- * @stable ICU 3.4
- */
-#define UTEXT_PREVIOUS32(ut)  \
-    ((ut)->chunkOffset > 0 && \
-     (ut)->chunkContents[(ut)->chunkOffset-1] < 0xd800 ? \
-          (ut)->chunkContents[--((ut)->chunkOffset)]  :  utext_previous32(ut))
-
-/**
-  *  inline version of utext_getNativeIndex(), for performance-critical situations.
-  *
-  * Get the current iterator position, which can range from 0 to 
-  * the length of the text.
-  * The position is a native index into the input text, in whatever format it
-  * may have (possibly UTF-8 for example), and may not always be the same as
-  * the corresponding UChar (UTF-16) index.
-  * The returned position will always be aligned to a code point boundary. 
-  *
-  * @stable ICU 3.6
-  */
-#define UTEXT_GETNATIVEINDEX(ut)                       \
-    ((ut)->chunkOffset <= (ut)->nativeIndexingLimit?   \
-        (ut)->chunkNativeStart+(ut)->chunkOffset :     \
-        (ut)->pFuncs->mapOffsetToNative(ut))    
-
-/**
-  *  inline version of utext_setNativeIndex(), for performance-critical situations.
-  *
-  * Set the current iteration position to the nearest code point
-  * boundary at or preceding the specified index.
-  * The index is in the native units of the original input text.
-  * If the index is out of range, it will be pinned to be within
-  * the range of the input text.
-  *
-  * @stable ICU 4.0
-  */
-#define UTEXT_SETNATIVEINDEX(ut, ix)                       \
-    { int64_t __offset = (ix) - (ut)->chunkNativeStart; \
-      if (__offset>=0 && __offset<=(int64_t)(ut)->nativeIndexingLimit) { \
-          (ut)->chunkOffset=(int32_t)__offset; \
-      } else { \
-          utext_setNativeIndex((ut), (ix)); } }
-
-
-
-/************************************************************************************
- *
- *   Functions related to writing or modifying the text.
- *   These will work only with modifiable UTexts.  Attempting to
- *   modify a read-only UText will return an error status.
- *
- ************************************************************************************/
-
-
-/**
- *  Return TRUE if the text can be written (modified) with utext_replace() or
- *  utext_copy().  For the text to be writable, the text provider must
- *  be of a type that supports writing and the UText must not be frozen.
- *
- *  Attempting to modify text when utext_isWriteable() is FALSE will fail -
- *  the text will not be modified, and an error will be returned from the function
- *  that attempted the modification.
- *
- * @param  ut   the UText to be tested.
- * @return TRUE if the text is modifiable.
- *
- * @see    utext_freeze()
- * @see    utext_replace()
- * @see    utext_copy()
- * @stable ICU 3.4
- *
- */
-U_STABLE UBool U_EXPORT2
-utext_isWritable(const UText *ut);
-
-
-/**
-  * Test whether there is meta data associated with the text.
-  * @see Replaceable::hasMetaData()
-  *
-  * @param ut The UText to be tested
-  * @return TRUE if the underlying text includes meta data.
-  * @stable ICU 3.4
-  */
-U_STABLE UBool U_EXPORT2
-utext_hasMetaData(const UText *ut);
-
-
-/**
- * Replace a range of the original text with a replacement text.
- *
- * Leaves the current iteration position at the position following the
- *  newly inserted replacement text.
- *
- * This function is only available on UText types that support writing,
- * that is, ones where utext_isWritable() returns TRUE.
- *
- * When using this function, there should be only a single UText opened onto the
- * underlying native text string.  Behavior after a replace operation
- * on a UText is undefined for any other additional UTexts that refer to the
- * modified string.
- *
- * @param ut               the UText representing the text to be operated on.
- * @param nativeStart      the native index of the start of the region to be replaced
- * @param nativeLimit      the native index of the character following the region to be replaced.
- * @param replacementText  pointer to the replacement text
- * @param replacementLength length of the replacement text, or -1 if the text is NUL terminated.
- * @param status           receives any error status.  Possible errors include
- *                         U_NO_WRITE_PERMISSION
- *
- * @return The signed number of (native) storage units by which
- *         the length of the text expanded or contracted.
- *
- * @stable ICU 3.4
- */
-U_STABLE int32_t U_EXPORT2
-utext_replace(UText *ut,
-             int64_t nativeStart, int64_t nativeLimit,
-             const UChar *replacementText, int32_t replacementLength,
-             UErrorCode *status);
-
-
-
-/**
- *
- * Copy or move a substring from one position to another within the text,
- * while retaining any metadata associated with the text.
- * This function is used to duplicate or reorder substrings.
- * The destination index must not overlap the source range.
- *
- * The text to be copied or moved is inserted at destIndex;
- * it does not replace or overwrite any existing text.
- *
- * The iteration position is left following the newly inserted text
- * at the destination position.
- *
- * This function is only available on UText types that support writing,
- * that is, ones where utext_isWritable() returns TRUE.
- *
- * When using this function, there should be only a single UText opened onto the
- * underlying native text string.  Behavior after a copy operation
- * on a UText is undefined in any other additional UTexts that refer to the
- * modified string.
- *
- * @param ut           The UText representing the text to be operated on.
- * @param nativeStart  The native index of the start of the region to be copied or moved
- * @param nativeLimit  The native index of the character position following the region
- *                     to be copied.
- * @param destIndex    The native destination index to which the source substring is
- *                     copied or moved.
- * @param move         If TRUE, then the substring is moved, not copied/duplicated.
- * @param status       receives any error status.  Possible errors include U_NO_WRITE_PERMISSION
- *                       
- * @stable ICU 3.4
- */
-U_STABLE void U_EXPORT2
-utext_copy(UText *ut,
-          int64_t nativeStart, int64_t nativeLimit,
-          int64_t destIndex,
-          UBool move,
-          UErrorCode *status);
-
-
-/**
-  *  <p>
-  *  Freeze a UText.  This prevents any modification to the underlying text itself
-  *  by means of functions operating on this UText.
-  *  </p>
-  *  <p>
-  *  Once frozen, a UText can not be unfrozen.  The intent is to ensure
-  *  that a the text underlying a frozen UText wrapper cannot be modified via that UText.
-  *  </p>
-  *  <p>
-  *  Caution:  freezing a UText will disable changes made via the specific
-  *   frozen UText wrapper only; it will not have any effect on the ability to
-  *   directly modify the text by bypassing the UText.  Any such backdoor modifications
-  *   are always an error while UText access is occuring because the underlying
-  *   text can get out of sync with UText's buffering.
-  *  </p>
-  *
-  *  @param ut  The UText to be frozen.
-  *  @see   utext_isWritable()
-  *  @stable ICU 3.6
-  */
-U_STABLE void U_EXPORT2
-utext_freeze(UText *ut);
-
-
-/**
- * UText provider properties (bit field indexes).
- *
- * @see UText
- * @stable ICU 3.4
- */
-enum {
-    /**
-     * It is potentially time consuming for the provider to determine the length of the text.
-     * @stable ICU 3.4
-     */
-    UTEXT_PROVIDER_LENGTH_IS_EXPENSIVE = 1,
-    /**
-     * Text chunks remain valid and usable until the text object is modified or
-     * deleted, not just until the next time the access() function is called
-     * (which is the default).
-     * @stable ICU 3.4
-     */
-    UTEXT_PROVIDER_STABLE_CHUNKS = 2,
-    /**
-     * The provider supports modifying the text via the replace() and copy()
-     * functions.
-     * @see Replaceable
-     * @stable ICU 3.4
-     */
-    UTEXT_PROVIDER_WRITABLE = 3,
-    /**
-     * There is meta data associated with the text.
-     * @see Replaceable::hasMetaData()
-     * @stable ICU 3.4
-     */ 
-    UTEXT_PROVIDER_HAS_META_DATA = 4,
-    /**
-     * Text provider owns the text storage.
-     *  Generally occurs as the result of a deep clone of the UText.
-     *  When closing the UText, the associated text must
-     *  also be closed/deleted/freed/ whatever is appropriate.
-     * @stable ICU 3.6
-     */
-     UTEXT_PROVIDER_OWNS_TEXT = 5
-};
-
-/**
-  * Function type declaration for UText.clone().
-  *
-  *  clone a UText.  Much like opening a UText where the source text is itself
-  *  another UText.
-  *
-  *  A deep clone will copy both the UText data structures and the underlying text.
-  *  The original and cloned UText will operate completely independently; modifications
-  *  made to the text in one will not effect the other.  Text providers are not
-  *  required to support deep clones.  The user of clone() must check the status return
-  *  and be prepared to handle failures.
-  *
-  *  A shallow clone replicates only the UText data structures; it does not make
-  *  a copy of the underlying text.  Shallow clones can be used as an efficient way to 
-  *  have multiple iterators active in a single text string that is not being
-  *  modified.
-  *
-  *  A shallow clone operation must not fail except for truly exceptional conditions such
-  *  as memory allocation failures.
-  *
-  *  A UText and its clone may be safely concurrently accessed by separate threads.
-  *  This is true for both shallow and deep clones.
-  *  It is the responsibility of the Text Provider to ensure that this thread safety
-  *  constraint is met.
-
-  *
-  *  @param dest   A UText struct to be filled in with the result of the clone operation,
-  *                or NULL if the clone function should heap-allocate a new UText struct.
-  *  @param src    The UText to be cloned.
-  *  @param deep   TRUE to request a deep clone, FALSE for a shallow clone.
-  *  @param status Errors are returned here.  For deep clones, U_UNSUPPORTED_ERROR
-  *                should be returned if the text provider is unable to clone the
-  *                original text.
-  *  @return       The newly created clone, or NULL if the clone operation failed.
-  *
-  * @stable ICU 3.4
-  */
-typedef UText * U_CALLCONV
-UTextClone(UText *dest, const UText *src, UBool deep, UErrorCode *status);
-
-
-/**
- * Function type declaration for UText.nativeLength().
- *
- * @param ut the UText to get the length of.
- * @return the length, in the native units of the original text string.
- * @see UText
- * @stable ICU 3.4
- */
-typedef int64_t U_CALLCONV
-UTextNativeLength(UText *ut);
-
-/**
- * Function type declaration for UText.access().  Get the description of the text chunk
- *  containing the text at a requested native index.  The UText's iteration
- *  position will be left at the requested index.  If the index is out
- *  of bounds, the iteration position will be left at the start or end
- *  of the string, as appropriate.
- *
- *  Chunks must begin and end on code point boundaries.  A single code point
- *  comprised of multiple storage units must never span a chunk boundary.
- *
- *
- * @param ut          the UText being accessed.
- * @param nativeIndex Requested index of the text to be accessed.
- * @param forward     If TRUE, then the returned chunk must contain text
- *                    starting from the index, so that start<=index<limit.
- *                    If FALSE, then the returned chunk must contain text
- *                    before the index, so that start<index<=limit.
- * @return            True if the requested index could be accessed.  The chunk
- *                    will contain the requested text.
- *                    False value if a chunk cannot be accessed
- *                    (the requested index is out of bounds).
- *
- * @see UText
- * @stable ICU 3.4
- */
-typedef UBool U_CALLCONV
-UTextAccess(UText *ut, int64_t nativeIndex, UBool forward);
-
-/**
- * Function type declaration for UText.extract().
- *
- * Extract text from a UText into a UChar buffer.  The range of text to be extracted
- * is specified in the native indices of the UText provider.  These may not necessarily
- * be UTF-16 indices.
- * <p>
- * The size (number of 16 bit UChars) in the data to be extracted is returned.  The
- * full amount is returned, even when the specified buffer size is smaller.
- * <p>
- * The extracted string will (if you are a user) / must (if you are a text provider)
- * be NUL-terminated if there is sufficient space in the destination buffer.
- *
- * @param  ut            the UText from which to extract data.
- * @param  nativeStart   the native index of the first characer to extract.
- * @param  nativeLimit   the native string index of the position following the last
- *                       character to extract.
- * @param  dest          the UChar (UTF-16) buffer into which the extracted text is placed
- * @param  destCapacity  The size, in UChars, of the destination buffer.  May be zero
- *                       for precomputing the required size.
- * @param  status        receives any error status.
- *                       If U_BUFFER_OVERFLOW_ERROR: Returns number of UChars for
- *                       preflighting.
- * @return Number of UChars in the data.  Does not include a trailing NUL.
- *
- * @stable ICU 3.4
- */
-typedef int32_t U_CALLCONV
-UTextExtract(UText *ut,
-             int64_t nativeStart, int64_t nativeLimit,
-             UChar *dest, int32_t destCapacity,
-             UErrorCode *status);
-
-/**
- * Function type declaration for UText.replace().
- *
- * Replace a range of the original text with a replacement text.
- *
- * Leaves the current iteration position at the position following the
- *  newly inserted replacement text.
- *
- * This function need only be implemented on UText types that support writing.
- *
- * When using this function, there should be only a single UText opened onto the
- * underlying native text string.  The function is responsible for updating the
- * text chunk within the UText to reflect the updated iteration position,
- * taking into account any changes to the underlying string's structure caused
- * by the replace operation.
- *
- * @param ut               the UText representing the text to be operated on.
- * @param nativeStart      the index of the start of the region to be replaced
- * @param nativeLimit      the index of the character following the region to be replaced.
- * @param replacementText  pointer to the replacement text
- * @param replacmentLength length of the replacement text in UChars, or -1 if the text is NUL terminated.
- * @param status           receives any error status.  Possible errors include
- *                         U_NO_WRITE_PERMISSION
- *
- * @return The signed number of (native) storage units by which
- *         the length of the text expanded or contracted.
- *
- * @stable ICU 3.4
- */
-typedef int32_t U_CALLCONV
-UTextReplace(UText *ut,
-             int64_t nativeStart, int64_t nativeLimit,
-             const UChar *replacementText, int32_t replacmentLength,
-             UErrorCode *status);
-
-/**
- * Function type declaration for UText.copy().
- *
- * Copy or move a substring from one position to another within the text,
- * while retaining any metadata associated with the text.
- * This function is used to duplicate or reorder substrings.
- * The destination index must not overlap the source range.
- *
- * The text to be copied or moved is inserted at destIndex;
- * it does not replace or overwrite any existing text.
- *
- * This function need only be implemented for UText types that support writing.
- *
- * When using this function, there should be only a single UText opened onto the
- * underlying native text string.  The function is responsible for updating the
- * text chunk within the UText to reflect the updated iteration position,
- * taking into account any changes to the underlying string's structure caused
- * by the replace operation.
- *
- * @param ut           The UText representing the text to be operated on.
- * @param nativeStart  The index of the start of the region to be copied or moved
- * @param nativeLimit  The index of the character following the region to be replaced.
- * @param nativeDest   The destination index to which the source substring is copied or moved.
- * @param move         If TRUE, then the substring is moved, not copied/duplicated.
- * @param status       receives any error status.  Possible errors include U_NO_WRITE_PERMISSION
- *
- * @stable ICU 3.4
- */
-typedef void U_CALLCONV
-UTextCopy(UText *ut,
-          int64_t nativeStart, int64_t nativeLimit,
-          int64_t nativeDest,
-          UBool move,
-          UErrorCode *status);
-
-/**
- * Function type declaration for UText.mapOffsetToNative().
- * Map from the current UChar offset within the current text chunk to
- *  the corresponding native index in the original source text.
- *
- * This is required only for text providers that do not use native UTF-16 indexes.
- *
- * @param ut     the UText.
- * @return Absolute (native) index corresponding to chunkOffset in the current chunk.
- *         The returned native index should always be to a code point boundary.
- *
- * @stable ICU 3.4
- */
-typedef int64_t U_CALLCONV
-UTextMapOffsetToNative(const UText *ut);
-
-/**
- * Function type declaration for UText.mapIndexToUTF16().
- * Map from a native index to a UChar offset within a text chunk.
- * Behavior is undefined if the native index does not fall within the
- *   current chunk.
- *
- * This function is required only for text providers that do not use native UTF-16 indexes.
- *
- * @param ut          The UText containing the text chunk.
- * @param nativeIndex Absolute (native) text index, chunk->start<=index<=chunk->limit.
- * @return            Chunk-relative UTF-16 offset corresponding to the specified native
- *                    index.
- *
- * @stable ICU 3.4
- */
-typedef int32_t U_CALLCONV
-UTextMapNativeIndexToUTF16(const UText *ut, int64_t nativeIndex);
-
-
-/**
- * Function type declaration for UText.utextClose().
- *
- * A Text Provider close function is only required for provider types that make
- *  allocations in their open function (or other functions) that must be 
- *  cleaned when the UText is closed.
- *
- * The allocation of the UText struct itself and any "extra" storage
- * associated with the UText is handled by the common UText implementation
- * and does not require provider specific cleanup in a close function.
- *
- * Most UText provider implementations do not need to implement this function.
- *
- * @param ut A UText object to be closed.
- *
- * @stable ICU 3.4
- */
-typedef void U_CALLCONV
-UTextClose(UText *ut);
-
-
-/**
-  *   (public)  Function dispatch table for UText.
-  *             Conceptually very much like a C++ Virtual Function Table.
-  *             This struct defines the organization of the table.
-  *             Each text provider implementation must provide an
-  *              actual table that is initialized with the appropriate functions
-  *              for the type of text being handled.
-  *   @stable ICU 3.6
-  */
-struct UTextFuncs {
-    /**
-     *   (public)  Function table size, sizeof(UTextFuncs)
-     *             Intended for use should the table grow to accomodate added
-     *             functions in the future, to allow tests for older format
-     *             function tables that do not contain the extensions.
-     *
-     *             Fields are placed for optimal alignment on
-     *             32/64/128-bit-pointer machines, by normally grouping together
-     *             4 32-bit fields,
-     *             4 pointers,
-     *             2 64-bit fields
-     *             in sequence.
-     *   @stable ICU 3.6
-     */
-    int32_t       tableSize;
-
-    /**
-      *   (private)  Alignment padding.
-      *              Do not use, reserved for use by the UText framework only.
-      *   @internal
-      */
-    int32_t       reserved1, /** @internal */ reserved2, /** @internal */ reserved3;
-
-
-    /**
-     * (public) Function pointer for UTextClone
-     *
-     * @see UTextClone
-     * @stable ICU 3.6
-     */
-    UTextClone *clone;
-
-    /**
-     * (public) function pointer for UTextLength
-     * May be expensive to compute!
-     *
-     * @see UTextLength
-     * @stable ICU 3.6
-     */
-    UTextNativeLength *nativeLength;
-
-    /**
-     * (public) Function pointer for UTextAccess.
-     *
-     * @see UTextAccess
-     * @stable ICU 3.6
-     */
-    UTextAccess *access;
-
-    /**
-     * (public) Function pointer for UTextExtract.
-     *
-     * @see UTextExtract
-     * @stable ICU 3.6
-     */
-    UTextExtract *extract;
-
-    /**
-     * (public) Function pointer for UTextReplace.
-     *
-     * @see UTextReplace
-     * @stable ICU 3.6
-     */
-    UTextReplace *replace;
-
-    /**
-     * (public) Function pointer for UTextCopy.
-     *
-     * @see UTextCopy
-     * @stable ICU 3.6
-     */
-    UTextCopy *copy;
-
-    /**
-     * (public) Function pointer for UTextMapOffsetToNative.
-     *
-     * @see UTextMapOffsetToNative
-     * @stable ICU 3.6
-     */
-    UTextMapOffsetToNative *mapOffsetToNative;
-
-    /**
-     * (public) Function pointer for UTextMapNativeIndexToUTF16.
-     *
-     * @see UTextMapNativeIndexToUTF16
-     * @stable ICU 3.6
-     */
-    UTextMapNativeIndexToUTF16 *mapNativeIndexToUTF16;
-
-    /**
-     * (public) Function pointer for UTextClose.
-      *
-      * @see UTextClose
-      * @stable ICU 3.6
-      */
-    UTextClose  *close;
-
-    /**
-      * (private)  Spare function pointer
-      * @internal
-      */
-
-    UTextClose  *spare1;
-    /**
-      * (private)  Spare function pointer
-      * @internal
-      */
-    UTextClose  *spare2;
-
-    /**
-      * (private)  Spare function pointer
-      * @internal
-      */
-    UTextClose  *spare3;
-
-};
-/**
- * Function dispatch table for UText
- * @see UTextFuncs
- */
-typedef struct UTextFuncs UTextFuncs;
-
- /**
-  *   UText struct.  Provides the interface between the generic UText access code
-  *                  and the UText provider code that works on specific kinds of
-  *                  text  (UTF-8, noncontiguous UTF-16, whatever.)
-  *
-  *                  Applications that are using predefined types of text providers
-  *                  to pass text data to ICU services will have no need to view the
-  *                  internals of the UText structs that they open.
-  *
-  * @stable ICU 3.6
-  */
-struct UText {
-    /**
-     *     (private)  Magic.  Used to help detect when UText functions are handed
-     *                        invalid or unitialized UText structs.
-     *                        utext_openXYZ() functions take an initialized,
-     *                        but not necessarily open, UText struct as an
-     *                        optional fill-in parameter.  This magic field
-     *                        is used to check for that initialization.
-     *                        Text provider close functions must NOT clear
-     *                        the magic field because that would prevent
-     *                        reuse of the UText struct.
-     * @internal
-     */
-    uint32_t       magic;
-
-
-    /**
-     *     (private)  Flags for managing the allocation and freeing of
-     *                memory associated with this UText.
-     * @internal
-     */
-    int32_t        flags;
-
-
-    /**
-      *  Text provider properties.  This set of flags is maintainted by the
-      *                             text provider implementation.
-      *  @stable ICU 3.4
-      */
-    int32_t         providerProperties;
-
-    /**
-     * (public) sizeOfStruct=sizeof(UText)
-     * Allows possible backward compatible extension.
-     *
-     * @stable ICU 3.4
-     */
-    int32_t         sizeOfStruct;
-    
-    /* ------ 16 byte alignment boundary -----------  */
-    
-
-    /**
-      *  (protected) Native index of the first character position following
-      *              the current chunk.
-      *  @stable ICU 3.6
-      */
-    int64_t         chunkNativeLimit;
-
-    /**
-     *   (protected)  Size in bytes of the extra space (pExtra).
-     *  @stable ICU 3.4
-     */
-    int32_t        extraSize;
-
-    /**
-      *    (protected) The highest chunk offset where native indexing and
-      *    chunk (UTF-16) indexing correspond.  For UTF-16 sources, value
-      *    will be equal to chunkLength.
-      *
-      *    @stable ICU 3.6
-      */
-    int32_t         nativeIndexingLimit;
-
-    /* ---- 16 byte alignment boundary------ */
-    
-    /**
-     *  (protected) Native index of the first character in the text chunk.
-     *  @stable ICU 3.6
-     */
-    int64_t         chunkNativeStart;
-
-    /**
-     *  (protected) Current iteration position within the text chunk (UTF-16 buffer).
-     *  This is the index to the character that will be returned by utext_next32().
-     *  @stable ICU 3.6
-     */
-    int32_t         chunkOffset;
-
-    /**
-     *  (protected) Length the text chunk (UTF-16 buffer), in UChars.
-     *  @stable ICU 3.6
-     */
-    int32_t         chunkLength;
-
-    /* ---- 16  byte alignment boundary-- */
-    
-
-    /**
-     *  (protected)  pointer to a chunk of text in UTF-16 format.
-     *  May refer either to original storage of the source of the text, or
-     *  if conversion was required, to a buffer owned by the UText.
-     *  @stable ICU 3.6
-     */
-    const UChar    *chunkContents;
-
-     /**
-      * (public)     Pointer to Dispatch table for accessing functions for this UText.
-      * @stable ICU 3.6
-      */
-    const UTextFuncs     *pFuncs;
-
-    /**
-     *  (protected)  Pointer to additional space requested by the
-     *               text provider during the utext_open operation.
-     * @stable ICU 3.4
-     */
-    void          *pExtra;
-
-    /**
-     * (protected) Pointer to string or text-containin object or similar.
-     * This is the source of the text that this UText is wrapping, in a format
-     *  that is known to the text provider functions.
-     * @stable ICU 3.4
-     */
-    const void   *context;
-
-    /* --- 16 byte alignment boundary--- */
-
-    /**
-     * (protected) Pointer fields available for use by the text provider.
-     * Not used by UText common code.
-     * @stable ICU 3.6
-     */
-    const void     *p; 
-    /**
-     * (protected) Pointer fields available for use by the text provider.
-     * Not used by UText common code.
-     * @stable ICU 3.6
-     */
-    const void     *q;
-     /**
-     * (protected) Pointer fields available for use by the text provider.
-     * Not used by UText common code.
-     * @stable ICU 3.6
-      */
-    const void     *r;
-
-    /**
-      *  Private field reserved for future use by the UText framework
-      *     itself.  This is not to be touched by the text providers.
-      * @internal ICU 3.4
-      */
-    void           *privP;
-
-
-    /* --- 16 byte alignment boundary--- */
-    
-
-    /**
-      * (protected) Integer field reserved for use by the text provider.
-      * Not used by the UText framework, or by the client (user) of the UText.
-      * @stable ICU 3.4
-      */
-    int64_t         a;
-
-    /**
-      * (protected) Integer field reserved for use by the text provider.
-      * Not used by the UText framework, or by the client (user) of the UText.
-      * @stable ICU 3.4
-      */
-    int32_t         b;
-
-    /**
-      * (protected) Integer field reserved for use by the text provider.
-      * Not used by the UText framework, or by the client (user) of the UText.
-      * @stable ICU 3.4
-      */
-    int32_t         c;
-
-    /*  ---- 16 byte alignment boundary---- */
-
-
-    /**
-      *  Private field reserved for future use by the UText framework
-      *     itself.  This is not to be touched by the text providers.
-      * @internal ICU 3.4
-      */
-    int64_t         privA;
-    /**
-      *  Private field reserved for future use by the UText framework
-      *     itself.  This is not to be touched by the text providers.
-      * @internal ICU 3.4
-      */
-    int32_t         privB;
-    /**
-      *  Private field reserved for future use by the UText framework
-      *     itself.  This is not to be touched by the text providers.
-      * @internal ICU 3.4
-      */
-    int32_t         privC;
-};
-
-
-/**
- *  Common function for use by Text Provider implementations to allocate and/or initialize
- *  a new UText struct.  To be called in the implementation of utext_open() functions.
- *  If the supplied UText parameter is null, a new UText struct will be allocated on the heap.
- *  If the supplied UText is already open, the provider's close function will be called
- *  so that the struct can be reused by the open that is in progress.
- *
- * @param ut   pointer to a UText struct to be re-used, or null if a new UText
- *             should be allocated.
- * @param extraSpace The amount of additional space to be allocated as part
- *             of this UText, for use by types of providers that require
- *             additional storage.
- * @param status Errors are returned here.
- * @return pointer to the UText, allocated if necessary, with extra space set up if requested.
- * @stable ICU 3.4
- */
-U_STABLE UText * U_EXPORT2
-utext_setup(UText *ut, int32_t extraSpace, UErrorCode *status);
-
-/**
-  * @internal
-  *  Value used to help identify correctly initialized UText structs.
-  *  Note:  must be publicly visible so that UTEXT_INITIALIZER can access it.
-  */
-enum {
-    UTEXT_MAGIC = 0x345ad82c
-};
-
-/**
- * initializer to be used with local (stack) instances of a UText
- *  struct.  UText structs must be initialized before passing
- *  them to one of the utext_open functions.
- *
- * @stable ICU 3.6
- */
-#define UTEXT_INITIALIZER {                                        \
-                  UTEXT_MAGIC,          /* magic                */ \
-                  0,                    /* flags                */ \
-                  0,                    /* providerProps        */ \
-                  sizeof(UText),        /* sizeOfStruct         */ \
-                  0,                    /* chunkNativeLimit     */ \
-                  0,                    /* extraSize            */ \
-                  0,                    /* nativeIndexingLimit  */ \
-                  0,                    /* chunkNativeStart     */ \
-                  0,                    /* chunkOffset          */ \
-                  0,                    /* chunkLength          */ \
-                  NULL,                 /* chunkContents        */ \
-                  NULL,                 /* pFuncs               */ \
-                  NULL,                 /* pExtra               */ \
-                  NULL,                 /* context              */ \
-                  NULL, NULL, NULL,     /* p, q, r              */ \
-                  NULL,                 /* privP                */ \
-                  0, 0, 0,              /* a, b, c              */ \
-                  0, 0, 0               /* privA,B,C,           */ \
-                  }
-
-
-U_CDECL_END
-
-
-
-#endif

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/utf.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/utf.h b/apps/couch_collate/platform/osx/icu/unicode/utf.h
deleted file mode 100644
index 1682283..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/utf.h
+++ /dev/null
@@ -1,227 +0,0 @@
-/*
-*******************************************************************************
-*
-*   Copyright (C) 1999-2007, International Business Machines
-*   Corporation and others.  All Rights Reserved.
-*
-*******************************************************************************
-*   file name:  utf.h
-*   encoding:   US-ASCII
-*   tab size:   8 (not used)
-*   indentation:4
-*
-*   created on: 1999sep09
-*   created by: Markus W. Scherer
-*/
-
-/**
- * \file
- * \brief C API: Code point macros
- *
- * This file defines macros for checking whether a code point is
- * a surrogate or a non-character etc.
- *
- * The UChar and UChar32 data types for Unicode code units and code points
- * are defined in umachines.h because they can be machine-dependent.
- *
- * utf.h is included by utypes.h and itself includes utf8.h and utf16.h after some
- * common definitions. Those files define macros for efficiently getting code points
- * in and out of UTF-8/16 strings.
- * utf16.h macros have "U16_" prefixes.
- * utf8.h defines similar macros with "U8_" prefixes for UTF-8 string handling.
- *
- * ICU processes 16-bit Unicode strings.
- * Most of the time, such strings are well-formed UTF-16.
- * Single, unpaired surrogates must be handled as well, and are treated in ICU
- * like regular code points where possible.
- * (Pairs of surrogate code points are indistinguishable from supplementary
- * code points encoded as pairs of supplementary code units.)
- *
- * In fact, almost all Unicode code points in normal text (>99%)
- * are on the BMP (<=U+ffff) and even <=U+d7ff.
- * ICU functions handle supplementary code points (U+10000..U+10ffff)
- * but are optimized for the much more frequently occurring BMP code points.
- *
- * utf.h defines UChar to be an unsigned 16-bit integer. If this matches wchar_t, then
- * UChar is defined to be exactly wchar_t, otherwise uint16_t.
- *
- * UChar32 is defined to be a signed 32-bit integer (int32_t), large enough for a 21-bit
- * Unicode code point (Unicode scalar value, 0..0x10ffff).
- * Before ICU 2.4, the definition of UChar32 was similarly platform-dependent as
- * the definition of UChar. For details see the documentation for UChar32 itself.
- *
- * utf.h also defines a small number of C macros for single Unicode code points.
- * These are simple checks for surrogates and non-characters.
- * For actual Unicode character properties see uchar.h.
- *
- * By default, string operations must be done with error checking in case
- * a string is not well-formed UTF-16.
- * The macros will detect if a surrogate code unit is unpaired
- * (lead unit without trail unit or vice versa) and just return the unit itself
- * as the code point.
- * (It is an accidental property of Unicode and UTF-16 that all
- * malformed sequences can be expressed unambiguously with a distinct subrange
- * of Unicode code points.)
- *
- * The regular "safe" macros require that the initial, passed-in string index
- * is within bounds. They only check the index when they read more than one
- * code unit. This is usually done with code similar to the following loop:
- * <pre>while(i<length) {
- *   U16_NEXT(s, i, length, c);
- *   // use c
- * }</pre>
- *
- * When it is safe to assume that text is well-formed UTF-16
- * (does not contain single, unpaired surrogates), then one can use
- * U16_..._UNSAFE macros.
- * These do not check for proper code unit sequences or truncated text and may
- * yield wrong results or even cause a crash if they are used with "malformed"
- * text.
- * In practice, U16_..._UNSAFE macros will produce slightly less code but
- * should not be faster because the processing is only different when a
- * surrogate code unit is detected, which will be rare.
- *
- * Similarly for UTF-8, there are "safe" macros without a suffix,
- * and U8_..._UNSAFE versions.
- * The performance differences are much larger here because UTF-8 provides so
- * many opportunities for malformed sequences.
- * The unsafe UTF-8 macros are entirely implemented inside the macro definitions
- * and are fast, while the safe UTF-8 macros call functions for all but the
- * trivial (ASCII) cases.
- * (ICU 3.6 optimizes U8_NEXT() and U8_APPEND() to handle most other common
- * characters inline as well.)
- *
- * Unlike with UTF-16, malformed sequences cannot be expressed with distinct
- * code point values (0..U+10ffff). They are indicated with negative values instead.
- *
- * For more information see the ICU User Guide Strings chapter
- * (http://icu-project.org/userguide/strings.html).
- *
- * <em>Usage:</em>
- * ICU coding guidelines for if() statements should be followed when using these macros.
- * Compound statements (curly braces {}) must be used  for if-else-while... 
- * bodies and all macro statements should be terminated with semicolon.
- *
- * @stable ICU 2.4
- */
-
-#ifndef __UTF_H__
-#define __UTF_H__
-
-#include "unicode/utypes.h"
-/* include the utfXX.h after the following definitions */
-
-/* single-code point definitions -------------------------------------------- */
-
-/**
- * This value is intended for sentinel values for APIs that
- * (take or) return single code points (UChar32).
- * It is outside of the Unicode code point range 0..0x10ffff.
- * 
- * For example, a "done" or "error" value in a new API
- * could be indicated with U_SENTINEL.
- *
- * ICU APIs designed before ICU 2.4 usually define service-specific "done"
- * values, mostly 0xffff.
- * Those may need to be distinguished from
- * actual U+ffff text contents by calling functions like
- * CharacterIterator::hasNext() or UnicodeString::length().
- *
- * @return -1
- * @see UChar32
- * @stable ICU 2.4
- */
-#define U_SENTINEL (-1)
-
-/**
- * Is this code point a Unicode noncharacter?
- * @param c 32-bit code point
- * @return TRUE or FALSE
- * @stable ICU 2.4
- */
-#define U_IS_UNICODE_NONCHAR(c) \
-    ((c)>=0xfdd0 && \
-     ((uint32_t)(c)<=0xfdef || ((c)&0xfffe)==0xfffe) && \
-     (uint32_t)(c)<=0x10ffff)
-
-/**
- * Is c a Unicode code point value (0..U+10ffff)
- * that can be assigned a character?
- *
- * Code points that are not characters include:
- * - single surrogate code points (U+d800..U+dfff, 2048 code points)
- * - the last two code points on each plane (U+__fffe and U+__ffff, 34 code points)
- * - U+fdd0..U+fdef (new with Unicode 3.1, 32 code points)
- * - the highest Unicode code point value is U+10ffff
- *
- * This means that all code points below U+d800 are character code points,
- * and that boundary is tested first for performance.
- *
- * @param c 32-bit code point
- * @return TRUE or FALSE
- * @stable ICU 2.4
- */
-#define U_IS_UNICODE_CHAR(c) \
-    ((uint32_t)(c)<0xd800 || \
-        ((uint32_t)(c)>0xdfff && \
-         (uint32_t)(c)<=0x10ffff && \
-         !U_IS_UNICODE_NONCHAR(c)))
-
-/**
- * Is this code point a BMP code point (U+0000..U+ffff)?
- * @param c 32-bit code point
- * @return TRUE or FALSE
- * @stable ICU 2.8
- */
-#define U_IS_BMP(c) ((uint32_t)(c)<=0xffff)
-
-/**
- * Is this code point a supplementary code point (U+10000..U+10ffff)?
- * @param c 32-bit code point
- * @return TRUE or FALSE
- * @stable ICU 2.8
- */
-#define U_IS_SUPPLEMENTARY(c) ((uint32_t)((c)-0x10000)<=0xfffff)
- 
-/**
- * Is this code point a lead surrogate (U+d800..U+dbff)?
- * @param c 32-bit code point
- * @return TRUE or FALSE
- * @stable ICU 2.4
- */
-#define U_IS_LEAD(c) (((c)&0xfffffc00)==0xd800)
-
-/**
- * Is this code point a trail surrogate (U+dc00..U+dfff)?
- * @param c 32-bit code point
- * @return TRUE or FALSE
- * @stable ICU 2.4
- */
-#define U_IS_TRAIL(c) (((c)&0xfffffc00)==0xdc00)
-
-/**
- * Is this code point a surrogate (U+d800..U+dfff)?
- * @param c 32-bit code point
- * @return TRUE or FALSE
- * @stable ICU 2.4
- */
-#define U_IS_SURROGATE(c) (((c)&0xfffff800)==0xd800)
-
-/**
- * Assuming c is a surrogate code point (U_IS_SURROGATE(c)),
- * is it a lead surrogate?
- * @param c 32-bit code point
- * @return TRUE or FALSE
- * @stable ICU 2.4
- */
-#define U_IS_SURROGATE_LEAD(c) (((c)&0x400)==0)
-
-/* include the utfXX.h ------------------------------------------------------ */
-
-#include "unicode/utf8.h"
-#include "unicode/utf16.h"
-
-/* utf_old.h contains deprecated, pre-ICU 2.4 definitions */
-#include "unicode/utf_old.h"
-
-#endif

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/utf16.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/utf16.h b/apps/couch_collate/platform/osx/icu/unicode/utf16.h
deleted file mode 100644
index 719bc04..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/utf16.h
+++ /dev/null
@@ -1,605 +0,0 @@
-/*
-*******************************************************************************
-*
-*   Copyright (C) 1999-2007, International Business Machines
-*   Corporation and others.  All Rights Reserved.
-*
-*******************************************************************************
-*   file name:  utf16.h
-*   encoding:   US-ASCII
-*   tab size:   8 (not used)
-*   indentation:4
-*
-*   created on: 1999sep09
-*   created by: Markus W. Scherer
-*/
-
-/**
- * \file
- * \brief C API: 16-bit Unicode handling macros
- * 
- * This file defines macros to deal with 16-bit Unicode (UTF-16) code units and strings.
- * utf16.h is included by utf.h after unicode/umachine.h
- * and some common definitions.
- *
- * For more information see utf.h and the ICU User Guide Strings chapter
- * (http://icu-project.org/userguide/strings.html).
- *
- * <em>Usage:</em>
- * ICU coding guidelines for if() statements should be followed when using these macros.
- * Compound statements (curly braces {}) must be used  for if-else-while... 
- * bodies and all macro statements should be terminated with semicolon.
- */
-
-#ifndef __UTF16_H__
-#define __UTF16_H__
-
-/* utf.h must be included first. */
-#ifndef __UTF_H__
-#   include "unicode/utf.h"
-#endif
-
-/* single-code point definitions -------------------------------------------- */
-
-/**
- * Does this code unit alone encode a code point (BMP, not a surrogate)?
- * @param c 16-bit code unit
- * @return TRUE or FALSE
- * @stable ICU 2.4
- */
-#define U16_IS_SINGLE(c) !U_IS_SURROGATE(c)
-
-/**
- * Is this code unit a lead surrogate (U+d800..U+dbff)?
- * @param c 16-bit code unit
- * @return TRUE or FALSE
- * @stable ICU 2.4
- */
-#define U16_IS_LEAD(c) (((c)&0xfffffc00)==0xd800)
-
-/**
- * Is this code unit a trail surrogate (U+dc00..U+dfff)?
- * @param c 16-bit code unit
- * @return TRUE or FALSE
- * @stable ICU 2.4
- */
-#define U16_IS_TRAIL(c) (((c)&0xfffffc00)==0xdc00)
-
-/**
- * Is this code unit a surrogate (U+d800..U+dfff)?
- * @param c 16-bit code unit
- * @return TRUE or FALSE
- * @stable ICU 2.4
- */
-#define U16_IS_SURROGATE(c) U_IS_SURROGATE(c)
-
-/**
- * Assuming c is a surrogate code point (U16_IS_SURROGATE(c)),
- * is it a lead surrogate?
- * @param c 16-bit code unit
- * @return TRUE or FALSE
- * @stable ICU 2.4
- */
-#define U16_IS_SURROGATE_LEAD(c) (((c)&0x400)==0)
-
-/**
- * Helper constant for U16_GET_SUPPLEMENTARY.
- * @internal
- */
-#define U16_SURROGATE_OFFSET ((0xd800<<10UL)+0xdc00-0x10000)
-
-/**
- * Get a supplementary code point value (U+10000..U+10ffff)
- * from its lead and trail surrogates.
- * The result is undefined if the input values are not
- * lead and trail surrogates.
- *
- * @param lead lead surrogate (U+d800..U+dbff)
- * @param trail trail surrogate (U+dc00..U+dfff)
- * @return supplementary code point (U+10000..U+10ffff)
- * @stable ICU 2.4
- */
-#define U16_GET_SUPPLEMENTARY(lead, trail) \
-    (((UChar32)(lead)<<10UL)+(UChar32)(trail)-U16_SURROGATE_OFFSET)
-
-
-/**
- * Get the lead surrogate (0xd800..0xdbff) for a
- * supplementary code point (0x10000..0x10ffff).
- * @param supplementary 32-bit code point (U+10000..U+10ffff)
- * @return lead surrogate (U+d800..U+dbff) for supplementary
- * @stable ICU 2.4
- */
-#define U16_LEAD(supplementary) (UChar)(((supplementary)>>10)+0xd7c0)
-
-/**
- * Get the trail surrogate (0xdc00..0xdfff) for a
- * supplementary code point (0x10000..0x10ffff).
- * @param supplementary 32-bit code point (U+10000..U+10ffff)
- * @return trail surrogate (U+dc00..U+dfff) for supplementary
- * @stable ICU 2.4
- */
-#define U16_TRAIL(supplementary) (UChar)(((supplementary)&0x3ff)|0xdc00)
-
-/**
- * How many 16-bit code units are used to encode this Unicode code point? (1 or 2)
- * The result is not defined if c is not a Unicode code point (U+0000..U+10ffff).
- * @param c 32-bit code point
- * @return 1 or 2
- * @stable ICU 2.4
- */
-#define U16_LENGTH(c) ((uint32_t)(c)<=0xffff ? 1 : 2)
-
-/**
- * The maximum number of 16-bit code units per Unicode code point (U+0000..U+10ffff).
- * @return 2
- * @stable ICU 2.4
- */
-#define U16_MAX_LENGTH 2
-
-/**
- * Get a code point from a string at a random-access offset,
- * without changing the offset.
- * "Unsafe" macro, assumes well-formed UTF-16.
- *
- * The offset may point to either the lead or trail surrogate unit
- * for a supplementary code point, in which case the macro will read
- * the adjacent matching surrogate as well.
- * The result is undefined if the offset points to a single, unpaired surrogate.
- * Iteration through a string is more efficient with U16_NEXT_UNSAFE or U16_NEXT.
- *
- * @param s const UChar * string
- * @param i string offset
- * @param c output UChar32 variable
- * @see U16_GET
- * @stable ICU 2.4
- */
-#define U16_GET_UNSAFE(s, i, c) { \
-    (c)=(s)[i]; \
-    if(U16_IS_SURROGATE(c)) { \
-        if(U16_IS_SURROGATE_LEAD(c)) { \
-            (c)=U16_GET_SUPPLEMENTARY((c), (s)[(i)+1]); \
-        } else { \
-            (c)=U16_GET_SUPPLEMENTARY((s)[(i)-1], (c)); \
-        } \
-    } \
-}
-
-/**
- * Get a code point from a string at a random-access offset,
- * without changing the offset.
- * "Safe" macro, handles unpaired surrogates and checks for string boundaries.
- *
- * The offset may point to either the lead or trail surrogate unit
- * for a supplementary code point, in which case the macro will read
- * the adjacent matching surrogate as well.
- * If the offset points to a single, unpaired surrogate, then that itself
- * will be returned as the code point.
- * Iteration through a string is more efficient with U16_NEXT_UNSAFE or U16_NEXT.
- *
- * @param s const UChar * string
- * @param start starting string offset (usually 0)
- * @param i string offset, must be start<=i<length
- * @param length string length
- * @param c output UChar32 variable
- * @see U16_GET_UNSAFE
- * @stable ICU 2.4
- */
-#define U16_GET(s, start, i, length, c) { \
-    (c)=(s)[i]; \
-    if(U16_IS_SURROGATE(c)) { \
-        uint16_t __c2; \
-        if(U16_IS_SURROGATE_LEAD(c)) { \
-            if((i)+1<(length) && U16_IS_TRAIL(__c2=(s)[(i)+1])) { \
-                (c)=U16_GET_SUPPLEMENTARY((c), __c2); \
-            } \
-        } else { \
-            if((i)-1>=(start) && U16_IS_LEAD(__c2=(s)[(i)-1])) { \
-                (c)=U16_GET_SUPPLEMENTARY(__c2, (c)); \
-            } \
-        } \
-    } \
-}
-
-/* definitions with forward iteration --------------------------------------- */
-
-/**
- * Get a code point from a string at a code point boundary offset,
- * and advance the offset to the next code point boundary.
- * (Post-incrementing forward iteration.)
- * "Unsafe" macro, assumes well-formed UTF-16.
- *
- * The offset may point to the lead surrogate unit
- * for a supplementary code point, in which case the macro will read
- * the following trail surrogate as well.
- * If the offset points to a trail surrogate, then that itself
- * will be returned as the code point.
- * The result is undefined if the offset points to a single, unpaired lead surrogate.
- *
- * @param s const UChar * string
- * @param i string offset
- * @param c output UChar32 variable
- * @see U16_NEXT
- * @stable ICU 2.4
- */
-#define U16_NEXT_UNSAFE(s, i, c) { \
-    (c)=(s)[(i)++]; \
-    if(U16_IS_LEAD(c)) { \
-        (c)=U16_GET_SUPPLEMENTARY((c), (s)[(i)++]); \
-    } \
-}
-
-/**
- * Get a code point from a string at a code point boundary offset,
- * and advance the offset to the next code point boundary.
- * (Post-incrementing forward iteration.)
- * "Safe" macro, handles unpaired surrogates and checks for string boundaries.
- *
- * The offset may point to the lead surrogate unit
- * for a supplementary code point, in which case the macro will read
- * the following trail surrogate as well.
- * If the offset points to a trail surrogate or
- * to a single, unpaired lead surrogate, then that itself
- * will be returned as the code point.
- *
- * @param s const UChar * string
- * @param i string offset, must be i<length
- * @param length string length
- * @param c output UChar32 variable
- * @see U16_NEXT_UNSAFE
- * @stable ICU 2.4
- */
-#define U16_NEXT(s, i, length, c) { \
-    (c)=(s)[(i)++]; \
-    if(U16_IS_LEAD(c)) { \
-        uint16_t __c2; \
-        if((i)<(length) && U16_IS_TRAIL(__c2=(s)[(i)])) { \
-            ++(i); \
-            (c)=U16_GET_SUPPLEMENTARY((c), __c2); \
-        } \
-    } \
-}
-
-/**
- * Append a code point to a string, overwriting 1 or 2 code units.
- * The offset points to the current end of the string contents
- * and is advanced (post-increment).
- * "Unsafe" macro, assumes a valid code point and sufficient space in the string.
- * Otherwise, the result is undefined.
- *
- * @param s const UChar * string buffer
- * @param i string offset
- * @param c code point to append
- * @see U16_APPEND
- * @stable ICU 2.4
- */
-#define U16_APPEND_UNSAFE(s, i, c) { \
-    if((uint32_t)(c)<=0xffff) { \
-        (s)[(i)++]=(uint16_t)(c); \
-    } else { \
-        (s)[(i)++]=(uint16_t)(((c)>>10)+0xd7c0); \
-        (s)[(i)++]=(uint16_t)(((c)&0x3ff)|0xdc00); \
-    } \
-}
-
-/**
- * Append a code point to a string, overwriting 1 or 2 code units.
- * The offset points to the current end of the string contents
- * and is advanced (post-increment).
- * "Safe" macro, checks for a valid code point.
- * If a surrogate pair is written, checks for sufficient space in the string.
- * If the code point is not valid or a trail surrogate does not fit,
- * then isError is set to TRUE.
- *
- * @param s const UChar * string buffer
- * @param i string offset, must be i<capacity
- * @param capacity size of the string buffer
- * @param c code point to append
- * @param isError output UBool set to TRUE if an error occurs, otherwise not modified
- * @see U16_APPEND_UNSAFE
- * @stable ICU 2.4
- */
-#define U16_APPEND(s, i, capacity, c, isError) { \
-    if((uint32_t)(c)<=0xffff) { \
-        (s)[(i)++]=(uint16_t)(c); \
-    } else if((uint32_t)(c)<=0x10ffff && (i)+1<(capacity)) { \
-        (s)[(i)++]=(uint16_t)(((c)>>10)+0xd7c0); \
-        (s)[(i)++]=(uint16_t)(((c)&0x3ff)|0xdc00); \
-    } else /* c>0x10ffff or not enough space */ { \
-        (isError)=TRUE; \
-    } \
-}
-
-/**
- * Advance the string offset from one code point boundary to the next.
- * (Post-incrementing iteration.)
- * "Unsafe" macro, assumes well-formed UTF-16.
- *
- * @param s const UChar * string
- * @param i string offset
- * @see U16_FWD_1
- * @stable ICU 2.4
- */
-#define U16_FWD_1_UNSAFE(s, i) { \
-    if(U16_IS_LEAD((s)[(i)++])) { \
-        ++(i); \
-    } \
-}
-
-/**
- * Advance the string offset from one code point boundary to the next.
- * (Post-incrementing iteration.)
- * "Safe" macro, handles unpaired surrogates and checks for string boundaries.
- *
- * @param s const UChar * string
- * @param i string offset, must be i<length
- * @param length string length
- * @see U16_FWD_1_UNSAFE
- * @stable ICU 2.4
- */
-#define U16_FWD_1(s, i, length) { \
-    if(U16_IS_LEAD((s)[(i)++]) && (i)<(length) && U16_IS_TRAIL((s)[i])) { \
-        ++(i); \
-    } \
-}
-
-/**
- * Advance the string offset from one code point boundary to the n-th next one,
- * i.e., move forward by n code points.
- * (Post-incrementing iteration.)
- * "Unsafe" macro, assumes well-formed UTF-16.
- *
- * @param s const UChar * string
- * @param i string offset
- * @param n number of code points to skip
- * @see U16_FWD_N
- * @stable ICU 2.4
- */
-#define U16_FWD_N_UNSAFE(s, i, n) { \
-    int32_t __N=(n); \
-    while(__N>0) { \
-        U16_FWD_1_UNSAFE(s, i); \
-        --__N; \
-    } \
-}
-
-/**
- * Advance the string offset from one code point boundary to the n-th next one,
- * i.e., move forward by n code points.
- * (Post-incrementing iteration.)
- * "Safe" macro, handles unpaired surrogates and checks for string boundaries.
- *
- * @param s const UChar * string
- * @param i string offset, must be i<length
- * @param length string length
- * @param n number of code points to skip
- * @see U16_FWD_N_UNSAFE
- * @stable ICU 2.4
- */
-#define U16_FWD_N(s, i, length, n) { \
-    int32_t __N=(n); \
-    while(__N>0 && (i)<(length)) { \
-        U16_FWD_1(s, i, length); \
-        --__N; \
-    } \
-}
-
-/**
- * Adjust a random-access offset to a code point boundary
- * at the start of a code point.
- * If the offset points to the trail surrogate of a surrogate pair,
- * then the offset is decremented.
- * Otherwise, it is not modified.
- * "Unsafe" macro, assumes well-formed UTF-16.
- *
- * @param s const UChar * string
- * @param i string offset
- * @see U16_SET_CP_START
- * @stable ICU 2.4
- */
-#define U16_SET_CP_START_UNSAFE(s, i) { \
-    if(U16_IS_TRAIL((s)[i])) { \
-        --(i); \
-    } \
-}
-
-/**
- * Adjust a random-access offset to a code point boundary
- * at the start of a code point.
- * If the offset points to the trail surrogate of a surrogate pair,
- * then the offset is decremented.
- * Otherwise, it is not modified.
- * "Safe" macro, handles unpaired surrogates and checks for string boundaries.
- *
- * @param s const UChar * string
- * @param start starting string offset (usually 0)
- * @param i string offset, must be start<=i
- * @see U16_SET_CP_START_UNSAFE
- * @stable ICU 2.4
- */
-#define U16_SET_CP_START(s, start, i) { \
-    if(U16_IS_TRAIL((s)[i]) && (i)>(start) && U16_IS_LEAD((s)[(i)-1])) { \
-        --(i); \
-    } \
-}
-
-/* definitions with backward iteration -------------------------------------- */
-
-/**
- * Move the string offset from one code point boundary to the previous one
- * and get the code point between them.
- * (Pre-decrementing backward iteration.)
- * "Unsafe" macro, assumes well-formed UTF-16.
- *
- * The input offset may be the same as the string length.
- * If the offset is behind a trail surrogate unit
- * for a supplementary code point, then the macro will read
- * the preceding lead surrogate as well.
- * If the offset is behind a lead surrogate, then that itself
- * will be returned as the code point.
- * The result is undefined if the offset is behind a single, unpaired trail surrogate.
- *
- * @param s const UChar * string
- * @param i string offset
- * @param c output UChar32 variable
- * @see U16_PREV
- * @stable ICU 2.4
- */
-#define U16_PREV_UNSAFE(s, i, c) { \
-    (c)=(s)[--(i)]; \
-    if(U16_IS_TRAIL(c)) { \
-        (c)=U16_GET_SUPPLEMENTARY((s)[--(i)], (c)); \
-    } \
-}
-
-/**
- * Move the string offset from one code point boundary to the previous one
- * and get the code point between them.
- * (Pre-decrementing backward iteration.)
- * "Safe" macro, handles unpaired surrogates and checks for string boundaries.
- *
- * The input offset may be the same as the string length.
- * If the offset is behind a trail surrogate unit
- * for a supplementary code point, then the macro will read
- * the preceding lead surrogate as well.
- * If the offset is behind a lead surrogate or behind a single, unpaired
- * trail surrogate, then that itself
- * will be returned as the code point.
- *
- * @param s const UChar * string
- * @param start starting string offset (usually 0)
- * @param i string offset, must be start<i
- * @param c output UChar32 variable
- * @see U16_PREV_UNSAFE
- * @stable ICU 2.4
- */
-#define U16_PREV(s, start, i, c) { \
-    (c)=(s)[--(i)]; \
-    if(U16_IS_TRAIL(c)) { \
-        uint16_t __c2; \
-        if((i)>(start) && U16_IS_LEAD(__c2=(s)[(i)-1])) { \
-            --(i); \
-            (c)=U16_GET_SUPPLEMENTARY(__c2, (c)); \
-        } \
-    } \
-}
-
-/**
- * Move the string offset from one code point boundary to the previous one.
- * (Pre-decrementing backward iteration.)
- * The input offset may be the same as the string length.
- * "Unsafe" macro, assumes well-formed UTF-16.
- *
- * @param s const UChar * string
- * @param i string offset
- * @see U16_BACK_1
- * @stable ICU 2.4
- */
-#define U16_BACK_1_UNSAFE(s, i) { \
-    if(U16_IS_TRAIL((s)[--(i)])) { \
-        --(i); \
-    } \
-}
-
-/**
- * Move the string offset from one code point boundary to the previous one.
- * (Pre-decrementing backward iteration.)
- * The input offset may be the same as the string length.
- * "Safe" macro, handles unpaired surrogates and checks for string boundaries.
- *
- * @param s const UChar * string
- * @param start starting string offset (usually 0)
- * @param i string offset, must be start<i
- * @see U16_BACK_1_UNSAFE
- * @stable ICU 2.4
- */
-#define U16_BACK_1(s, start, i) { \
-    if(U16_IS_TRAIL((s)[--(i)]) && (i)>(start) && U16_IS_LEAD((s)[(i)-1])) { \
-        --(i); \
-    } \
-}
-
-/**
- * Move the string offset from one code point boundary to the n-th one before it,
- * i.e., move backward by n code points.
- * (Pre-decrementing backward iteration.)
- * The input offset may be the same as the string length.
- * "Unsafe" macro, assumes well-formed UTF-16.
- *
- * @param s const UChar * string
- * @param i string offset
- * @param n number of code points to skip
- * @see U16_BACK_N
- * @stable ICU 2.4
- */
-#define U16_BACK_N_UNSAFE(s, i, n) { \
-    int32_t __N=(n); \
-    while(__N>0) { \
-        U16_BACK_1_UNSAFE(s, i); \
-        --__N; \
-    } \
-}
-
-/**
- * Move the string offset from one code point boundary to the n-th one before it,
- * i.e., move backward by n code points.
- * (Pre-decrementing backward iteration.)
- * The input offset may be the same as the string length.
- * "Safe" macro, handles unpaired surrogates and checks for string boundaries.
- *
- * @param s const UChar * string
- * @param start start of string
- * @param i string offset, must be start<i
- * @param n number of code points to skip
- * @see U16_BACK_N_UNSAFE
- * @stable ICU 2.4
- */
-#define U16_BACK_N(s, start, i, n) { \
-    int32_t __N=(n); \
-    while(__N>0 && (i)>(start)) { \
-        U16_BACK_1(s, start, i); \
-        --__N; \
-    } \
-}
-
-/**
- * Adjust a random-access offset to a code point boundary after a code point.
- * If the offset is behind the lead surrogate of a surrogate pair,
- * then the offset is incremented.
- * Otherwise, it is not modified.
- * The input offset may be the same as the string length.
- * "Unsafe" macro, assumes well-formed UTF-16.
- *
- * @param s const UChar * string
- * @param i string offset
- * @see U16_SET_CP_LIMIT
- * @stable ICU 2.4
- */
-#define U16_SET_CP_LIMIT_UNSAFE(s, i) { \
-    if(U16_IS_LEAD((s)[(i)-1])) { \
-        ++(i); \
-    } \
-}
-
-/**
- * Adjust a random-access offset to a code point boundary after a code point.
- * If the offset is behind the lead surrogate of a surrogate pair,
- * then the offset is incremented.
- * Otherwise, it is not modified.
- * The input offset may be the same as the string length.
- * "Safe" macro, handles unpaired surrogates and checks for string boundaries.
- *
- * @param s const UChar * string
- * @param start starting string offset (usually 0)
- * @param i string offset, start<=i<=length
- * @param length string length
- * @see U16_SET_CP_LIMIT_UNSAFE
- * @stable ICU 2.4
- */
-#define U16_SET_CP_LIMIT(s, start, i, length) { \
-    if((start)<(i) && (i)<(length) && U16_IS_LEAD((s)[(i)-1]) && U16_IS_TRAIL((s)[i])) { \
-        ++(i); \
-    } \
-}
-
-#endif

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/utf32.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/utf32.h b/apps/couch_collate/platform/osx/icu/unicode/utf32.h
deleted file mode 100644
index bf63e69..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/utf32.h
+++ /dev/null
@@ -1,23 +0,0 @@
-/*
-*******************************************************************************
-*
-*   Copyright (C) 1999-2001, International Business Machines
-*   Corporation and others.  All Rights Reserved.
-*
-*******************************************************************************
-*   file name:  utf32.h
-*   encoding:   US-ASCII
-*   tab size:   8 (not used)
-*   indentation:4
-*
-*   created on: 1999sep20
-*   created by: Markus W. Scherer
-*/
-/**
- * \file
- * \brief C API: UTF-32 macros
- *
- * This file is obsolete and its contents moved to utf_old.h.
- * See utf_old.h and Jitterbug 2150 and its discussion on the ICU mailing list
- * in September 2002.
- */


[47/57] [abbrv] couchdb commit: updated refs/heads/1994-merge-rcouch-multi-repo to b19d055

Posted by be...@apache.org.
remove couch_replicator


Project: http://git-wip-us.apache.org/repos/asf/couchdb/repo
Commit: http://git-wip-us.apache.org/repos/asf/couchdb/commit/4c39d7a5
Tree: http://git-wip-us.apache.org/repos/asf/couchdb/tree/4c39d7a5
Diff: http://git-wip-us.apache.org/repos/asf/couchdb/diff/4c39d7a5

Branch: refs/heads/1994-merge-rcouch-multi-repo
Commit: 4c39d7a58ce3f3af8ffa6c07fa2a973ae8de15f9
Parents: 20a68fe
Author: Benoit Chesneau <bc...@gmail.com>
Authored: Thu Feb 13 16:39:13 2014 +0100
Committer: Benoit Chesneau <bc...@gmail.com>
Committed: Thu Feb 13 16:39:13 2014 +0100

----------------------------------------------------------------------
 .../src/couch_replicator.app.src                |  28 -
 apps/couch_replicator/src/couch_replicator.erl  | 996 -------------------
 apps/couch_replicator/src/couch_replicator.hrl  |  32 -
 .../src/couch_replicator_api_wrap.erl           | 900 -----------------
 .../src/couch_replicator_api_wrap.hrl           |  36 -
 .../src/couch_replicator_app.erl                |  29 -
 .../src/couch_replicator_httpc.erl              | 297 ------
 .../src/couch_replicator_httpc_pool.erl         | 138 ---
 .../src/couch_replicator_httpd.erl              |  66 --
 .../src/couch_replicator_job_sup.erl            |  31 -
 .../src/couch_replicator_js_functions.hrl       | 151 ---
 .../src/couch_replicator_manager.erl            | 709 -------------
 .../src/couch_replicator_manager_sup.erl        |  47 -
 .../src/couch_replicator_notifier.erl           |  57 --
 .../src/couch_replicator_sup.erl                |  63 --
 .../src/couch_replicator_utils.erl              | 419 --------
 .../src/couch_replicator_worker.erl             | 515 ----------
 apps/couch_replicator/test/01-load.t            |  38 -
 apps/couch_replicator/test/02-httpc-pool.t      | 249 -----
 .../test/03-replication-compact.t               | 489 ---------
 .../test/04-replication-large-atts.t            | 266 -----
 .../test/05-replication-many-leaves.t           | 295 ------
 .../test/06-doc-missing-stubs.t                 | 303 ------
 apps/couch_replicator/test/07-use-checkpoints.t | 255 -----
 24 files changed, 6409 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/couchdb/blob/4c39d7a5/apps/couch_replicator/src/couch_replicator.app.src
----------------------------------------------------------------------
diff --git a/apps/couch_replicator/src/couch_replicator.app.src b/apps/couch_replicator/src/couch_replicator.app.src
deleted file mode 100644
index 3e71b3b..0000000
--- a/apps/couch_replicator/src/couch_replicator.app.src
+++ /dev/null
@@ -1,28 +0,0 @@
-% Licensed 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.
-
-{application, couch_replicator, [
-    {description, "CouchDB replicator"},
-    {vsn, "1.6.1"},
-    {modules, []},
-    {registered, [
-        couch_replicator_manager_sup,
-        couch_replicator_job_sup,
-        couch_replicator_sup
-    ]},
-    {applications, [kernel, stdlib, crypto, sasl, inets, oauth, ibrowse,
-                   couch]},
-
-    {mod, { couch_replicator_app, []}},
-    {env, []}
-]}.
-

http://git-wip-us.apache.org/repos/asf/couchdb/blob/4c39d7a5/apps/couch_replicator/src/couch_replicator.erl
----------------------------------------------------------------------
diff --git a/apps/couch_replicator/src/couch_replicator.erl b/apps/couch_replicator/src/couch_replicator.erl
deleted file mode 100644
index 10aaf37..0000000
--- a/apps/couch_replicator/src/couch_replicator.erl
+++ /dev/null
@@ -1,996 +0,0 @@
-% Licensed 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.
-
--module(couch_replicator).
--behaviour(gen_server).
-
-% public API
--export([replicate/1]).
-
-% meant to be used only by the replicator database listener
--export([async_replicate/1]).
--export([cancel_replication/1]).
-
-% gen_server callbacks
--export([init/1, terminate/2, code_change/3]).
--export([handle_call/3, handle_cast/2, handle_info/2]).
-
--include_lib("couch/include/couch_db.hrl").
--include("couch_replicator_api_wrap.hrl").
--include("couch_replicator.hrl").
-
--import(couch_util, [
-    get_value/2,
-    get_value/3,
-    to_binary/1
-]).
-
--import(couch_replicator_utils, [
-    start_db_compaction_notifier/2,
-    stop_db_compaction_notifier/1
-]).
-
--record(rep_state, {
-    rep_details,
-    source_name,
-    target_name,
-    source,
-    target,
-    history,
-    checkpoint_history,
-    start_seq,
-    committed_seq,
-    current_through_seq,
-    seqs_in_progress = [],
-    highest_seq_done = {0, ?LOWEST_SEQ},
-    source_log,
-    target_log,
-    rep_starttime,
-    src_starttime,
-    tgt_starttime,
-    timer, % checkpoint timer
-    changes_queue,
-    changes_manager,
-    changes_reader,
-    workers,
-    stats = #rep_stats{},
-    session_id,
-    source_db_compaction_notifier = nil,
-    target_db_compaction_notifier = nil,
-    source_monitor = nil,
-    target_monitor = nil,
-    source_seq = nil,
-    use_checkpoints = true,
-    checkpoint_interval = 5000,
-    type = db,
-    view = nil
-}).
-
-
-replicate(#rep{id = RepId, options = Options, user_ctx = UserCtx} = Rep) ->
-    case get_value(cancel, Options, false) of
-    true ->
-        case get_value(id, Options, nil) of
-        nil ->
-            cancel_replication(RepId);
-        RepId2 ->
-            cancel_replication(RepId2, UserCtx)
-        end;
-    false ->
-        {ok, Listener} = rep_result_listener(RepId),
-        Result = do_replication_loop(Rep),
-        couch_replicator_notifier:stop(Listener),
-        Result
-    end.
-
-
-do_replication_loop(#rep{id = {BaseId, Ext} = Id, options = Options} = Rep) ->
-    case async_replicate(Rep) of
-    {ok, _Pid} ->
-        case get_value(continuous, Options, false) of
-        true ->
-            {ok, {continuous, ?l2b(BaseId ++ Ext)}};
-        false ->
-            wait_for_result(Id)
-        end;
-    Error ->
-        Error
-    end.
-
-
-async_replicate(#rep{id = {BaseId, Ext}, source = Src, target = Tgt} = Rep) ->
-    RepChildId = BaseId ++ Ext,
-    Source = couch_replicator_api_wrap:db_uri(Src),
-    Target = couch_replicator_api_wrap:db_uri(Tgt),
-    Timeout = get_value(connection_timeout, Rep#rep.options),
-    ChildSpec = {
-        RepChildId,
-        {gen_server, start_link, [?MODULE, Rep, [{timeout, Timeout}]]},
-        temporary,
-        250,
-        worker,
-        [?MODULE]
-    },
-    % All these nested cases to attempt starting/restarting a replication child
-    % are ugly and not 100% race condition free. The following patch submission
-    % is a solution:
-    %
-    % http://erlang.2086793.n4.nabble.com/PATCH-supervisor-atomically-delete-child-spec-when-child-terminates-td3226098.html
-    %
-    case supervisor:start_child(couch_replicator_job_sup, ChildSpec) of
-    {ok, Pid} ->
-        ?LOG_INFO("starting new replication `~s` at ~p (`~s` -> `~s`)",
-            [RepChildId, Pid, Source, Target]),
-        {ok, Pid};
-    {error, already_present} ->
-        case supervisor:restart_child(couch_replicator_job_sup, RepChildId) of
-        {ok, Pid} ->
-            ?LOG_INFO("restarting replication `~s` at ~p (`~s` -> `~s`)",
-                [RepChildId, Pid, Source, Target]),
-            {ok, Pid};
-        {error, running} ->
-            %% this error occurs if multiple replicators are racing
-            %% each other to start and somebody else won. Just grab
-            %% the Pid by calling start_child again.
-            {error, {already_started, Pid}} =
-                supervisor:start_child(couch_replicator_job_sup, ChildSpec),
-            ?LOG_INFO("replication `~s` already running at ~p (`~s` -> `~s`)",
-                [RepChildId, Pid, Source, Target]),
-            {ok, Pid};
-        {error, {'EXIT', {badarg,
-            [{erlang, apply, [gen_server, start_link, undefined]} | _]}}} ->
-            % Clause to deal with a change in the supervisor module introduced
-            % in R14B02. For more details consult the thread at:
-            %     http://erlang.org/pipermail/erlang-bugs/2011-March/002273.html
-            _ = supervisor:delete_child(couch_replicator_job_sup, RepChildId),
-            async_replicate(Rep);
-        {error, _} = Error ->
-            Error
-        end;
-    {error, {already_started, Pid}} ->
-        ?LOG_INFO("replication `~s` already running at ~p (`~s` -> `~s`)",
-            [RepChildId, Pid, Source, Target]),
-        {ok, Pid};
-    {error, {Error, _}} ->
-        {error, Error}
-    end.
-
-
-rep_result_listener(RepId) ->
-    ReplyTo = self(),
-    {ok, _Listener} = couch_replicator_notifier:start_link(
-        fun({_, RepId2, _} = Ev) when RepId2 =:= RepId ->
-                ReplyTo ! Ev;
-            (_) ->
-                ok
-        end).
-
-
-wait_for_result(RepId) ->
-    receive
-    {finished, RepId, RepResult} ->
-        {ok, RepResult};
-    {error, RepId, Reason} ->
-        {error, Reason}
-    end.
-
-
-cancel_replication({BaseId, Extension}) ->
-    FullRepId = BaseId ++ Extension,
-    ?LOG_INFO("Canceling replication `~s`...", [FullRepId]),
-    case supervisor:terminate_child(couch_replicator_job_sup, FullRepId) of
-    ok ->
-        ?LOG_INFO("Replication `~s` canceled.", [FullRepId]),
-        case supervisor:delete_child(couch_replicator_job_sup, FullRepId) of
-            ok ->
-                {ok, {cancelled, ?l2b(FullRepId)}};
-            {error, not_found} ->
-                {ok, {cancelled, ?l2b(FullRepId)}};
-            Error ->
-                Error
-        end;
-    Error ->
-        ?LOG_ERROR("Error canceling replication `~s`: ~p", [FullRepId, Error]),
-        Error
-    end.
-
-cancel_replication(RepId, #user_ctx{name = Name, roles = Roles}) ->
-    case lists:member(<<"_admin">>, Roles) of
-    true ->
-        cancel_replication(RepId);
-    false ->
-        {BaseId, Ext} = RepId,
-        case lists:keysearch(
-            BaseId ++ Ext, 1, supervisor:which_children(couch_replicator_job_sup)) of
-        {value, {_, Pid, _, _}} when is_pid(Pid) ->
-            case (catch gen_server:call(Pid, get_details, infinity)) of
-            {ok, #rep{user_ctx = #user_ctx{name = Name}}} ->
-                cancel_replication(RepId);
-            {ok, _} ->
-                throw({unauthorized,
-                    <<"Can't cancel a replication triggered by another user">>});
-            {'EXIT', {noproc, {gen_server, call, _}}} ->
-                {error, not_found};
-            Error ->
-                throw(Error)
-            end;
-        _ ->
-            {error, not_found}
-        end
-    end.
-
-init(InitArgs) ->
-    try
-        do_init(InitArgs)
-    catch
-    throw:{unauthorized, DbUri} ->
-        {stop, {unauthorized,
-            <<"unauthorized to access or create database ", DbUri/binary>>}};
-    throw:{db_not_found, DbUri} ->
-        {stop, {db_not_found, <<"could not open ", DbUri/binary>>}};
-    throw:Error ->
-        {stop, Error}
-    end.
-
-do_init(#rep{options = Options, id = {BaseId, Ext}} = Rep) ->
-    process_flag(trap_exit, true),
-
-    #rep_state{
-        source = Source,
-        target = Target,
-        source_name = SourceName,
-        target_name = TargetName,
-        start_seq = {_Ts, StartSeq},
-        source_seq = SourceCurSeq,
-        committed_seq = {_, CommittedSeq},
-        checkpoint_interval = CheckpointInterval
-    } = State = init_state(Rep),
-
-    NumWorkers = get_value(worker_processes, Options),
-    BatchSize = get_value(worker_batch_size, Options),
-    {ok, ChangesQueue} = couch_work_queue:new([
-        {max_items, BatchSize * NumWorkers * 2},
-        {max_size, 100 * 1024 * NumWorkers}
-    ]),
-    % This starts the _changes reader process. It adds the changes from
-    % the source db to the ChangesQueue.
-    ChangesReader = spawn_changes_reader(StartSeq, Source, ChangesQueue, Options),
-    % Changes manager - responsible for dequeing batches from the changes queue
-    % and deliver them to the worker processes.
-    ChangesManager = spawn_changes_manager(self(), ChangesQueue, BatchSize),
-    % This starts the worker processes. They ask the changes queue manager for a
-    % a batch of _changes rows to process -> check which revs are missing in the
-    % target, and for the missing ones, it copies them from the source to the target.
-    MaxConns = get_value(http_connections, Options),
-    Workers = lists:map(
-        fun(_) ->
-            {ok, Pid} = couch_replicator_worker:start_link(
-                self(), Source, Target, ChangesManager, MaxConns),
-            Pid
-        end,
-        lists:seq(1, NumWorkers)),
-
-    couch_task_status:add_task([
-        {type, replication},
-        {replication_id, ?l2b(BaseId ++ Ext)},
-        {doc_id, Rep#rep.doc_id},
-        {source, ?l2b(SourceName)},
-        {target, ?l2b(TargetName)},
-        {continuous, get_value(continuous, Options, false)},
-        {revisions_checked, 0},
-        {missing_revisions_found, 0},
-        {docs_read, 0},
-        {docs_written, 0},
-        {doc_write_failures, 0},
-        {source_seq, SourceCurSeq},
-        {checkpointed_source_seq, CommittedSeq},
-        {progress, 0},
-        {checkpoint_interval, CheckpointInterval}
-    ]),
-    couch_task_status:set_update_frequency(1000),
-
-    % Until OTP R14B03:
-    %
-    % Restarting a temporary supervised child implies that the original arguments
-    % (#rep{} record) specified in the MFA component of the supervisor
-    % child spec will always be used whenever the child is restarted.
-    % This implies the same replication performance tunning parameters will
-    % always be used. The solution is to delete the child spec (see
-    % cancel_replication/1) and then start the replication again, but this is
-    % unfortunately not immune to race conditions.
-
-    ?LOG_INFO("Replication `~p` is using:~n"
-        "~c~p worker processes~n"
-        "~ca worker batch size of ~p~n"
-        "~c~p HTTP connections~n"
-        "~ca connection timeout of ~p milliseconds~n"
-        "~c~p retries per request~n"
-        "~csocket options are: ~s~s",
-        [BaseId ++ Ext, $\t, NumWorkers, $\t, BatchSize, $\t,
-            MaxConns, $\t, get_value(connection_timeout, Options),
-            $\t, get_value(retries, Options),
-            $\t, io_lib:format("~p", [get_value(socket_options, Options)]),
-            case StartSeq of
-            ?LOWEST_SEQ ->
-                "";
-            _ ->
-                io_lib:format("~n~csource start sequence ~p", [$\t, StartSeq])
-            end]),
-
-    ?LOG_DEBUG("Worker pids are: ~p", [Workers]),
-
-    couch_replicator_manager:replication_started(Rep),
-
-    {ok, State#rep_state{
-            changes_queue = ChangesQueue,
-            changes_manager = ChangesManager,
-            changes_reader = ChangesReader,
-            workers = Workers
-        }
-    }.
-
-
-handle_info(shutdown, St) ->
-    {stop, shutdown, St};
-
-handle_info({'DOWN', Ref, _, _, Why}, #rep_state{source_monitor = Ref} = St) ->
-    ?LOG_ERROR("Source database is down. Reason: ~p", [Why]),
-    {stop, source_db_down, St};
-
-handle_info({'DOWN', Ref, _, _, Why}, #rep_state{target_monitor = Ref} = St) ->
-    ?LOG_ERROR("Target database is down. Reason: ~p", [Why]),
-    {stop, target_db_down, St};
-
-handle_info({'EXIT', Pid, normal}, #rep_state{changes_reader=Pid} = State) ->
-    {noreply, State};
-
-handle_info({'EXIT', Pid, Reason}, #rep_state{changes_reader=Pid} = State) ->
-    ?LOG_ERROR("ChangesReader process died with reason: ~p", [Reason]),
-    {stop, changes_reader_died, cancel_timer(State)};
-
-handle_info({'EXIT', Pid, normal}, #rep_state{changes_manager = Pid} = State) ->
-    {noreply, State};
-
-handle_info({'EXIT', Pid, Reason}, #rep_state{changes_manager = Pid} = State) ->
-    ?LOG_ERROR("ChangesManager process died with reason: ~p", [Reason]),
-    {stop, changes_manager_died, cancel_timer(State)};
-
-handle_info({'EXIT', Pid, normal}, #rep_state{changes_queue=Pid} = State) ->
-    {noreply, State};
-
-handle_info({'EXIT', Pid, Reason}, #rep_state{changes_queue=Pid} = State) ->
-    ?LOG_ERROR("ChangesQueue process died with reason: ~p", [Reason]),
-    {stop, changes_queue_died, cancel_timer(State)};
-
-handle_info({'EXIT', Pid, normal}, #rep_state{workers = Workers} = State) ->
-    case Workers -- [Pid] of
-    Workers ->
-        {stop, {unknown_process_died, Pid, normal}, State};
-    [] ->
-        catch unlink(State#rep_state.changes_manager),
-        catch exit(State#rep_state.changes_manager, kill),
-        do_last_checkpoint(State);
-    Workers2 ->
-        {noreply, State#rep_state{workers = Workers2}}
-    end;
-
-handle_info({'EXIT', Pid, Reason}, #rep_state{workers = Workers} = State) ->
-    State2 = cancel_timer(State),
-    case lists:member(Pid, Workers) of
-    false ->
-        {stop, {unknown_process_died, Pid, Reason}, State2};
-    true ->
-        ?LOG_ERROR("Worker ~p died with reason: ~p", [Pid, Reason]),
-        {stop, {worker_died, Pid, Reason}, State2}
-    end.
-
-
-handle_call(get_details, _From, #rep_state{rep_details = Rep} = State) ->
-    {reply, {ok, Rep}, State};
-
-handle_call({add_stats, Stats}, From, State) ->
-    gen_server:reply(From, ok),
-    NewStats = couch_replicator_utils:sum_stats(State#rep_state.stats, Stats),
-    {noreply, State#rep_state{stats = NewStats}};
-
-handle_call({report_seq_done, Seq, StatsInc}, From,
-    #rep_state{seqs_in_progress = SeqsInProgress, highest_seq_done = HighestDone,
-        current_through_seq = ThroughSeq, stats = Stats} = State) ->
-    gen_server:reply(From, ok),
-    {NewThroughSeq0, NewSeqsInProgress} = case SeqsInProgress of
-    [Seq | Rest] ->
-        {Seq, Rest};
-    [_ | _] ->
-        {ThroughSeq, ordsets:del_element(Seq, SeqsInProgress)}
-    end,
-    NewHighestDone = lists:max([HighestDone, Seq]),
-    NewThroughSeq = case NewSeqsInProgress of
-    [] ->
-        lists:max([NewThroughSeq0, NewHighestDone]);
-    _ ->
-        NewThroughSeq0
-    end,
-    ?LOG_DEBUG("Worker reported seq ~p, through seq was ~p, "
-        "new through seq is ~p, highest seq done was ~p, "
-        "new highest seq done is ~p~n"
-        "Seqs in progress were: ~p~nSeqs in progress are now: ~p",
-        [Seq, ThroughSeq, NewThroughSeq, HighestDone,
-            NewHighestDone, SeqsInProgress, NewSeqsInProgress]),
-    SourceCurSeq = source_cur_seq(State),
-    NewState = State#rep_state{
-        stats = couch_replicator_utils:sum_stats(Stats, StatsInc),
-        current_through_seq = NewThroughSeq,
-        seqs_in_progress = NewSeqsInProgress,
-        highest_seq_done = NewHighestDone,
-        source_seq = SourceCurSeq
-    },
-    update_task(NewState),
-    {noreply, NewState}.
-
-
-handle_cast({db_compacted, DbName},
-    #rep_state{source = #db{name = DbName} = Source} = State) ->
-    {ok, NewSource} = couch_db:reopen(Source),
-    {noreply, State#rep_state{source = NewSource}};
-
-handle_cast({db_compacted, DbName},
-    #rep_state{target = #db{name = DbName} = Target} = State) ->
-    {ok, NewTarget} = couch_db:reopen(Target),
-    {noreply, State#rep_state{target = NewTarget}};
-
-handle_cast(checkpoint, State) ->
-    case do_checkpoint(State) of
-    {ok, NewState} ->
-        {noreply, NewState#rep_state{timer = start_timer(State)}};
-    Error ->
-        {stop, Error, State}
-    end;
-
-handle_cast({report_seq, Seq},
-    #rep_state{seqs_in_progress = SeqsInProgress} = State) ->
-    NewSeqsInProgress = ordsets:add_element(Seq, SeqsInProgress),
-    {noreply, State#rep_state{seqs_in_progress = NewSeqsInProgress}}.
-
-
-code_change(OldVsn, OldState, Extra) when tuple_size(OldState) =:= 30 ->
-    code_change(OldVsn, erlang:append_element(OldState, true), Extra);
-code_change(OldVsn, OldState, Extra) when tuple_size(OldState) =:= 31 ->
-    code_change(OldVsn, erlang:append_element(OldState, 5000), Extra);
-code_change(_OldVsn, #rep_state{}=State, _Extra) ->
-    {ok, State}.
-
-
-terminate(normal, #rep_state{rep_details = #rep{id = RepId} = Rep,
-    checkpoint_history = CheckpointHistory} = State) ->
-    terminate_cleanup(State),
-    couch_replicator_notifier:notify({finished, RepId, CheckpointHistory}),
-    couch_replicator_manager:replication_completed(Rep, rep_stats(State));
-
-terminate(shutdown, #rep_state{rep_details = #rep{id = RepId}} = State) ->
-    % cancelled replication throught ?MODULE:cancel_replication/1
-    couch_replicator_notifier:notify({error, RepId, <<"cancelled">>}),
-    terminate_cleanup(State);
-
-terminate(Reason, State) ->
-    #rep_state{
-        source_name = Source,
-        target_name = Target,
-        rep_details = #rep{id = {BaseId, Ext} = RepId} = Rep
-    } = State,
-    ?LOG_ERROR("Replication `~s` (`~s` -> `~s`) failed: ~s",
-        [BaseId ++ Ext, Source, Target, to_binary(Reason)]),
-    terminate_cleanup(State),
-    couch_replicator_notifier:notify({error, RepId, Reason}),
-    couch_replicator_manager:replication_error(Rep, Reason).
-
-
-terminate_cleanup(State) ->
-    update_task(State),
-    stop_db_compaction_notifier(State#rep_state.source_db_compaction_notifier),
-    stop_db_compaction_notifier(State#rep_state.target_db_compaction_notifier),
-    couch_replicator_api_wrap:db_close(State#rep_state.source),
-    couch_replicator_api_wrap:db_close(State#rep_state.target).
-
-
-do_last_checkpoint(#rep_state{seqs_in_progress = [],
-    highest_seq_done = {_Ts, ?LOWEST_SEQ}} = State) ->
-    {stop, normal, cancel_timer(State)};
-do_last_checkpoint(#rep_state{seqs_in_progress = [],
-    highest_seq_done = Seq} = State) ->
-    case do_checkpoint(State#rep_state{current_through_seq = Seq}) of
-    {ok, NewState} ->
-        {stop, normal, cancel_timer(NewState)};
-    Error ->
-        {stop, Error, State}
-    end.
-
-
-start_timer(State) ->
-    After = State#rep_state.checkpoint_interval,
-    case timer:apply_after(After, gen_server, cast, [self(), checkpoint]) of
-    {ok, Ref} ->
-        Ref;
-    Error ->
-        ?LOG_ERROR("Replicator, error scheduling checkpoint:  ~p", [Error]),
-        nil
-    end.
-
-
-cancel_timer(#rep_state{timer = nil} = State) ->
-    State;
-cancel_timer(#rep_state{timer = Timer} = State) ->
-    {ok, cancel} = timer:cancel(Timer),
-    State#rep_state{timer = nil}.
-
-
-init_state(Rep) ->
-    #rep{
-        source = Src, target = Tgt,
-        options = Options, user_ctx = UserCtx,
-        type = Type, view = View
-    } = Rep,
-    {ok, Source} = couch_replicator_api_wrap:db_open(Src, [{user_ctx, UserCtx}]),
-    {ok, Target} = couch_replicator_api_wrap:db_open(Tgt, [{user_ctx, UserCtx}],
-        get_value(create_target, Options, false)),
-
-    {ok, SourceInfo} = couch_replicator_api_wrap:get_db_info(Source),
-    {ok, TargetInfo} = couch_replicator_api_wrap:get_db_info(Target),
-
-    [SourceLog, TargetLog] = find_replication_logs([Source, Target], Rep),
-
-    {StartSeq0, History} = compare_replication_logs(SourceLog, TargetLog),
-    StartSeq1 = get_value(since_seq, Options, StartSeq0),
-    StartSeq = {0, StartSeq1},
-
-    SourceSeq = case Type of
-        db -> get_value(<<"update_seq">>, SourceInfo, ?LOWEST_SEQ);
-        view ->
-            {DDoc, VName} = View,
-            {ok, VInfo} = couch_replicator_api_wrap:get_view_info(Source, DDoc,
-                                                                  VName),
-            get_value(<<"update_seq">>, VInfo, ?LOWEST_SEQ)
-    end,
-
-
-    #doc{body={CheckpointHistory}} = SourceLog,
-    State = #rep_state{
-        rep_details = Rep,
-        source_name = couch_replicator_api_wrap:db_uri(Source),
-        target_name = couch_replicator_api_wrap:db_uri(Target),
-        source = Source,
-        target = Target,
-        history = History,
-        checkpoint_history = {[{<<"no_changes">>, true}| CheckpointHistory]},
-        start_seq = StartSeq,
-        current_through_seq = StartSeq,
-        committed_seq = StartSeq,
-        source_log = SourceLog,
-        target_log = TargetLog,
-        rep_starttime = couch_util:rfc1123_date(),
-        src_starttime = get_value(<<"instance_start_time">>, SourceInfo),
-        tgt_starttime = get_value(<<"instance_start_time">>, TargetInfo),
-        session_id = couch_uuids:random(),
-        source_db_compaction_notifier =
-            start_db_compaction_notifier(Source, self()),
-        target_db_compaction_notifier =
-            start_db_compaction_notifier(Target, self()),
-        source_monitor = db_monitor(Source),
-        target_monitor = db_monitor(Target),
-        source_seq = SourceSeq,
-        use_checkpoints = get_value(use_checkpoints, Options, true),
-        checkpoint_interval = get_value(checkpoint_interval, Options,
-                                        5000),
-        type = Type,
-        view = View
-    },
-    State#rep_state{timer = start_timer(State)}.
-
-
-find_replication_logs(DbList, #rep{id = {BaseId, _}} = Rep) ->
-    LogId = ?l2b(?LOCAL_DOC_PREFIX ++ BaseId),
-    fold_replication_logs(DbList, ?REP_ID_VERSION, LogId, LogId, Rep, []).
-
-
-fold_replication_logs([], _Vsn, _LogId, _NewId, _Rep, Acc) ->
-    lists:reverse(Acc);
-
-fold_replication_logs([Db | Rest] = Dbs, Vsn, LogId, NewId, Rep, Acc) ->
-    case couch_replicator_api_wrap:open_doc(Db, LogId, [ejson_body]) of
-    {error, <<"not_found">>} when Vsn > 1 ->
-        OldRepId = couch_replicator_utils:replication_id(Rep, Vsn - 1),
-        fold_replication_logs(Dbs, Vsn - 1,
-            ?l2b(?LOCAL_DOC_PREFIX ++ OldRepId), NewId, Rep, Acc);
-    {error, <<"not_found">>} ->
-        fold_replication_logs(
-            Rest, ?REP_ID_VERSION, NewId, NewId, Rep, [#doc{id = NewId} | Acc]);
-    {ok, Doc} when LogId =:= NewId ->
-        fold_replication_logs(
-            Rest, ?REP_ID_VERSION, NewId, NewId, Rep, [Doc | Acc]);
-    {ok, Doc} ->
-        MigratedLog = #doc{id = NewId, body = Doc#doc.body},
-        fold_replication_logs(
-            Rest, ?REP_ID_VERSION, NewId, NewId, Rep, [MigratedLog | Acc])
-    end.
-
-
-spawn_changes_reader(StartSeq, #httpdb{} = Db, ChangesQueue, Options) ->
-    spawn_link(fun() ->
-        put(last_seq, StartSeq),
-        put(retries_left, Db#httpdb.retries),
-        read_changes(StartSeq, Db#httpdb{retries = 0}, ChangesQueue, Options)
-    end);
-spawn_changes_reader(StartSeq, Db, ChangesQueue, Options) ->
-    spawn_link(fun() ->
-        read_changes(StartSeq, Db, ChangesQueue, Options)
-    end).
-
-read_changes(StartSeq, Db, ChangesQueue, Options) ->
-    try
-        couch_replicator_api_wrap:changes_since(Db, all_docs, StartSeq,
-            fun(#doc_info{high_seq = Seq, id = Id} = DocInfo) ->
-                case Id of
-                <<>> ->
-                    % Previous CouchDB releases had a bug which allowed a doc
-                    % with an empty ID to be inserted into databases. Such doc
-                    % is impossible to GET.
-                    ?LOG_ERROR("Replicator: ignoring document with empty ID in "
-                        "source database `~s` (_changes sequence ~p)",
-                        [couch_replicator_api_wrap:db_uri(Db), Seq]);
-                _ ->
-                    ok = couch_work_queue:queue(ChangesQueue, DocInfo)
-                end,
-                put(last_seq, Seq)
-            end, Options),
-        couch_work_queue:close(ChangesQueue)
-    catch exit:{http_request_failed, _, _, _} = Error ->
-        case get(retries_left) of
-        N when N > 0 ->
-            put(retries_left, N - 1),
-            LastSeq = get(last_seq),
-            Db2 = case LastSeq of
-            StartSeq ->
-                ?LOG_INFO("Retrying _changes request to source database ~s"
-                    " with since=~p in ~p seconds",
-                    [couch_replicator_api_wrap:db_uri(Db), LastSeq, Db#httpdb.wait / 1000]),
-                ok = timer:sleep(Db#httpdb.wait),
-                Db#httpdb{wait = 2 * Db#httpdb.wait};
-            _ ->
-                ?LOG_INFO("Retrying _changes request to source database ~s"
-                    " with since=~p", [couch_replicator_api_wrap:db_uri(Db), LastSeq]),
-                Db
-            end,
-            read_changes(LastSeq, Db2, ChangesQueue, Options);
-        _ ->
-            exit(Error)
-        end
-    end.
-
-
-spawn_changes_manager(Parent, ChangesQueue, BatchSize) ->
-    spawn_link(fun() ->
-        changes_manager_loop_open(Parent, ChangesQueue, BatchSize, 1)
-    end).
-
-changes_manager_loop_open(Parent, ChangesQueue, BatchSize, Ts) ->
-    receive
-    {get_changes, From} ->
-        case couch_work_queue:dequeue(ChangesQueue, BatchSize) of
-        closed ->
-            From ! {closed, self()};
-        {ok, Changes} ->
-            #doc_info{high_seq = Seq} = lists:last(Changes),
-            ReportSeq = {Ts, Seq},
-            ok = gen_server:cast(Parent, {report_seq, ReportSeq}),
-            From ! {changes, self(), Changes, ReportSeq}
-        end,
-        changes_manager_loop_open(Parent, ChangesQueue, BatchSize, Ts + 1)
-    end.
-
-
-do_checkpoint(#rep_state{use_checkpoints=false} = State) ->
-    NewState = State#rep_state{checkpoint_history = {[{<<"use_checkpoints">>, false}]} },
-    {ok, NewState};
-do_checkpoint(#rep_state{current_through_seq=Seq, committed_seq=Seq} = State) ->
-    SourceCurSeq = source_cur_seq(State),
-    NewState = State#rep_state{source_seq = SourceCurSeq},
-    update_task(NewState),
-    {ok, NewState};
-do_checkpoint(State) ->
-    #rep_state{
-        source_name=SourceName,
-        target_name=TargetName,
-        source = Source,
-        target = Target,
-        history = OldHistory,
-        start_seq = {_, StartSeq},
-        current_through_seq = {_Ts, NewSeq} = NewTsSeq,
-        source_log = SourceLog,
-        target_log = TargetLog,
-        rep_starttime = ReplicationStartTime,
-        src_starttime = SrcInstanceStartTime,
-        tgt_starttime = TgtInstanceStartTime,
-        stats = Stats,
-        rep_details = #rep{options = Options},
-        session_id = SessionId
-    } = State,
-    case commit_to_both(Source, Target) of
-    {source_error, Reason} ->
-         {checkpoint_commit_failure,
-             <<"Failure on source commit: ", (to_binary(Reason))/binary>>};
-    {target_error, Reason} ->
-         {checkpoint_commit_failure,
-             <<"Failure on target commit: ", (to_binary(Reason))/binary>>};
-    {SrcInstanceStartTime, TgtInstanceStartTime} ->
-        ?LOG_INFO("recording a checkpoint for `~s` -> `~s` at source update_seq ~p",
-            [SourceName, TargetName, NewSeq]),
-        StartTime = ?l2b(ReplicationStartTime),
-        EndTime = ?l2b(couch_util:rfc1123_date()),
-        NewHistoryEntry = {[
-            {<<"session_id">>, SessionId},
-            {<<"start_time">>, StartTime},
-            {<<"end_time">>, EndTime},
-            {<<"start_last_seq">>, StartSeq},
-            {<<"end_last_seq">>, NewSeq},
-            {<<"recorded_seq">>, NewSeq},
-            {<<"missing_checked">>, Stats#rep_stats.missing_checked},
-            {<<"missing_found">>, Stats#rep_stats.missing_found},
-            {<<"docs_read">>, Stats#rep_stats.docs_read},
-            {<<"docs_written">>, Stats#rep_stats.docs_written},
-            {<<"doc_write_failures">>, Stats#rep_stats.doc_write_failures}
-        ]},
-        BaseHistory = [
-            {<<"session_id">>, SessionId},
-            {<<"source_last_seq">>, NewSeq},
-            {<<"replication_id_version">>, ?REP_ID_VERSION}
-        ] ++ case get_value(doc_ids, Options) of
-        undefined ->
-            [];
-        _DocIds ->
-            % backwards compatibility with the result of a replication by
-            % doc IDs in versions 0.11.x and 1.0.x
-            % TODO: deprecate (use same history format, simplify code)
-            [
-                {<<"start_time">>, StartTime},
-                {<<"end_time">>, EndTime},
-                {<<"docs_read">>, Stats#rep_stats.docs_read},
-                {<<"docs_written">>, Stats#rep_stats.docs_written},
-                {<<"doc_write_failures">>, Stats#rep_stats.doc_write_failures}
-            ]
-        end,
-        % limit history to 50 entries
-        NewRepHistory = {
-            BaseHistory ++
-            [{<<"history">>, lists:sublist([NewHistoryEntry | OldHistory], 50)}]
-        },
-
-        try
-            {SrcRevPos, SrcRevId} = update_checkpoint(
-                Source, SourceLog#doc{body = NewRepHistory}, source),
-            {TgtRevPos, TgtRevId} = update_checkpoint(
-                Target, TargetLog#doc{body = NewRepHistory}, target),
-            SourceCurSeq = source_cur_seq(State),
-            NewState = State#rep_state{
-                source_seq = SourceCurSeq,
-                checkpoint_history = NewRepHistory,
-                committed_seq = NewTsSeq,
-                source_log = SourceLog#doc{revs={SrcRevPos, [SrcRevId]}},
-                target_log = TargetLog#doc{revs={TgtRevPos, [TgtRevId]}}
-            },
-            update_task(NewState),
-            {ok, NewState}
-        catch throw:{checkpoint_commit_failure, _} = Failure ->
-            Failure
-        end;
-    {SrcInstanceStartTime, _NewTgtInstanceStartTime} ->
-        {checkpoint_commit_failure, <<"Target database out of sync. "
-            "Try to increase max_dbs_open at the target's server.">>};
-    {_NewSrcInstanceStartTime, TgtInstanceStartTime} ->
-        {checkpoint_commit_failure, <<"Source database out of sync. "
-            "Try to increase max_dbs_open at the source's server.">>};
-    {_NewSrcInstanceStartTime, _NewTgtInstanceStartTime} ->
-        {checkpoint_commit_failure, <<"Source and target databases out of "
-            "sync. Try to increase max_dbs_open at both servers.">>}
-    end.
-
-
-update_checkpoint(Db, Doc, DbType) ->
-    try
-        update_checkpoint(Db, Doc)
-    catch throw:{checkpoint_commit_failure, Reason} ->
-        throw({checkpoint_commit_failure,
-            <<"Error updating the ", (to_binary(DbType))/binary,
-                " checkpoint document: ", (to_binary(Reason))/binary>>})
-    end.
-
-update_checkpoint(Db, #doc{id = LogId, body = LogBody} = Doc) ->
-    try
-        case couch_replicator_api_wrap:update_doc(Db, Doc, [delay_commit]) of
-        {ok, PosRevId} ->
-            PosRevId;
-        {error, Reason} ->
-            throw({checkpoint_commit_failure, Reason})
-        end
-    catch throw:conflict ->
-        case (catch couch_replicator_api_wrap:open_doc(Db, LogId, [ejson_body])) of
-        {ok, #doc{body = LogBody, revs = {Pos, [RevId | _]}}} ->
-            % This means that we were able to update successfully the
-            % checkpoint doc in a previous attempt but we got a connection
-            % error (timeout for e.g.) before receiving the success response.
-            % Therefore the request was retried and we got a conflict, as the
-            % revision we sent is not the current one.
-            % We confirm this by verifying the doc body we just got is the same
-            % that we have just sent.
-            {Pos, RevId};
-        _ ->
-            throw({checkpoint_commit_failure, conflict})
-        end
-    end.
-
-
-commit_to_both(Source, Target) ->
-    % commit the src async
-    ParentPid = self(),
-    SrcCommitPid = spawn_link(
-        fun() ->
-            Result = (catch couch_replicator_api_wrap:ensure_full_commit(Source)),
-            ParentPid ! {self(), Result}
-        end),
-
-    % commit tgt sync
-    TargetResult = (catch couch_replicator_api_wrap:ensure_full_commit(Target)),
-
-    SourceResult = receive
-    {SrcCommitPid, Result} ->
-        unlink(SrcCommitPid),
-        receive {'EXIT', SrcCommitPid, _} -> ok after 0 -> ok end,
-        Result;
-    {'EXIT', SrcCommitPid, Reason} ->
-        {error, Reason}
-    end,
-    case TargetResult of
-    {ok, TargetStartTime} ->
-        case SourceResult of
-        {ok, SourceStartTime} ->
-            {SourceStartTime, TargetStartTime};
-        SourceError ->
-            {source_error, SourceError}
-        end;
-    TargetError ->
-        {target_error, TargetError}
-    end.
-
-
-compare_replication_logs(SrcDoc, TgtDoc) ->
-    #doc{body={RepRecProps}} = SrcDoc,
-    #doc{body={RepRecPropsTgt}} = TgtDoc,
-    case get_value(<<"session_id">>, RepRecProps) ==
-            get_value(<<"session_id">>, RepRecPropsTgt) of
-    true ->
-        % if the records have the same session id,
-        % then we have a valid replication history
-        OldSeqNum = get_value(<<"source_last_seq">>, RepRecProps, ?LOWEST_SEQ),
-        OldHistory = get_value(<<"history">>, RepRecProps, []),
-        {OldSeqNum, OldHistory};
-    false ->
-        SourceHistory = get_value(<<"history">>, RepRecProps, []),
-        TargetHistory = get_value(<<"history">>, RepRecPropsTgt, []),
-        ?LOG_INFO("Replication records differ. "
-                "Scanning histories to find a common ancestor.", []),
-        ?LOG_DEBUG("Record on source:~p~nRecord on target:~p~n",
-                [RepRecProps, RepRecPropsTgt]),
-        compare_rep_history(SourceHistory, TargetHistory)
-    end.
-
-compare_rep_history(S, T) when S =:= [] orelse T =:= [] ->
-    ?LOG_INFO("no common ancestry -- performing full replication", []),
-    {?LOWEST_SEQ, []};
-compare_rep_history([{S} | SourceRest], [{T} | TargetRest] = Target) ->
-    SourceId = get_value(<<"session_id">>, S),
-    case has_session_id(SourceId, Target) of
-    true ->
-        RecordSeqNum = get_value(<<"recorded_seq">>, S, ?LOWEST_SEQ),
-        ?LOG_INFO("found a common replication record with source_seq ~p",
-            [RecordSeqNum]),
-        {RecordSeqNum, SourceRest};
-    false ->
-        TargetId = get_value(<<"session_id">>, T),
-        case has_session_id(TargetId, SourceRest) of
-        true ->
-            RecordSeqNum = get_value(<<"recorded_seq">>, T, ?LOWEST_SEQ),
-            ?LOG_INFO("found a common replication record with source_seq ~p",
-                [RecordSeqNum]),
-            {RecordSeqNum, TargetRest};
-        false ->
-            compare_rep_history(SourceRest, TargetRest)
-        end
-    end.
-
-
-has_session_id(_SessionId, []) ->
-    false;
-has_session_id(SessionId, [{Props} | Rest]) ->
-    case get_value(<<"session_id">>, Props, nil) of
-    SessionId ->
-        true;
-    _Else ->
-        has_session_id(SessionId, Rest)
-    end.
-
-
-db_monitor(#db{} = Db) ->
-    couch_db:monitor(Db);
-db_monitor(_HttpDb) ->
-    nil.
-
-source_cur_seq(#rep_state{source = #httpdb{} = Db, source_seq = Seq,
-                          type = view, view = {DDoc, VName}}) ->
-    case (catch couch_replicator_api_wrap:get_view_info(
-                Db#httpdb{retries = 3}, DDoc, VName)) of
-    {ok, Info} ->
-        get_value(<<"update_seq">>, Info, Seq);
-    _ ->
-        Seq
-    end;
-
-source_cur_seq(#rep_state{source = Db, source_seq = Seq,
-                          type = view, view = {DDoc, VName}}) ->
-    {ok, Info} = couch_replicator_api_wrap:get_view_info(Db, DDoc, VName),
-    get_value(<<"update_seq">>, Info, Seq);
-
-source_cur_seq(#rep_state{source = #httpdb{} = Db, source_seq = Seq}) ->
-    case (catch couch_replicator_api_wrap:get_db_info(Db#httpdb{retries = 3})) of
-    {ok, Info} ->
-        get_value(<<"update_seq">>, Info, Seq);
-    _ ->
-        Seq
-    end;
-source_cur_seq(#rep_state{source = Db, source_seq = Seq}) ->
-    {ok, Info} = couch_replicator_api_wrap:get_db_info(Db),
-    get_value(<<"update_seq">>, Info, Seq).
-
-
-update_task(State) ->
-    #rep_state{
-        current_through_seq = {_, CurSeq},
-        source_seq = SourceCurSeq
-    } = State,
-    couch_task_status:update(
-        rep_stats(State) ++ [
-        {source_seq, SourceCurSeq},
-        case is_number(CurSeq) andalso is_number(SourceCurSeq) of
-        true ->
-            case SourceCurSeq of
-            0 ->
-                {progress, 0};
-            _ ->
-                {progress, (CurSeq * 100) div SourceCurSeq}
-            end;
-        false ->
-            {progress, null}
-        end
-    ]).
-
-
-rep_stats(State) ->
-    #rep_state{
-        committed_seq = {_, CommittedSeq},
-        stats = Stats
-    } = State,
-    [
-        {revisions_checked, Stats#rep_stats.missing_checked},
-        {missing_revisions_found, Stats#rep_stats.missing_found},
-        {docs_read, Stats#rep_stats.docs_read},
-        {docs_written, Stats#rep_stats.docs_written},
-        {doc_write_failures, Stats#rep_stats.doc_write_failures},
-        {checkpointed_source_seq, CommittedSeq}
-    ].
-

http://git-wip-us.apache.org/repos/asf/couchdb/blob/4c39d7a5/apps/couch_replicator/src/couch_replicator.hrl
----------------------------------------------------------------------
diff --git a/apps/couch_replicator/src/couch_replicator.hrl b/apps/couch_replicator/src/couch_replicator.hrl
deleted file mode 100644
index 1eee88e..0000000
--- a/apps/couch_replicator/src/couch_replicator.hrl
+++ /dev/null
@@ -1,32 +0,0 @@
-% Licensed 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.
-
--define(REP_ID_VERSION, 3).
-
--record(rep, {
-    id,
-    source,
-    target,
-    options,
-    user_ctx,
-    type = db,
-    view = nil,
-    doc_id
-}).
-
--record(rep_stats, {
-    missing_checked = 0,
-    missing_found = 0,
-    docs_read = 0,
-    docs_written = 0,
-    doc_write_failures = 0
-}).

http://git-wip-us.apache.org/repos/asf/couchdb/blob/4c39d7a5/apps/couch_replicator/src/couch_replicator_api_wrap.erl
----------------------------------------------------------------------
diff --git a/apps/couch_replicator/src/couch_replicator_api_wrap.erl b/apps/couch_replicator/src/couch_replicator_api_wrap.erl
deleted file mode 100644
index 1e0e660..0000000
--- a/apps/couch_replicator/src/couch_replicator_api_wrap.erl
+++ /dev/null
@@ -1,900 +0,0 @@
-% Licensed 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.
-
--module(couch_replicator_api_wrap).
-
-% This module wraps the native erlang API, and allows for performing
-% operations on a remote vs. local databases via the same API.
-%
-% Notes:
-% Many options and apis aren't yet supported here, they are added as needed.
-
--include_lib("couch/include/couch_db.hrl").
--include_lib("couch_mrview/include/couch_mrview.hrl").
--include("couch_replicator_api_wrap.hrl").
-
--export([
-    db_open/2,
-    db_open/3,
-    db_close/1,
-    get_db_info/1,
-    get_view_info/3,
-    update_doc/3,
-    update_doc/4,
-    update_docs/3,
-    update_docs/4,
-    ensure_full_commit/1,
-    get_missing_revs/2,
-    open_doc/3,
-    open_doc_revs/6,
-    changes_since/5,
-    db_uri/1
-    ]).
-
--import(couch_replicator_httpc, [
-    send_req/3
-    ]).
-
--import(couch_util, [
-    encode_doc_id/1,
-    get_value/2,
-    get_value/3
-    ]).
-
--define(MAX_WAIT, 5 * 60 * 1000).
-
-db_uri(#httpdb{url = Url}) ->
-    couch_util:url_strip_password(Url);
-
-db_uri(#db{name = Name}) ->
-    db_uri(Name);
-
-db_uri(DbName) ->
-    ?b2l(DbName).
-
-
-db_open(Db, Options) ->
-    db_open(Db, Options, false).
-
-db_open(#httpdb{} = Db1, _Options, Create) ->
-    {ok, Db} = couch_replicator_httpc:setup(Db1),
-    case Create of
-    false ->
-        ok;
-    true ->
-        send_req(Db, [{method, put}], fun(_, _, _) -> ok end)
-    end,
-    send_req(Db, [{method, head}],
-        fun(200, _, _) ->
-            {ok, Db};
-        (401, _, _) ->
-            throw({unauthorized, ?l2b(db_uri(Db))});
-        (_, _, _) ->
-            throw({db_not_found, ?l2b(db_uri(Db))})
-        end);
-db_open(DbName, Options, Create) ->
-    try
-        case Create of
-        false ->
-            ok;
-        true ->
-            ok = couch_httpd:verify_is_server_admin(
-                get_value(user_ctx, Options)),
-            couch_db:create(DbName, Options)
-        end,
-        case couch_db:open(DbName, Options) of
-        {error, illegal_database_name, _} ->
-            throw({db_not_found, DbName});
-        {not_found, _Reason} ->
-            throw({db_not_found, DbName});
-        {ok, _Db} = Success ->
-            Success
-        end
-    catch
-    throw:{unauthorized, _} ->
-        throw({unauthorized, DbName})
-    end.
-
-db_close(#httpdb{httpc_pool = Pool}) ->
-    unlink(Pool),
-    ok = couch_replicator_httpc_pool:stop(Pool);
-db_close(DbName) ->
-    catch couch_db:close(DbName).
-
-
-get_db_info(#httpdb{} = Db) ->
-    send_req(Db, [],
-        fun(200, _, {Props}) ->
-            {ok, Props}
-        end);
-get_db_info(#db{name = DbName, user_ctx = UserCtx}) ->
-    {ok, Db} = couch_db:open(DbName, [{user_ctx, UserCtx}]),
-    {ok, Info} = couch_db:get_db_info(Db),
-    couch_db:close(Db),
-    {ok, [{couch_util:to_binary(K), V} || {K, V} <- Info]}.
-
-
-get_view_info(#httpdb{} = Db, DDocId, ViewName) ->
-    Path = iolist_to_binary([DDocId, "/_view/", ViewName, "/_info"]),
-    send_req(Db, [{path, Path}],
-        fun(200, _, {Props}) ->
-            {ok, Props}
-        end);
-get_view_info(#db{name = DbName}, DDocId, ViewName) ->
-    couch_mrview:get_view_info(DbName, DDocId, ViewName).
-
-
-ensure_full_commit(#httpdb{} = Db) ->
-    send_req(
-        Db,
-        [{method, post}, {path, "_ensure_full_commit"},
-            {headers, [{"Content-Type", "application/json"}]}],
-        fun(201, _, {Props}) ->
-            {ok, get_value(<<"instance_start_time">>, Props)};
-        (_, _, {Props}) ->
-            {error, get_value(<<"error">>, Props)}
-        end);
-ensure_full_commit(Db) ->
-    couch_db:ensure_full_commit(Db).
-
-
-get_missing_revs(#httpdb{} = Db, IdRevs) ->
-    JsonBody = {[{Id, couch_doc:revs_to_strs(Revs)} || {Id, Revs} <- IdRevs]},
-    send_req(
-        Db,
-        [{method, post}, {path, "_revs_diff"}, {body, ?JSON_ENCODE(JsonBody)},
-            {headers, [{"Content-Type", "application/json"}]}],
-        fun(200, _, {Props}) ->
-            ConvertToNativeFun = fun({Id, {Result}}) ->
-                MissingRevs = couch_doc:parse_revs(
-                    get_value(<<"missing">>, Result)
-                ),
-                PossibleAncestors = couch_doc:parse_revs(
-                    get_value(<<"possible_ancestors">>, Result, [])
-                ),
-                {Id, MissingRevs, PossibleAncestors}
-            end,
-            {ok, lists:map(ConvertToNativeFun, Props)}
-        end);
-get_missing_revs(Db, IdRevs) ->
-    couch_db:get_missing_revs(Db, IdRevs).
-
-
-
-open_doc_revs(#httpdb{retries = 0} = HttpDb, Id, Revs, Options, _Fun, _Acc) ->
-    Path = encode_doc_id(Id),
-    QS = options_to_query_args(HttpDb, Path, [revs, {open_revs, Revs} | Options]),
-    Url = couch_util:url_strip_password(
-        couch_replicator_httpc:full_url(HttpDb, [{path,Path}, {qs,QS}])
-    ),
-    ?LOG_ERROR("Replication crashing because GET ~s failed", [Url]),
-    exit(kaboom);
-open_doc_revs(#httpdb{} = HttpDb, Id, Revs, Options, Fun, Acc) ->
-    Path = encode_doc_id(Id),
-    QS = options_to_query_args(HttpDb, Path, [revs, {open_revs, Revs} | Options]),
-    {Pid, Ref} = spawn_monitor(fun() ->
-        Self = self(),
-        Callback = fun(200, Headers, StreamDataFun) ->
-            remote_open_doc_revs_streamer_start(Self),
-            {<<"--">>, _, _} = couch_httpd:parse_multipart_request(
-                get_value("Content-Type", Headers),
-                StreamDataFun,
-                fun mp_parse_mixed/1
-            )
-        end,
-        Streamer = spawn_link(fun() ->
-            Params = [
-                {path, Path},
-                {qs, QS},
-                {ibrowse_options, [{stream_to, {self(), once}}]},
-                {headers, [{"Accept", "multipart/mixed"}]}
-            ],
-            % We're setting retries to 0 here to avoid the case where the
-            % Streamer retries the request and ends up jumbling together two
-            % different response bodies.  Retries are handled explicitly by
-            % open_doc_revs itself.
-            send_req(HttpDb#httpdb{retries = 0}, Params, Callback)
-        end),
-        % If this process dies normally we can leave
-        % the Streamer process hanging around keeping an
-        % HTTP connection open. This is a bit of a
-        % hammer approach to making sure it releases
-        % that connection back to the pool.
-        spawn(fun() ->
-            Ref = erlang:monitor(process, Self),
-            receive
-                {'DOWN', Ref, process, Self, normal} ->
-                    exit(Streamer, {streamer_parent_died, Self});
-                {'DOWN', Ref, process, Self, _} ->
-                    ok
-                end
-        end),
-        receive
-        {started_open_doc_revs, Ref} ->
-            Ret = receive_docs_loop(Streamer, Fun, Id, Revs, Ref, Acc),
-            exit({exit_ok, Ret})
-        end
-    end),
-    receive
-        {'DOWN', Ref, process, Pid, {exit_ok, Ret}} ->
-            Ret;
-        {'DOWN', Ref, process, Pid, {{nocatch, {missing_stub,_} = Stub}, _}} ->
-            throw(Stub);
-        {'DOWN', Ref, process, Pid, Else} ->
-            Url = couch_util:url_strip_password(
-                couch_replicator_httpc:full_url(HttpDb, [{path,Path}, {qs,QS}])
-            ),
-            #httpdb{retries = Retries, wait = Wait0} = HttpDb,
-            Wait = 2 * erlang:min(Wait0 * 2, ?MAX_WAIT),
-            ?LOG_INFO("Retrying GET to ~s in ~p seconds due to error ~p",
-                [Url, Wait / 1000, error_reason(Else)]
-            ),
-            ok = timer:sleep(Wait),
-            RetryDb = HttpDb#httpdb{
-                retries = Retries - 1,
-                wait = Wait
-            },
-            open_doc_revs(RetryDb, Id, Revs, Options, Fun, Acc)
-    end;
-open_doc_revs(Db, Id, Revs, Options, Fun, Acc) ->
-    {ok, Results} = couch_db:open_doc_revs(Db, Id, Revs, Options),
-    {ok, lists:foldl(fun(R, A) -> {_, A2} = Fun(R, A), A2 end, Acc, Results)}.
-
-error_reason({http_request_failed, "GET", _Url, {error, timeout}}) ->
-    timeout;
-error_reason({http_request_failed, "GET", _Url, {error, {_, req_timedout}}}) ->
-    req_timedout;
-error_reason({http_request_failed, "GET", _Url, Error}) ->
-    Error;
-error_reason(Else) ->
-    Else.
-
-open_doc(#httpdb{} = Db, Id, Options) ->
-    send_req(
-        Db,
-        [{path, encode_doc_id(Id)}, {qs, options_to_query_args(Options, [])}],
-        fun(200, _, Body) ->
-            {ok, couch_doc:from_json_obj(Body)};
-        (_, _, {Props}) ->
-            {error, get_value(<<"error">>, Props)}
-        end);
-open_doc(Db, Id, Options) ->
-    case couch_db:open_doc(Db, Id, Options) of
-    {ok, _} = Ok ->
-        Ok;
-    {not_found, _Reason} ->
-        {error, <<"not_found">>}
-    end.
-
-
-update_doc(Db, Doc, Options) ->
-    update_doc(Db, Doc, Options, interactive_edit).
-
-update_doc(#httpdb{} = HttpDb, #doc{id = DocId} = Doc, Options, Type) ->
-    QArgs = case Type of
-    replicated_changes ->
-        [{"new_edits", "false"}];
-    _ ->
-        []
-    end ++ options_to_query_args(Options, []),
-    Boundary = couch_uuids:random(),
-    JsonBytes = ?JSON_ENCODE(
-        couch_doc:to_json_obj(
-          Doc, [revs, attachments, follows, att_encoding_info | Options])),
-    {ContentType, Len} = couch_doc:len_doc_to_multi_part_stream(Boundary,
-        JsonBytes, Doc#doc.atts, true),
-    Headers = case lists:member(delay_commit, Options) of
-    true ->
-        [{"X-Couch-Full-Commit", "false"}];
-    false ->
-        []
-    end ++ [{"Content-Type", ?b2l(ContentType)}, {"Content-Length", Len}],
-    Body = {fun stream_doc/1, {JsonBytes, Doc#doc.atts, Boundary, Len}},
-    send_req(
-        % A crash here bubbles all the way back up to run_user_fun inside
-        % open_doc_revs, which will retry the whole thing.  That's the
-        % appropriate course of action, since we've already started streaming
-        % the response body from the GET request.
-        HttpDb#httpdb{retries = 0},
-        [{method, put}, {path, encode_doc_id(DocId)},
-            {qs, QArgs}, {headers, Headers}, {body, Body}],
-        fun(Code, _, {Props}) when Code =:= 200 orelse Code =:= 201 ->
-                {ok, couch_doc:parse_rev(get_value(<<"rev">>, Props))};
-            (409, _, _) ->
-                throw(conflict);
-            (Code, _, {Props}) ->
-                case {Code, get_value(<<"error">>, Props)} of
-                {401, <<"unauthorized">>} ->
-                    throw({unauthorized, get_value(<<"reason">>, Props)});
-                {403, <<"forbidden">>} ->
-                    throw({forbidden, get_value(<<"reason">>, Props)});
-                {412, <<"missing_stub">>} ->
-                    throw({missing_stub, get_value(<<"reason">>, Props)});
-                {_, Error} ->
-                    {error, Error}
-                end
-        end);
-update_doc(Db, Doc, Options, Type) ->
-    couch_db:update_doc(Db, Doc, Options, Type).
-
-
-update_docs(Db, DocList, Options) ->
-    update_docs(Db, DocList, Options, interactive_edit).
-
-update_docs(_Db, [], _Options, _UpdateType) ->
-    {ok, []};
-update_docs(#httpdb{} = HttpDb, DocList, Options, UpdateType) ->
-    FullCommit = atom_to_list(not lists:member(delay_commit, Options)),
-    Prefix = case UpdateType of
-    replicated_changes ->
-        <<"{\"new_edits\":false,\"docs\":[">>;
-    interactive_edit ->
-        <<"{\"docs\":[">>
-    end,
-    Suffix = <<"]}">>,
-    % Note: nginx and other servers don't like PUT/POST requests without
-    % a Content-Length header, so we can't do a chunked transfer encoding
-    % and JSON encode each doc only before sending it through the socket.
-    {Docs, Len} = lists:mapfoldl(
-        fun(#doc{} = Doc, Acc) ->
-            Json = ?JSON_ENCODE(couch_doc:to_json_obj(Doc, [revs, attachments])),
-            {Json, Acc + iolist_size(Json)};
-        (Doc, Acc) ->
-            {Doc, Acc + iolist_size(Doc)}
-        end,
-        byte_size(Prefix) + byte_size(Suffix) + length(DocList) - 1,
-        DocList),
-    BodyFun = fun(eof) ->
-            eof;
-        ([]) ->
-            {ok, Suffix, eof};
-        ([prefix | Rest]) ->
-            {ok, Prefix, Rest};
-        ([Doc]) ->
-            {ok, Doc, []};
-        ([Doc | RestDocs]) ->
-            {ok, [Doc, ","], RestDocs}
-    end,
-    Headers = [
-        {"Content-Length", Len},
-        {"Content-Type", "application/json"},
-        {"X-Couch-Full-Commit", FullCommit}
-    ],
-    send_req(
-        HttpDb,
-        [{method, post}, {path, "_bulk_docs"},
-            {body, {BodyFun, [prefix | Docs]}}, {headers, Headers}],
-        fun(201, _, Results) when is_list(Results) ->
-                {ok, bulk_results_to_errors(DocList, Results, remote)};
-           (417, _, Results) when is_list(Results) ->
-                {ok, bulk_results_to_errors(DocList, Results, remote)}
-        end);
-update_docs(Db, DocList, Options, UpdateType) ->
-    Result = couch_db:update_docs(Db, DocList, Options, UpdateType),
-    {ok, bulk_results_to_errors(DocList, Result, UpdateType)}.
-
-
-changes_since(#httpdb{headers = Headers1} = HttpDb, Style, StartSeq,
-    UserFun, Options) ->
-    HeartBeat = erlang:max(1000, HttpDb#httpdb.timeout div 3),
-    BaseQArgs = case get_value(continuous, Options, false) of
-    false ->
-        [{"feed", "normal"}];
-    true ->
-        [{"feed", "continuous"}]
-    end ++ [
-        {"style", atom_to_list(Style)}, {"since", ?JSON_ENCODE(StartSeq)},
-        {"heartbeat", integer_to_list(HeartBeat)}
-    ],
-    DocIds = get_value(doc_ids, Options),
-    {QArgs, Method, Body, Headers} = case DocIds of
-    undefined ->
-        QArgs1 = maybe_add_changes_filter_q_args(BaseQArgs, Options),
-        {QArgs1, get, [], Headers1};
-    _ when is_list(DocIds) ->
-        Headers2 = [{"Content-Type", "application/json"} | Headers1],
-        JsonDocIds = ?JSON_ENCODE({[{<<"doc_ids">>, DocIds}]}),
-        {[{"filter", "_doc_ids"} | BaseQArgs], post, JsonDocIds, Headers2}
-    end,
-    send_req(
-        HttpDb,
-        [{method, Method}, {path, "_changes"}, {qs, QArgs},
-            {headers, Headers}, {body, Body},
-            {ibrowse_options, [{stream_to, {self(), once}}]}],
-        fun(200, _, DataStreamFun) ->
-                parse_changes_feed(Options, UserFun, DataStreamFun);
-            (405, _, _) when is_list(DocIds) ->
-                % CouchDB versions < 1.1.0 don't have the builtin _changes feed
-                % filter "_doc_ids" neither support POST
-                send_req(HttpDb, [{method, get}, {path, "_changes"},
-                    {qs, BaseQArgs}, {headers, Headers1},
-                    {ibrowse_options, [{stream_to, {self(), once}}]}],
-                    fun(200, _, DataStreamFun2) ->
-                        UserFun2 = fun(#doc_info{id = Id} = DocInfo) ->
-                            case lists:member(Id, DocIds) of
-                            true ->
-                                UserFun(DocInfo);
-                            false ->
-                                ok
-                            end
-                        end,
-                        parse_changes_feed(Options, UserFun2, DataStreamFun2)
-                    end)
-        end);
-changes_since(Db, Style, StartSeq, UserFun, Options) ->
-    Filter = case get_value(doc_ids, Options) of
-    undefined ->
-        ?b2l(get_value(filter, Options, <<>>));
-    _DocIds ->
-        "_doc_ids"
-    end,
-    Args = #changes_args{
-        style = Style,
-        since = StartSeq,
-        filter = Filter,
-        feed = case get_value(continuous, Options, false) of
-            true ->
-                "continuous";
-            false ->
-                "normal"
-        end,
-        timeout = infinity
-    },
-    QueryParams = get_value(query_params, Options, {[]}),
-    Req = changes_json_req(Db, Filter, QueryParams, Options),
-    ChangesFeedFun = couch_httpd_changes:handle_changes(Args, {json_req, Req},
-                                                        Db),
-    ChangesFeedFun(fun({change, Change, _}, _) ->
-            UserFun(json_to_doc_info(Change));
-        (_, _) ->
-            ok
-    end).
-
-
-% internal functions
-
-maybe_add_changes_filter_q_args(BaseQS, Options) ->
-    case get_value(filter, Options) of
-    undefined ->
-        BaseQS;
-    FilterName ->
-        %% get list of view attributes
-        ViewFields0 = [atom_to_list(F) || F <- record_info(fields,  mrargs)],
-        ViewFields = ["key" | ViewFields0],
-
-        {Params} = get_value(query_params, Options, {[]}),
-        [{"filter", ?b2l(FilterName)} | lists:foldl(
-            fun({K, V}, QSAcc) ->
-                Ks = couch_util:to_list(K),
-                case lists:keymember(Ks, 1, QSAcc) of
-                true ->
-                    QSAcc;
-                false when FilterName =:= <<"_view">> ->
-                    V1 = case lists:member(Ks, ViewFields) of
-                        true -> ?JSON_ENCODE(V);
-                        false -> couch_util:to_list(V)
-                    end,
-                    [{Ks, V1} | QSAcc];
-                false ->
-                    [{Ks, couch_util:to_list(V)} | QSAcc]
-                end
-            end,
-            BaseQS, Params)]
-    end.
-
-parse_changes_feed(Options, UserFun, DataStreamFun) ->
-    case get_value(continuous, Options, false) of
-    true ->
-        continuous_changes(DataStreamFun, UserFun);
-    false ->
-        EventFun = fun(Ev) ->
-            changes_ev1(Ev, fun(DocInfo, _) -> UserFun(DocInfo) end, [])
-        end,
-        json_stream_parse:events(DataStreamFun, EventFun)
-    end.
-
-changes_json_req(_Db, "", _QueryParams, _Options) ->
-    {[]};
-changes_json_req(_Db, "_doc_ids", _QueryParams, Options) ->
-    {[{<<"doc_ids">>, get_value(doc_ids, Options)}]};
-changes_json_req(Db, FilterName, {QueryParams}, _Options) ->
-    {ok, Info} = couch_db:get_db_info(Db),
-    % simulate a request to db_name/_changes
-    {[
-        {<<"info">>, {Info}},
-        {<<"id">>, null},
-        {<<"method">>, 'GET'},
-        {<<"path">>, [couch_db:name(Db), <<"_changes">>]},
-        {<<"query">>, {[{<<"filter">>, FilterName} | QueryParams]}},
-        {<<"headers">>, []},
-        {<<"body">>, []},
-        {<<"peer">>, <<"replicator">>},
-        {<<"form">>, []},
-        {<<"cookie">>, []},
-        {<<"userCtx">>, couch_util:json_user_ctx(Db)}
-    ]}.
-
-
-options_to_query_args(HttpDb, Path, Options) ->
-    case lists:keytake(atts_since, 1, Options) of
-    false ->
-        options_to_query_args(Options, []);
-    {value, {atts_since, []}, Options2} ->
-        options_to_query_args(Options2, []);
-    {value, {atts_since, PAs}, Options2} ->
-        QueryArgs1 = options_to_query_args(Options2, []),
-        FullUrl = couch_replicator_httpc:full_url(
-            HttpDb, [{path, Path}, {qs, QueryArgs1}]),
-        RevList = atts_since_arg(
-            length("GET " ++ FullUrl ++ " HTTP/1.1\r\n") +
-            length("&atts_since=") + 6,  % +6 = % encoded [ and ]
-            PAs, []),
-        [{"atts_since", ?JSON_ENCODE(RevList)} | QueryArgs1]
-    end.
-
-
-options_to_query_args([], Acc) ->
-    lists:reverse(Acc);
-options_to_query_args([ejson_body | Rest], Acc) ->
-    options_to_query_args(Rest, Acc);
-options_to_query_args([delay_commit | Rest], Acc) ->
-    options_to_query_args(Rest, Acc);
-options_to_query_args([revs | Rest], Acc) ->
-    options_to_query_args(Rest, [{"revs", "true"} | Acc]);
-options_to_query_args([{open_revs, all} | Rest], Acc) ->
-    options_to_query_args(Rest, [{"open_revs", "all"} | Acc]);
-options_to_query_args([latest | Rest], Acc) ->
-    options_to_query_args(Rest, [{"latest", "true"} | Acc]);
-options_to_query_args([{open_revs, Revs} | Rest], Acc) ->
-    JsonRevs = ?b2l(?JSON_ENCODE(couch_doc:revs_to_strs(Revs))),
-    options_to_query_args(Rest, [{"open_revs", JsonRevs} | Acc]).
-
-
--define(MAX_URL_LEN, 7000).
-
-atts_since_arg(_UrlLen, [], Acc) ->
-    lists:reverse(Acc);
-atts_since_arg(UrlLen, [PA | Rest], Acc) ->
-    RevStr = couch_doc:rev_to_str(PA),
-    NewUrlLen = case Rest of
-    [] ->
-        % plus 2 double quotes (% encoded)
-        UrlLen + size(RevStr) + 6;
-    _ ->
-        % plus 2 double quotes and a comma (% encoded)
-        UrlLen + size(RevStr) + 9
-    end,
-    case NewUrlLen >= ?MAX_URL_LEN of
-    true ->
-        lists:reverse(Acc);
-    false ->
-        atts_since_arg(NewUrlLen, Rest, [RevStr | Acc])
-    end.
-
-
-% TODO: A less verbose, more elegant and automatic restart strategy for
-%       the exported open_doc_revs/6 function. The restart should be
-%       transparent to the caller like any other Couch API function exported
-%       by this module.
-receive_docs_loop(Streamer, Fun, Id, Revs, Ref, Acc) ->
-    try
-        % Left only for debugging purposes via an interactive or remote shell
-        erlang:put(open_doc_revs, {Id, Revs, Ref, Streamer}),
-        receive_docs(Streamer, Fun, Ref, Acc)
-    catch
-    error:{restart_open_doc_revs, NewRef} ->
-        receive_docs_loop(Streamer, Fun, Id, Revs, NewRef, Acc)
-    end.
-
-receive_docs(Streamer, UserFun, Ref, UserAcc) ->
-    Streamer ! {get_headers, Ref, self()},
-    receive
-    {started_open_doc_revs, NewRef} ->
-        restart_remote_open_doc_revs(Ref, NewRef);
-    {headers, Ref, Headers} ->
-        case get_value("content-type", Headers) of
-        {"multipart/related", _} = ContentType ->
-            case doc_from_multi_part_stream(
-                ContentType,
-                fun() -> receive_doc_data(Streamer, Ref) end,
-                Ref) of
-            {ok, Doc, Parser} ->
-                case run_user_fun(UserFun, {ok, Doc}, UserAcc, Ref) of
-                {ok, UserAcc2} ->
-                    ok;
-                {skip, UserAcc2} ->
-                    couch_doc:abort_multi_part_stream(Parser)
-                end,
-                receive_docs(Streamer, UserFun, Ref, UserAcc2)
-            end;
-        {"application/json", []} ->
-            Doc = couch_doc:from_json_obj(
-                    ?JSON_DECODE(receive_all(Streamer, Ref, []))),
-            {_, UserAcc2} = run_user_fun(UserFun, {ok, Doc}, UserAcc, Ref),
-            receive_docs(Streamer, UserFun, Ref, UserAcc2);
-        {"application/json", [{"error","true"}]} ->
-            {ErrorProps} = ?JSON_DECODE(receive_all(Streamer, Ref, [])),
-            Rev = get_value(<<"missing">>, ErrorProps),
-            Result = {{not_found, missing}, couch_doc:parse_rev(Rev)},
-            {_, UserAcc2} = run_user_fun(UserFun, Result, UserAcc, Ref),
-            receive_docs(Streamer, UserFun, Ref, UserAcc2)
-        end;
-    {done, Ref} ->
-        {ok, UserAcc}
-    end.
-
-
-run_user_fun(UserFun, Arg, UserAcc, OldRef) ->
-    {Pid, Ref} = spawn_monitor(fun() ->
-        try UserFun(Arg, UserAcc) of
-            Resp ->
-                exit({exit_ok, Resp})
-        catch
-            throw:Reason ->
-                exit({exit_throw, Reason});
-            error:Reason ->
-                exit({exit_error, Reason});
-            exit:Reason ->
-                exit({exit_exit, Reason})
-        end
-    end),
-    receive
-        {started_open_doc_revs, NewRef} ->
-            erlang:demonitor(Ref, [flush]),
-            exit(Pid, kill),
-            restart_remote_open_doc_revs(OldRef, NewRef);
-        {'DOWN', Ref, process, Pid, {exit_ok, Ret}} ->
-            Ret;
-        {'DOWN', Ref, process, Pid, {exit_throw, Reason}} ->
-            throw(Reason);
-        {'DOWN', Ref, process, Pid, {exit_error, Reason}} ->
-            erlang:error(Reason);
-        {'DOWN', Ref, process, Pid, {exit_exit, Reason}} ->
-            erlang:exit(Reason)
-    end.
-
-
-restart_remote_open_doc_revs(Ref, NewRef) ->
-    receive
-    {body_bytes, Ref, _} ->
-        restart_remote_open_doc_revs(Ref, NewRef);
-    {body_done, Ref} ->
-        restart_remote_open_doc_revs(Ref, NewRef);
-    {done, Ref} ->
-        restart_remote_open_doc_revs(Ref, NewRef);
-    {headers, Ref, _} ->
-        restart_remote_open_doc_revs(Ref, NewRef)
-    after 0 ->
-        erlang:error({restart_open_doc_revs, NewRef})
-    end.
-
-
-remote_open_doc_revs_streamer_start(Parent) ->
-    receive
-    {get_headers, _Ref, Parent} ->
-        remote_open_doc_revs_streamer_start(Parent);
-    {next_bytes, _Ref, Parent} ->
-        remote_open_doc_revs_streamer_start(Parent)
-    after 0 ->
-        Parent ! {started_open_doc_revs, make_ref()}
-    end.
-
-
-receive_all(Streamer, Ref, Acc) ->
-    Streamer ! {next_bytes, Ref, self()},
-    receive
-    {started_open_doc_revs, NewRef} ->
-        restart_remote_open_doc_revs(Ref, NewRef);
-    {body_bytes, Ref, Bytes} ->
-        receive_all(Streamer, Ref, [Bytes | Acc]);
-    {body_done, Ref} ->
-        lists:reverse(Acc)
-    end.
-
-
-mp_parse_mixed(eof) ->
-    receive {get_headers, Ref, From} ->
-        From ! {done, Ref}
-    end;
-mp_parse_mixed({headers, H}) ->
-    receive {get_headers, Ref, From} ->
-        From ! {headers, Ref, H}
-    end,
-    fun mp_parse_mixed/1;
-mp_parse_mixed({body, Bytes}) ->
-    receive {next_bytes, Ref, From} ->
-        From ! {body_bytes, Ref, Bytes}
-    end,
-    fun mp_parse_mixed/1;
-mp_parse_mixed(body_end) ->
-    receive {next_bytes, Ref, From} ->
-        From ! {body_done, Ref};
-    {get_headers, Ref, From} ->
-        self() ! {get_headers, Ref, From}
-    end,
-    fun mp_parse_mixed/1.
-
-
-receive_doc_data(Streamer, Ref) ->
-    Streamer ! {next_bytes, Ref, self()},
-    receive
-    {body_bytes, Ref, Bytes} ->
-        {Bytes, fun() -> receive_doc_data(Streamer, Ref) end};
-    {body_done, Ref} ->
-        {<<>>, fun() -> receive_doc_data(Streamer, Ref) end}
-    end.
-
-doc_from_multi_part_stream(ContentType, DataFun, Ref) ->
-    Self = self(),
-    Parser = spawn_link(fun() ->
-        {<<"--">>, _, _} = couch_httpd:parse_multipart_request(
-            ContentType, DataFun,
-            fun(Next) -> couch_doc:mp_parse_doc(Next, []) end),
-        unlink(Self)
-        end),
-    Parser ! {get_doc_bytes, Ref, self()},
-    receive
-    {started_open_doc_revs, NewRef} ->
-        unlink(Parser),
-        exit(Parser, kill),
-        restart_remote_open_doc_revs(Ref, NewRef);
-    {doc_bytes, Ref, DocBytes} ->
-        Doc = couch_doc:from_json_obj(?JSON_DECODE(DocBytes)),
-        ReadAttachmentDataFun = fun() ->
-            link(Parser),
-            Parser ! {get_bytes, Ref, self()},
-            receive
-            {started_open_doc_revs, NewRef} ->
-                unlink(Parser),
-                exit(Parser, kill),
-                receive {bytes, Ref, _} -> ok after 0 -> ok end,
-                restart_remote_open_doc_revs(Ref, NewRef);
-            {bytes, Ref, Bytes} ->
-                Bytes
-            end
-        end,
-        Atts2 = lists:map(
-            fun(#att{data = follows} = A) ->
-                A#att{data = ReadAttachmentDataFun};
-            (A) ->
-                A
-            end, Doc#doc.atts),
-        {ok, Doc#doc{atts = Atts2}, Parser}
-    end.
-
-
-changes_ev1(object_start, UserFun, UserAcc) ->
-    fun(Ev) -> changes_ev2(Ev, UserFun, UserAcc) end.
-
-changes_ev2({key, <<"results">>}, UserFun, UserAcc) ->
-    fun(Ev) -> changes_ev3(Ev, UserFun, UserAcc) end;
-changes_ev2(_, UserFun, UserAcc) ->
-    fun(Ev) -> changes_ev2(Ev, UserFun, UserAcc) end.
-
-changes_ev3(array_start, UserFun, UserAcc) ->
-    fun(Ev) -> changes_ev_loop(Ev, UserFun, UserAcc) end.
-
-changes_ev_loop(object_start, UserFun, UserAcc) ->
-    fun(Ev) ->
-        json_stream_parse:collect_object(Ev,
-            fun(Obj) ->
-                UserAcc2 = UserFun(json_to_doc_info(Obj), UserAcc),
-                fun(Ev2) -> changes_ev_loop(Ev2, UserFun, UserAcc2) end
-            end)
-    end;
-changes_ev_loop(array_end, _UserFun, _UserAcc) ->
-    fun(_Ev) -> changes_ev_done() end.
-
-changes_ev_done() ->
-    fun(_Ev) -> changes_ev_done() end.
-
-continuous_changes(DataFun, UserFun) ->
-    {DataFun2, _, Rest} = json_stream_parse:events(
-        DataFun,
-        fun(Ev) -> parse_changes_line(Ev, UserFun) end),
-    continuous_changes(fun() -> {Rest, DataFun2} end, UserFun).
-
-parse_changes_line(object_start, UserFun) ->
-    fun(Ev) ->
-        json_stream_parse:collect_object(Ev,
-            fun(Obj) -> UserFun(json_to_doc_info(Obj)) end)
-    end.
-
-json_to_doc_info({Props}) ->
-    RevsInfo = lists:map(
-        fun({Change}) ->
-            Rev = couch_doc:parse_rev(get_value(<<"rev">>, Change)),
-            Del = (true =:= get_value(<<"deleted">>, Change)),
-            #rev_info{rev=Rev, deleted=Del}
-        end, get_value(<<"changes">>, Props)),
-    #doc_info{
-        id = get_value(<<"id">>, Props),
-        high_seq = get_value(<<"seq">>, Props),
-        revs = RevsInfo
-    }.
-
-
-bulk_results_to_errors(Docs, {ok, Results}, interactive_edit) ->
-    lists:reverse(lists:foldl(
-        fun({_, {ok, _}}, Acc) ->
-            Acc;
-        ({#doc{id = Id, revs = {Pos, [RevId | _]}}, Error}, Acc) ->
-            {_, Error, Reason} = couch_httpd:error_info(Error),
-            [ {[{id, Id}, {rev, rev_to_str({Pos, RevId})},
-                {error, Error}, {reason, Reason}]} | Acc ]
-        end,
-        [], lists:zip(Docs, Results)));
-
-bulk_results_to_errors(Docs, {ok, Results}, replicated_changes) ->
-    bulk_results_to_errors(Docs, {aborted, Results}, interactive_edit);
-
-bulk_results_to_errors(_Docs, {aborted, Results}, interactive_edit) ->
-    lists:map(
-        fun({{Id, Rev}, Err}) ->
-            {_, Error, Reason} = couch_httpd:error_info(Err),
-            {[{id, Id}, {rev, rev_to_str(Rev)}, {error, Error}, {reason, Reason}]}
-        end,
-        Results);
-
-bulk_results_to_errors(_Docs, Results, remote) ->
-    lists:reverse(lists:foldl(
-        fun({Props}, Acc) ->
-            case get_value(<<"error">>, Props, get_value(error, Props)) of
-            undefined ->
-                Acc;
-            Error ->
-                Id = get_value(<<"id">>, Props, get_value(id, Props)),
-                Rev = get_value(<<"rev">>, Props, get_value(rev, Props)),
-                Reason = get_value(<<"reason">>, Props, get_value(reason, Props)),
-                [ {[{id, Id}, {rev, rev_to_str(Rev)},
-                    {error, Error}, {reason, Reason}]} | Acc ]
-            end
-        end,
-        [], Results)).
-
-
-rev_to_str({_Pos, _Id} = Rev) ->
-    couch_doc:rev_to_str(Rev);
-rev_to_str(Rev) ->
-    Rev.
-
-write_fun() ->
-    fun(Data) ->
-        receive {get_data, Ref, From} ->
-            From ! {data, Ref, Data}
-        end
-    end.
-
-stream_doc({JsonBytes, Atts, Boundary, Len}) ->
-    case erlang:erase({doc_streamer, Boundary}) of
-    Pid when is_pid(Pid) ->
-        unlink(Pid),
-        exit(Pid, kill);
-    _ ->
-        ok
-    end,
-    DocStreamer = spawn_link(
-        couch_doc,
-        doc_to_multi_part_stream,
-        [Boundary, JsonBytes, Atts, write_fun(), true]
-    ),
-    erlang:put({doc_streamer, Boundary}, DocStreamer),
-    {ok, <<>>, {Len, Boundary}};
-stream_doc({0, Id}) ->
-    erlang:erase({doc_streamer, Id}),
-    eof;
-stream_doc({LenLeft, Id}) when LenLeft > 0 ->
-    Ref = make_ref(),
-    erlang:get({doc_streamer, Id}) ! {get_data, Ref, self()},
-    receive {data, Ref, Data} ->
-        {ok, Data, {LenLeft - iolist_size(Data), Id}}
-    end.

http://git-wip-us.apache.org/repos/asf/couchdb/blob/4c39d7a5/apps/couch_replicator/src/couch_replicator_api_wrap.hrl
----------------------------------------------------------------------
diff --git a/apps/couch_replicator/src/couch_replicator_api_wrap.hrl b/apps/couch_replicator/src/couch_replicator_api_wrap.hrl
deleted file mode 100644
index 1a6f27a..0000000
--- a/apps/couch_replicator/src/couch_replicator_api_wrap.hrl
+++ /dev/null
@@ -1,36 +0,0 @@
-% Licensed 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.
-
-
-
--record(httpdb, {
-    url,
-    oauth = nil,
-    headers = [
-        {"Accept", "application/json"},
-        {"User-Agent", "CouchDB/" ++ couch_server:get_version()}
-    ],
-    timeout,            % milliseconds
-    ibrowse_options = [],
-    retries = 10,
-    wait = 250,         % milliseconds
-    httpc_pool = nil,
-    http_connections
-}).
-
--record(oauth, {
-    consumer_key,
-    token,
-    token_secret,
-    consumer_secret,
-    signature_method
-}).

http://git-wip-us.apache.org/repos/asf/couchdb/blob/4c39d7a5/apps/couch_replicator/src/couch_replicator_app.erl
----------------------------------------------------------------------
diff --git a/apps/couch_replicator/src/couch_replicator_app.erl b/apps/couch_replicator/src/couch_replicator_app.erl
deleted file mode 100644
index 4083db6..0000000
--- a/apps/couch_replicator/src/couch_replicator_app.erl
+++ /dev/null
@@ -1,29 +0,0 @@
-% Licensed 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.
-
--module(couch_replicator_app).
-
--behaviour(application).
-
-%% Application callbacks
--export([start/2, stop/1]).
-
-%% ===================================================================
-%% Application callbacks
-%% ===================================================================
-
-start(_StartType, _StartArgs) ->
-    couch_util:start_app_deps(couch_replicator),
-    couch_replicator_sup:start_link().
-
-stop(_State) ->
-    ok.


[21/57] [abbrv] remove couch_collate

Posted by be...@apache.org.
http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/ubrk.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/ubrk.h b/apps/couch_collate/platform/osx/icu/unicode/ubrk.h
deleted file mode 100644
index d57ba37..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/ubrk.h
+++ /dev/null
@@ -1,482 +0,0 @@
-/*
-******************************************************************************
-* Copyright (C) 1996-2007, International Business Machines Corporation and others.
-* All Rights Reserved.
-******************************************************************************
-*/
-
-#ifndef UBRK_H
-#define UBRK_H
-
-#include "unicode/utypes.h"
-#include "unicode/uloc.h"
-#include "unicode/utext.h"
-
-/**
- * A text-break iterator.
- *  For usage in C programs.
- */
-#ifndef UBRK_TYPEDEF_UBREAK_ITERATOR
-#   define UBRK_TYPEDEF_UBREAK_ITERATOR
-    /**
-     *  Opaque type representing an ICU Break iterator object.
-     *  @stable ICU 2.0
-     */
-    typedef void UBreakIterator;
-#endif
-
-#if !UCONFIG_NO_BREAK_ITERATION
-
-#include "unicode/parseerr.h"
-
-/**
- * \file
- * \brief C API: BreakIterator
- *
- * <h2> BreakIterator C API </h2>
- *
- * The BreakIterator C API defines  methods for finding the location
- * of boundaries in text. Pointer to a UBreakIterator maintain a
- * current position and scan over text returning the index of characters
- * where boundaries occur.
- * <p>
- * Line boundary analysis determines where a text string can be broken
- * when line-wrapping. The mechanism correctly handles punctuation and
- * hyphenated words.
- * <p>
- * Sentence boundary analysis allows selection with correct
- * interpretation of periods within numbers and abbreviations, and
- * trailing punctuation marks such as quotation marks and parentheses.
- * <p>
- * Word boundary analysis is used by search and replace functions, as
- * well as within text editing applications that allow the user to
- * select words with a double click. Word selection provides correct
- * interpretation of punctuation marks within and following
- * words. Characters that are not part of a word, such as symbols or
- * punctuation marks, have word-breaks on both sides.
- * <p>
- * Character boundary analysis allows users to interact with
- * characters as they expect to, for example, when moving the cursor
- * through a text string. Character boundary analysis provides correct
- * navigation of through character strings, regardless of how the
- * character is stored.  For example, an accented character might be
- * stored as a base character and a diacritical mark. What users
- * consider to be a character can differ between languages.
- * <p>
- * Title boundary analysis locates all positions,
- * typically starts of words, that should be set to Title Case
- * when title casing the text.
- * <p>
- * The text boundary positions are found according to the rules
- * described in Unicode Standard Annex #29, Text Boundaries, and
- * Unicode Standard Annex #14, Line Breaking Properties.  These
- * are available at http://www.unicode.org/reports/tr14/ and
- * http://www.unicode.org/reports/tr29/.
- * <p>
- * In addition to the plain C API defined in this header file, an
- * object oriented C++ API with equivalent functionality is defined in the
- * file brkiter.h.
- * <p>
- * Code snippits illustrating the use of the Break Iterator APIs
- * are available in the ICU User Guide,
- * http://icu-project.org/userguide/boundaryAnalysis.html
- * and in the sample program icu/source/samples/break/break.cpp"
- */
-
-/** The possible types of text boundaries.  @stable ICU 2.0 */
-typedef enum UBreakIteratorType {
-  /** Character breaks  @stable ICU 2.0 */
-  UBRK_CHARACTER = 0,
-  /** Word breaks @stable ICU 2.0 */
-  UBRK_WORD = 1,
-  /** Line breaks @stable ICU 2.0 */
-  UBRK_LINE = 2,
-  /** Sentence breaks @stable ICU 2.0 */
-  UBRK_SENTENCE = 3,
-
-#ifndef U_HIDE_DEPRECATED_API
-  /**
-   * Title Case breaks
-   * The iterator created using this type locates title boundaries as described for
-   * Unicode 3.2 only. For Unicode 4.0 and above title boundary iteration,
-   * please use Word Boundary iterator.
-   *
-   * @deprecated ICU 2.8 Use the word break iterator for titlecasing for Unicode 4 and later.
-   */
-  UBRK_TITLE = 4,
-#endif /* U_HIDE_DEPRECATED_API */
-  UBRK_COUNT = 5
-} UBreakIteratorType;
-
-/** Value indicating all text boundaries have been returned.
- *  @stable ICU 2.0
- */
-#define UBRK_DONE ((int32_t) -1)
-
-
-/**
- *  Enum constants for the word break tags returned by
- *  getRuleStatus().  A range of values is defined for each category of
- *  word, to allow for further subdivisions of a category in future releases.
- *  Applications should check for tag values falling within the range, rather
- *  than for single individual values.
- *  @stable ICU 2.2
-*/
-typedef enum UWordBreak {
-    /** Tag value for "words" that do not fit into any of other categories.
-     *  Includes spaces and most punctuation. */
-    UBRK_WORD_NONE           = 0,
-    /** Upper bound for tags for uncategorized words. */
-    UBRK_WORD_NONE_LIMIT     = 100,
-    /** Tag value for words that appear to be numbers, lower limit.    */
-    UBRK_WORD_NUMBER         = 100,
-    /** Tag value for words that appear to be numbers, upper limit.    */
-    UBRK_WORD_NUMBER_LIMIT   = 200,
-    /** Tag value for words that contain letters, excluding
-     *  hiragana, katakana or ideographic characters, lower limit.    */
-    UBRK_WORD_LETTER         = 200,
-    /** Tag value for words containing letters, upper limit  */
-    UBRK_WORD_LETTER_LIMIT   = 300,
-    /** Tag value for words containing kana characters, lower limit */
-    UBRK_WORD_KANA           = 300,
-    /** Tag value for words containing kana characters, upper limit */
-    UBRK_WORD_KANA_LIMIT     = 400,
-    /** Tag value for words containing ideographic characters, lower limit */
-    UBRK_WORD_IDEO           = 400,
-    /** Tag value for words containing ideographic characters, upper limit */
-    UBRK_WORD_IDEO_LIMIT     = 500
-} UWordBreak;
-
-/**
- *  Enum constants for the line break tags returned by getRuleStatus().
- *  A range of values is defined for each category of
- *  word, to allow for further subdivisions of a category in future releases.
- *  Applications should check for tag values falling within the range, rather
- *  than for single individual values.
- *  @stable ICU 2.8
-*/
-typedef enum ULineBreakTag {
-    /** Tag value for soft line breaks, positions at which a line break
-      *  is acceptable but not required                */
-    UBRK_LINE_SOFT            = 0,
-    /** Upper bound for soft line breaks.              */
-    UBRK_LINE_SOFT_LIMIT      = 100,
-    /** Tag value for a hard, or mandatory line break  */
-    UBRK_LINE_HARD            = 100,
-    /** Upper bound for hard line breaks.              */
-    UBRK_LINE_HARD_LIMIT      = 200
-} ULineBreakTag;
-
-
-
-/**
- *  Enum constants for the sentence break tags returned by getRuleStatus().
- *  A range of values is defined for each category of
- *  sentence, to allow for further subdivisions of a category in future releases.
- *  Applications should check for tag values falling within the range, rather
- *  than for single individual values.
- *  @stable ICU 2.8
-*/
-typedef enum USentenceBreakTag {
-    /** Tag value for for sentences  ending with a sentence terminator
-      * ('.', '?', '!', etc.) character, possibly followed by a
-      * hard separator (CR, LF, PS, etc.)
-      */
-    UBRK_SENTENCE_TERM       = 0,
-    /** Upper bound for tags for sentences ended by sentence terminators.    */
-    UBRK_SENTENCE_TERM_LIMIT = 100,
-    /** Tag value for for sentences that do not contain an ending
-      * sentence terminator ('.', '?', '!', etc.) character, but
-      * are ended only by a hard separator (CR, LF, PS, etc.) or end of input.
-      */
-    UBRK_SENTENCE_SEP        = 100,
-    /** Upper bound for tags for sentences ended by a separator.              */
-    UBRK_SENTENCE_SEP_LIMIT  = 200
-    /** Tag value for a hard, or mandatory line break  */
-} USentenceBreakTag;
-
-
-/**
- * Open a new UBreakIterator for locating text boundaries for a specified locale.
- * A UBreakIterator may be used for detecting character, line, word,
- * and sentence breaks in text.
- * @param type The type of UBreakIterator to open: one of UBRK_CHARACTER, UBRK_WORD,
- * UBRK_LINE, UBRK_SENTENCE
- * @param locale The locale specifying the text-breaking conventions.
- * @param text The text to be iterated over.
- * @param textLength The number of characters in text, or -1 if null-terminated.
- * @param status A UErrorCode to receive any errors.
- * @return A UBreakIterator for the specified locale.
- * @see ubrk_openRules
- * @stable ICU 2.0
- */
-U_STABLE UBreakIterator* U_EXPORT2
-ubrk_open(UBreakIteratorType type,
-      const char *locale,
-      const UChar *text,
-      int32_t textLength,
-      UErrorCode *status);
-
-/**
- * Open a new UBreakIterator for locating text boundaries using specified breaking rules.
- * The rule syntax is ... (TBD)
- * @param rules A set of rules specifying the text breaking conventions.
- * @param rulesLength The number of characters in rules, or -1 if null-terminated.
- * @param text The text to be iterated over.  May be null, in which case ubrk_setText() is
- *        used to specify the text to be iterated.
- * @param textLength The number of characters in text, or -1 if null-terminated.
- * @param parseErr   Receives position and context information for any syntax errors
- *                   detected while parsing the rules.
- * @param status A UErrorCode to receive any errors.
- * @return A UBreakIterator for the specified rules.
- * @see ubrk_open
- * @stable ICU 2.2
- */
-U_STABLE UBreakIterator* U_EXPORT2
-ubrk_openRules(const UChar     *rules,
-               int32_t         rulesLength,
-               const UChar     *text,
-               int32_t          textLength,
-               UParseError     *parseErr,
-               UErrorCode      *status);
-
-/**
- * Thread safe cloning operation
- * @param bi iterator to be cloned
- * @param stackBuffer user allocated space for the new clone. If NULL new memory will be allocated.
- *  If buffer is not large enough, new memory will be allocated.
- *  Clients can use the U_BRK_SAFECLONE_BUFFERSIZE. This will probably be enough to avoid memory allocations.
- * @param pBufferSize pointer to size of allocated space.
- *  If *pBufferSize == 0, a sufficient size for use in cloning will
- *  be returned ('pre-flighting')
- *  If *pBufferSize is not enough for a stack-based safe clone,
- *  new memory will be allocated.
- * @param status to indicate whether the operation went on smoothly or there were errors
- *  An informational status value, U_SAFECLONE_ALLOCATED_ERROR, is used if any allocations were necessary.
- * @return pointer to the new clone
- * @stable ICU 2.0
- */
-U_STABLE UBreakIterator * U_EXPORT2
-ubrk_safeClone(
-          const UBreakIterator *bi,
-          void *stackBuffer,
-          int32_t *pBufferSize,
-          UErrorCode *status);
-
-/**
-  * A recommended size (in bytes) for the memory buffer to be passed to ubrk_saveClone().
-  * @stable ICU 2.0
-  */
-#define U_BRK_SAFECLONE_BUFFERSIZE 512
-
-/**
-* Close a UBreakIterator.
-* Once closed, a UBreakIterator may no longer be used.
-* @param bi The break iterator to close.
- * @stable ICU 2.0
-*/
-U_STABLE void U_EXPORT2
-ubrk_close(UBreakIterator *bi);
-
-/**
- * Sets an existing iterator to point to a new piece of text
- * @param bi The iterator to use
- * @param text The text to be set
- * @param textLength The length of the text
- * @param status The error code
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2
-ubrk_setText(UBreakIterator* bi,
-             const UChar*    text,
-             int32_t         textLength,
-             UErrorCode*     status);
-
-
-/**
- * Sets an existing iterator to point to a new piece of text
- * @param bi The iterator to use
- * @param text The text to be set.
- *             This function makes a shallow clone of the supplied UText.  This means
- *             that the caller is free to immediately close or otherwise reuse the
- *             UText that was passed as a parameter, but that the underlying text itself
- *             must not be altered while being referenced by the break iterator.
- * @param status The error code
- * @stable ICU 3.4
- */
-U_STABLE void U_EXPORT2
-ubrk_setUText(UBreakIterator* bi,
-             UText*          text,
-             UErrorCode*     status);
-
-
-
-/**
- * Determine the most recently-returned text boundary.
- *
- * @param bi The break iterator to use.
- * @return The character index most recently returned by \ref ubrk_next, \ref ubrk_previous,
- * \ref ubrk_first, or \ref ubrk_last.
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2
-ubrk_current(const UBreakIterator *bi);
-
-/**
- * Determine the text boundary following the current text boundary.
- *
- * @param bi The break iterator to use.
- * @return The character index of the next text boundary, or UBRK_DONE
- * if all text boundaries have been returned.
- * @see ubrk_previous
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2
-ubrk_next(UBreakIterator *bi);
-
-/**
- * Determine the text boundary preceding the current text boundary.
- *
- * @param bi The break iterator to use.
- * @return The character index of the preceding text boundary, or UBRK_DONE
- * if all text boundaries have been returned.
- * @see ubrk_next
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2
-ubrk_previous(UBreakIterator *bi);
-
-/**
- * Determine the index of the first character in the text being scanned.
- * This is not always the same as index 0 of the text.
- * @param bi The break iterator to use.
- * @return The character index of the first character in the text being scanned.
- * @see ubrk_last
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2
-ubrk_first(UBreakIterator *bi);
-
-/**
- * Determine the index immediately <EM>beyond</EM> the last character in the text being
- * scanned.
- * This is not the same as the last character.
- * @param bi The break iterator to use.
- * @return The character offset immediately <EM>beyond</EM> the last character in the
- * text being scanned.
- * @see ubrk_first
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2
-ubrk_last(UBreakIterator *bi);
-
-/**
- * Determine the text boundary preceding the specified offset.
- * The value returned is always smaller than offset, or UBRK_DONE.
- * @param bi The break iterator to use.
- * @param offset The offset to begin scanning.
- * @return The text boundary preceding offset, or UBRK_DONE.
- * @see ubrk_following
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2
-ubrk_preceding(UBreakIterator *bi,
-           int32_t offset);
-
-/**
- * Determine the text boundary following the specified offset.
- * The value returned is always greater than offset, or UBRK_DONE.
- * @param bi The break iterator to use.
- * @param offset The offset to begin scanning.
- * @return The text boundary following offset, or UBRK_DONE.
- * @see ubrk_preceding
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2
-ubrk_following(UBreakIterator *bi,
-           int32_t offset);
-
-/**
-* Get a locale for which text breaking information is available.
-* A UBreakIterator in a locale returned by this function will perform the correct
-* text breaking for the locale.
-* @param index The index of the desired locale.
-* @return A locale for which number text breaking information is available, or 0 if none.
-* @see ubrk_countAvailable
-* @stable ICU 2.0
-*/
-U_STABLE const char* U_EXPORT2
-ubrk_getAvailable(int32_t index);
-
-/**
-* Determine how many locales have text breaking information available.
-* This function is most useful as determining the loop ending condition for
-* calls to \ref ubrk_getAvailable.
-* @return The number of locales for which text breaking information is available.
-* @see ubrk_getAvailable
-* @stable ICU 2.0
-*/
-U_STABLE int32_t U_EXPORT2
-ubrk_countAvailable(void);
-
-
-/**
-* Returns true if the specfied position is a boundary position.  As a side
-* effect, leaves the iterator pointing to the first boundary position at
-* or after "offset".
-* @param bi The break iterator to use.
-* @param offset the offset to check.
-* @return True if "offset" is a boundary position.
-* @stable ICU 2.0
-*/
-U_STABLE  UBool U_EXPORT2
-ubrk_isBoundary(UBreakIterator *bi, int32_t offset);
-
-/**
- * Return the status from the break rule that determined the most recently
- * returned break position.  The values appear in the rule source
- * within brackets, {123}, for example.  For rules that do not specify a
- * status, a default value of 0 is returned.
- * <p>
- * For word break iterators, the possible values are defined in enum UWordBreak.
- * @stable ICU 2.2
- */
-U_STABLE  int32_t U_EXPORT2
-ubrk_getRuleStatus(UBreakIterator *bi);
-
-/**
- * Get the statuses from the break rules that determined the most recently
- * returned break position.  The values appear in the rule source
- * within brackets, {123}, for example.  The default status value for rules
- * that do not explicitly provide one is zero.
- * <p>
- * For word break iterators, the possible values are defined in enum UWordBreak.
- * @param bi        The break iterator to use
- * @param fillInVec an array to be filled in with the status values.
- * @param capacity  the length of the supplied vector.  A length of zero causes
- *                  the function to return the number of status values, in the
- *                  normal way, without attemtping to store any values.
- * @param status    receives error codes.
- * @return          The number of rule status values from rules that determined
- *                  the most recent boundary returned by the break iterator.
- * @stable ICU 3.0
- */
-U_STABLE  int32_t U_EXPORT2
-ubrk_getRuleStatusVec(UBreakIterator *bi, int32_t *fillInVec, int32_t capacity, UErrorCode *status);
-
-/**
- * Return the locale of the break iterator. You can choose between the valid and
- * the actual locale.
- * @param bi break iterator
- * @param type locale type (valid or actual)
- * @param status error code
- * @return locale string
- * @stable ICU 2.8
- */
-U_STABLE const char* U_EXPORT2
-ubrk_getLocaleByType(const UBreakIterator *bi, ULocDataLocaleType type, UErrorCode* status);
-
-
-#endif /* #if !UCONFIG_NO_BREAK_ITERATION */
-
-#endif

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/ucal.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/ucal.h b/apps/couch_collate/platform/osx/icu/unicode/ucal.h
deleted file mode 100644
index 9ba2668..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/ucal.h
+++ /dev/null
@@ -1,1161 +0,0 @@
-/*
- *******************************************************************************
- * Copyright (C) 1996-2008, International Business Machines Corporation and
- * others. All Rights Reserved.
- *******************************************************************************
- */
-
-#ifndef UCAL_H
-#define UCAL_H
-
-#include "unicode/utypes.h"
-#include "unicode/uenum.h"
-#include "unicode/uloc.h"
-
-#if !UCONFIG_NO_FORMATTING
-
-/**
- * \file
- * \brief C API: Calendar
- *
- * <h2>Calendar C API</h2>
- *
- * UCalendar C API is used  for converting between a <code>UDate</code> object
- * and a set of integer fields such as <code>UCAL_YEAR</code>, <code>UCAL_MONTH</code>,
- * <code>UCAL_DAY</code>, <code>UCAL_HOUR</code>, and so on.
- * (A <code>UDate</code> object represents a specific instant in
- * time with millisecond precision. See UDate
- * for information about the <code>UDate</code> .)
- *
- * <p>
- * Types of <code>UCalendar</code> interpret a <code>UDate</code>
- * according to the rules of a specific calendar system. The U_STABLE
- * provides the enum UCalendarType with UCAL_TRADITIONAL and
- * UCAL_GREGORIAN.
- * <p>
- * Like other locale-sensitive C API, calendar API  provides a
- * function, <code>ucal_open()</code>, which returns a pointer to
- * <code>UCalendar</code> whose time fields have been initialized
- * with the current date and time. We need to specify the type of
- * calendar to be opened and the  timezoneId.
- * \htmlonly<blockquote>\endhtmlonly
- * <pre>
- * \code
- * UCalendar *caldef;
- * UChar *tzId;
- * UErrorCode status;
- * tzId=(UChar*)malloc(sizeof(UChar) * (strlen("PST") +1) );
- * u_uastrcpy(tzId, "PST");
- * caldef=ucal_open(tzID, u_strlen(tzID), NULL, UCAL_TRADITIONAL, &status);
- * \endcode
- * </pre>
- * \htmlonly</blockquote>\endhtmlonly
- *
- * <p>
- * A <code>UCalendar</code> object can produce all the time field values
- * needed to implement the date-time formatting for a particular language
- * and calendar style (for example, Japanese-Gregorian, Japanese-Traditional).
- *
- * <p>
- * When computing a <code>UDate</code> from time fields, two special circumstances
- * may arise: there may be insufficient information to compute the
- * <code>UDate</code> (such as only year and month but no day in the month),
- * or there may be inconsistent information (such as "Tuesday, July 15, 1996"
- * -- July 15, 1996 is actually a Monday).
- *
- * <p>
- * <strong>Insufficient information.</strong> The calendar will use default
- * information to specify the missing fields. This may vary by calendar; for
- * the Gregorian calendar, the default for a field is the same as that of the
- * start of the epoch: i.e., UCAL_YEAR = 1970, UCAL_MONTH = JANUARY, UCAL_DATE = 1, etc.
- *
- * <p>
- * <strong>Inconsistent information.</strong> If fields conflict, the calendar
- * will give preference to fields set more recently. For example, when
- * determining the day, the calendar will look for one of the following
- * combinations of fields.  The most recent combination, as determined by the
- * most recently set single field, will be used.
- *
- * \htmlonly<blockquote>\endhtmlonly
- * <pre>
- * \code
- * UCAL_MONTH + UCAL_DAY_OF_MONTH
- * UCAL_MONTH + UCAL_WEEK_OF_MONTH + UCAL_DAY_OF_WEEK
- * UCAL_MONTH + UCAL_DAY_OF_WEEK_IN_MONTH + UCAL_DAY_OF_WEEK
- * UCAL_DAY_OF_YEAR
- * UCAL_DAY_OF_WEEK + UCAL_WEEK_OF_YEAR
- * \endcode
- * </pre>
- * \htmlonly</blockquote>\endhtmlonly
- *
- * For the time of day:
- *
- * \htmlonly<blockquote>\endhtmlonly
- * <pre>
- * \code
- * UCAL_HOUR_OF_DAY
- * UCAL_AM_PM + UCAL_HOUR
- * \endcode
- * </pre>
- * \htmlonly</blockquote>\endhtmlonly
- *
- * <p>
- * <strong>Note:</strong> for some non-Gregorian calendars, different
- * fields may be necessary for complete disambiguation. For example, a full
- * specification of the historial Arabic astronomical calendar requires year,
- * month, day-of-month <em>and</em> day-of-week in some cases.
- *
- * <p>
- * <strong>Note:</strong> There are certain possible ambiguities in
- * interpretation of certain singular times, which are resolved in the
- * following ways:
- * <ol>
- *     <li> 24:00:00 "belongs" to the following day. That is,
- *          23:59 on Dec 31, 1969 &lt; 24:00 on Jan 1, 1970 &lt; 24:01:00 on Jan 1, 1970
- *
- *     <li> Although historically not precise, midnight also belongs to "am",
- *          and noon belongs to "pm", so on the same day,
- *          12:00 am (midnight) &lt; 12:01 am, and 12:00 pm (noon) &lt; 12:01 pm
- * </ol>
- *
- * <p>
- * The date or time format strings are not part of the definition of a
- * calendar, as those must be modifiable or overridable by the user at
- * runtime. Use {@link DateFormat}
- * to format dates.
- *
- * <p>
- * <code>Calendar</code> provides an API for field "rolling", where fields
- * can be incremented or decremented, but wrap around. For example, rolling the
- * month up in the date <code>December 12, <b>1996</b></code> results in
- * <code>January 12, <b>1996</b></code>.
- *
- * <p>
- * <code>Calendar</code> also provides a date arithmetic function for
- * adding the specified (signed) amount of time to a particular time field.
- * For example, subtracting 5 days from the date <code>September 12, 1996</code>
- * results in <code>September 7, 1996</code>.
- *
- * @stable ICU 2.0
- */
-
-/** A calendar.
- *  For usage in C programs.
- * @stable ICU 2.0
- */
-typedef void* UCalendar;
-
-/** Possible types of UCalendars 
- * @stable ICU 2.0
- */
-enum UCalendarType {
-  /**
-   * Despite the name, UCAL_TRADITIONAL designates the locale's default calendar,
-   * which may be the Gregorian calendar or some other calendar.
-   * @stable ICU 2.0
-   */
-  UCAL_TRADITIONAL,
-  /**
-   * Unambiguously designates the Gregorian calendar for the locale.
-   * @stable ICU 2.0
-   */
-  UCAL_GREGORIAN,
-  /**
-   * A better name for UCAL_TRADITIONAL.
-   * @draft ICU 4.2
-   */
-  UCAL_DEFAULT = UCAL_TRADITIONAL
-};
-
-/** @stable ICU 2.0 */
-typedef enum UCalendarType UCalendarType;
-
-/** Possible fields in a UCalendar 
- * @stable ICU 2.0
- */
-enum UCalendarDateFields {
-  /** 
-   * Field number indicating the era, e.g., AD or BC in the Gregorian (Julian) calendar. 
-   * This is a calendar-specific value.
-   * @stable ICU 2.6 
-   */
-  UCAL_ERA,
-
-  /**
-   * Field number indicating the year. This is a calendar-specific value.
-   * @stable ICU 2.6 
-   */
-  UCAL_YEAR,
-
-  /**
-   * Field number indicating the month. This is a calendar-specific value. 
-   * The first month of the year is
-   * <code>JANUARY</code>; the last depends on the number of months in a year.
-   * @see #UCAL_JANUARY
-   * @see #UCAL_FEBRUARY
-   * @see #UCAL_MARCH
-   * @see #UCAL_APRIL
-   * @see #UCAL_MAY
-   * @see #UCAL_JUNE
-   * @see #UCAL_JULY
-   * @see #UCAL_AUGUST
-   * @see #UCAL_SEPTEMBER
-   * @see #UCAL_OCTOBER
-   * @see #UCAL_NOVEMBER
-   * @see #UCAL_DECEMBER
-   * @see #UCAL_UNDECIMBER
-   * @stable ICU 2.6 
-   */
-  UCAL_MONTH,
-
-  /**
-   * Field number indicating the
-   * week number within the current year.  The first week of the year, as
-   * defined by <code>UCAL_FIRST_DAY_OF_WEEK</code> and <code>UCAL_MINIMAL_DAYS_IN_FIRST_WEEK</code>
-   * attributes, has value 1.  Subclasses define
-   * the value of <code>UCAL_WEEK_OF_YEAR</code> for days before the first week of
-   * the year.
-   * @see ucal_getAttribute
-   * @see ucal_setAttribute
-   * @stable ICU 2.6 
-   */
-  UCAL_WEEK_OF_YEAR,
-
- /**
-   * Field number indicating the
-   * week number within the current month.  The first week of the month, as
-   * defined by <code>UCAL_FIRST_DAY_OF_WEEK</code> and <code>UCAL_MINIMAL_DAYS_IN_FIRST_WEEK</code>
-   * attributes, has value 1.  Subclasses define
-   * the value of <code>WEEK_OF_MONTH</code> for days before the first week of
-   * the month.
-   * @see ucal_getAttribute
-   * @see ucal_setAttribute
-   * @see #UCAL_FIRST_DAY_OF_WEEK
-   * @see #UCAL_MINIMAL_DAYS_IN_FIRST_WEEK
-   * @stable ICU 2.6 
-   */
-  UCAL_WEEK_OF_MONTH,
-
- /**
-   * Field number indicating the
-   * day of the month. This is a synonym for <code>DAY_OF_MONTH</code>.
-   * The first day of the month has value 1.
-   * @see #UCAL_DAY_OF_MONTH
-   * @stable ICU 2.6 
-   */
-  UCAL_DATE,
-
- /**
-   * Field number indicating the day
-   * number within the current year.  The first day of the year has value 1.
-   * @stable ICU 2.6 
-   */
-  UCAL_DAY_OF_YEAR,
-
- /**
-   * Field number indicating the day
-   * of the week.  This field takes values <code>SUNDAY</code>,
-   * <code>MONDAY</code>, <code>TUESDAY</code>, <code>WEDNESDAY</code>,
-   * <code>THURSDAY</code>, <code>FRIDAY</code>, and <code>SATURDAY</code>.
-   * @see #UCAL_SUNDAY
-   * @see #UCAL_MONDAY
-   * @see #UCAL_TUESDAY
-   * @see #UCAL_WEDNESDAY
-   * @see #UCAL_THURSDAY
-   * @see #UCAL_FRIDAY
-   * @see #UCAL_SATURDAY
-   * @stable ICU 2.6 
-   */
-  UCAL_DAY_OF_WEEK,
-
- /**
-   * Field number indicating the
-   * ordinal number of the day of the week within the current month. Together
-   * with the <code>DAY_OF_WEEK</code> field, this uniquely specifies a day
-   * within a month.  Unlike <code>WEEK_OF_MONTH</code> and
-   * <code>WEEK_OF_YEAR</code>, this field's value does <em>not</em> depend on
-   * <code>getFirstDayOfWeek()</code> or
-   * <code>getMinimalDaysInFirstWeek()</code>.  <code>DAY_OF_MONTH 1</code>
-   * through <code>7</code> always correspond to <code>DAY_OF_WEEK_IN_MONTH
-   * 1</code>; <code>8</code> through <code>15</code> correspond to
-   * <code>DAY_OF_WEEK_IN_MONTH 2</code>, and so on.
-   * <code>DAY_OF_WEEK_IN_MONTH 0</code> indicates the week before
-   * <code>DAY_OF_WEEK_IN_MONTH 1</code>.  Negative values count back from the
-   * end of the month, so the last Sunday of a month is specified as
-   * <code>DAY_OF_WEEK = SUNDAY, DAY_OF_WEEK_IN_MONTH = -1</code>.  Because
-   * negative values count backward they will usually be aligned differently
-   * within the month than positive values.  For example, if a month has 31
-   * days, <code>DAY_OF_WEEK_IN_MONTH -1</code> will overlap
-   * <code>DAY_OF_WEEK_IN_MONTH 5</code> and the end of <code>4</code>.
-   * @see #UCAL_DAY_OF_WEEK
-   * @see #UCAL_WEEK_OF_MONTH
-   * @stable ICU 2.6 
-   */
-  UCAL_DAY_OF_WEEK_IN_MONTH,
-
- /**
-   * Field number indicating
-   * whether the <code>HOUR</code> is before or after noon.
-   * E.g., at 10:04:15.250 PM the <code>AM_PM</code> is <code>PM</code>.
-   * @see #UCAL_AM
-   * @see #UCAL_PM
-   * @see #UCAL_HOUR
-   * @stable ICU 2.6 
-   */
-  UCAL_AM_PM,
-
- /**
-   * Field number indicating the
-   * hour of the morning or afternoon. <code>HOUR</code> is used for the 12-hour
-   * clock.
-   * E.g., at 10:04:15.250 PM the <code>HOUR</code> is 10.
-   * @see #UCAL_AM_PM
-   * @see #UCAL_HOUR_OF_DAY
-   * @stable ICU 2.6 
-   */
-  UCAL_HOUR,
-
- /**
-   * Field number indicating the
-   * hour of the day. <code>HOUR_OF_DAY</code> is used for the 24-hour clock.
-   * E.g., at 10:04:15.250 PM the <code>HOUR_OF_DAY</code> is 22.
-   * @see #UCAL_HOUR
-   * @stable ICU 2.6 
-   */
-  UCAL_HOUR_OF_DAY,
-
- /**
-   * Field number indicating the
-   * minute within the hour.
-   * E.g., at 10:04:15.250 PM the <code>UCAL_MINUTE</code> is 4.
-   * @stable ICU 2.6 
-   */
-  UCAL_MINUTE,
-
- /**
-   * Field number indicating the
-   * second within the minute.
-   * E.g., at 10:04:15.250 PM the <code>UCAL_SECOND</code> is 15.
-   * @stable ICU 2.6 
-   */
-  UCAL_SECOND,
-
- /**
-   * Field number indicating the
-   * millisecond within the second.
-   * E.g., at 10:04:15.250 PM the <code>UCAL_MILLISECOND</code> is 250.
-   * @stable ICU 2.6 
-   */
-  UCAL_MILLISECOND,
-
- /**
-   * Field number indicating the
-   * raw offset from GMT in milliseconds.
-   * @stable ICU 2.6 
-   */
-  UCAL_ZONE_OFFSET,
-
- /**
-   * Field number indicating the
-   * daylight savings offset in milliseconds.
-   * @stable ICU 2.6 
-   */
-  UCAL_DST_OFFSET,
-  
- /**
-   * Field number 
-   * indicating the extended year corresponding to the
-   * <code>UCAL_WEEK_OF_YEAR</code> field.  This may be one greater or less
-   * than the value of <code>UCAL_EXTENDED_YEAR</code>.
-   * @stable ICU 2.6
-   */
-  UCAL_YEAR_WOY,
-
- /**
-   * Field number 
-   * indicating the localized day of week.  This will be a value from 1
-   * to 7 inclusive, with 1 being the localized first day of the week.
-   * @stable ICU 2.6
-   */
-  UCAL_DOW_LOCAL,
-
-  /**
-   * Year of this calendar system, encompassing all supra-year fields. For example, 
-   * in Gregorian/Julian calendars, positive Extended Year values indicate years AD,
-   *  1 BC = 0 extended, 2 BC = -1 extended, and so on. 
-   * @stable ICU 2.8 
-   */
-  UCAL_EXTENDED_YEAR,
-
- /**
-   * Field number 
-   * indicating the modified Julian day number.  This is different from
-   * the conventional Julian day number in two regards.  First, it
-   * demarcates days at local zone midnight, rather than noon GMT.
-   * Second, it is a local number; that is, it depends on the local time
-   * zone.  It can be thought of as a single number that encompasses all
-   * the date-related fields.
-   * @stable ICU 2.8
-   */
-  UCAL_JULIAN_DAY, 
-
-  /**
-   * Ranges from 0 to 23:59:59.999 (regardless of DST).  This field behaves <em>exactly</em> 
-   * like a composite of all time-related fields, not including the zone fields.  As such, 
-   * it also reflects discontinuities of those fields on DST transition days.  On a day
-   * of DST onset, it will jump forward.  On a day of DST cessation, it will jump 
-   * backward.  This reflects the fact that it must be combined with the DST_OFFSET field
-   * to obtain a unique local time value.
-   * @stable ICU 2.8
-   */
-  UCAL_MILLISECONDS_IN_DAY,
-
-  /**
-   * Whether or not the current month is a leap month (0 or 1). See the Chinese calendar for
-   * an example of this.
-   */
-  UCAL_IS_LEAP_MONTH,
-  
-  /**
-   * Field count
-   * @stable ICU 2.6
-   */
-  UCAL_FIELD_COUNT,
-
- /**
-   * Field number indicating the
-   * day of the month. This is a synonym for <code>UCAL_DATE</code>.
-   * The first day of the month has value 1.
-   * @see #UCAL_DATE
-   * Synonym for UCAL_DATE
-   * @stable ICU 2.8
-   **/
-  UCAL_DAY_OF_MONTH=UCAL_DATE
-};
-
-/** @stable ICU 2.0 */
-typedef enum UCalendarDateFields UCalendarDateFields;
-    /**
-     * Useful constant for days of week. Note: Calendar day-of-week is 1-based. Clients
-     * who create locale resources for the field of first-day-of-week should be aware of
-     * this. For instance, in US locale, first-day-of-week is set to 1, i.e., UCAL_SUNDAY.
-     */
-/** Possible days of the week in a UCalendar 
- * @stable ICU 2.0
- */
-enum UCalendarDaysOfWeek {
-  /** Sunday */
-  UCAL_SUNDAY = 1,
-  /** Monday */
-  UCAL_MONDAY,
-  /** Tuesday */
-  UCAL_TUESDAY,
-  /** Wednesday */
-  UCAL_WEDNESDAY,
-  /** Thursday */
-  UCAL_THURSDAY,
-  /** Friday */
-  UCAL_FRIDAY,
-  /** Saturday */
-  UCAL_SATURDAY
-};
-
-/** @stable ICU 2.0 */
-typedef enum UCalendarDaysOfWeek UCalendarDaysOfWeek;
-
-/** Possible months in a UCalendar. Note: Calendar month is 0-based.
- * @stable ICU 2.0
- */
-enum UCalendarMonths {
-  /** January */
-  UCAL_JANUARY,
-  /** February */
-  UCAL_FEBRUARY,
-  /** March */
-  UCAL_MARCH,
-  /** April */
-  UCAL_APRIL,
-  /** May */
-  UCAL_MAY,
-  /** June */
-  UCAL_JUNE,
-  /** July */
-  UCAL_JULY,
-  /** August */
-  UCAL_AUGUST,
-  /** September */
-  UCAL_SEPTEMBER,
-  /** October */
-  UCAL_OCTOBER,
-  /** November */
-  UCAL_NOVEMBER,
-  /** December */
-  UCAL_DECEMBER,
-  /** Value of the <code>UCAL_MONTH</code> field indicating the
-    * thirteenth month of the year. Although the Gregorian calendar
-    * does not use this value, lunar calendars do.
-    */
-  UCAL_UNDECIMBER
-};
-
-/** @stable ICU 2.0 */
-typedef enum UCalendarMonths UCalendarMonths;
-
-/** Possible AM/PM values in a UCalendar 
- * @stable ICU 2.0
- */
-enum UCalendarAMPMs {
-    /** AM */
-  UCAL_AM,
-  /** PM */
-  UCAL_PM
-};
-
-/** @stable ICU 2.0 */
-typedef enum UCalendarAMPMs UCalendarAMPMs;
-
-/**
- * Create an enumeration over all time zones.
- *
- * @param ec input/output error code
- *
- * @return an enumeration object that the caller must dispose of using
- * uenum_close(), or NULL upon failure. In case of failure *ec will
- * indicate the error.
- *
- * @stable ICU 2.6
- */
-U_STABLE UEnumeration* U_EXPORT2
-ucal_openTimeZones(UErrorCode* ec);
-
-/**
- * Create an enumeration over all time zones associated with the given
- * country. Some zones are affiliated with no country (e.g., "UTC");
- * these may also be retrieved, as a group.
- *
- * @param country the ISO 3166 two-letter country code, or NULL to
- * retrieve zones not affiliated with any country
- *
- * @param ec input/output error code
- *
- * @return an enumeration object that the caller must dispose of using
- * uenum_close(), or NULL upon failure. In case of failure *ec will
- * indicate the error.
- *
- * @stable ICU 2.6
- */
-U_STABLE UEnumeration* U_EXPORT2
-ucal_openCountryTimeZones(const char* country, UErrorCode* ec);
-
-/**
- * Return the default time zone. The default is determined initially
- * by querying the host operating system. It may be changed with
- * ucal_setDefaultTimeZone() or with the C++ TimeZone API.
- *
- * @param result A buffer to receive the result, or NULL
- *
- * @param resultCapacity The capacity of the result buffer
- *
- * @param ec input/output error code
- *
- * @return The result string length, not including the terminating
- * null
- *
- * @stable ICU 2.6
- */
-U_STABLE int32_t U_EXPORT2
-ucal_getDefaultTimeZone(UChar* result, int32_t resultCapacity, UErrorCode* ec);
-
-/**
- * Set the default time zone.
- *
- * @param zoneID null-terminated time zone ID
- *
- * @param ec input/output error code
- *
- * @stable ICU 2.6
- */
-U_STABLE void U_EXPORT2
-ucal_setDefaultTimeZone(const UChar* zoneID, UErrorCode* ec);
-
-/**
- * Return the amount of time in milliseconds that the clock is
- * advanced during daylight savings time for the given time zone, or
- * zero if the time zone does not observe daylight savings time.
- *
- * @param zoneID null-terminated time zone ID
- *
- * @param ec input/output error code
- *
- * @return the number of milliseconds the time is advanced with
- * respect to standard time when the daylight savings rules are in
- * effect. This is always a non-negative number, most commonly either
- * 3,600,000 (one hour) or zero.
- *
- * @stable ICU 2.6
- */
-U_STABLE int32_t U_EXPORT2
-ucal_getDSTSavings(const UChar* zoneID, UErrorCode* ec);
-
-/**
- * Get the current date and time.
- * The value returned is represented as milliseconds from the epoch.
- * @return The current date and time.
- * @stable ICU 2.0
- */
-U_STABLE UDate U_EXPORT2 
-ucal_getNow(void);
-
-/**
- * Open a UCalendar.
- * A UCalendar may be used to convert a millisecond value to a year,
- * month, and day.
- * @param zoneID The desired TimeZone ID.  If 0, use the default time zone.
- * @param len The length of zoneID, or -1 if null-terminated.
- * @param locale The desired locale
- * @param type The type of UCalendar to open. This can be UCAL_GREGORIAN to open the Gregorian
- * calendar for the locale, or UCAL_DEFAULT to open the default calendar for the locale (the
- * default calendar may also be Gregorian). To open a specific non-Gregorian calendar for the
- * locale, use uloc_setKeywordValue to set the value of the calendar keyword for the locale
- * and then pass the locale to ucal_open with UCAL_DEFAULT as the type.
- * @param status A pointer to an UErrorCode to receive any errors
- * @return A pointer to a UCalendar, or 0 if an error occurred.
- * @stable ICU 2.0
- */
-U_STABLE UCalendar* U_EXPORT2 
-ucal_open(const UChar*   zoneID,
-          int32_t        len,
-          const char*    locale,
-          UCalendarType  type,
-          UErrorCode*    status);
-
-/**
- * Close a UCalendar.
- * Once closed, a UCalendar may no longer be used.
- * @param cal The UCalendar to close.
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2 
-ucal_close(UCalendar *cal);
-
-/**
- * Open a copy of a UCalendar.
- * This function performs a deep copy.
- * @param cal The calendar to copy
- * @param status A pointer to an UErrorCode to receive any errors.
- * @return A pointer to a UCalendar identical to cal.
- * @draft ICU 4.0
- */
-U_DRAFT UCalendar* U_EXPORT2 
-ucal_clone(const UCalendar* cal,
-           UErrorCode*      status);
-
-/**
- * Set the TimeZone used by a UCalendar.
- * A UCalendar uses a timezone for converting from Greenwich time to local time.
- * @param cal The UCalendar to set.
- * @param zoneID The desired TimeZone ID.  If 0, use the default time zone.
- * @param len The length of zoneID, or -1 if null-terminated.
- * @param status A pointer to an UErrorCode to receive any errors.
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2 
-ucal_setTimeZone(UCalendar*    cal,
-                 const UChar*  zoneID,
-                 int32_t       len,
-                 UErrorCode*   status);
-
-/**
- * Possible formats for a UCalendar's display name 
- * @stable ICU 2.0
- */
-enum UCalendarDisplayNameType {
-  /** Standard display name */
-  UCAL_STANDARD,
-  /** Short standard display name */
-  UCAL_SHORT_STANDARD,
-  /** Daylight savings display name */
-  UCAL_DST,
-  /** Short daylight savings display name */
-  UCAL_SHORT_DST
-};
-
-/** @stable ICU 2.0 */
-typedef enum UCalendarDisplayNameType UCalendarDisplayNameType;
-
-/**
- * Get the display name for a UCalendar's TimeZone.
- * A display name is suitable for presentation to a user.
- * @param cal          The UCalendar to query.
- * @param type         The desired display name format; one of UCAL_STANDARD, UCAL_SHORT_STANDARD,
- *                     UCAL_DST, UCAL_SHORT_DST
- * @param locale       The desired locale for the display name.
- * @param result       A pointer to a buffer to receive the formatted number.
- * @param resultLength The maximum size of result.
- * @param status       A pointer to an UErrorCode to receive any errors
- * @return             The total buffer size needed; if greater than resultLength, the output was truncated.
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2 
-ucal_getTimeZoneDisplayName(const UCalendar*          cal,
-                            UCalendarDisplayNameType  type,
-                            const char*               locale,
-                            UChar*                    result,
-                            int32_t                   resultLength,
-                            UErrorCode*               status);
-
-/**
- * Determine if a UCalendar is currently in daylight savings time.
- * Daylight savings time is not used in all parts of the world.
- * @param cal The UCalendar to query.
- * @param status A pointer to an UErrorCode to receive any errors
- * @return TRUE if cal is currently in daylight savings time, FALSE otherwise
- * @stable ICU 2.0
- */
-U_STABLE UBool U_EXPORT2 
-ucal_inDaylightTime(const UCalendar*  cal,
-                    UErrorCode*       status );
-
-/**
- * Sets the GregorianCalendar change date. This is the point when the switch from
- * Julian dates to Gregorian dates occurred. Default is 00:00:00 local time, October
- * 15, 1582. Previous to this time and date will be Julian dates.
- *
- * This function works only for Gregorian calendars. If the UCalendar is not
- * an instance of a Gregorian calendar, then a U_UNSUPPORTED_ERROR
- * error code is set.
- *
- * @param cal        The calendar object.
- * @param date       The given Gregorian cutover date.
- * @param pErrorCode Pointer to a standard ICU error code. Its input value must
- *                   pass the U_SUCCESS() test, or else the function returns
- *                   immediately. Check for U_FAILURE() on output or use with
- *                   function chaining. (See User Guide for details.)
- *
- * @see GregorianCalendar::setGregorianChange
- * @see ucal_getGregorianChange
- * @stable ICU 3.6
- */
-U_STABLE void U_EXPORT2
-ucal_setGregorianChange(UCalendar *cal, UDate date, UErrorCode *pErrorCode);
-
-/**
- * Gets the Gregorian Calendar change date. This is the point when the switch from
- * Julian dates to Gregorian dates occurred. Default is 00:00:00 local time, October
- * 15, 1582. Previous to this time and date will be Julian dates.
- *
- * This function works only for Gregorian calendars. If the UCalendar is not
- * an instance of a Gregorian calendar, then a U_UNSUPPORTED_ERROR
- * error code is set.
- *
- * @param cal        The calendar object.
- * @param pErrorCode Pointer to a standard ICU error code. Its input value must
- *                   pass the U_SUCCESS() test, or else the function returns
- *                   immediately. Check for U_FAILURE() on output or use with
- *                   function chaining. (See User Guide for details.)
- * @return   The Gregorian cutover time for this calendar.
- *
- * @see GregorianCalendar::getGregorianChange
- * @see ucal_setGregorianChange
- * @stable ICU 3.6
- */
-U_STABLE UDate U_EXPORT2
-ucal_getGregorianChange(const UCalendar *cal, UErrorCode *pErrorCode);
-
-/**
- * Types of UCalendar attributes 
- * @stable ICU 2.0
- */
-enum UCalendarAttribute {
-    /** Lenient parsing */
-  UCAL_LENIENT,
-  /** First day of week */
-  UCAL_FIRST_DAY_OF_WEEK,
-  /** Minimum number of days in first week */
-  UCAL_MINIMAL_DAYS_IN_FIRST_WEEK
-};
-
-/** @stable ICU 2.0 */
-typedef enum UCalendarAttribute UCalendarAttribute;
-
-/**
- * Get a numeric attribute associated with a UCalendar.
- * Numeric attributes include the first day of the week, or the minimal numbers
- * of days in the first week of the month.
- * @param cal The UCalendar to query.
- * @param attr The desired attribute; one of UCAL_LENIENT, UCAL_FIRST_DAY_OF_WEEK,
- * or UCAL_MINIMAL_DAYS_IN_FIRST_WEEK
- * @return The value of attr.
- * @see ucal_setAttribute
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2 
-ucal_getAttribute(const UCalendar*    cal,
-                  UCalendarAttribute  attr);
-
-/**
- * Set a numeric attribute associated with a UCalendar.
- * Numeric attributes include the first day of the week, or the minimal numbers
- * of days in the first week of the month.
- * @param cal The UCalendar to set.
- * @param attr The desired attribute; one of UCAL_LENIENT, UCAL_FIRST_DAY_OF_WEEK,
- * or UCAL_MINIMAL_DAYS_IN_FIRST_WEEK
- * @param newValue The new value of attr.
- * @see ucal_getAttribute
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2 
-ucal_setAttribute(UCalendar*          cal,
-                  UCalendarAttribute  attr,
-                  int32_t             newValue);
-
-/**
- * Get a locale for which calendars are available.
- * A UCalendar in a locale returned by this function will contain the correct
- * day and month names for the locale.
- * @param index The index of the desired locale.
- * @return A locale for which calendars are available, or 0 if none.
- * @see ucal_countAvailable
- * @stable ICU 2.0
- */
-U_STABLE const char* U_EXPORT2 
-ucal_getAvailable(int32_t index);
-
-/**
- * Determine how many locales have calendars available.
- * This function is most useful as determining the loop ending condition for
- * calls to \ref ucal_getAvailable.
- * @return The number of locales for which calendars are available.
- * @see ucal_getAvailable
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2 
-ucal_countAvailable(void);
-
-/**
- * Get a UCalendar's current time in millis.
- * The time is represented as milliseconds from the epoch.
- * @param cal The UCalendar to query.
- * @param status A pointer to an UErrorCode to receive any errors
- * @return The calendar's current time in millis.
- * @see ucal_setMillis
- * @see ucal_setDate
- * @see ucal_setDateTime
- * @stable ICU 2.0
- */
-U_STABLE UDate U_EXPORT2 
-ucal_getMillis(const UCalendar*  cal,
-               UErrorCode*       status);
-
-/**
- * Set a UCalendar's current time in millis.
- * The time is represented as milliseconds from the epoch.
- * @param cal The UCalendar to set.
- * @param dateTime The desired date and time.
- * @param status A pointer to an UErrorCode to receive any errors
- * @see ucal_getMillis
- * @see ucal_setDate
- * @see ucal_setDateTime
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2 
-ucal_setMillis(UCalendar*   cal,
-               UDate        dateTime,
-               UErrorCode*  status );
-
-/**
- * Set a UCalendar's current date.
- * The date is represented as a series of 32-bit integers.
- * @param cal The UCalendar to set.
- * @param year The desired year.
- * @param month The desired month; one of UCAL_JANUARY, UCAL_FEBRUARY, UCAL_MARCH, UCAL_APRIL, UCAL_MAY,
- * UCAL_JUNE, UCAL_JULY, UCAL_AUGUST, UCAL_SEPTEMBER, UCAL_OCTOBER, UCAL_NOVEMBER, UCAL_DECEMBER, UCAL_UNDECIMBER
- * @param date The desired day of the month.
- * @param status A pointer to an UErrorCode to receive any errors
- * @see ucal_getMillis
- * @see ucal_setMillis
- * @see ucal_setDateTime
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2 
-ucal_setDate(UCalendar*   cal,
-             int32_t      year,
-             int32_t      month,
-             int32_t      date,
-             UErrorCode*  status);
-
-/**
- * Set a UCalendar's current date.
- * The date is represented as a series of 32-bit integers.
- * @param cal The UCalendar to set.
- * @param year The desired year.
- * @param month The desired month; one of UCAL_JANUARY, UCAL_FEBRUARY, UCAL_MARCH, UCAL_APRIL, UCAL_MAY,
- * UCAL_JUNE, UCAL_JULY, UCAL_AUGUST, UCAL_SEPTEMBER, UCAL_OCTOBER, UCAL_NOVEMBER, UCAL_DECEMBER, UCAL_UNDECIMBER
- * @param date The desired day of the month.
- * @param hour The desired hour of day.
- * @param minute The desired minute.
- * @param second The desirec second.
- * @param status A pointer to an UErrorCode to receive any errors
- * @see ucal_getMillis
- * @see ucal_setMillis
- * @see ucal_setDate
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2 
-ucal_setDateTime(UCalendar*   cal,
-                 int32_t      year,
-                 int32_t      month,
-                 int32_t      date,
-                 int32_t      hour,
-                 int32_t      minute,
-                 int32_t      second,
-                 UErrorCode*  status);
-
-/**
- * Returns TRUE if two UCalendars are equivalent.  Equivalent
- * UCalendars will behave identically, but they may be set to
- * different times.
- * @param cal1 The first of the UCalendars to compare.
- * @param cal2 The second of the UCalendars to compare.
- * @return TRUE if cal1 and cal2 are equivalent, FALSE otherwise.
- * @stable ICU 2.0
- */
-U_STABLE UBool U_EXPORT2 
-ucal_equivalentTo(const UCalendar*  cal1,
-                  const UCalendar*  cal2);
-
-/**
- * Add a specified signed amount to a particular field in a UCalendar.
- * This can modify more significant fields in the calendar.
- * @param cal The UCalendar to which to add.
- * @param field The field to which to add the signed value; one of UCAL_ERA, UCAL_YEAR, UCAL_MONTH,
- * UCAL_WEEK_OF_YEAR, UCAL_WEEK_OF_MONTH, UCAL_DATE, UCAL_DAY_OF_YEAR, UCAL_DAY_OF_WEEK,
- * UCAL_DAY_OF_WEEK_IN_MONTH, UCAL_AM_PM, UCAL_HOUR, UCAL_HOUR_OF_DAY, UCAL_MINUTE, UCAL_SECOND,
- * UCAL_MILLISECOND, UCAL_ZONE_OFFSET, UCAL_DST_OFFSET.
- * @param amount The signed amount to add to field. If the amount causes the value
- * to exceed to maximum or minimum values for that field, other fields are modified
- * to preserve the magnitude of the change.
- * @param status A pointer to an UErrorCode to receive any errors
- * @see ucal_roll
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2 
-ucal_add(UCalendar*           cal,
-         UCalendarDateFields  field,
-         int32_t              amount,
-         UErrorCode*          status);
-
-/**
- * Add a specified signed amount to a particular field in a UCalendar.
- * This will not modify more significant fields in the calendar.
- * @param cal The UCalendar to which to add.
- * @param field The field to which to add the signed value; one of UCAL_ERA, UCAL_YEAR, UCAL_MONTH,
- * UCAL_WEEK_OF_YEAR, UCAL_WEEK_OF_MONTH, UCAL_DATE, UCAL_DAY_OF_YEAR, UCAL_DAY_OF_WEEK,
- * UCAL_DAY_OF_WEEK_IN_MONTH, UCAL_AM_PM, UCAL_HOUR, UCAL_HOUR_OF_DAY, UCAL_MINUTE, UCAL_SECOND,
- * UCAL_MILLISECOND, UCAL_ZONE_OFFSET, UCAL_DST_OFFSET.
- * @param amount The signed amount to add to field. If the amount causes the value
- * to exceed to maximum or minimum values for that field, the field is pinned to a permissible
- * value.
- * @param status A pointer to an UErrorCode to receive any errors
- * @see ucal_add
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2 
-ucal_roll(UCalendar*           cal,
-          UCalendarDateFields  field,
-          int32_t              amount,
-          UErrorCode*          status);
-
-/**
- * Get the current value of a field from a UCalendar.
- * All fields are represented as 32-bit integers.
- * @param cal The UCalendar to query.
- * @param field The desired field; one of UCAL_ERA, UCAL_YEAR, UCAL_MONTH,
- * UCAL_WEEK_OF_YEAR, UCAL_WEEK_OF_MONTH, UCAL_DATE, UCAL_DAY_OF_YEAR, UCAL_DAY_OF_WEEK,
- * UCAL_DAY_OF_WEEK_IN_MONTH, UCAL_AM_PM, UCAL_HOUR, UCAL_HOUR_OF_DAY, UCAL_MINUTE, UCAL_SECOND,
- * UCAL_MILLISECOND, UCAL_ZONE_OFFSET, UCAL_DST_OFFSET.
- * @param status A pointer to an UErrorCode to receive any errors
- * @return The value of the desired field.
- * @see ucal_set
- * @see ucal_isSet
- * @see ucal_clearField
- * @see ucal_clear
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2 
-ucal_get(const UCalendar*     cal,
-         UCalendarDateFields  field,
-         UErrorCode*          status );
-
-/**
- * Set the value of a field in a UCalendar.
- * All fields are represented as 32-bit integers.
- * @param cal The UCalendar to set.
- * @param field The field to set; one of UCAL_ERA, UCAL_YEAR, UCAL_MONTH,
- * UCAL_WEEK_OF_YEAR, UCAL_WEEK_OF_MONTH, UCAL_DATE, UCAL_DAY_OF_YEAR, UCAL_DAY_OF_WEEK,
- * UCAL_DAY_OF_WEEK_IN_MONTH, UCAL_AM_PM, UCAL_HOUR, UCAL_HOUR_OF_DAY, UCAL_MINUTE, UCAL_SECOND,
- * UCAL_MILLISECOND, UCAL_ZONE_OFFSET, UCAL_DST_OFFSET.
- * @param value The desired value of field.
- * @see ucal_get
- * @see ucal_isSet
- * @see ucal_clearField
- * @see ucal_clear
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2 
-ucal_set(UCalendar*           cal,
-         UCalendarDateFields  field,
-         int32_t              value);
-
-/**
- * Determine if a field in a UCalendar is set.
- * All fields are represented as 32-bit integers.
- * @param cal The UCalendar to query.
- * @param field The desired field; one of UCAL_ERA, UCAL_YEAR, UCAL_MONTH,
- * UCAL_WEEK_OF_YEAR, UCAL_WEEK_OF_MONTH, UCAL_DATE, UCAL_DAY_OF_YEAR, UCAL_DAY_OF_WEEK,
- * UCAL_DAY_OF_WEEK_IN_MONTH, UCAL_AM_PM, UCAL_HOUR, UCAL_HOUR_OF_DAY, UCAL_MINUTE, UCAL_SECOND,
- * UCAL_MILLISECOND, UCAL_ZONE_OFFSET, UCAL_DST_OFFSET.
- * @return TRUE if field is set, FALSE otherwise.
- * @see ucal_get
- * @see ucal_set
- * @see ucal_clearField
- * @see ucal_clear
- * @stable ICU 2.0
- */
-U_STABLE UBool U_EXPORT2 
-ucal_isSet(const UCalendar*     cal,
-           UCalendarDateFields  field);
-
-/**
- * Clear a field in a UCalendar.
- * All fields are represented as 32-bit integers.
- * @param cal The UCalendar containing the field to clear.
- * @param field The field to clear; one of UCAL_ERA, UCAL_YEAR, UCAL_MONTH,
- * UCAL_WEEK_OF_YEAR, UCAL_WEEK_OF_MONTH, UCAL_DATE, UCAL_DAY_OF_YEAR, UCAL_DAY_OF_WEEK,
- * UCAL_DAY_OF_WEEK_IN_MONTH, UCAL_AM_PM, UCAL_HOUR, UCAL_HOUR_OF_DAY, UCAL_MINUTE, UCAL_SECOND,
- * UCAL_MILLISECOND, UCAL_ZONE_OFFSET, UCAL_DST_OFFSET.
- * @see ucal_get
- * @see ucal_set
- * @see ucal_isSet
- * @see ucal_clear
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2 
-ucal_clearField(UCalendar*           cal,
-                UCalendarDateFields  field);
-
-/**
- * Clear all fields in a UCalendar.
- * All fields are represented as 32-bit integers.
- * @param calendar The UCalendar to clear.
- * @see ucal_get
- * @see ucal_set
- * @see ucal_isSet
- * @see ucal_clearField
- * @stable ICU 2.0
- */
-U_STABLE void U_EXPORT2 
-ucal_clear(UCalendar* calendar);
-
-/**
- * Possible limit values for a UCalendar 
- * @stable ICU 2.0
- */
-enum UCalendarLimitType {
-  /** Minimum value */
-  UCAL_MINIMUM,
-  /** Maximum value */
-  UCAL_MAXIMUM,
-  /** Greatest minimum value */
-  UCAL_GREATEST_MINIMUM,
-  /** Leaest maximum value */
-  UCAL_LEAST_MAXIMUM,
-  /** Actual minimum value */
-  UCAL_ACTUAL_MINIMUM,
-  /** Actual maximum value */
-  UCAL_ACTUAL_MAXIMUM
-};
-
-/** @stable ICU 2.0 */
-typedef enum UCalendarLimitType UCalendarLimitType;
-
-/**
- * Determine a limit for a field in a UCalendar.
- * A limit is a maximum or minimum value for a field.
- * @param cal The UCalendar to query.
- * @param field The desired field; one of UCAL_ERA, UCAL_YEAR, UCAL_MONTH,
- * UCAL_WEEK_OF_YEAR, UCAL_WEEK_OF_MONTH, UCAL_DATE, UCAL_DAY_OF_YEAR, UCAL_DAY_OF_WEEK,
- * UCAL_DAY_OF_WEEK_IN_MONTH, UCAL_AM_PM, UCAL_HOUR, UCAL_HOUR_OF_DAY, UCAL_MINUTE, UCAL_SECOND,
- * UCAL_MILLISECOND, UCAL_ZONE_OFFSET, UCAL_DST_OFFSET.
- * @param type The desired critical point; one of UCAL_MINIMUM, UCAL_MAXIMUM, UCAL_GREATEST_MINIMUM,
- * UCAL_LEAST_MAXIMUM, UCAL_ACTUAL_MINIMUM, UCAL_ACTUAL_MAXIMUM
- * @param status A pointer to an UErrorCode to receive any errors.
- * @return The requested value.
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2 
-ucal_getLimit(const UCalendar*     cal,
-              UCalendarDateFields  field,
-              UCalendarLimitType   type,
-              UErrorCode*          status);
-
-/** Get the locale for this calendar object. You can choose between valid and actual locale.
- *  @param cal The calendar object
- *  @param type type of the locale we're looking for (valid or actual) 
- *  @param status error code for the operation
- *  @return the locale name
- *  @stable ICU 2.8
- */
-U_STABLE const char * U_EXPORT2
-ucal_getLocaleByType(const UCalendar *cal, ULocDataLocaleType type, UErrorCode* status);
-
-/**
- * Returns the timezone data version currently used by ICU.
- * @param status error code for the operation
- * @return the version string, such as "2007f"
- * @stable ICU 3.8
- */
-U_DRAFT const char * U_EXPORT2
-ucal_getTZDataVersion(UErrorCode* status);
-
-/**
- * Returns the canonical system timezone ID or the normalized
- * custom time zone ID for the given time zone ID.
- * @param id        The input timezone ID to be canonicalized.
- * @param len       The length of id, or -1 if null-terminated.
- * @param result    The buffer receives the canonical system timezone ID
- *                  or the custom timezone ID in normalized format.
- * @param resultCapacity    The capacity of the result buffer.
- * @param isSystemID        Receives if the given ID is a known system
-     *                      timezone ID.
- * @param status    Recevies the status.  When the given timezone ID
- *                  is neither a known system time zone ID nor a
- *                  valid custom timezone ID, U_ILLEGAL_ARGUMENT_ERROR
- *                  is set.
- * @return          The result string length, not including the terminating
- *                  null.
- * @draft ICU 4.0
- */
-U_DRAFT int32_t U_EXPORT2
-ucal_getCanonicalTimeZoneID(const UChar* id, int32_t len,
-                            UChar* result, int32_t resultCapacity, UBool *isSystemID, UErrorCode* status);
-/**
- * Get the resource keyword value string designating the calendar type for the UCalendar.
- * @param cal The UCalendar to query.
- * @param status The error code for the operation.
- * @return The resource keyword value string.
- * @draft ICU 4.2
- */
-U_DRAFT const char * U_EXPORT2
-ucal_getType(const UCalendar *cal, UErrorCode* status);
-
-/**
- * The following is a temporary Apple-specific API to help InternationalPrefs
- * transition to the updated version of the above ICU API. It will be removed soon.
- */
-U_DRAFT const char * U_EXPORT2
-ucal_getTypeWithError(const UCalendar *cal, UErrorCode* status);
-
-#endif /* #if !UCONFIG_NO_FORMATTING */
-
-#endif

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/ucasemap.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/ucasemap.h b/apps/couch_collate/platform/osx/icu/unicode/ucasemap.h
deleted file mode 100644
index 7ba622b..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/ucasemap.h
+++ /dev/null
@@ -1,391 +0,0 @@
-/*
-*******************************************************************************
-*
-*   Copyright (C) 2005-2008, International Business Machines
-*   Corporation and others.  All Rights Reserved.
-*
-*******************************************************************************
-*   file name:  ucasemap.h
-*   encoding:   US-ASCII
-*   tab size:   8 (not used)
-*   indentation:4
-*
-*   created on: 2005may06
-*   created by: Markus W. Scherer
-*
-*   Case mapping service object and functions using it.
-*/
-
-#ifndef __UCASEMAP_H__
-#define __UCASEMAP_H__
-
-#include "unicode/utypes.h"
-#include "unicode/ustring.h"
-
-/**
- * \file
- * \brief C API: Unicode case mapping functions using a UCaseMap service object.
- *
- * The service object takes care of memory allocations, data loading, and setup
- * for the attributes, as usual.
- *
- * Currently, the functionality provided here does not overlap with uchar.h
- * and ustring.h, except for ucasemap_toTitle().
- *
- * ucasemap_utf8XYZ() functions operate directly on UTF-8 strings.
- */
-
-/**
- * UCaseMap is an opaque service object for newer ICU case mapping functions.
- * Older functions did not use a service object.
- * @stable ICU 3.4
- */
-struct UCaseMap;
-typedef struct UCaseMap UCaseMap; /**< C typedef for struct UCaseMap. @stable ICU 3.4 */
-
-/**
- * Open a UCaseMap service object for a locale and a set of options.
- * The locale ID and options are preprocessed so that functions using the
- * service object need not process them in each call.
- *
- * @param locale ICU locale ID, used for language-dependent
- *               upper-/lower-/title-casing according to the Unicode standard.
- *               Usual semantics: ""=root, NULL=default locale, etc.
- * @param options Options bit set, used for case folding and string comparisons.
- *                Same flags as for u_foldCase(), u_strFoldCase(),
- *                u_strCaseCompare(), etc.
- *                Use 0 or U_FOLD_CASE_DEFAULT for default behavior.
- * @param pErrorCode Must be a valid pointer to an error code value,
- *                   which must not indicate a failure before the function call.
- * @return Pointer to a UCaseMap service object, if successful.
- *
- * @see U_FOLD_CASE_DEFAULT
- * @see U_FOLD_CASE_EXCLUDE_SPECIAL_I
- * @see U_TITLECASE_NO_LOWERCASE
- * @see U_TITLECASE_NO_BREAK_ADJUSTMENT
- * @stable ICU 3.4
- */
-U_STABLE UCaseMap * U_EXPORT2
-ucasemap_open(const char *locale, uint32_t options, UErrorCode *pErrorCode);
-
-/**
- * Close a UCaseMap service object.
- * @param csm Object to be closed.
- * @stable ICU 3.4
- */
-U_STABLE void U_EXPORT2
-ucasemap_close(UCaseMap *csm);
-
-/**
- * Get the locale ID that is used for language-dependent case mappings.
- * @param csm UCaseMap service object.
- * @return locale ID
- * @stable ICU 3.4
- */
-U_STABLE const char * U_EXPORT2
-ucasemap_getLocale(const UCaseMap *csm);
-
-/**
- * Get the options bit set that is used for case folding and string comparisons.
- * @param csm UCaseMap service object.
- * @return options bit set
- * @stable ICU 3.4
- */
-U_STABLE uint32_t U_EXPORT2
-ucasemap_getOptions(const UCaseMap *csm);
-
-/**
- * Set the locale ID that is used for language-dependent case mappings.
- *
- * @param csm UCaseMap service object.
- * @param locale Locale ID, see ucasemap_open().
- * @param pErrorCode Must be a valid pointer to an error code value,
- *                   which must not indicate a failure before the function call.
- *
- * @see ucasemap_open
- * @stable ICU 3.4
- */
-U_STABLE void U_EXPORT2
-ucasemap_setLocale(UCaseMap *csm, const char *locale, UErrorCode *pErrorCode);
-
-/**
- * Set the options bit set that is used for case folding and string comparisons.
- *
- * @param csm UCaseMap service object.
- * @param options Options bit set, see ucasemap_open().
- * @param pErrorCode Must be a valid pointer to an error code value,
- *                   which must not indicate a failure before the function call.
- *
- * @see ucasemap_open
- * @stable ICU 3.4
- */
-U_STABLE void U_EXPORT2
-ucasemap_setOptions(UCaseMap *csm, uint32_t options, UErrorCode *pErrorCode);
-
-/**
- * Do not lowercase non-initial parts of words when titlecasing.
- * Option bit for titlecasing APIs that take an options bit set.
- *
- * By default, titlecasing will titlecase the first cased character
- * of a word and lowercase all other characters.
- * With this option, the other characters will not be modified.
- *
- * @see ucasemap_setOptions
- * @see ucasemap_toTitle
- * @see ucasemap_utf8ToTitle
- * @see UnicodeString::toTitle
- * @stable ICU 4.0
- */
-#define U_TITLECASE_NO_LOWERCASE 0x100
-
-/**
- * Do not adjust the titlecasing indexes from BreakIterator::next() indexes;
- * titlecase exactly the characters at breaks from the iterator.
- * Option bit for titlecasing APIs that take an options bit set.
- *
- * By default, titlecasing will take each break iterator index,
- * adjust it by looking for the next cased character, and titlecase that one.
- * Other characters are lowercased.
- *
- * This follows Unicode 4 & 5 section 3.13 Default Case Operations:
- *
- * R3  toTitlecase(X): Find the word boundaries based on Unicode Standard Annex
- * #29, "Text Boundaries." Between each pair of word boundaries, find the first
- * cased character F. If F exists, map F to default_title(F); then map each
- * subsequent character C to default_lower(C).
- *
- * @see ucasemap_setOptions
- * @see ucasemap_toTitle
- * @see ucasemap_utf8ToTitle
- * @see UnicodeString::toTitle
- * @see U_TITLECASE_NO_LOWERCASE
- * @stable ICU 4.0
- */
-#define U_TITLECASE_NO_BREAK_ADJUSTMENT 0x200
-
-#if !UCONFIG_NO_BREAK_ITERATION
-
-/**
- * Get the break iterator that is used for titlecasing.
- * Do not modify the returned break iterator.
- * @param csm UCaseMap service object.
- * @return titlecasing break iterator
- * @stable ICU 4.0
- */
-U_DRAFT const UBreakIterator * U_EXPORT2
-ucasemap_getBreakIterator(const UCaseMap *csm);
-
-/**
- * Set the break iterator that is used for titlecasing.
- * The UCaseMap service object releases a previously set break iterator
- * and "adopts" this new one, taking ownership of it.
- * It will be released in a subsequent call to ucasemap_setBreakIterator()
- * or ucasemap_close().
- *
- * Break iterator operations are not thread-safe. Therefore, titlecasing
- * functions use non-const UCaseMap objects. It is not possible to titlecase
- * strings concurrently using the same UCaseMap.
- *
- * @param csm UCaseMap service object.
- * @param iterToAdopt Break iterator to be adopted for titlecasing.
- * @param pErrorCode Must be a valid pointer to an error code value,
- *                   which must not indicate a failure before the function call.
- *
- * @see ucasemap_toTitle
- * @see ucasemap_utf8ToTitle
- * @stable ICU 4.0
- */
-U_DRAFT void U_EXPORT2
-ucasemap_setBreakIterator(UCaseMap *csm, UBreakIterator *iterToAdopt, UErrorCode *pErrorCode);
-
-/**
- * Titlecase a UTF-16 string. This function is almost a duplicate of u_strToTitle(),
- * except that it takes ucasemap_setOptions() into account and has performance
- * advantages from being able to use a UCaseMap object for multiple case mapping
- * operations, saving setup time.
- *
- * Casing is locale-dependent and context-sensitive.
- * Titlecasing uses a break iterator to find the first characters of words
- * that are to be titlecased. It titlecases those characters and lowercases
- * all others. (This can be modified with ucasemap_setOptions().)
- *
- * The titlecase break iterator can be provided to customize for arbitrary
- * styles, using rules and dictionaries beyond the standard iterators.
- * It may be more efficient to always provide an iterator to avoid
- * opening and closing one for each string.
- * The standard titlecase iterator for the root locale implements the
- * algorithm of Unicode TR 21.
- *
- * This function uses only the setText(), first() and next() methods of the
- * provided break iterator.
- *
- * The result may be longer or shorter than the original.
- * The source string and the destination buffer must not overlap.
- *
- * @param csm       UCaseMap service object.
- * @param dest      A buffer for the result string. The result will be NUL-terminated if
- *                  the buffer is large enough.
- *                  The contents is undefined in case of failure.
- * @param destCapacity The size of the buffer (number of bytes). If it is 0, then
- *                  dest may be NULL and the function will only return the length of the result
- *                  without writing any of the result string.
- * @param src       The original string.
- * @param srcLength The length of the original string. If -1, then src must be NUL-terminated.
- * @param pErrorCode Must be a valid pointer to an error code value,
- *                  which must not indicate a failure before the function call.
- * @return The length of the result string, if successful - or in case of a buffer overflow,
- *         in which case it will be greater than destCapacity.
- *
- * @see u_strToTitle
- * @stable ICU 4.0
- */
-U_DRAFT int32_t U_EXPORT2
-ucasemap_toTitle(UCaseMap *csm,
-                 UChar *dest, int32_t destCapacity,
-                 const UChar *src, int32_t srcLength,
-                 UErrorCode *pErrorCode);
-
-#endif
-
-/**
- * Lowercase the characters in a UTF-8 string.
- * Casing is locale-dependent and context-sensitive.
- * The result may be longer or shorter than the original.
- * The source string and the destination buffer must not overlap.
- *
- * @param csm       UCaseMap service object.
- * @param dest      A buffer for the result string. The result will be NUL-terminated if
- *                  the buffer is large enough.
- *                  The contents is undefined in case of failure.
- * @param destCapacity The size of the buffer (number of bytes). If it is 0, then
- *                  dest may be NULL and the function will only return the length of the result
- *                  without writing any of the result string.
- * @param src       The original string.
- * @param srcLength The length of the original string. If -1, then src must be NUL-terminated.
- * @param pErrorCode Must be a valid pointer to an error code value,
- *                  which must not indicate a failure before the function call.
- * @return The length of the result string, if successful - or in case of a buffer overflow,
- *         in which case it will be greater than destCapacity.
- *
- * @see u_strToLower
- * @stable ICU 3.4
- */
-U_STABLE int32_t U_EXPORT2
-ucasemap_utf8ToLower(const UCaseMap *csm,
-                     char *dest, int32_t destCapacity,
-                     const char *src, int32_t srcLength,
-                     UErrorCode *pErrorCode);
-
-/**
- * Uppercase the characters in a UTF-8 string.
- * Casing is locale-dependent and context-sensitive.
- * The result may be longer or shorter than the original.
- * The source string and the destination buffer must not overlap.
- *
- * @param csm       UCaseMap service object.
- * @param dest      A buffer for the result string. The result will be NUL-terminated if
- *                  the buffer is large enough.
- *                  The contents is undefined in case of failure.
- * @param destCapacity The size of the buffer (number of bytes). If it is 0, then
- *                  dest may be NULL and the function will only return the length of the result
- *                  without writing any of the result string.
- * @param src       The original string.
- * @param srcLength The length of the original string. If -1, then src must be NUL-terminated.
- * @param pErrorCode Must be a valid pointer to an error code value,
- *                  which must not indicate a failure before the function call.
- * @return The length of the result string, if successful - or in case of a buffer overflow,
- *         in which case it will be greater than destCapacity.
- *
- * @see u_strToUpper
- * @stable ICU 3.4
- */
-U_STABLE int32_t U_EXPORT2
-ucasemap_utf8ToUpper(const UCaseMap *csm,
-                     char *dest, int32_t destCapacity,
-                     const char *src, int32_t srcLength,
-                     UErrorCode *pErrorCode);
-
-#if !UCONFIG_NO_BREAK_ITERATION
-
-/**
- * Titlecase a UTF-8 string.
- * Casing is locale-dependent and context-sensitive.
- * Titlecasing uses a break iterator to find the first characters of words
- * that are to be titlecased. It titlecases those characters and lowercases
- * all others. (This can be modified with ucasemap_setOptions().)
- *
- * The titlecase break iterator can be provided to customize for arbitrary
- * styles, using rules and dictionaries beyond the standard iterators.
- * It may be more efficient to always provide an iterator to avoid
- * opening and closing one for each string.
- * The standard titlecase iterator for the root locale implements the
- * algorithm of Unicode TR 21.
- *
- * This function uses only the setText(), first() and next() methods of the
- * provided break iterator.
- *
- * The result may be longer or shorter than the original.
- * The source string and the destination buffer must not overlap.
- *
- * @param csm       UCaseMap service object.
- * @param dest      A buffer for the result string. The result will be NUL-terminated if
- *                  the buffer is large enough.
- *                  The contents is undefined in case of failure.
- * @param destCapacity The size of the buffer (number of bytes). If it is 0, then
- *                  dest may be NULL and the function will only return the length of the result
- *                  without writing any of the result string.
- * @param src       The original string.
- * @param srcLength The length of the original string. If -1, then src must be NUL-terminated.
- * @param pErrorCode Must be a valid pointer to an error code value,
- *                  which must not indicate a failure before the function call.
- * @return The length of the result string, if successful - or in case of a buffer overflow,
- *         in which case it will be greater than destCapacity.
- *
- * @see u_strToTitle
- * @see U_TITLECASE_NO_LOWERCASE
- * @see U_TITLECASE_NO_BREAK_ADJUSTMENT
- * @stable ICU 4.0
- */
-U_DRAFT int32_t U_EXPORT2
-ucasemap_utf8ToTitle(UCaseMap *csm,
-                    char *dest, int32_t destCapacity,
-                    const char *src, int32_t srcLength,
-                    UErrorCode *pErrorCode);
-
-#endif
-
-/**
- * Case-fold the characters in a UTF-8 string.
- * Case-folding is locale-independent and not context-sensitive,
- * but there is an option for whether to include or exclude mappings for dotted I
- * and dotless i that are marked with 'I' in CaseFolding.txt.
- * The result may be longer or shorter than the original.
- * The source string and the destination buffer must not overlap.
- *
- * @param csm       UCaseMap service object.
- * @param dest      A buffer for the result string. The result will be NUL-terminated if
- *                  the buffer is large enough.
- *                  The contents is undefined in case of failure.
- * @param destCapacity The size of the buffer (number of bytes). If it is 0, then
- *                  dest may be NULL and the function will only return the length of the result
- *                  without writing any of the result string.
- * @param src       The original string.
- * @param srcLength The length of the original string. If -1, then src must be NUL-terminated.
- * @param pErrorCode Must be a valid pointer to an error code value,
- *                  which must not indicate a failure before the function call.
- * @return The length of the result string, if successful - or in case of a buffer overflow,
- *         in which case it will be greater than destCapacity.
- *
- * @see u_strFoldCase
- * @see ucasemap_setOptions
- * @see U_FOLD_CASE_DEFAULT
- * @see U_FOLD_CASE_EXCLUDE_SPECIAL_I
- * @stable ICU 4.0
- */
-U_DRAFT int32_t U_EXPORT2
-ucasemap_utf8FoldCase(const UCaseMap *csm,
-                      char *dest, int32_t destCapacity,
-                      const char *src, int32_t srcLength,
-                      UErrorCode *pErrorCode);
-
-#endif

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/ucat.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/ucat.h b/apps/couch_collate/platform/osx/icu/unicode/ucat.h
deleted file mode 100644
index ad9f037..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/ucat.h
+++ /dev/null
@@ -1,158 +0,0 @@
-/*
-**********************************************************************
-* Copyright (c) 2003-2004, International Business Machines
-* Corporation and others.  All Rights Reserved.
-**********************************************************************
-* Author: Alan Liu
-* Created: March 19 2003
-* Since: ICU 2.6
-**********************************************************************
-*/
-#ifndef UCAT_H
-#define UCAT_H
-
-#include "unicode/utypes.h"
-#include "unicode/ures.h"
-
-/**
- * \file
- * \brief C API: Message Catalog Wrappers
- *
- * This C API provides look-alike functions that deliberately resemble
- * the POSIX catopen, catclose, and catgets functions.  The underlying
- * implementation is in terms of ICU resource bundles, rather than
- * POSIX message catalogs.
- *
- * The ICU resource bundles obey standard ICU inheritance policies.
- * To facilitate this, sets and messages are flattened into one tier.
- * This is done by creating resource bundle keys of the form
- * &lt;set_num&gt;%&lt;msg_num&gt; where set_num is the set number and msg_num is
- * the message number, formatted as decimal strings.
- *
- * Example:  Consider a message catalog containing two sets:
- *
- * Set 1: Message 4  = "Good morning."
- *        Message 5  = "Good afternoon."
- *        Message 7  = "Good evening."
- *        Message 8  = "Good night."
- * Set 4: Message 14 = "Please "
- *        Message 19 = "Thank you."
- *        Message 20 = "Sincerely,"
- *
- * The ICU resource bundle source file would, assuming it is named
- * "greet.txt", would look like this:
- *
- * greet
- * {
- *     1%4  { "Good morning." }
- *     1%5  { "Good afternoon." }
- *     1%7  { "Good evening." }
- *     1%8  { "Good night." }
- * 
- *     4%14 { "Please " }
- *     4%19 { "Thank you." }
- *     4%20 { "Sincerely," }
- * }
- *
- * The catgets function is commonly used in combination with functions
- * like printf and strftime.  ICU components like message format can
- * be used instead, although they use a different format syntax.
- * There is an ICU package, icuio, that provides some of
- * the POSIX-style formatting API.
- */
-
-U_CDECL_BEGIN
-
-/**
- * An ICU message catalog descriptor, analogous to nl_catd.
- * 
- * @stable ICU 2.6
- */
-typedef UResourceBundle* u_nl_catd;
-
-/**
- * Open and return an ICU message catalog descriptor. The descriptor
- * may be passed to u_catgets() to retrieve localized strings.
- *
- * @param name string containing the full path pointing to the
- * directory where the resources reside followed by the package name
- * e.g. "/usr/resource/my_app/resources/guimessages" on a Unix system.
- * If NULL, ICU default data files will be used.
- *
- * Unlike POSIX, environment variables are not interpolated within the
- * name.
- *
- * @param locale the locale for which we want to open the resource. If
- * NULL, the default ICU locale will be used (see uloc_getDefault). If
- * strlen(locale) == 0, the root locale will be used.
- *
- * @param ec input/output error code. Upon output,
- * U_USING_FALLBACK_WARNING indicates that a fallback locale was
- * used. For example, 'de_CH' was requested, but nothing was found
- * there, so 'de' was used. U_USING_DEFAULT_WARNING indicates that the
- * default locale data or root locale data was used; neither the
- * requested locale nor any of its fallback locales were found.
- *
- * @return a message catalog descriptor that may be passed to
- * u_catgets(). If the ec parameter indicates success, then the caller
- * is responsible for calling u_catclose() to close the message
- * catalog. If the ec parameter indicates failure, then NULL will be
- * returned.
- * 
- * @stable ICU 2.6
- */
-U_STABLE u_nl_catd U_EXPORT2
-u_catopen(const char* name, const char* locale, UErrorCode* ec);
-
-/**
- * Close an ICU message catalog, given its descriptor.
- *
- * @param catd a message catalog descriptor to be closed. May be NULL,
- * in which case no action is taken.
- * 
- * @stable ICU 2.6
- */
-U_STABLE void U_EXPORT2
-u_catclose(u_nl_catd catd);
-
-/**
- * Retrieve a localized string from an ICU message catalog.
- *
- * @param catd a message catalog descriptor returned by u_catopen.
- *
- * @param set_num the message catalog set number. Sets need not be
- * numbered consecutively.
- *
- * @param msg_num the message catalog message number within the
- * set. Messages need not be numbered consecutively.
- *
- * @param s the default string. This is returned if the string
- * specified by the set_num and msg_num is not found. It must be
- * zero-terminated.
- *
- * @param len fill-in parameter to receive the length of the result.
- * May be NULL, in which case it is ignored.
- *
- * @param ec input/output error code. May be U_USING_FALLBACK_WARNING
- * or U_USING_DEFAULT_WARNING. U_MISSING_RESOURCE_ERROR indicates that
- * the set_num/msg_num tuple does not specify a valid message string
- * in this catalog.
- *
- * @return a pointer to a zero-terminated UChar array which lives in
- * an internal buffer area, typically a memory mapped/DLL file. The
- * caller must NOT delete this pointer. If the call is unsuccessful
- * for any reason, then s is returned.  This includes the situation in
- * which ec indicates a failing error code upon entry to this
- * function.
- * 
- * @stable ICU 2.6
- */
-U_STABLE const UChar* U_EXPORT2
-u_catgets(u_nl_catd catd, int32_t set_num, int32_t msg_num,
-          const UChar* s,
-          int32_t* len, UErrorCode* ec);
-
-U_CDECL_END
-
-#endif /*UCAT_H*/
-/*eof*/


[05/57] [abbrv] remove couch_collate

Posted by be...@apache.org.
http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/ushape.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/ushape.h b/apps/couch_collate/platform/osx/icu/unicode/ushape.h
deleted file mode 100644
index f165e14..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/ushape.h
+++ /dev/null
@@ -1,263 +0,0 @@
-/*
-******************************************************************************
-*
-*   Copyright (C) 2000-2007, International Business Machines
-*   Corporation and others.  All Rights Reserved.
-*
-******************************************************************************
-*   file name:  ushape.h
-*   encoding:   US-ASCII
-*   tab size:   8 (not used)
-*   indentation:4
-*
-*   created on: 2000jun29
-*   created by: Markus W. Scherer
-*/
-
-#ifndef __USHAPE_H__
-#define __USHAPE_H__
-
-#include "unicode/utypes.h"
-
-/**
- * \file
- * \brief C API:  Arabic shaping
- * 
- */
-
-/**
- * Shape Arabic text on a character basis.
- *
- * <p>This function performs basic operations for "shaping" Arabic text. It is most
- * useful for use with legacy data formats and legacy display technology
- * (simple terminals). All operations are performed on Unicode characters.</p>
- *
- * <p>Text-based shaping means that some character code points in the text are
- * replaced by others depending on the context. It transforms one kind of text
- * into another. In comparison, modern displays for Arabic text select
- * appropriate, context-dependent font glyphs for each text element, which means
- * that they transform text into a glyph vector.</p>
- *
- * <p>Text transformations are necessary when modern display technology is not
- * available or when text needs to be transformed to or from legacy formats that
- * use "shaped" characters. Since the Arabic script is cursive, connecting
- * adjacent letters to each other, computers select images for each letter based
- * on the surrounding letters. This usually results in four images per Arabic
- * letter: initial, middle, final, and isolated forms. In Unicode, on the other
- * hand, letters are normally stored abstract, and a display system is expected
- * to select the necessary glyphs. (This makes searching and other text
- * processing easier because the same letter has only one code.) It is possible
- * to mimic this with text transformations because there are characters in
- * Unicode that are rendered as letters with a specific shape
- * (or cursive connectivity). They were included for interoperability with
- * legacy systems and codepages, and for unsophisticated display systems.</p>
- *
- * <p>A second kind of text transformations is supported for Arabic digits:
- * For compatibility with legacy codepages that only include European digits,
- * it is possible to replace one set of digits by another, changing the
- * character code points. These operations can be performed for either
- * Arabic-Indic Digits (U+0660...U+0669) or Eastern (Extended) Arabic-Indic
- * digits (U+06f0...U+06f9).</p>
- *
- * <p>Some replacements may result in more or fewer characters (code points).
- * By default, this means that the destination buffer may receive text with a
- * length different from the source length. Some legacy systems rely on the
- * length of the text to be constant. They expect extra spaces to be added
- * or consumed either next to the affected character or at the end of the
- * text.</p>
- *
- * <p>For details about the available operations, see the description of the
- * <code>U_SHAPE_...</code> options.</p>
- *
- * @param source The input text.
- *
- * @param sourceLength The number of UChars in <code>source</code>.
- *
- * @param dest The destination buffer that will receive the results of the
- *             requested operations. It may be <code>NULL</code> only if
- *             <code>destSize</code> is 0. The source and destination must not
- *             overlap.
- *
- * @param destSize The size (capacity) of the destination buffer in UChars.
- *                 If <code>destSize</code> is 0, then no output is produced,
- *                 but the necessary buffer size is returned ("preflighting").
- *
- * @param options This is a 32-bit set of flags that specify the operations
- *                that are performed on the input text. If no error occurs,
- *                then the result will always be written to the destination
- *                buffer.
- *
- * @param pErrorCode must be a valid pointer to an error code value,
- *        which must not indicate a failure before the function call.
- *
- * @return The number of UChars written to the destination buffer.
- *         If an error occured, then no output was written, or it may be
- *         incomplete. If <code>U_BUFFER_OVERFLOW_ERROR</code> is set, then
- *         the return value indicates the necessary destination buffer size.
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2
-u_shapeArabic(const UChar *source, int32_t sourceLength,
-              UChar *dest, int32_t destSize,
-              uint32_t options,
-              UErrorCode *pErrorCode);
-
-/**
- * Memory option: allow the result to have a different length than the source.
- * @stable ICU 2.0
- */
-#define U_SHAPE_LENGTH_GROW_SHRINK              0
-
-/**
- * Memory option: the result must have the same length as the source.
- * If more room is necessary, then try to consume spaces next to modified characters.
- * @stable ICU 2.0
- */
-#define U_SHAPE_LENGTH_FIXED_SPACES_NEAR        1
-
-/**
- * Memory option: the result must have the same length as the source.
- * If more room is necessary, then try to consume spaces at the end of the text.
- * @stable ICU 2.0
- */
-#define U_SHAPE_LENGTH_FIXED_SPACES_AT_END      2
-
-/**
- * Memory option: the result must have the same length as the source.
- * If more room is necessary, then try to consume spaces at the beginning of the text.
- * @stable ICU 2.0
- */
-#define U_SHAPE_LENGTH_FIXED_SPACES_AT_BEGINNING 3
-
-/** Bit mask for memory options. @stable ICU 2.0 */
-#define U_SHAPE_LENGTH_MASK                     3
-
-
-/** Direction indicator: the source is in logical (keyboard) order. @stable ICU 2.0 */
-#define U_SHAPE_TEXT_DIRECTION_LOGICAL          0
-
-/**
- * Direction indicator:
- * the source is in visual LTR order,
- * the leftmost displayed character stored first.
- * @stable ICU 2.0
- */
-#define U_SHAPE_TEXT_DIRECTION_VISUAL_LTR       4
-
-/** Bit mask for direction indicators. @stable ICU 2.0 */
-#define U_SHAPE_TEXT_DIRECTION_MASK             4
-
-
-/** Letter shaping option: do not perform letter shaping. @stable ICU 2.0 */
-#define U_SHAPE_LETTERS_NOOP                    0
-
-/** Letter shaping option: replace abstract letter characters by "shaped" ones. @stable ICU 2.0 */
-#define U_SHAPE_LETTERS_SHAPE                   8
-
-/** Letter shaping option: replace "shaped" letter characters by abstract ones. @stable ICU 2.0 */
-#define U_SHAPE_LETTERS_UNSHAPE                 0x10
-
-/**
- * Letter shaping option: replace abstract letter characters by "shaped" ones.
- * The only difference with U_SHAPE_LETTERS_SHAPE is that Tashkeel letters
- * are always "shaped" into the isolated form instead of the medial form
- * (selecting code points from the Arabic Presentation Forms-B block).
- * @stable ICU 2.0
- */
-#define U_SHAPE_LETTERS_SHAPE_TASHKEEL_ISOLATED 0x18
-
-/** Bit mask for letter shaping options. @stable ICU 2.0 */
-#define U_SHAPE_LETTERS_MASK                    0x18
-
-
-/** Digit shaping option: do not perform digit shaping. @stable ICU 2.0 */
-#define U_SHAPE_DIGITS_NOOP                     0
-
-/**
- * Digit shaping option:
- * Replace European digits (U+0030...) by Arabic-Indic digits.
- * @stable ICU 2.0
- */
-#define U_SHAPE_DIGITS_EN2AN                    0x20
-
-/**
- * Digit shaping option:
- * Replace Arabic-Indic digits by European digits (U+0030...).
- * @stable ICU 2.0
- */
-#define U_SHAPE_DIGITS_AN2EN                    0x40
-
-/**
- * Digit shaping option:
- * Replace European digits (U+0030...) by Arabic-Indic digits if the most recent
- * strongly directional character is an Arabic letter
- * (<code>u_charDirection()</code> result <code>U_RIGHT_TO_LEFT_ARABIC</code> [AL]).<br>
- * The direction of "preceding" depends on the direction indicator option.
- * For the first characters, the preceding strongly directional character
- * (initial state) is assumed to be not an Arabic letter
- * (it is <code>U_LEFT_TO_RIGHT</code> [L] or <code>U_RIGHT_TO_LEFT</code> [R]).
- * @stable ICU 2.0
- */
-#define U_SHAPE_DIGITS_ALEN2AN_INIT_LR          0x60
-
-/**
- * Digit shaping option:
- * Replace European digits (U+0030...) by Arabic-Indic digits if the most recent
- * strongly directional character is an Arabic letter
- * (<code>u_charDirection()</code> result <code>U_RIGHT_TO_LEFT_ARABIC</code> [AL]).<br>
- * The direction of "preceding" depends on the direction indicator option.
- * For the first characters, the preceding strongly directional character
- * (initial state) is assumed to be an Arabic letter.
- * @stable ICU 2.0
- */
-#define U_SHAPE_DIGITS_ALEN2AN_INIT_AL          0x80
-
-/** Not a valid option value. May be replaced by a new option. @stable ICU 2.0 */
-#define U_SHAPE_DIGITS_RESERVED                 0xa0
-
-/** Bit mask for digit shaping options. @stable ICU 2.0 */
-#define U_SHAPE_DIGITS_MASK                     0xe0
-
-
-/** Digit type option: Use Arabic-Indic digits (U+0660...U+0669). @stable ICU 2.0 */
-#define U_SHAPE_DIGIT_TYPE_AN                   0
-
-/** Digit type option: Use Eastern (Extended) Arabic-Indic digits (U+06f0...U+06f9). @stable ICU 2.0 */
-#define U_SHAPE_DIGIT_TYPE_AN_EXTENDED          0x100
-
-/** Not a valid option value. May be replaced by a new option. @stable ICU 2.0 */
-#define U_SHAPE_DIGIT_TYPE_RESERVED             0x200
-
-/** Bit mask for digit type options. @stable ICU 2.0 */
-#define U_SHAPE_DIGIT_TYPE_MASK                 0x3f00
-
-/** 
- * Tashkeel aggregation option:
- * Replaces any combination of U+0651 with one of
- * U+064C, U+064D, U+064E, U+064F, U+0650 with
- * U+FC5E, U+FC5F, U+FC60, U+FC61, U+FC62 consecutively.
- * @stable ICU 3.6
- */
-#define U_SHAPE_AGGREGATE_TASHKEEL              0x4000
-/** Tashkeel aggregation option: do not aggregate tashkeels. @stable ICU 3.6 */
-#define U_SHAPE_AGGREGATE_TASHKEEL_NOOP         0
-/** Bit mask for tashkeel aggregation. @stable ICU 3.6 */
-#define U_SHAPE_AGGREGATE_TASHKEEL_MASK         0x4000
-
-/** 
- * Presentation form option:
- * Don't replace Arabic Presentation Forms-A and Arabic Presentation Forms-B
- * characters with 0+06xx characters, before shaping.
- * @stable ICU 3.6
- */
-#define U_SHAPE_PRESERVE_PRESENTATION           0x8000
-/** Presentation form option: 
- * Replace Arabic Presentation Forms-A and Arabic Presentationo Forms-B with 
- * their unshaped correspondants in range 0+06xx, before shaping.
- * @stable ICU 3.6 
- */
-#define U_SHAPE_PRESERVE_PRESENTATION_NOOP      0
-/** Bit mask for preserve presentation form. @stable ICU 3.6 */
-#define U_SHAPE_PRESERVE_PRESENTATION_MASK      0x8000
-
-#endif

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/usprep.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/usprep.h b/apps/couch_collate/platform/osx/icu/unicode/usprep.h
deleted file mode 100644
index c7e75a5..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/usprep.h
+++ /dev/null
@@ -1,156 +0,0 @@
-/*
- *******************************************************************************
- *
- *   Copyright (C) 2003-2006, International Business Machines
- *   Corporation and others.  All Rights Reserved.
- *
- *******************************************************************************
- *   file name:  usprep.h
- *   encoding:   US-ASCII
- *   tab size:   8 (not used)
- *   indentation:4
- *
- *   created on: 2003jul2
- *   created by: Ram Viswanadha
- */
-
-#ifndef __USPREP_H__
-#define __USPREP_H__
-
-/**
- * \file 
- * \brief C API: Implements the StringPrep algorithm.
- */
-
-#include "unicode/utypes.h"
-/**
- *
- * StringPrep API implements the StingPrep framework as described by RFC 3454.
- * StringPrep prepares Unicode strings for use in network protocols.
- * Profiles of StingPrep are set of rules and data according to with the
- * Unicode Strings are prepared. Each profiles contains tables which describe
- * how a code point should be treated. The tables are broadly classied into
- * <ul>
- *     <li> Unassinged Table: Contains code points that are unassigned 
- *          in the Unicode Version supported by StringPrep. Currently 
- *          RFC 3454 supports Unicode 3.2. </li>
- *     <li> Prohibited Table: Contains code points that are prohibted from
- *          the output of the StringPrep processing function. </li>
- *     <li> Mapping Table: Contains code ponts that are deleted from the output or case mapped. </li>
- * </ul>
- * 
- * The procedure for preparing Unicode strings:
- * <ol>
- *      <li> Map: For each character in the input, check if it has a mapping
- *           and, if so, replace it with its mapping. </li>
- *      <li> Normalize: Possibly normalize the result of step 1 using Unicode
- *           normalization. </li>
- *      <li> Prohibit: Check for any characters that are not allowed in the
- *        output.  If any are found, return an error.</li>
- *      <li> Check bidi: Possibly check for right-to-left characters, and if
- *           any are found, make sure that the whole string satisfies the
- *           requirements for bidirectional strings.  If the string does not
- *           satisfy the requirements for bidirectional strings, return an
- *           error.  </li>
- * </ol>
- * @author Ram Viswanadha
- */
-#if !UCONFIG_NO_IDNA
-
-#include "unicode/parseerr.h"
-
-/**
- * The StringPrep profile
- * @stable ICU 2.8
- */
-typedef struct UStringPrepProfile UStringPrepProfile;
-
-
-/** 
- * Option to prohibit processing of unassigned code points in the input
- * 
- * @see  usprep_prepare
- * @stable ICU 2.8
- */
-#define USPREP_DEFAULT 0x0000
-
-/** 
- * Option to allow processing of unassigned code points in the input
- * 
- * @see  usprep_prepare
- * @stable ICU 2.8
- */
-#define USPREP_ALLOW_UNASSIGNED 0x0001
-
-
-/**
- * Creates a StringPrep profile from the data file.
- *
- * @param path      string containing the full path pointing to the directory
- *                  where the profile reside followed by the package name
- *                  e.g. "/usr/resource/my_app/profiles/mydata" on a Unix system.
- *                  if NULL, ICU default data files will be used.
- * @param fileName  name of the profile file to be opened
- * @param status    ICU error code in/out parameter. Must not be NULL.
- *                  Must fulfill U_SUCCESS before the function call.
- * @return Pointer to UStringPrepProfile that is opened. Should be closed by
- * calling usprep_close()
- * @see usprep_close()
- * @stable ICU 2.8
- */
-U_STABLE UStringPrepProfile* U_EXPORT2
-usprep_open(const char* path, 
-            const char* fileName,
-            UErrorCode* status);
-
-
-/**
- * Closes the profile
- * @param profile The profile to close
- * @stable ICU 2.8
- */
-U_STABLE void U_EXPORT2
-usprep_close(UStringPrepProfile* profile);
-
-
-/**
- * Prepare the input buffer for use in applications with the given profile. This operation maps, normalizes(NFKC),
- * checks for prohited and BiDi characters in the order defined by RFC 3454
- * depending on the options specified in the profile.
- *
- * @param prep          The profile to use 
- * @param src           Pointer to UChar buffer containing the string to prepare
- * @param srcLength     Number of characters in the source string
- * @param dest          Pointer to the destination buffer to receive the output
- * @param destCapacity  The capacity of destination array
- * @param options       A bit set of options:
- *
- *  - USPREP_NONE               Prohibit processing of unassigned code points in the input
- *
- *  - USPREP_ALLOW_UNASSIGNED   Treat the unassigned code points are in the input 
- *                              as normal Unicode code points.
- *
- * @param parseError        Pointer to UParseError struct to receive information on position 
- *                          of error if an error is encountered. Can be NULL.
- * @param status            ICU in/out error code parameter.
- *                          U_INVALID_CHAR_FOUND if src contains
- *                          unmatched single surrogates.
- *                          U_INDEX_OUTOFBOUNDS_ERROR if src contains
- *                          too many code points.
- *                          U_BUFFER_OVERFLOW_ERROR if destCapacity is not enough
- * @return The number of UChars in the destination buffer
- * @stable ICU 2.8
- */
-
-U_STABLE int32_t U_EXPORT2
-usprep_prepare(   const UStringPrepProfile* prep,
-                  const UChar* src, int32_t srcLength, 
-                  UChar* dest, int32_t destCapacity,
-                  int32_t options,
-                  UParseError* parseError,
-                  UErrorCode* status );
-
-
-#endif /* #if !UCONFIG_NO_IDNA */
-
-#endif

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/ustring.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/ustring.h b/apps/couch_collate/platform/osx/icu/unicode/ustring.h
deleted file mode 100644
index 12411ef..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/ustring.h
+++ /dev/null
@@ -1,1479 +0,0 @@
-/*
-**********************************************************************
-*   Copyright (C) 1998-2008, International Business Machines
-*   Corporation and others.  All Rights Reserved.
-**********************************************************************
-*
-* File ustring.h
-*
-* Modification History:
-*
-*   Date        Name        Description
-*   12/07/98    bertrand    Creation.
-******************************************************************************
-*/
-
-#ifndef USTRING_H
-#define USTRING_H
-
-#include "unicode/utypes.h"
-#include "unicode/putil.h"
-#include "unicode/uiter.h"
-
-/** Simple declaration for u_strToTitle() to avoid including unicode/ubrk.h. @stable ICU 2.1*/
-#ifndef UBRK_TYPEDEF_UBREAK_ITERATOR
-#   define UBRK_TYPEDEF_UBREAK_ITERATOR
-    typedef void UBreakIterator;
-#endif
-
-/**
- * \file
- * \brief C API: Unicode string handling functions
- *
- * These C API functions provide general Unicode string handling.
- *
- * Some functions are equivalent in name, signature, and behavior to the ANSI C <string.h>
- * functions. (For example, they do not check for bad arguments like NULL string pointers.)
- * In some cases, only the thread-safe variant of such a function is implemented here
- * (see u_strtok_r()).
- *
- * Other functions provide more Unicode-specific functionality like locale-specific
- * upper/lower-casing and string comparison in code point order.
- *
- * ICU uses 16-bit Unicode (UTF-16) in the form of arrays of UChar code units.
- * UTF-16 encodes each Unicode code point with either one or two UChar code units.
- * (This is the default form of Unicode, and a forward-compatible extension of the original,
- * fixed-width form that was known as UCS-2. UTF-16 superseded UCS-2 with Unicode 2.0
- * in 1996.)
- *
- * Some APIs accept a 32-bit UChar32 value for a single code point.
- *
- * ICU also handles 16-bit Unicode text with unpaired surrogates.
- * Such text is not well-formed UTF-16.
- * Code-point-related functions treat unpaired surrogates as surrogate code points,
- * i.e., as separate units.
- *
- * Although UTF-16 is a variable-width encoding form (like some legacy multi-byte encodings),
- * it is much more efficient even for random access because the code unit values
- * for single-unit characters vs. lead units vs. trail units are completely disjoint.
- * This means that it is easy to determine character (code point) boundaries from
- * random offsets in the string.
- *
- * Unicode (UTF-16) string processing is optimized for the single-unit case.
- * Although it is important to support supplementary characters
- * (which use pairs of lead/trail code units called "surrogates"),
- * their occurrence is rare. Almost all characters in modern use require only
- * a single UChar code unit (i.e., their code point values are <=0xffff).
- *
- * For more details see the User Guide Strings chapter (http://icu-project.org/userguide/strings.html).
- * For a discussion of the handling of unpaired surrogates see also
- * Jitterbug 2145 and its icu mailing list proposal on 2002-sep-18.
- */
-
-/**
- * \defgroup ustring_ustrlen String Length
- * \ingroup ustring_strlen
- */
-/*@{*/
-/**
- * Determine the length of an array of UChar.
- *
- * @param s The array of UChars, NULL (U+0000) terminated.
- * @return The number of UChars in <code>chars</code>, minus the terminator.
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2
-u_strlen(const UChar *s);
-/*@}*/
-
-/**
- * Count Unicode code points in the length UChar code units of the string.
- * A code point may occupy either one or two UChar code units.
- * Counting code points involves reading all code units.
- *
- * This functions is basically the inverse of the U16_FWD_N() macro (see utf.h).
- *
- * @param s The input string.
- * @param length The number of UChar code units to be checked, or -1 to count all
- *               code points before the first NUL (U+0000).
- * @return The number of code points in the specified code units.
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2
-u_countChar32(const UChar *s, int32_t length);
-
-/**
- * Check if the string contains more Unicode code points than a certain number.
- * This is more efficient than counting all code points in the entire string
- * and comparing that number with a threshold.
- * This function may not need to scan the string at all if the length is known
- * (not -1 for NUL-termination) and falls within a certain range, and
- * never needs to count more than 'number+1' code points.
- * Logically equivalent to (u_countChar32(s, length)>number).
- * A Unicode code point may occupy either one or two UChar code units.
- *
- * @param s The input string.
- * @param length The length of the string, or -1 if it is NUL-terminated.
- * @param number The number of code points in the string is compared against
- *               the 'number' parameter.
- * @return Boolean value for whether the string contains more Unicode code points
- *         than 'number'. Same as (u_countChar32(s, length)>number).
- * @stable ICU 2.4
- */
-U_STABLE UBool U_EXPORT2
-u_strHasMoreChar32Than(const UChar *s, int32_t length, int32_t number);
-
-/**
- * Concatenate two ustrings.  Appends a copy of <code>src</code>,
- * including the null terminator, to <code>dst</code>. The initial copied
- * character from <code>src</code> overwrites the null terminator in <code>dst</code>.
- *
- * @param dst The destination string.
- * @param src The source string.
- * @return A pointer to <code>dst</code>.
- * @stable ICU 2.0
- */
-U_STABLE UChar* U_EXPORT2
-u_strcat(UChar     *dst, 
-    const UChar     *src);
-
-/**
- * Concatenate two ustrings.  
- * Appends at most <code>n</code> characters from <code>src</code> to <code>dst</code>.
- * Adds a terminating NUL.
- * If src is too long, then only <code>n-1</code> characters will be copied
- * before the terminating NUL.
- * If <code>n&lt;=0</code> then dst is not modified.
- *
- * @param dst The destination string.
- * @param src The source string.
- * @param n The maximum number of characters to compare.
- * @return A pointer to <code>dst</code>.
- * @stable ICU 2.0
- */
-U_STABLE UChar* U_EXPORT2
-u_strncat(UChar     *dst, 
-     const UChar     *src, 
-     int32_t     n);
-
-/**
- * Find the first occurrence of a substring in a string.
- * The substring is found at code point boundaries.
- * That means that if the substring begins with
- * a trail surrogate or ends with a lead surrogate,
- * then it is found only if these surrogates stand alone in the text.
- * Otherwise, the substring edge units would be matched against
- * halves of surrogate pairs.
- *
- * @param s The string to search (NUL-terminated).
- * @param substring The substring to find (NUL-terminated).
- * @return A pointer to the first occurrence of <code>substring</code> in <code>s</code>,
- *         or <code>s</code> itself if the <code>substring</code> is empty,
- *         or <code>NULL</code> if <code>substring</code> is not in <code>s</code>.
- * @stable ICU 2.0
- *
- * @see u_strrstr
- * @see u_strFindFirst
- * @see u_strFindLast
- */
-U_STABLE UChar * U_EXPORT2
-u_strstr(const UChar *s, const UChar *substring);
-
-/**
- * Find the first occurrence of a substring in a string.
- * The substring is found at code point boundaries.
- * That means that if the substring begins with
- * a trail surrogate or ends with a lead surrogate,
- * then it is found only if these surrogates stand alone in the text.
- * Otherwise, the substring edge units would be matched against
- * halves of surrogate pairs.
- *
- * @param s The string to search.
- * @param length The length of s (number of UChars), or -1 if it is NUL-terminated.
- * @param substring The substring to find (NUL-terminated).
- * @param subLength The length of substring (number of UChars), or -1 if it is NUL-terminated.
- * @return A pointer to the first occurrence of <code>substring</code> in <code>s</code>,
- *         or <code>s</code> itself if the <code>substring</code> is empty,
- *         or <code>NULL</code> if <code>substring</code> is not in <code>s</code>.
- * @stable ICU 2.4
- *
- * @see u_strstr
- * @see u_strFindLast
- */
-U_STABLE UChar * U_EXPORT2
-u_strFindFirst(const UChar *s, int32_t length, const UChar *substring, int32_t subLength);
-
-/**
- * Find the first occurrence of a BMP code point in a string.
- * A surrogate code point is found only if its match in the text is not
- * part of a surrogate pair.
- * A NUL character is found at the string terminator.
- *
- * @param s The string to search (NUL-terminated).
- * @param c The BMP code point to find.
- * @return A pointer to the first occurrence of <code>c</code> in <code>s</code>
- *         or <code>NULL</code> if <code>c</code> is not in <code>s</code>.
- * @stable ICU 2.0
- *
- * @see u_strchr32
- * @see u_memchr
- * @see u_strstr
- * @see u_strFindFirst
- */
-U_STABLE UChar * U_EXPORT2
-u_strchr(const UChar *s, UChar c);
-
-/**
- * Find the first occurrence of a code point in a string.
- * A surrogate code point is found only if its match in the text is not
- * part of a surrogate pair.
- * A NUL character is found at the string terminator.
- *
- * @param s The string to search (NUL-terminated).
- * @param c The code point to find.
- * @return A pointer to the first occurrence of <code>c</code> in <code>s</code>
- *         or <code>NULL</code> if <code>c</code> is not in <code>s</code>.
- * @stable ICU 2.0
- *
- * @see u_strchr
- * @see u_memchr32
- * @see u_strstr
- * @see u_strFindFirst
- */
-U_STABLE UChar * U_EXPORT2
-u_strchr32(const UChar *s, UChar32 c);
-
-/**
- * Find the last occurrence of a substring in a string.
- * The substring is found at code point boundaries.
- * That means that if the substring begins with
- * a trail surrogate or ends with a lead surrogate,
- * then it is found only if these surrogates stand alone in the text.
- * Otherwise, the substring edge units would be matched against
- * halves of surrogate pairs.
- *
- * @param s The string to search (NUL-terminated).
- * @param substring The substring to find (NUL-terminated).
- * @return A pointer to the last occurrence of <code>substring</code> in <code>s</code>,
- *         or <code>s</code> itself if the <code>substring</code> is empty,
- *         or <code>NULL</code> if <code>substring</code> is not in <code>s</code>.
- * @stable ICU 2.4
- *
- * @see u_strstr
- * @see u_strFindFirst
- * @see u_strFindLast
- */
-U_STABLE UChar * U_EXPORT2
-u_strrstr(const UChar *s, const UChar *substring);
-
-/**
- * Find the last occurrence of a substring in a string.
- * The substring is found at code point boundaries.
- * That means that if the substring begins with
- * a trail surrogate or ends with a lead surrogate,
- * then it is found only if these surrogates stand alone in the text.
- * Otherwise, the substring edge units would be matched against
- * halves of surrogate pairs.
- *
- * @param s The string to search.
- * @param length The length of s (number of UChars), or -1 if it is NUL-terminated.
- * @param substring The substring to find (NUL-terminated).
- * @param subLength The length of substring (number of UChars), or -1 if it is NUL-terminated.
- * @return A pointer to the last occurrence of <code>substring</code> in <code>s</code>,
- *         or <code>s</code> itself if the <code>substring</code> is empty,
- *         or <code>NULL</code> if <code>substring</code> is not in <code>s</code>.
- * @stable ICU 2.4
- *
- * @see u_strstr
- * @see u_strFindLast
- */
-U_STABLE UChar * U_EXPORT2
-u_strFindLast(const UChar *s, int32_t length, const UChar *substring, int32_t subLength);
-
-/**
- * Find the last occurrence of a BMP code point in a string.
- * A surrogate code point is found only if its match in the text is not
- * part of a surrogate pair.
- * A NUL character is found at the string terminator.
- *
- * @param s The string to search (NUL-terminated).
- * @param c The BMP code point to find.
- * @return A pointer to the last occurrence of <code>c</code> in <code>s</code>
- *         or <code>NULL</code> if <code>c</code> is not in <code>s</code>.
- * @stable ICU 2.4
- *
- * @see u_strrchr32
- * @see u_memrchr
- * @see u_strrstr
- * @see u_strFindLast
- */
-U_STABLE UChar * U_EXPORT2
-u_strrchr(const UChar *s, UChar c);
-
-/**
- * Find the last occurrence of a code point in a string.
- * A surrogate code point is found only if its match in the text is not
- * part of a surrogate pair.
- * A NUL character is found at the string terminator.
- *
- * @param s The string to search (NUL-terminated).
- * @param c The code point to find.
- * @return A pointer to the last occurrence of <code>c</code> in <code>s</code>
- *         or <code>NULL</code> if <code>c</code> is not in <code>s</code>.
- * @stable ICU 2.4
- *
- * @see u_strrchr
- * @see u_memchr32
- * @see u_strrstr
- * @see u_strFindLast
- */
-U_STABLE UChar * U_EXPORT2
-u_strrchr32(const UChar *s, UChar32 c);
-
-/**
- * Locates the first occurrence in the string <code>string</code> of any of the characters
- * in the string <code>matchSet</code>.
- * Works just like C's strpbrk but with Unicode.
- *
- * @param string The string in which to search, NUL-terminated.
- * @param matchSet A NUL-terminated string defining a set of code points
- *                 for which to search in the text string.
- * @return A pointer to the  character in <code>string</code> that matches one of the
- *         characters in <code>matchSet</code>, or NULL if no such character is found.
- * @stable ICU 2.0
- */
-U_STABLE UChar * U_EXPORT2
-u_strpbrk(const UChar *string, const UChar *matchSet);
-
-/**
- * Returns the number of consecutive characters in <code>string</code>,
- * beginning with the first, that do not occur somewhere in <code>matchSet</code>.
- * Works just like C's strcspn but with Unicode.
- *
- * @param string The string in which to search, NUL-terminated.
- * @param matchSet A NUL-terminated string defining a set of code points
- *                 for which to search in the text string.
- * @return The number of initial characters in <code>string</code> that do not
- *         occur in <code>matchSet</code>.
- * @see u_strspn
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2
-u_strcspn(const UChar *string, const UChar *matchSet);
-
-/**
- * Returns the number of consecutive characters in <code>string</code>,
- * beginning with the first, that occur somewhere in <code>matchSet</code>.
- * Works just like C's strspn but with Unicode.
- *
- * @param string The string in which to search, NUL-terminated.
- * @param matchSet A NUL-terminated string defining a set of code points
- *                 for which to search in the text string.
- * @return The number of initial characters in <code>string</code> that do
- *         occur in <code>matchSet</code>.
- * @see u_strcspn
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2
-u_strspn(const UChar *string, const UChar *matchSet);
-
-/**
- * The string tokenizer API allows an application to break a string into
- * tokens. Unlike strtok(), the saveState (the current pointer within the
- * original string) is maintained in saveState. In the first call, the
- * argument src is a pointer to the string. In subsequent calls to
- * return successive tokens of that string, src must be specified as
- * NULL. The value saveState is set by this function to maintain the
- * function's position within the string, and on each subsequent call
- * you must give this argument the same variable. This function does
- * handle surrogate pairs. This function is similar to the strtok_r()
- * the POSIX Threads Extension (1003.1c-1995) version.
- *
- * @param src String containing token(s). This string will be modified.
- *            After the first call to u_strtok_r(), this argument must
- *            be NULL to get to the next token.
- * @param delim Set of delimiter characters (Unicode code points).
- * @param saveState The current pointer within the original string,
- *              which is set by this function. The saveState
- *              parameter should the address of a local variable of type
- *              UChar *. (i.e. defined "Uhar *myLocalSaveState" and use
- *              &myLocalSaveState for this parameter).
- * @return A pointer to the next token found in src, or NULL
- *         when there are no more tokens.
- * @stable ICU 2.0
- */
-U_STABLE UChar * U_EXPORT2
-u_strtok_r(UChar    *src, 
-     const UChar    *delim,
-           UChar   **saveState);
-
-/**
- * Compare two Unicode strings for bitwise equality (code unit order).
- *
- * @param s1 A string to compare.
- * @param s2 A string to compare.
- * @return 0 if <code>s1</code> and <code>s2</code> are bitwise equal; a negative
- * value if <code>s1</code> is bitwise less than <code>s2,</code>; a positive
- * value if <code>s1</code> is bitwise greater than <code>s2</code>.
- * @stable ICU 2.0
- */
-U_STABLE int32_t  U_EXPORT2
-u_strcmp(const UChar     *s1, 
-         const UChar     *s2);
-
-/**
- * Compare two Unicode strings in code point order.
- * See u_strCompare for details.
- *
- * @param s1 A string to compare.
- * @param s2 A string to compare.
- * @return a negative/zero/positive integer corresponding to whether
- * the first string is less than/equal to/greater than the second one
- * in code point order
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2
-u_strcmpCodePointOrder(const UChar *s1, const UChar *s2);
-
-/**
- * Compare two Unicode strings (binary order).
- *
- * The comparison can be done in code unit order or in code point order.
- * They differ only in UTF-16 when
- * comparing supplementary code points (U+10000..U+10ffff)
- * to BMP code points near the end of the BMP (i.e., U+e000..U+ffff).
- * In code unit order, high BMP code points sort after supplementary code points
- * because they are stored as pairs of surrogates which are at U+d800..U+dfff.
- *
- * This functions works with strings of different explicitly specified lengths
- * unlike the ANSI C-like u_strcmp() and u_memcmp() etc.
- * NUL-terminated strings are possible with length arguments of -1.
- *
- * @param s1 First source string.
- * @param length1 Length of first source string, or -1 if NUL-terminated.
- *
- * @param s2 Second source string.
- * @param length2 Length of second source string, or -1 if NUL-terminated.
- *
- * @param codePointOrder Choose between code unit order (FALSE)
- *                       and code point order (TRUE).
- *
- * @return <0 or 0 or >0 as usual for string comparisons
- *
- * @stable ICU 2.2
- */
-U_STABLE int32_t U_EXPORT2
-u_strCompare(const UChar *s1, int32_t length1,
-             const UChar *s2, int32_t length2,
-             UBool codePointOrder);
-
-/**
- * Compare two Unicode strings (binary order)
- * as presented by UCharIterator objects.
- * Works otherwise just like u_strCompare().
- *
- * Both iterators are reset to their start positions.
- * When the function returns, it is undefined where the iterators
- * have stopped.
- *
- * @param iter1 First source string iterator.
- * @param iter2 Second source string iterator.
- * @param codePointOrder Choose between code unit order (FALSE)
- *                       and code point order (TRUE).
- *
- * @return <0 or 0 or >0 as usual for string comparisons
- *
- * @see u_strCompare
- *
- * @stable ICU 2.6
- */
-U_STABLE int32_t U_EXPORT2
-u_strCompareIter(UCharIterator *iter1, UCharIterator *iter2, UBool codePointOrder);
-
-#ifndef U_COMPARE_CODE_POINT_ORDER
-/* see also unistr.h and unorm.h */
-/**
- * Option bit for u_strCaseCompare, u_strcasecmp, unorm_compare, etc:
- * Compare strings in code point order instead of code unit order.
- * @stable ICU 2.2
- */
-#define U_COMPARE_CODE_POINT_ORDER  0x8000
-#endif
-
-/**
- * Compare two strings case-insensitively using full case folding.
- * This is equivalent to
- *   u_strCompare(u_strFoldCase(s1, options),
- *                u_strFoldCase(s2, options),
- *                (options&U_COMPARE_CODE_POINT_ORDER)!=0).
- *
- * The comparison can be done in UTF-16 code unit order or in code point order.
- * They differ only when comparing supplementary code points (U+10000..U+10ffff)
- * to BMP code points near the end of the BMP (i.e., U+e000..U+ffff).
- * In code unit order, high BMP code points sort after supplementary code points
- * because they are stored as pairs of surrogates which are at U+d800..U+dfff.
- *
- * This functions works with strings of different explicitly specified lengths
- * unlike the ANSI C-like u_strcmp() and u_memcmp() etc.
- * NUL-terminated strings are possible with length arguments of -1.
- *
- * @param s1 First source string.
- * @param length1 Length of first source string, or -1 if NUL-terminated.
- *
- * @param s2 Second source string.
- * @param length2 Length of second source string, or -1 if NUL-terminated.
- *
- * @param options A bit set of options:
- *   - U_FOLD_CASE_DEFAULT or 0 is used for default options:
- *     Comparison in code unit order with default case folding.
- *
- *   - U_COMPARE_CODE_POINT_ORDER
- *     Set to choose code point order instead of code unit order
- *     (see u_strCompare for details).
- *
- *   - U_FOLD_CASE_EXCLUDE_SPECIAL_I
- *
- * @param pErrorCode Must be a valid pointer to an error code value,
- *                  which must not indicate a failure before the function call.
- *
- * @return <0 or 0 or >0 as usual for string comparisons
- *
- * @stable ICU 2.2
- */
-U_STABLE int32_t U_EXPORT2
-u_strCaseCompare(const UChar *s1, int32_t length1,
-                 const UChar *s2, int32_t length2,
-                 uint32_t options,
-                 UErrorCode *pErrorCode);
-
-/**
- * Compare two ustrings for bitwise equality. 
- * Compares at most <code>n</code> characters.
- *
- * @param ucs1 A string to compare.
- * @param ucs2 A string to compare.
- * @param n The maximum number of characters to compare.
- * @return 0 if <code>s1</code> and <code>s2</code> are bitwise equal; a negative
- * value if <code>s1</code> is bitwise less than <code>s2</code>; a positive
- * value if <code>s1</code> is bitwise greater than <code>s2</code>.
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2
-u_strncmp(const UChar     *ucs1, 
-     const UChar     *ucs2, 
-     int32_t     n);
-
-/**
- * Compare two Unicode strings in code point order.
- * This is different in UTF-16 from u_strncmp() if supplementary characters are present.
- * For details, see u_strCompare().
- *
- * @param s1 A string to compare.
- * @param s2 A string to compare.
- * @param n The maximum number of characters to compare.
- * @return a negative/zero/positive integer corresponding to whether
- * the first string is less than/equal to/greater than the second one
- * in code point order
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2
-u_strncmpCodePointOrder(const UChar *s1, const UChar *s2, int32_t n);
-
-/**
- * Compare two strings case-insensitively using full case folding.
- * This is equivalent to u_strcmp(u_strFoldCase(s1, options), u_strFoldCase(s2, options)).
- *
- * @param s1 A string to compare.
- * @param s2 A string to compare.
- * @param options A bit set of options:
- *   - U_FOLD_CASE_DEFAULT or 0 is used for default options:
- *     Comparison in code unit order with default case folding.
- *
- *   - U_COMPARE_CODE_POINT_ORDER
- *     Set to choose code point order instead of code unit order
- *     (see u_strCompare for details).
- *
- *   - U_FOLD_CASE_EXCLUDE_SPECIAL_I
- *
- * @return A negative, zero, or positive integer indicating the comparison result.
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2
-u_strcasecmp(const UChar *s1, const UChar *s2, uint32_t options);
-
-/**
- * Compare two strings case-insensitively using full case folding.
- * This is equivalent to u_strcmp(u_strFoldCase(s1, at most n, options),
- * u_strFoldCase(s2, at most n, options)).
- *
- * @param s1 A string to compare.
- * @param s2 A string to compare.
- * @param n The maximum number of characters each string to case-fold and then compare.
- * @param options A bit set of options:
- *   - U_FOLD_CASE_DEFAULT or 0 is used for default options:
- *     Comparison in code unit order with default case folding.
- *
- *   - U_COMPARE_CODE_POINT_ORDER
- *     Set to choose code point order instead of code unit order
- *     (see u_strCompare for details).
- *
- *   - U_FOLD_CASE_EXCLUDE_SPECIAL_I
- *
- * @return A negative, zero, or positive integer indicating the comparison result.
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2
-u_strncasecmp(const UChar *s1, const UChar *s2, int32_t n, uint32_t options);
-
-/**
- * Compare two strings case-insensitively using full case folding.
- * This is equivalent to u_strcmp(u_strFoldCase(s1, n, options),
- * u_strFoldCase(s2, n, options)).
- *
- * @param s1 A string to compare.
- * @param s2 A string to compare.
- * @param length The number of characters in each string to case-fold and then compare.
- * @param options A bit set of options:
- *   - U_FOLD_CASE_DEFAULT or 0 is used for default options:
- *     Comparison in code unit order with default case folding.
- *
- *   - U_COMPARE_CODE_POINT_ORDER
- *     Set to choose code point order instead of code unit order
- *     (see u_strCompare for details).
- *
- *   - U_FOLD_CASE_EXCLUDE_SPECIAL_I
- *
- * @return A negative, zero, or positive integer indicating the comparison result.
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2
-u_memcasecmp(const UChar *s1, const UChar *s2, int32_t length, uint32_t options);
-
-/**
- * Copy a ustring. Adds a null terminator.
- *
- * @param dst The destination string.
- * @param src The source string.
- * @return A pointer to <code>dst</code>.
- * @stable ICU 2.0
- */
-U_STABLE UChar* U_EXPORT2
-u_strcpy(UChar     *dst, 
-    const UChar     *src);
-
-/**
- * Copy a ustring.
- * Copies at most <code>n</code> characters.  The result will be null terminated
- * if the length of <code>src</code> is less than <code>n</code>.
- *
- * @param dst The destination string.
- * @param src The source string.
- * @param n The maximum number of characters to copy.
- * @return A pointer to <code>dst</code>.
- * @stable ICU 2.0
- */
-U_STABLE UChar* U_EXPORT2
-u_strncpy(UChar     *dst, 
-     const UChar     *src, 
-     int32_t     n);
-
-#if !UCONFIG_NO_CONVERSION
-
-/**
- * Copy a byte string encoded in the default codepage to a ustring.
- * Adds a null terminator.
- * Performs a host byte to UChar conversion
- *
- * @param dst The destination string.
- * @param src The source string.
- * @return A pointer to <code>dst</code>.
- * @stable ICU 2.0
- */
-U_STABLE UChar* U_EXPORT2 u_uastrcpy(UChar *dst,
-               const char *src );
-
-/**
- * Copy a byte string encoded in the default codepage to a ustring.
- * Copies at most <code>n</code> characters.  The result will be null terminated
- * if the length of <code>src</code> is less than <code>n</code>.
- * Performs a host byte to UChar conversion
- *
- * @param dst The destination string.
- * @param src The source string.
- * @param n The maximum number of characters to copy.
- * @return A pointer to <code>dst</code>.
- * @stable ICU 2.0
- */
-U_STABLE UChar* U_EXPORT2 u_uastrncpy(UChar *dst,
-            const char *src,
-            int32_t n);
-
-/**
- * Copy ustring to a byte string encoded in the default codepage.
- * Adds a null terminator.
- * Performs a UChar to host byte conversion
- *
- * @param dst The destination string.
- * @param src The source string.
- * @return A pointer to <code>dst</code>.
- * @stable ICU 2.0
- */
-U_STABLE char* U_EXPORT2 u_austrcpy(char *dst,
-            const UChar *src );
-
-/**
- * Copy ustring to a byte string encoded in the default codepage.
- * Copies at most <code>n</code> characters.  The result will be null terminated
- * if the length of <code>src</code> is less than <code>n</code>.
- * Performs a UChar to host byte conversion
- *
- * @param dst The destination string.
- * @param src The source string.
- * @param n The maximum number of characters to copy.
- * @return A pointer to <code>dst</code>.
- * @stable ICU 2.0
- */
-U_STABLE char* U_EXPORT2 u_austrncpy(char *dst,
-            const UChar *src,
-            int32_t n );
-
-#endif
-
-/**
- * Synonym for memcpy(), but with UChars only.
- * @param dest The destination string
- * @param src The source string
- * @param count The number of characters to copy
- * @return A pointer to <code>dest</code>
- * @stable ICU 2.0
- */
-U_STABLE UChar* U_EXPORT2
-u_memcpy(UChar *dest, const UChar *src, int32_t count);
-
-/**
- * Synonym for memmove(), but with UChars only.
- * @param dest The destination string
- * @param src The source string
- * @param count The number of characters to move
- * @return A pointer to <code>dest</code>
- * @stable ICU 2.0
- */
-U_STABLE UChar* U_EXPORT2
-u_memmove(UChar *dest, const UChar *src, int32_t count);
-
-/**
- * Initialize <code>count</code> characters of <code>dest</code> to <code>c</code>.
- *
- * @param dest The destination string.
- * @param c The character to initialize the string.
- * @param count The maximum number of characters to set.
- * @return A pointer to <code>dest</code>.
- * @stable ICU 2.0
- */
-U_STABLE UChar* U_EXPORT2
-u_memset(UChar *dest, UChar c, int32_t count);
-
-/**
- * Compare the first <code>count</code> UChars of each buffer.
- *
- * @param buf1 The first string to compare.
- * @param buf2 The second string to compare.
- * @param count The maximum number of UChars to compare.
- * @return When buf1 < buf2, a negative number is returned.
- *      When buf1 == buf2, 0 is returned.
- *      When buf1 > buf2, a positive number is returned.
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2
-u_memcmp(const UChar *buf1, const UChar *buf2, int32_t count);
-
-/**
- * Compare two Unicode strings in code point order.
- * This is different in UTF-16 from u_memcmp() if supplementary characters are present.
- * For details, see u_strCompare().
- *
- * @param s1 A string to compare.
- * @param s2 A string to compare.
- * @param count The maximum number of characters to compare.
- * @return a negative/zero/positive integer corresponding to whether
- * the first string is less than/equal to/greater than the second one
- * in code point order
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2
-u_memcmpCodePointOrder(const UChar *s1, const UChar *s2, int32_t count);
-
-/**
- * Find the first occurrence of a BMP code point in a string.
- * A surrogate code point is found only if its match in the text is not
- * part of a surrogate pair.
- * A NUL character is found at the string terminator.
- *
- * @param s The string to search (contains <code>count</code> UChars).
- * @param c The BMP code point to find.
- * @param count The length of the string.
- * @return A pointer to the first occurrence of <code>c</code> in <code>s</code>
- *         or <code>NULL</code> if <code>c</code> is not in <code>s</code>.
- * @stable ICU 2.0
- *
- * @see u_strchr
- * @see u_memchr32
- * @see u_strFindFirst
- */
-U_STABLE UChar* U_EXPORT2
-u_memchr(const UChar *s, UChar c, int32_t count);
-
-/**
- * Find the first occurrence of a code point in a string.
- * A surrogate code point is found only if its match in the text is not
- * part of a surrogate pair.
- * A NUL character is found at the string terminator.
- *
- * @param s The string to search (contains <code>count</code> UChars).
- * @param c The code point to find.
- * @param count The length of the string.
- * @return A pointer to the first occurrence of <code>c</code> in <code>s</code>
- *         or <code>NULL</code> if <code>c</code> is not in <code>s</code>.
- * @stable ICU 2.0
- *
- * @see u_strchr32
- * @see u_memchr
- * @see u_strFindFirst
- */
-U_STABLE UChar* U_EXPORT2
-u_memchr32(const UChar *s, UChar32 c, int32_t count);
-
-/**
- * Find the last occurrence of a BMP code point in a string.
- * A surrogate code point is found only if its match in the text is not
- * part of a surrogate pair.
- * A NUL character is found at the string terminator.
- *
- * @param s The string to search (contains <code>count</code> UChars).
- * @param c The BMP code point to find.
- * @param count The length of the string.
- * @return A pointer to the last occurrence of <code>c</code> in <code>s</code>
- *         or <code>NULL</code> if <code>c</code> is not in <code>s</code>.
- * @stable ICU 2.4
- *
- * @see u_strrchr
- * @see u_memrchr32
- * @see u_strFindLast
- */
-U_STABLE UChar* U_EXPORT2
-u_memrchr(const UChar *s, UChar c, int32_t count);
-
-/**
- * Find the last occurrence of a code point in a string.
- * A surrogate code point is found only if its match in the text is not
- * part of a surrogate pair.
- * A NUL character is found at the string terminator.
- *
- * @param s The string to search (contains <code>count</code> UChars).
- * @param c The code point to find.
- * @param count The length of the string.
- * @return A pointer to the last occurrence of <code>c</code> in <code>s</code>
- *         or <code>NULL</code> if <code>c</code> is not in <code>s</code>.
- * @stable ICU 2.4
- *
- * @see u_strrchr32
- * @see u_memrchr
- * @see u_strFindLast
- */
-U_STABLE UChar* U_EXPORT2
-u_memrchr32(const UChar *s, UChar32 c, int32_t count);
-
-/**
- * Unicode String literals in C.
- * We need one macro to declare a variable for the string
- * and to statically preinitialize it if possible,
- * and a second macro to dynamically intialize such a string variable if necessary.
- *
- * The macros are defined for maximum performance.
- * They work only for strings that contain "invariant characters", i.e.,
- * only latin letters, digits, and some punctuation.
- * See utypes.h for details.
- *
- * A pair of macros for a single string must be used with the same
- * parameters.
- * The string parameter must be a C string literal.
- * The length of the string, not including the terminating
- * <code>NUL</code>, must be specified as a constant.
- * The U_STRING_DECL macro should be invoked exactly once for one
- * such string variable before it is used.
- *
- * Usage:
- * <pre>
- *    U_STRING_DECL(ustringVar1, "Quick-Fox 2", 11);
- *    U_STRING_DECL(ustringVar2, "jumps 5%", 8);
- *    static UBool didInit=FALSE;
- * 
- *    int32_t function() {
- *        if(!didInit) {
- *            U_STRING_INIT(ustringVar1, "Quick-Fox 2", 11);
- *            U_STRING_INIT(ustringVar2, "jumps 5%", 8);
- *            didInit=TRUE;
- *        }
- *        return u_strcmp(ustringVar1, ustringVar2);
- *    }
- * </pre>
- * @stable ICU 2.0
- */
-#if defined(U_DECLARE_UTF16)
-#   define U_STRING_DECL(var, cs, length) static const UChar var[(length)+1]=U_DECLARE_UTF16(cs)
-    /**@stable ICU 2.0 */
-#   define U_STRING_INIT(var, cs, length)
-#elif U_SIZEOF_WCHAR_T==U_SIZEOF_UCHAR && (U_CHARSET_FAMILY==U_ASCII_FAMILY || (U_SIZEOF_UCHAR == 2 && defined(U_WCHAR_IS_UTF16)))
-#   define U_STRING_DECL(var, cs, length) static const UChar var[(length)+1]=L ## cs
-    /**@stable ICU 2.0 */
-#   define U_STRING_INIT(var, cs, length)
-#elif U_SIZEOF_UCHAR==1 && U_CHARSET_FAMILY==U_ASCII_FAMILY
-#   define U_STRING_DECL(var, cs, length) static const UChar var[(length)+1]=cs
-    /**@stable ICU 2.0 */
-#   define U_STRING_INIT(var, cs, length)
-#else
-#   define U_STRING_DECL(var, cs, length) static UChar var[(length)+1]
-    /**@stable ICU 2.0 */
-#   define U_STRING_INIT(var, cs, length) u_charsToUChars(cs, var, length+1)
-#endif
-
-/**
- * Unescape a string of characters and write the resulting
- * Unicode characters to the destination buffer.  The following escape
- * sequences are recognized:
- *
- * \\uhhhh       4 hex digits; h in [0-9A-Fa-f]
- * \\Uhhhhhhhh   8 hex digits
- * \\xhh         1-2 hex digits
- * \\x{h...}     1-8 hex digits
- * \\ooo         1-3 octal digits; o in [0-7]
- * \\cX          control-X; X is masked with 0x1F
- *
- * as well as the standard ANSI C escapes:
- *
- * \\a => U+0007, \\b => U+0008, \\t => U+0009, \\n => U+000A,
- * \\v => U+000B, \\f => U+000C, \\r => U+000D, \\e => U+001B,
- * \\" => U+0022, \\' => U+0027, \\? => U+003F, \\\\ => U+005C
- *
- * Anything else following a backslash is generically escaped.  For
- * example, "[a\\-z]" returns "[a-z]".
- *
- * If an escape sequence is ill-formed, this method returns an empty
- * string.  An example of an ill-formed sequence is "\\u" followed by
- * fewer than 4 hex digits.
- *
- * The above characters are recognized in the compiler's codepage,
- * that is, they are coded as 'u', '\\', etc.  Characters that are
- * not parts of escape sequences are converted using u_charsToUChars().
- *
- * This function is similar to UnicodeString::unescape() but not
- * identical to it.  The latter takes a source UnicodeString, so it
- * does escape recognition but no conversion.
- *
- * @param src a zero-terminated string of invariant characters
- * @param dest pointer to buffer to receive converted and unescaped
- * text and, if there is room, a zero terminator.  May be NULL for
- * preflighting, in which case no UChars will be written, but the
- * return value will still be valid.  On error, an empty string is
- * stored here (if possible).
- * @param destCapacity the number of UChars that may be written at
- * dest.  Ignored if dest == NULL.
- * @return the length of unescaped string.
- * @see u_unescapeAt
- * @see UnicodeString#unescape()
- * @see UnicodeString#unescapeAt()
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2
-u_unescape(const char *src,
-           UChar *dest, int32_t destCapacity);
-
-U_CDECL_BEGIN
-/**
- * Callback function for u_unescapeAt() that returns a character of
- * the source text given an offset and a context pointer.  The context
- * pointer will be whatever is passed into u_unescapeAt().
- *
- * @param offset pointer to the offset that will be passed to u_unescapeAt().
- * @param context an opaque pointer passed directly into u_unescapeAt()
- * @return the character represented by the escape sequence at
- * offset
- * @see u_unescapeAt
- * @stable ICU 2.0
- */
-typedef UChar (U_CALLCONV *UNESCAPE_CHAR_AT)(int32_t offset, void *context);
-U_CDECL_END
-
-/**
- * Unescape a single sequence. The character at offset-1 is assumed
- * (without checking) to be a backslash.  This method takes a callback
- * pointer to a function that returns the UChar at a given offset.  By
- * varying this callback, ICU functions are able to unescape char*
- * strings, UnicodeString objects, and UFILE pointers.
- *
- * If offset is out of range, or if the escape sequence is ill-formed,
- * (UChar32)0xFFFFFFFF is returned.  See documentation of u_unescape()
- * for a list of recognized sequences.
- *
- * @param charAt callback function that returns a UChar of the source
- * text given an offset and a context pointer.
- * @param offset pointer to the offset that will be passed to charAt.
- * The offset value will be updated upon return to point after the
- * last parsed character of the escape sequence.  On error the offset
- * is unchanged.
- * @param length the number of characters in the source text.  The
- * last character of the source text is considered to be at offset
- * length-1.
- * @param context an opaque pointer passed directly into charAt.
- * @return the character represented by the escape sequence at
- * offset, or (UChar32)0xFFFFFFFF on error.
- * @see u_unescape()
- * @see UnicodeString#unescape()
- * @see UnicodeString#unescapeAt()
- * @stable ICU 2.0
- */
-U_STABLE UChar32 U_EXPORT2
-u_unescapeAt(UNESCAPE_CHAR_AT charAt,
-             int32_t *offset,
-             int32_t length,
-             void *context);
-
-/**
- * Uppercase the characters in a string.
- * Casing is locale-dependent and context-sensitive.
- * The result may be longer or shorter than the original.
- * The source string and the destination buffer are allowed to overlap.
- *
- * @param dest      A buffer for the result string. The result will be zero-terminated if
- *                  the buffer is large enough.
- * @param destCapacity The size of the buffer (number of UChars). If it is 0, then
- *                  dest may be NULL and the function will only return the length of the result
- *                  without writing any of the result string.
- * @param src       The original string
- * @param srcLength The length of the original string. If -1, then src must be zero-terminated.
- * @param locale    The locale to consider, or "" for the root locale or NULL for the default locale.
- * @param pErrorCode Must be a valid pointer to an error code value,
- *                  which must not indicate a failure before the function call.
- * @return The length of the result string. It may be greater than destCapacity. In that case,
- *         only some of the result was written to the destination buffer.
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2
-u_strToUpper(UChar *dest, int32_t destCapacity,
-             const UChar *src, int32_t srcLength,
-             const char *locale,
-             UErrorCode *pErrorCode);
-
-/**
- * Lowercase the characters in a string.
- * Casing is locale-dependent and context-sensitive.
- * The result may be longer or shorter than the original.
- * The source string and the destination buffer are allowed to overlap.
- *
- * @param dest      A buffer for the result string. The result will be zero-terminated if
- *                  the buffer is large enough.
- * @param destCapacity The size of the buffer (number of UChars). If it is 0, then
- *                  dest may be NULL and the function will only return the length of the result
- *                  without writing any of the result string.
- * @param src       The original string
- * @param srcLength The length of the original string. If -1, then src must be zero-terminated.
- * @param locale    The locale to consider, or "" for the root locale or NULL for the default locale.
- * @param pErrorCode Must be a valid pointer to an error code value,
- *                  which must not indicate a failure before the function call.
- * @return The length of the result string. It may be greater than destCapacity. In that case,
- *         only some of the result was written to the destination buffer.
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2
-u_strToLower(UChar *dest, int32_t destCapacity,
-             const UChar *src, int32_t srcLength,
-             const char *locale,
-             UErrorCode *pErrorCode);
-
-#if !UCONFIG_NO_BREAK_ITERATION
-
-/**
- * Titlecase a string.
- * Casing is locale-dependent and context-sensitive.
- * Titlecasing uses a break iterator to find the first characters of words
- * that are to be titlecased. It titlecases those characters and lowercases
- * all others.
- *
- * The titlecase break iterator can be provided to customize for arbitrary
- * styles, using rules and dictionaries beyond the standard iterators.
- * It may be more efficient to always provide an iterator to avoid
- * opening and closing one for each string.
- * The standard titlecase iterator for the root locale implements the
- * algorithm of Unicode TR 21.
- *
- * This function uses only the setText(), first() and next() methods of the
- * provided break iterator.
- *
- * The result may be longer or shorter than the original.
- * The source string and the destination buffer are allowed to overlap.
- *
- * @param dest      A buffer for the result string. The result will be zero-terminated if
- *                  the buffer is large enough.
- * @param destCapacity The size of the buffer (number of UChars). If it is 0, then
- *                  dest may be NULL and the function will only return the length of the result
- *                  without writing any of the result string.
- * @param src       The original string
- * @param srcLength The length of the original string. If -1, then src must be zero-terminated.
- * @param titleIter A break iterator to find the first characters of words
- *                  that are to be titlecased.
- *                  If none is provided (NULL), then a standard titlecase
- *                  break iterator is opened.
- * @param locale    The locale to consider, or "" for the root locale or NULL for the default locale.
- * @param pErrorCode Must be a valid pointer to an error code value,
- *                  which must not indicate a failure before the function call.
- * @return The length of the result string. It may be greater than destCapacity. In that case,
- *         only some of the result was written to the destination buffer.
- * @stable ICU 2.1
- */
-U_STABLE int32_t U_EXPORT2
-u_strToTitle(UChar *dest, int32_t destCapacity,
-             const UChar *src, int32_t srcLength,
-             UBreakIterator *titleIter,
-             const char *locale,
-             UErrorCode *pErrorCode);
-
-#endif
-
-/**
- * Case-fold the characters in a string.
- * Case-folding is locale-independent and not context-sensitive,
- * but there is an option for whether to include or exclude mappings for dotted I
- * and dotless i that are marked with 'I' in CaseFolding.txt.
- * The result may be longer or shorter than the original.
- * The source string and the destination buffer are allowed to overlap.
- *
- * @param dest      A buffer for the result string. The result will be zero-terminated if
- *                  the buffer is large enough.
- * @param destCapacity The size of the buffer (number of UChars). If it is 0, then
- *                  dest may be NULL and the function will only return the length of the result
- *                  without writing any of the result string.
- * @param src       The original string
- * @param srcLength The length of the original string. If -1, then src must be zero-terminated.
- * @param options   Either U_FOLD_CASE_DEFAULT or U_FOLD_CASE_EXCLUDE_SPECIAL_I
- * @param pErrorCode Must be a valid pointer to an error code value,
- *                  which must not indicate a failure before the function call.
- * @return The length of the result string. It may be greater than destCapacity. In that case,
- *         only some of the result was written to the destination buffer.
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2
-u_strFoldCase(UChar *dest, int32_t destCapacity,
-              const UChar *src, int32_t srcLength,
-              uint32_t options,
-              UErrorCode *pErrorCode);
-
-#if defined(U_WCHAR_IS_UTF16) || defined(U_WCHAR_IS_UTF32) || !UCONFIG_NO_CONVERSION
-/**
- * Converts a sequence of UChars to wchar_t units.
- *
- * @param dest          A buffer for the result string. The result will be zero-terminated if
- *                      the buffer is large enough.
- * @param destCapacity  The size of the buffer (number of wchar_t's). If it is 0, then
- *                      dest may be NULL and the function will only return the length of the 
- *                      result without writing any of the result string (pre-flighting).
- * @param pDestLength   A pointer to receive the number of units written to the destination. If 
- *                      pDestLength!=NULL then *pDestLength is always set to the 
- *                      number of output units corresponding to the transformation of 
- *                      all the input units, even in case of a buffer overflow.
- * @param src           The original source string
- * @param srcLength     The length of the original string. If -1, then src must be zero-terminated.
- * @param pErrorCode    Must be a valid pointer to an error code value,
- *                      which must not indicate a failure before the function call.
- * @return The pointer to destination buffer.
- * @stable ICU 2.0
- */
-U_STABLE wchar_t* U_EXPORT2
-u_strToWCS(wchar_t *dest, 
-           int32_t destCapacity,
-           int32_t *pDestLength,
-           const UChar *src, 
-           int32_t srcLength,
-           UErrorCode *pErrorCode);
-/**
- * Converts a sequence of wchar_t units to UChars
- *
- * @param dest          A buffer for the result string. The result will be zero-terminated if
- *                      the buffer is large enough.
- * @param destCapacity  The size of the buffer (number of UChars). If it is 0, then
- *                      dest may be NULL and the function will only return the length of the 
- *                      result without writing any of the result string (pre-flighting).
- * @param pDestLength   A pointer to receive the number of units written to the destination. If 
- *                      pDestLength!=NULL then *pDestLength is always set to the 
- *                      number of output units corresponding to the transformation of 
- *                      all the input units, even in case of a buffer overflow.
- * @param src           The original source string
- * @param srcLength     The length of the original string. If -1, then src must be zero-terminated.
- * @param pErrorCode    Must be a valid pointer to an error code value,
- *                      which must not indicate a failure before the function call.
- * @return The pointer to destination buffer.
- * @stable ICU 2.0
- */
-U_STABLE UChar* U_EXPORT2
-u_strFromWCS(UChar   *dest,
-             int32_t destCapacity, 
-             int32_t *pDestLength,
-             const wchar_t *src,
-             int32_t srcLength,
-             UErrorCode *pErrorCode);
-#endif /* defined(U_WCHAR_IS_UTF16) || defined(U_WCHAR_IS_UTF32) || !UCONFIG_NO_CONVERSION */
-
-/**
- * Converts a sequence of UChars (UTF-16) to UTF-8 bytes
- *
- * @param dest          A buffer for the result string. The result will be zero-terminated if
- *                      the buffer is large enough.
- * @param destCapacity  The size of the buffer (number of chars). If it is 0, then
- *                      dest may be NULL and the function will only return the length of the 
- *                      result without writing any of the result string (pre-flighting).
- * @param pDestLength   A pointer to receive the number of units written to the destination. If 
- *                      pDestLength!=NULL then *pDestLength is always set to the 
- *                      number of output units corresponding to the transformation of 
- *                      all the input units, even in case of a buffer overflow.
- * @param src           The original source string
- * @param srcLength     The length of the original string. If -1, then src must be zero-terminated.
- * @param pErrorCode    Must be a valid pointer to an error code value,
- *                      which must not indicate a failure before the function call.
- * @return The pointer to destination buffer.
- * @stable ICU 2.0
- * @see u_strToUTF8WithSub
- * @see u_strFromUTF8
- */
-U_STABLE char* U_EXPORT2 
-u_strToUTF8(char *dest,           
-            int32_t destCapacity,
-            int32_t *pDestLength,
-            const UChar *src, 
-            int32_t srcLength,
-            UErrorCode *pErrorCode);
-
-/**
- * Converts a sequence of UTF-8 bytes to UChars (UTF-16).
- *
- * @param dest          A buffer for the result string. The result will be zero-terminated if
- *                      the buffer is large enough.
- * @param destCapacity  The size of the buffer (number of UChars). If it is 0, then
- *                      dest may be NULL and the function will only return the length of the 
- *                      result without writing any of the result string (pre-flighting).
- * @param pDestLength   A pointer to receive the number of units written to the destination. If 
- *                      pDestLength!=NULL then *pDestLength is always set to the 
- *                      number of output units corresponding to the transformation of 
- *                      all the input units, even in case of a buffer overflow.
- * @param src           The original source string
- * @param srcLength     The length of the original string. If -1, then src must be zero-terminated.
- * @param pErrorCode    Must be a valid pointer to an error code value,
- *                      which must not indicate a failure before the function call.
- * @return The pointer to destination buffer.
- * @stable ICU 2.0
- * @see u_strFromUTF8WithSub
- * @see u_strFromUTF8Lenient
- */
-U_STABLE UChar* U_EXPORT2
-u_strFromUTF8(UChar *dest,             
-              int32_t destCapacity,
-              int32_t *pDestLength,
-              const char *src, 
-              int32_t srcLength,
-              UErrorCode *pErrorCode);
-
-/**
- * Converts a sequence of UChars (UTF-16) to UTF-8 bytes.
- * Same as u_strToUTF8() except for the additional subchar which is output for
- * illegal input sequences, instead of stopping with the U_INVALID_CHAR_FOUND error code.
- * With subchar==U_SENTINEL, this function behaves exactly like u_strToUTF8().
- *
- * @param dest          A buffer for the result string. The result will be zero-terminated if
- *                      the buffer is large enough.
- * @param destCapacity  The size of the buffer (number of chars). If it is 0, then
- *                      dest may be NULL and the function will only return the length of the 
- *                      result without writing any of the result string (pre-flighting).
- * @param pDestLength   A pointer to receive the number of units written to the destination. If 
- *                      pDestLength!=NULL then *pDestLength is always set to the 
- *                      number of output units corresponding to the transformation of 
- *                      all the input units, even in case of a buffer overflow.
- * @param src           The original source string
- * @param srcLength     The length of the original string. If -1, then src must be zero-terminated.
- * @param subchar       The substitution character to use in place of an illegal input sequence,
- *                      or U_SENTINEL if the function is to return with U_INVALID_CHAR_FOUND instead.
- *                      A substitution character can be any valid Unicode code point (up to U+10FFFF)
- *                      except for surrogate code points (U+D800..U+DFFF).
- *                      The recommended value is U+FFFD "REPLACEMENT CHARACTER".
- * @param pNumSubstitutions Output parameter receiving the number of substitutions if subchar>=0.
- *                      Set to 0 if no substitutions occur or subchar<0.
- *                      pNumSubstitutions can be NULL.
- * @param pErrorCode    Pointer to a standard ICU error code. Its input value must
- *                      pass the U_SUCCESS() test, or else the function returns
- *                      immediately. Check for U_FAILURE() on output or use with
- *                      function chaining. (See User Guide for details.)
- * @return The pointer to destination buffer.
- * @see u_strToUTF8
- * @see u_strFromUTF8WithSub
- * @stable ICU 3.6
- */
-U_STABLE char* U_EXPORT2
-u_strToUTF8WithSub(char *dest,
-            int32_t destCapacity,
-            int32_t *pDestLength,
-            const UChar *src,
-            int32_t srcLength,
-            UChar32 subchar, int32_t *pNumSubstitutions,
-            UErrorCode *pErrorCode);
-
-/**
- * Converts a sequence of UTF-8 bytes to UChars (UTF-16).
- * Same as u_strFromUTF8() except for the additional subchar which is output for
- * illegal input sequences, instead of stopping with the U_INVALID_CHAR_FOUND error code.
- * With subchar==U_SENTINEL, this function behaves exactly like u_strFromUTF8().
- *
- * @param dest          A buffer for the result string. The result will be zero-terminated if
- *                      the buffer is large enough.
- * @param destCapacity  The size of the buffer (number of UChars). If it is 0, then
- *                      dest may be NULL and the function will only return the length of the 
- *                      result without writing any of the result string (pre-flighting).
- * @param pDestLength   A pointer to receive the number of units written to the destination. If 
- *                      pDestLength!=NULL then *pDestLength is always set to the 
- *                      number of output units corresponding to the transformation of 
- *                      all the input units, even in case of a buffer overflow.
- * @param src           The original source string
- * @param srcLength     The length of the original string. If -1, then src must be zero-terminated.
- * @param subchar       The substitution character to use in place of an illegal input sequence,
- *                      or U_SENTINEL if the function is to return with U_INVALID_CHAR_FOUND instead.
- *                      A substitution character can be any valid Unicode code point (up to U+10FFFF)
- *                      except for surrogate code points (U+D800..U+DFFF).
- *                      The recommended value is U+FFFD "REPLACEMENT CHARACTER".
- * @param pNumSubstitutions Output parameter receiving the number of substitutions if subchar>=0.
- *                      Set to 0 if no substitutions occur or subchar<0.
- *                      pNumSubstitutions can be NULL.
- * @param pErrorCode    Pointer to a standard ICU error code. Its input value must
- *                      pass the U_SUCCESS() test, or else the function returns
- *                      immediately. Check for U_FAILURE() on output or use with
- *                      function chaining. (See User Guide for details.)
- * @return The pointer to destination buffer.
- * @see u_strFromUTF8
- * @see u_strFromUTF8Lenient
- * @see u_strToUTF8WithSub
- * @stable ICU 3.6
- */
-U_STABLE UChar* U_EXPORT2
-u_strFromUTF8WithSub(UChar *dest,
-              int32_t destCapacity,
-              int32_t *pDestLength,
-              const char *src,
-              int32_t srcLength,
-              UChar32 subchar, int32_t *pNumSubstitutions,
-              UErrorCode *pErrorCode);
-
-/**
- * Converts a sequence of UTF-8 bytes to UChars (UTF-16).
- * Same as u_strFromUTF8() except that this function is designed to be very fast,
- * which it achieves by being lenient about malformed UTF-8 sequences.
- * This function is intended for use in environments where UTF-8 text is
- * expected to be well-formed.
- *
- * Its semantics are:
- * - Well-formed UTF-8 text is correctly converted to well-formed UTF-16 text.
- * - The function will not read beyond the input string, nor write beyond
- *   the destCapacity.
- * - Malformed UTF-8 results in "garbage" 16-bit Unicode strings which may not
- *   be well-formed UTF-16.
- *   The function will resynchronize to valid code point boundaries
- *   within a small number of code points after an illegal sequence.
- * - Non-shortest forms are not detected and will result in "spoofing" output.
- *
- * For further performance improvement, if srcLength is given (>=0),
- * then it must be destCapacity>=srcLength.
- *
- * @param dest          A buffer for the result string. The result will be zero-terminated if
- *                      the buffer is large enough.
- * @param destCapacity  The size of the buffer (number of UChars). If it is 0, then
- *                      dest may be NULL and the function will only return the length of the 
- *                      result without writing any of the result string (pre-flighting).
- *                      Unlike for other ICU functions, if srcLength>=0 then it
- *                      must be destCapacity>=srcLength.
- * @param pDestLength   A pointer to receive the number of units written to the destination. If 
- *                      pDestLength!=NULL then *pDestLength is always set to the 
- *                      number of output units corresponding to the transformation of 
- *                      all the input units, even in case of a buffer overflow.
- *                      Unlike for other ICU functions, if srcLength>=0 but
- *                      destCapacity<srcLength, then *pDestLength will be set to srcLength
- *                      (and U_BUFFER_OVERFLOW_ERROR will be set)
- *                      regardless of the actual result length.
- * @param src           The original source string
- * @param srcLength     The length of the original string. If -1, then src must be zero-terminated.
- * @param pErrorCode    Pointer to a standard ICU error code. Its input value must
- *                      pass the U_SUCCESS() test, or else the function returns
- *                      immediately. Check for U_FAILURE() on output or use with
- *                      function chaining. (See User Guide for details.)
- * @return The pointer to destination buffer.
- * @see u_strFromUTF8
- * @see u_strFromUTF8WithSub
- * @see u_strToUTF8WithSub
- * @stable ICU 3.6
- */
-U_STABLE UChar * U_EXPORT2
-u_strFromUTF8Lenient(UChar *dest,
-                     int32_t destCapacity,
-                     int32_t *pDestLength,
-                     const char *src,
-                     int32_t srcLength,
-                     UErrorCode *pErrorCode);
-
-/**
- * Converts a sequence of UChars (UTF-16) to UTF32 units.
- *
- * @param dest          A buffer for the result string. The result will be zero-terminated if
- *                      the buffer is large enough.
- * @param destCapacity  The size of the buffer (number of UChar32s). If it is 0, then
- *                      dest may be NULL and the function will only return the length of the 
- *                      result without writing any of the result string (pre-flighting).
- * @param pDestLength   A pointer to receive the number of units written to the destination. If 
- *                      pDestLength!=NULL then *pDestLength is always set to the 
- *                      number of output units corresponding to the transformation of 
- *                      all the input units, even in case of a buffer overflow.
- * @param src           The original source string
- * @param srcLength     The length of the original string. If -1, then src must be zero-terminated.
- * @param pErrorCode    Must be a valid pointer to an error code value,
- *                      which must not indicate a failure before the function call.
- * @return The pointer to destination buffer.
- * @stable ICU 2.0
- */
-U_STABLE UChar32* U_EXPORT2 
-u_strToUTF32(UChar32 *dest, 
-             int32_t  destCapacity,
-             int32_t  *pDestLength,
-             const UChar *src, 
-             int32_t  srcLength,
-             UErrorCode *pErrorCode);
-
-/**
- * Converts a sequence of UTF32 units to UChars (UTF-16)
- *
- * @param dest          A buffer for the result string. The result will be zero-terminated if
- *                      the buffer is large enough.
- * @param destCapacity  The size of the buffer (number of UChars). If it is 0, then
- *                      dest may be NULL and the function will only return the length of the 
- *                      result without writing any of the result string (pre-flighting).
- * @param pDestLength   A pointer to receive the number of units written to the destination. If 
- *                      pDestLength!=NULL then *pDestLength is always set to the 
- *                      number of output units corresponding to the transformation of 
- *                      all the input units, even in case of a buffer overflow.
- * @param src           The original source string
- * @param srcLength     The length of the original string. If -1, then src must be zero-terminated.
- * @param pErrorCode    Must be a valid pointer to an error code value,
- *                      which must not indicate a failure before the function call.
- * @return The pointer to destination buffer.
- * @stable ICU 2.0
- */
-U_STABLE UChar* U_EXPORT2 
-u_strFromUTF32(UChar   *dest,
-               int32_t destCapacity, 
-               int32_t *pDestLength,
-               const UChar32 *src,
-               int32_t srcLength,
-               UErrorCode *pErrorCode);
-
-#endif

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/usystem.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/usystem.h b/apps/couch_collate/platform/osx/icu/unicode/usystem.h
deleted file mode 100644
index 752e2f1..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/usystem.h
+++ /dev/null
@@ -1,46 +0,0 @@
-/*
-*******************************************************************************
-*   Copyright (C) 2004-2008, International Business Machines
-*   Corporation and others.  All Rights Reserved.
-*******************************************************************************
-*
-*   file name:  
-*   encoding:   US-ASCII
-*   tab size:   8 (not used)
-*   indentation:4
-*
-*   Created by: genheaders.pl, a perl script written by Ram Viswanadha
-*
-*  Contains data for commenting out APIs.
-*  Gets included by umachine.h
-*
-*  THIS FILE IS MACHINE-GENERATED, DON'T PLAY WITH IT IF YOU DON'T KNOW WHAT
-*  YOU ARE DOING, OTHERWISE VERY BAD THINGS WILL HAPPEN!
-*/
-
-#ifndef USYSTEM_H
-#define USYSTEM_H
-
-#ifdef U_HIDE_SYSTEM_API
-
-#    if U_DISABLE_RENAMING
-#        define u_cleanup u_cleanup_SYSTEM_API_DO_NOT_USE
-#        define u_setAtomicIncDecFunctions u_setAtomicIncDecFunctions_SYSTEM_API_DO_NOT_USE
-#        define u_setMemoryFunctions u_setMemoryFunctions_SYSTEM_API_DO_NOT_USE
-#        define u_setMutexFunctions u_setMutexFunctions_SYSTEM_API_DO_NOT_USE
-#        define ucnv_setDefaultName ucnv_setDefaultName_SYSTEM_API_DO_NOT_USE
-#        define uloc_getDefault uloc_getDefault_SYSTEM_API_DO_NOT_USE
-#        define uloc_setDefault uloc_setDefault_SYSTEM_API_DO_NOT_USE
-#    else
-#        define u_cleanup_4_0 u_cleanup_SYSTEM_API_DO_NOT_USE
-#        define u_setAtomicIncDecFunctions_4_0 u_setAtomicIncDecFunctions_SYSTEM_API_DO_NOT_USE
-#        define u_setMemoryFunctions_4_0 u_setMemoryFunctions_SYSTEM_API_DO_NOT_USE
-#        define u_setMutexFunctions_4_0 u_setMutexFunctions_SYSTEM_API_DO_NOT_USE
-#        define ucnv_setDefaultName_4_0 ucnv_setDefaultName_SYSTEM_API_DO_NOT_USE
-#        define uloc_getDefault_4_0 uloc_getDefault_SYSTEM_API_DO_NOT_USE
-#        define uloc_setDefault_4_0 uloc_setDefault_SYSTEM_API_DO_NOT_USE
-#    endif /* U_DISABLE_RENAMING */
-
-#endif /* U_HIDE_SYSTEM_API */
-#endif /* USYSTEM_H */
-


[53/57] [abbrv] remove couch_httpd

Posted by be...@apache.org.
http://git-wip-us.apache.org/repos/asf/couchdb/blob/c0855434/apps/couch_httpd/src/couch_httpd_cors.erl
----------------------------------------------------------------------
diff --git a/apps/couch_httpd/src/couch_httpd_cors.erl b/apps/couch_httpd/src/couch_httpd_cors.erl
deleted file mode 100644
index 4e46819..0000000
--- a/apps/couch_httpd/src/couch_httpd_cors.erl
+++ /dev/null
@@ -1,351 +0,0 @@
-% Licensed 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.
-
-%% @doc module to handle Cross-Origin Resource Sharing
-%%
-%% This module handles CORS requests and preflight request for
-%% CouchDB. The configuration is done in the ini file.
-%%
-%% This implements http://www.w3.org/TR/cors/
-
-
--module(couch_httpd_cors).
-
--include_lib("couch/include/couch_db.hrl").
-
--export([is_preflight_request/1, cors_headers/2]).
-
--define(SUPPORTED_HEADERS, "Accept, Accept-Language, Content-Type," ++
-        "Expires, Last-Modified, Pragma, Origin, Content-Length," ++
-        "If-Match, Destination, X-Requested-With, " ++
-        "X-Http-Method-Override, Content-Range").
-
--define(SUPPORTED_METHODS, "GET, HEAD, POST, PUT, DELETE," ++
-        "TRACE, CONNECT, COPY, OPTIONS").
-
-% as defined in http://www.w3.org/TR/cors/#terminology
--define(SIMPLE_HEADERS, ["Cache-Control", "Content-Language",
-        "Content-Type", "Expires", "Last-Modified", "Pragma"]).
--define(ALLOWED_HEADERS, lists:sort(["Server", "Etag",
-        "Accept-Ranges" | ?SIMPLE_HEADERS])).
--define(SIMPLE_CONTENT_TYPE_VALUES, ["application/x-www-form-urlencoded",
-        "multipart/form-data", "text/plain"]).
-
-% TODO: - pick a sane default
--define(CORS_DEFAULT_MAX_AGE, 12345).
-
-%% is_preflight_request/1
-
-% http://www.w3.org/TR/cors/#resource-preflight-requests
-
-is_preflight_request(#httpd{method=Method}=Req) when Method /= 'OPTIONS' ->
-    Req;
-is_preflight_request(Req) ->
-    EnableCors = enable_cors(),
-    is_preflight_request(Req, EnableCors).
-
-is_preflight_request(Req, false) ->
-    Req;
-is_preflight_request(#httpd{mochi_req=MochiReq}=Req, true) ->
-    case preflight_request(MochiReq) of
-    {ok, PreflightHeaders} ->
-        send_preflight_response(Req, PreflightHeaders);
-    _ ->
-        Req
-    end.
-
-
-preflight_request(MochiReq) ->
-    Origin = MochiReq:get_header_value("Origin"),
-    preflight_request(MochiReq, Origin).
-
-preflight_request(MochiReq, undefined) ->
-    % If the Origin header is not present terminate this set of
-    % steps. The request is outside the scope of this specification.
-    % http://www.w3.org/TR/cors/#resource-preflight-requests
-    MochiReq;
-preflight_request(MochiReq, Origin) ->
-    Host = couch_httpd_vhost:host(MochiReq),
-    AcceptedOrigins = get_accepted_origins(Host),
-    AcceptAll = lists:member("*", AcceptedOrigins),
-
-    HandlerFun = fun() ->
-        OriginList = couch_util:to_list(Origin),
-        handle_preflight_request(OriginList, Host, MochiReq)
-    end,
-
-    case AcceptAll of
-    true ->
-        % Always matching is acceptable since the list of
-        % origins can be unbounded.
-        % http://www.w3.org/TR/cors/#resource-preflight-requests
-        HandlerFun();
-    false ->
-        case lists:member(Origin, AcceptedOrigins) of
-        % The Origin header can only contain a single origin as
-        % the user agent will not follow redirects.
-        % http://www.w3.org/TR/cors/#resource-preflight-requests
-        % TODO: Square against multi origin thinger in Security Considerations
-        true ->
-            HandlerFun();
-        false ->
-            % If the value of the Origin header is not a
-            % case-sensitive match for any of the values
-            % in list of origins do not set any additional
-            % headers and terminate this set of steps.
-            % http://www.w3.org/TR/cors/#resource-preflight-requests
-            false
-        end
-    end.
-
-
-handle_preflight_request(Origin, Host, MochiReq) ->
-    %% get supported methods
-    SupportedMethods = split_list(cors_config(Host, "methods",
-                                              ?SUPPORTED_METHODS)),
-
-    % get supported headers
-    AllSupportedHeaders = split_list(cors_config(Host, "headers",
-                                                 ?SUPPORTED_HEADERS)),
-
-    SupportedHeaders = [string:to_lower(H) || H <- AllSupportedHeaders],
-
-    % get max age
-    MaxAge = cors_config(Host, "max_age", ?CORS_DEFAULT_MAX_AGE),
-
-    PreflightHeaders0 = maybe_add_credentials(Origin, Host, [
-        {"Access-Control-Allow-Origin", Origin},
-        {"Access-Control-Max-Age", MaxAge},
-        {"Access-Control-Allow-Methods",
-            string:join(SupportedMethods, ", ")}]),
-
-    case MochiReq:get_header_value("Access-Control-Request-Method") of
-    undefined ->
-        % If there is no Access-Control-Request-Method header
-        % or if parsing failed, do not set any additional headers
-        % and terminate this set of steps. The request is outside
-        % the scope of this specification.
-        % http://www.w3.org/TR/cors/#resource-preflight-requests
-        {ok, PreflightHeaders0};
-    Method ->
-        case lists:member(Method, SupportedMethods) of
-        true ->
-            % method ok , check headers
-            AccessHeaders = MochiReq:get_header_value(
-                    "Access-Control-Request-Headers"),
-            {FinalReqHeaders, ReqHeaders} = case AccessHeaders of
-                undefined -> {"", []};
-                Headers ->
-                    % transform header list in something we
-                    % could check. make sure everything is a
-                    % list
-                    RH = [string:to_lower(H)
-                          || H <- split_headers(Headers)],
-                    {Headers, RH}
-            end,
-            % check if headers are supported
-            case ReqHeaders -- SupportedHeaders of
-            [] ->
-                PreflightHeaders = PreflightHeaders0 ++
-                                   [{"Access-Control-Allow-Headers",
-                                     FinalReqHeaders}],
-                {ok, PreflightHeaders};
-            _ ->
-                false
-            end;
-        false ->
-        % If method is not a case-sensitive match for any of
-        % the values in list of methods do not set any additional
-        % headers and terminate this set of steps.
-        % http://www.w3.org/TR/cors/#resource-preflight-requests
-            false
-        end
-    end.
-
-
-send_preflight_response(#httpd{mochi_req=MochiReq}=Req, Headers) ->
-    couch_httpd:log_request(Req, 204),
-    couch_stats_collector:increment({httpd_status_codes, 204}),
-    Headers1 = couch_httpd:http_1_0_keep_alive(MochiReq, Headers),
-    Headers2 = Headers1 ++ couch_httpd:server_header() ++
-               couch_httpd_auth:cookie_auth_header(Req, Headers1),
-    {ok, MochiReq:respond({204, Headers2, <<>>})}.
-
-
-% cors_headers/1
-
-cors_headers(MochiReq, RequestHeaders) ->
-    EnableCors = enable_cors(),
-    CorsHeaders = do_cors_headers(MochiReq, EnableCors),
-    maybe_apply_cors_headers(CorsHeaders, RequestHeaders).
-
-do_cors_headers(#httpd{mochi_req=MochiReq}, true) ->
-    Host = couch_httpd_vhost:host(MochiReq),
-    AcceptedOrigins = get_accepted_origins(Host),
-    case MochiReq:get_header_value("Origin") of
-    undefined ->
-        % If the Origin header is not present terminate
-        % this set of steps. The request is outside the scope
-        % of this specification.
-        % http://www.w3.org/TR/cors/#resource-processing-model
-        [];
-    Origin ->
-        handle_cors_headers(couch_util:to_list(Origin),
-                            Host, AcceptedOrigins)
-    end;
-do_cors_headers(_MochiReq, false) ->
-    [].
-
-maybe_apply_cors_headers([], RequestHeaders) ->
-    RequestHeaders;
-maybe_apply_cors_headers(CorsHeaders, RequestHeaders0) ->
-    % for each RequestHeader that isn't in SimpleHeaders,
-    % (or Content-Type with SIMPLE_CONTENT_TYPE_VALUES)
-    % append to Access-Control-Expose-Headers
-    % return: RequestHeaders ++ CorsHeaders ++ ACEH
-
-    RequestHeaders = [K || {K,_V} <- RequestHeaders0],
-    ExposedHeaders0 = reduce_headers(RequestHeaders, ?ALLOWED_HEADERS),
-
-    % here we may have not moved Content-Type into ExposedHeaders,
-    % now we need to check whether the Content-Type valus is
-    % in ?SIMPLE_CONTENT_TYPE_VALUES and if it isn’t add Content-
-    % Type to to ExposedHeaders
-    ContentType =  proplists:get_value("Content-Type", RequestHeaders0),
-    IncludeContentType = case ContentType of
-    undefined ->
-        false;
-    _ ->
-        ContentType_ = string:to_lower(ContentType),
-        lists:member(ContentType_, ?SIMPLE_CONTENT_TYPE_VALUES)
-    end,
-    ExposedHeaders = case IncludeContentType of
-    false ->
-        lists:umerge(ExposedHeaders0, ["Content-Type"]);
-    true ->
-        ExposedHeaders0
-    end,
-    CorsHeaders
-    ++ RequestHeaders0
-    ++ [{"Access-Control-Expose-Headers",
-            string:join(ExposedHeaders, ", ")}].
-
-
-reduce_headers(A, B) ->
-    reduce_headers0(A, B, []).
-
-reduce_headers0([], _B, Result) ->
-    lists:sort(Result);
-reduce_headers0([ElmA|RestA], B, Result) ->
-    R = case member_nocase(ElmA, B) of
-    false -> Result;
-    _Else -> [ElmA | Result]
-    end,
-    reduce_headers0(RestA, B, R).
-
-member_nocase(ElmA, List) ->
-    lists:any(fun(ElmB) ->
-        string:to_lower(ElmA) =:= string:to_lower(ElmB)
-    end, List).
-
-handle_cors_headers(_Origin, _Host, []) ->
-    [];
-handle_cors_headers(Origin, Host, AcceptedOrigins) ->
-    AcceptAll = lists:member("*", AcceptedOrigins),
-    case {AcceptAll, lists:member(Origin, AcceptedOrigins)} of
-    {true, _} ->
-        make_cors_header(Origin, Host);
-    {false, true}  ->
-        make_cors_header(Origin, Host);
-    _ ->
-        % If the value of the Origin header is not a
-        % case-sensitive match for any of the values
-        % in list of origins, do not set any additional
-        % headers and terminate this set of steps.
-        % http://www.w3.org/TR/cors/#resource-requests
-        []
-    end.
-
-
-make_cors_header(Origin, Host) ->
-    Headers = [{"Access-Control-Allow-Origin", Origin}],
-    maybe_add_credentials(Origin, Host, Headers).
-
-
-%% util
-
-maybe_add_credentials(Origin, Host, Headers) ->
-    maybe_add_credentials(Headers, allow_credentials(Origin, Host)).
-
-maybe_add_credentials(Headers, false) ->
-    Headers;
-maybe_add_credentials(Headers, true) ->
-    Headers ++ [{"Access-Control-Allow-Credentials", "true"}].
-
-
-allow_credentials("*", _Host) ->
-    false;
-allow_credentials(_Origin, Host) ->
-    Default = get_bool_config("cors", "credentials", false),
-    get_bool_config(cors_section(Host), "credentials", Default).
-
-
-
-cors_config(Host, Key, Default) ->
-    couch_config:get(cors_section(Host), Key,
-                     couch_config:get("cors", Key, Default)).
-
-cors_section(Host0) ->
-    {Host, _Port} = split_host_port(Host0),
-    "cors:" ++ Host.
-
-enable_cors() ->
-    get_bool_config("httpd", "enable_cors", false).
-
-get_bool_config(Section, Key, Default) ->
-    case couch_config:get(Section, Key) of
-    undefined ->
-        Default;
-    "true" ->
-        true;
-    "false" ->
-        false
-    end.
-
-get_accepted_origins(Host) ->
-    split_list(cors_config(Host, "origins", [])).
-
-split_list(S) ->
-    re:split(S, "\\s*,\\s*", [trim, {return, list}]).
-
-split_headers(H) ->
-    re:split(H, ",\\s*", [{return,list}, trim]).
-
-split_host_port(HostAsString) ->
-    % split at semicolon ":"
-    Split = string:rchr(HostAsString, $:),
-    split_host_port(HostAsString, Split).
-
-split_host_port(HostAsString, 0) ->
-    % no semicolon
-    {HostAsString, '*'};
-split_host_port(HostAsString, N) ->
-    HostPart = string:substr(HostAsString, 1, N-1),
-    % parse out port
-    % is there a nicer way?
-    case (catch erlang:list_to_integer(string:substr(HostAsString,
-                    N+1, length(HostAsString)))) of
-    {'EXIT', _} ->
-        {HostAsString, '*'};
-    Port ->
-        {HostPart, Port}
-    end.

http://git-wip-us.apache.org/repos/asf/couchdb/blob/c0855434/apps/couch_httpd/src/couch_httpd_db.erl
----------------------------------------------------------------------
diff --git a/apps/couch_httpd/src/couch_httpd_db.erl b/apps/couch_httpd/src/couch_httpd_db.erl
deleted file mode 100644
index 0d1e0f8..0000000
--- a/apps/couch_httpd/src/couch_httpd_db.erl
+++ /dev/null
@@ -1,1226 +0,0 @@
-% Licensed 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.
-
--module(couch_httpd_db).
--include_lib("couch/include/couch_db.hrl").
-
--export([handle_request/1, handle_compact_req/2, handle_design_req/2,
-    db_req/2, couch_doc_open/4,handle_changes_req/2,
-    update_doc_result_to_json/1, update_doc_result_to_json/2,
-    handle_design_info_req/3]).
-
--import(couch_httpd,
-        [send_json/2,send_json/3,send_json/4,send_method_not_allowed/2,
-         start_json_response/2,send_chunk/2,last_chunk/1,end_json_response/1,
-         start_chunked_response/3, absolute_uri/2, send/2,
-         start_response_length/4, send_error/4]).
-
--record(doc_query_args, {
-    options = [],
-    rev = nil,
-    open_revs = [],
-    update_type = interactive_edit,
-    atts_since = nil
-}).
-
-% Database request handlers
-handle_request(#httpd{path_parts=[DbName|RestParts],method=Method,
-        db_url_handlers=DbUrlHandlers}=Req)->
-    case {Method, RestParts} of
-    {'PUT', []} ->
-        create_db_req(Req, DbName);
-    {'DELETE', []} ->
-        % if we get ?rev=... the user is using a faulty script where the
-        % document id is empty by accident. Let them recover safely.
-        case couch_httpd:qs_value(Req, "rev", false) of
-            false -> delete_db_req(Req, DbName);
-            _Rev -> throw({bad_request,
-                "You tried to DELETE a database with a ?=rev parameter. "
-                ++ "Did you mean to DELETE a document instead?"})
-        end;
-    {_, []} ->
-        do_db_req(Req, fun db_req/2);
-    {_, [SecondPart|_]} ->
-        Handler = couch_util:dict_find(SecondPart, DbUrlHandlers, fun db_req/2),
-        do_db_req(Req, Handler)
-    end.
-
-handle_changes_req(#httpd{method='POST'}=Req, Db) ->
-    couch_httpd:validate_ctype(Req, "application/json"),
-    handle_changes_req1(Req, Db);
-handle_changes_req(#httpd{method='GET'}=Req, Db) ->
-    handle_changes_req1(Req, Db);
-handle_changes_req(#httpd{path_parts=[_,<<"_changes">>]}=Req, _Db) ->
-    send_method_not_allowed(Req, "GET,HEAD,POST").
-
-handle_changes_req1(Req, #db{name=DbName}=Db) ->
-    AuthDbName = ?l2b(couch_config:get("couch_httpd_auth", "authentication_db")),
-    case AuthDbName of
-    DbName ->
-        % in the authentication database, _changes is admin-only.
-        ok = couch_db:check_is_admin(Db);
-    _Else ->
-        % on other databases, _changes is free for all.
-        ok
-    end,
-    handle_changes_req2(Req, Db).
-
-handle_changes_req2(Req, Db) ->
-    MakeCallback = fun(Resp) ->
-        fun({change, {ChangeProp}=Change, _}, "eventsource") ->
-            Seq = proplists:get_value(<<"seq">>, ChangeProp),
-            send_chunk(Resp, ["data: ", ?JSON_ENCODE(Change),
-                              "\n", "id: ", ?JSON_ENCODE(Seq),
-                              "\n\n"]);
-        ({change, Change, _}, "continuous") ->
-            send_chunk(Resp, [?JSON_ENCODE(Change) | "\n"]);
-        ({change, Change, Prepend}, _) ->
-            send_chunk(Resp, [Prepend, ?JSON_ENCODE(Change)]);
-        (start, "eventsource") ->
-            ok;
-        (start, "continuous") ->
-            ok;
-        (start, _) ->
-            send_chunk(Resp, "{\"results\":[\n");
-        ({stop, _EndSeq}, "eventsource") ->
-            end_json_response(Resp);
-        ({stop, EndSeq}, "continuous") ->
-            send_chunk(
-                Resp,
-                [?JSON_ENCODE({[{<<"last_seq">>, EndSeq}]}) | "\n"]
-            ),
-            end_json_response(Resp);
-        ({stop, EndSeq}, _) ->
-            send_chunk(
-                Resp,
-                io_lib:format("\n],\n\"last_seq\":~w}\n", [EndSeq])
-            ),
-            end_json_response(Resp);
-        (timeout, _) ->
-            send_chunk(Resp, "\n")
-        end
-    end,
-    ChangesArgs = parse_changes_query(Req, Db),
-    ChangesFun = couch_changes:handle_changes(ChangesArgs, Req, Db),
-    WrapperFun = case ChangesArgs#changes_args.feed of
-    "normal" ->
-        {ok, Info} = couch_db:get_db_info(Db),
-        CurrentEtag = couch_httpd:make_etag(Info),
-        fun(FeedChangesFun) ->
-            couch_httpd:etag_respond(
-                Req,
-                CurrentEtag,
-                fun() ->
-                    {ok, Resp} = couch_httpd:start_json_response(
-                         Req, 200, [{"ETag", CurrentEtag}]
-                    ),
-                    FeedChangesFun(MakeCallback(Resp))
-                end
-            )
-        end;
-    "eventsource" ->
-        Headers = [
-            {"Content-Type", "text/event-stream"},
-            {"Cache-Control", "no-cache"}
-        ],
-        {ok, Resp} = couch_httpd:start_chunked_response(Req, 200, Headers),
-        fun(FeedChangesFun) ->
-            FeedChangesFun(MakeCallback(Resp))
-        end;
-    _ ->
-        % "longpoll" or "continuous"
-        {ok, Resp} = couch_httpd:start_json_response(Req, 200),
-        fun(FeedChangesFun) ->
-            FeedChangesFun(MakeCallback(Resp))
-        end
-    end,
-    couch_stats_collector:increment(
-        {httpd, clients_requesting_changes}
-    ),
-    try
-        WrapperFun(ChangesFun)
-    after
-    couch_stats_collector:decrement(
-        {httpd, clients_requesting_changes}
-    )
-    end.
-
-handle_compact_req(#httpd{method='POST'}=Req, Db) ->
-    case Req#httpd.path_parts of
-        [_DbName, <<"_compact">>] ->
-            ok = couch_db:check_is_admin(Db),
-            couch_httpd:validate_ctype(Req, "application/json"),
-            {ok, _} = couch_db:start_compact(Db),
-            send_json(Req, 202, {[{ok, true}]});
-        [_DbName, <<"_compact">>, DesignName | _] ->
-            DesignId = <<"_design/", DesignName/binary>>,
-            DDoc = couch_httpd_db:couch_doc_open(
-                Db, DesignId, nil, [ejson_body]
-            ),
-            couch_mrview_http:handle_compact_req(Req, Db, DDoc)
-    end;
-
-handle_compact_req(Req, _Db) ->
-    send_method_not_allowed(Req, "POST").
-
-
-handle_design_req(#httpd{
-        path_parts=[_DbName, _Design, DesignName, <<"_",_/binary>> = Action | _Rest],
-        design_url_handlers = DesignUrlHandlers
-    }=Req, Db) ->
-    case couch_db:is_system_db(Db) of
-    true ->
-        case (catch couch_db:check_is_admin(Db)) of
-        ok -> ok;
-        _ ->
-            throw({forbidden, <<"Only admins can access design document",
-                " actions for system databases.">>})
-        end;
-    false -> ok
-    end,
-
-    % load ddoc
-    DesignId = <<"_design/", DesignName/binary>>,
-    DDoc = couch_httpd_db:couch_doc_open(Db, DesignId, nil, [ejson_body]),
-    Handler = couch_util:dict_find(Action, DesignUrlHandlers, fun(_, _, _) ->
-        throw({not_found, <<"missing handler: ", Action/binary>>})
-    end),
-    Handler(Req, Db, DDoc);
-
-handle_design_req(Req, Db) ->
-    db_req(Req, Db).
-
-handle_design_info_req(#httpd{
-            method='GET',
-            path_parts=[_DbName, _Design, DesignName, _]
-        }=Req, Db, _DDoc) ->
-    DesignId = <<"_design/", DesignName/binary>>,
-    DDoc = couch_httpd_db:couch_doc_open(Db, DesignId, nil, [ejson_body]),
-    couch_mrview_http:handle_info_req(Req, Db, DDoc).
-
-create_db_req(#httpd{user_ctx=UserCtx}=Req, DbName) ->
-    ok = couch_httpd:verify_is_server_admin(Req),
-    case couch_server:create(DbName, [{user_ctx, UserCtx}]) of
-    {ok, Db} ->
-        couch_db:close(Db),
-        DbUrl = absolute_uri(Req, "/" ++ couch_util:url_encode(DbName)),
-        send_json(Req, 201, [{"Location", DbUrl}], {[{ok, true}]});
-    Error ->
-        throw(Error)
-    end.
-
-delete_db_req(#httpd{user_ctx=UserCtx}=Req, DbName) ->
-    ok = couch_httpd:verify_is_server_admin(Req),
-    case couch_server:delete(DbName, [{user_ctx, UserCtx}]) of
-    ok ->
-        send_json(Req, 200, {[{ok, true}]});
-    Error ->
-        throw(Error)
-    end.
-
-do_db_req(#httpd{user_ctx=UserCtx,path_parts=[DbName|_]}=Req, Fun) ->
-    case couch_db:open(DbName, [{user_ctx, UserCtx}]) of
-    {ok, Db} ->
-        try
-            Fun(Req, Db)
-        after
-            catch couch_db:close(Db)
-        end;
-    Error ->
-        throw(Error)
-    end.
-
-db_req(#httpd{method='GET',path_parts=[_DbName]}=Req, Db) ->
-    {ok, DbInfo} = couch_db:get_db_info(Db),
-    send_json(Req, {DbInfo});
-
-db_req(#httpd{method='POST',path_parts=[_DbName]}=Req, Db) ->
-    couch_httpd:validate_ctype(Req, "application/json"),
-    Doc = couch_doc:from_json_obj(couch_httpd:json_body(Req)),
-    validate_attachment_names(Doc),
-    Doc2 = case Doc#doc.id of
-        <<"">> ->
-            Doc#doc{id=couch_uuids:new(), revs={0, []}};
-        _ ->
-            Doc
-    end,
-    DocId = Doc2#doc.id,
-    update_doc(Req, Db, DocId, Doc2);
-
-db_req(#httpd{path_parts=[_DbName]}=Req, _Db) ->
-    send_method_not_allowed(Req, "DELETE,GET,HEAD,POST");
-
-db_req(#httpd{method='POST',path_parts=[_,<<"_ensure_full_commit">>]}=Req, Db) ->
-    couch_httpd:validate_ctype(Req, "application/json"),
-    UpdateSeq = couch_db:get_update_seq(Db),
-    CommittedSeq = couch_db:get_committed_update_seq(Db),
-    {ok, StartTime} =
-    case couch_httpd:qs_value(Req, "seq") of
-    undefined ->
-        couch_db:ensure_full_commit(Db);
-    RequiredStr ->
-        RequiredSeq = list_to_integer(RequiredStr),
-        if RequiredSeq > UpdateSeq ->
-            throw({bad_request,
-                "can't do a full commit ahead of current update_seq"});
-        RequiredSeq > CommittedSeq ->
-            couch_db:ensure_full_commit(Db);
-        true ->
-            {ok, Db#db.instance_start_time}
-        end
-    end,
-    send_json(Req, 201, {[
-        {ok, true},
-        {instance_start_time, StartTime}
-    ]});
-
-db_req(#httpd{path_parts=[_,<<"_ensure_full_commit">>]}=Req, _Db) ->
-    send_method_not_allowed(Req, "POST");
-
-db_req(#httpd{method='POST',path_parts=[_,<<"_bulk_docs">>]}=Req, Db) ->
-    couch_stats_collector:increment({httpd, bulk_requests}),
-    couch_httpd:validate_ctype(Req, "application/json"),
-    {JsonProps} = couch_httpd:json_body_obj(Req),
-    case couch_util:get_value(<<"docs">>, JsonProps) of
-    undefined ->
-        send_error(Req, 400, <<"bad_request">>, <<"Missing JSON list of 'docs'">>);
-    DocsArray ->
-        case couch_httpd:header_value(Req, "X-Couch-Full-Commit") of
-        "true" ->
-            Options = [full_commit];
-        "false" ->
-            Options = [delay_commit];
-        _ ->
-            Options = []
-        end,
-        case couch_util:get_value(<<"new_edits">>, JsonProps, true) of
-        true ->
-            Docs = lists:map(
-                fun({ObjProps} = JsonObj) ->
-                    Doc = couch_doc:from_json_obj(JsonObj),
-                    validate_attachment_names(Doc),
-                    Id = case Doc#doc.id of
-                        <<>> -> couch_uuids:new();
-                        Id0 -> Id0
-                    end,
-                    case couch_util:get_value(<<"_rev">>, ObjProps) of
-                    undefined ->
-                       Revs = {0, []};
-                    Rev  ->
-                        {Pos, RevId} = couch_doc:parse_rev(Rev),
-                        Revs = {Pos, [RevId]}
-                    end,
-                    Doc#doc{id=Id,revs=Revs}
-                end,
-                DocsArray),
-            Options2 =
-            case couch_util:get_value(<<"all_or_nothing">>, JsonProps) of
-            true  -> [all_or_nothing|Options];
-            _ -> Options
-            end,
-            case couch_db:update_docs(Db, Docs, Options2) of
-            {ok, Results} ->
-                % output the results
-                DocResults = lists:zipwith(fun update_doc_result_to_json/2,
-                    Docs, Results),
-                send_json(Req, 201, DocResults);
-            {aborted, Errors} ->
-                ErrorsJson =
-                    lists:map(fun update_doc_result_to_json/1, Errors),
-                send_json(Req, 417, ErrorsJson)
-            end;
-        false ->
-            Docs = lists:map(fun(JsonObj) ->
-                    Doc = couch_doc:from_json_obj(JsonObj),
-                    validate_attachment_names(Doc),
-                    Doc
-                end, DocsArray),
-            {ok, Errors} = couch_db:update_docs(Db, Docs, Options, replicated_changes),
-            ErrorsJson =
-                lists:map(fun update_doc_result_to_json/1, Errors),
-            send_json(Req, 201, ErrorsJson)
-        end
-    end;
-db_req(#httpd{path_parts=[_,<<"_bulk_docs">>]}=Req, _Db) ->
-    send_method_not_allowed(Req, "POST");
-
-db_req(#httpd{method='POST',path_parts=[_,<<"_purge">>]}=Req, Db) ->
-    couch_httpd:validate_ctype(Req, "application/json"),
-    {IdsRevs} = couch_httpd:json_body_obj(Req),
-    IdsRevs2 = [{Id, couch_doc:parse_revs(Revs)} || {Id, Revs} <- IdsRevs],
-
-    case couch_db:purge_docs(Db, IdsRevs2) of
-    {ok, PurgeSeq, PurgedIdsRevs} ->
-        PurgedIdsRevs2 = [{Id, couch_doc:revs_to_strs(Revs)} || {Id, Revs} <- PurgedIdsRevs],
-        send_json(Req, 200, {[{<<"purge_seq">>, PurgeSeq}, {<<"purged">>, {PurgedIdsRevs2}}]});
-    Error ->
-        throw(Error)
-    end;
-
-db_req(#httpd{path_parts=[_,<<"_purge">>]}=Req, _Db) ->
-    send_method_not_allowed(Req, "POST");
-
-db_req(#httpd{method='POST',path_parts=[_,<<"_missing_revs">>]}=Req, Db) ->
-    {JsonDocIdRevs} = couch_httpd:json_body_obj(Req),
-    JsonDocIdRevs2 = [{Id, [couch_doc:parse_rev(RevStr) || RevStr <- RevStrs]} || {Id, RevStrs} <- JsonDocIdRevs],
-    {ok, Results} = couch_db:get_missing_revs(Db, JsonDocIdRevs2),
-    Results2 = [{Id, couch_doc:revs_to_strs(Revs)} || {Id, Revs, _} <- Results],
-    send_json(Req, {[
-        {missing_revs, {Results2}}
-    ]});
-
-db_req(#httpd{path_parts=[_,<<"_missing_revs">>]}=Req, _Db) ->
-    send_method_not_allowed(Req, "POST");
-
-db_req(#httpd{method='POST',path_parts=[_,<<"_revs_diff">>]}=Req, Db) ->
-    {JsonDocIdRevs} = couch_httpd:json_body_obj(Req),
-    JsonDocIdRevs2 =
-        [{Id, couch_doc:parse_revs(RevStrs)} || {Id, RevStrs} <- JsonDocIdRevs],
-    {ok, Results} = couch_db:get_missing_revs(Db, JsonDocIdRevs2),
-    Results2 =
-    lists:map(fun({Id, MissingRevs, PossibleAncestors}) ->
-        {Id,
-            {[{missing, couch_doc:revs_to_strs(MissingRevs)}] ++
-                if PossibleAncestors == [] ->
-                    [];
-                true ->
-                    [{possible_ancestors,
-                        couch_doc:revs_to_strs(PossibleAncestors)}]
-                end}}
-    end, Results),
-    send_json(Req, {Results2});
-
-db_req(#httpd{path_parts=[_,<<"_revs_diff">>]}=Req, _Db) ->
-    send_method_not_allowed(Req, "POST");
-
-db_req(#httpd{method='PUT',path_parts=[_,<<"_security">>]}=Req, Db) ->
-    SecObj = couch_httpd:json_body(Req),
-    ok = couch_db:set_security(Db, SecObj),
-    send_json(Req, {[{<<"ok">>, true}]});
-
-db_req(#httpd{method='GET',path_parts=[_,<<"_security">>]}=Req, Db) ->
-    send_json(Req, couch_db:get_security(Db));
-
-db_req(#httpd{path_parts=[_,<<"_security">>]}=Req, _Db) ->
-    send_method_not_allowed(Req, "PUT,GET");
-
-db_req(#httpd{method='PUT',path_parts=[_,<<"_revs_limit">>]}=Req,
-        Db) ->
-    Limit = couch_httpd:json_body(Req),
-   case is_integer(Limit) of
-   true ->
-       ok = couch_db:set_revs_limit(Db, Limit),
-       send_json(Req, {[{<<"ok">>, true}]});
-   false ->
-       throw({bad_request, <<"Rev limit has to be an integer">>})
-   end;
-
-db_req(#httpd{method='GET',path_parts=[_,<<"_revs_limit">>]}=Req, Db) ->
-    send_json(Req, couch_db:get_revs_limit(Db));
-
-db_req(#httpd{path_parts=[_,<<"_revs_limit">>]}=Req, _Db) ->
-    send_method_not_allowed(Req, "PUT,GET");
-
-% Special case to enable using an unencoded slash in the URL of design docs,
-% as slashes in document IDs must otherwise be URL encoded.
-db_req(#httpd{method='GET',mochi_req=MochiReq, path_parts=[DbName,<<"_design/",_/binary>>|_]}=Req, _Db) ->
-    PathFront = "/" ++ couch_httpd:quote(binary_to_list(DbName)) ++ "/",
-    [_|PathTail] = re:split(MochiReq:get(raw_path), "_design%2F",
-        [{return, list}]),
-    couch_httpd:send_redirect(Req, PathFront ++ "_design/" ++
-        mochiweb_util:join(PathTail, "_design%2F"));
-
-db_req(#httpd{path_parts=[_DbName,<<"_design">>,Name]}=Req, Db) ->
-    db_doc_req(Req, Db, <<"_design/",Name/binary>>);
-
-db_req(#httpd{path_parts=[_DbName,<<"_design">>,Name|FileNameParts]}=Req, Db) ->
-    db_attachment_req(Req, Db, <<"_design/",Name/binary>>, FileNameParts);
-
-
-% Special case to allow for accessing local documents without %2F
-% encoding the docid. Throws out requests that don't have the second
-% path part or that specify an attachment name.
-db_req(#httpd{path_parts=[_DbName, <<"_local">>]}, _Db) ->
-    throw({bad_request, <<"Invalid _local document id.">>});
-
-db_req(#httpd{path_parts=[_DbName, <<"_local/">>]}, _Db) ->
-    throw({bad_request, <<"Invalid _local document id.">>});
-
-db_req(#httpd{path_parts=[_DbName, <<"_local">>, Name]}=Req, Db) ->
-    db_doc_req(Req, Db, <<"_local/", Name/binary>>);
-
-db_req(#httpd{path_parts=[_DbName, <<"_local">> | _Rest]}, _Db) ->
-    throw({bad_request, <<"_local documents do not accept attachments.">>});
-
-db_req(#httpd{path_parts=[_, DocId]}=Req, Db) ->
-    db_doc_req(Req, Db, DocId);
-
-db_req(#httpd{path_parts=[_, DocId | FileNameParts]}=Req, Db) ->
-    db_attachment_req(Req, Db, DocId, FileNameParts).
-
-db_doc_req(#httpd{method='DELETE'}=Req, Db, DocId) ->
-    % check for the existence of the doc to handle the 404 case.
-    couch_doc_open(Db, DocId, nil, []),
-    case couch_httpd:qs_value(Req, "rev") of
-    undefined ->
-        update_doc(Req, Db, DocId,
-                couch_doc_from_req(Req, DocId, {[{<<"_deleted">>,true}]}));
-    Rev ->
-        update_doc(Req, Db, DocId,
-                couch_doc_from_req(Req, DocId,
-                    {[{<<"_rev">>, ?l2b(Rev)},{<<"_deleted">>,true}]}))
-    end;
-
-db_doc_req(#httpd{method = 'GET', mochi_req = MochiReq} = Req, Db, DocId) ->
-    #doc_query_args{
-        rev = Rev,
-        open_revs = Revs,
-        options = Options1,
-        atts_since = AttsSince
-    } = parse_doc_query(Req),
-    Options = case AttsSince of
-    nil ->
-        Options1;
-    RevList when is_list(RevList) ->
-        [{atts_since, RevList}, attachments | Options1]
-    end,
-    case Revs of
-    [] ->
-        Doc = couch_doc_open(Db, DocId, Rev, Options),
-        send_doc(Req, Doc, Options);
-    _ ->
-        {ok, Results} = couch_db:open_doc_revs(Db, DocId, Revs, Options),
-        case MochiReq:accepts_content_type("multipart/mixed") of
-        false ->
-            {ok, Resp} = start_json_response(Req, 200),
-            send_chunk(Resp, "["),
-            % We loop through the docs. The first time through the separator
-            % is whitespace, then a comma on subsequent iterations.
-            lists:foldl(
-                fun(Result, AccSeparator) ->
-                    case Result of
-                    {ok, Doc} ->
-                        JsonDoc = couch_doc:to_json_obj(Doc, Options),
-                        Json = ?JSON_ENCODE({[{ok, JsonDoc}]}),
-                        send_chunk(Resp, AccSeparator ++ Json);
-                    {{not_found, missing}, RevId} ->
-                        RevStr = couch_doc:rev_to_str(RevId),
-                        Json = ?JSON_ENCODE({[{"missing", RevStr}]}),
-                        send_chunk(Resp, AccSeparator ++ Json)
-                    end,
-                    "," % AccSeparator now has a comma
-                end,
-                "", Results),
-            send_chunk(Resp, "]"),
-            end_json_response(Resp);
-        true ->
-            send_docs_multipart(Req, Results, Options)
-        end
-    end;
-
-
-db_doc_req(#httpd{method='POST'}=Req, Db, DocId) ->
-    couch_httpd:validate_referer(Req),
-    couch_doc:validate_docid(DocId),
-    couch_httpd:validate_ctype(Req, "multipart/form-data"),
-    Form = couch_httpd:parse_form(Req),
-    case couch_util:get_value("_doc", Form) of
-    undefined ->
-        Rev = couch_doc:parse_rev(couch_util:get_value("_rev", Form)),
-        {ok, [{ok, Doc}]} = couch_db:open_doc_revs(Db, DocId, [Rev], []);
-    Json ->
-        Doc = couch_doc_from_req(Req, DocId, ?JSON_DECODE(Json))
-    end,
-    UpdatedAtts = [
-        #att{name=validate_attachment_name(Name),
-            type=list_to_binary(ContentType),
-            data=Content} ||
-        {Name, {ContentType, _}, Content} <-
-        proplists:get_all_values("_attachments", Form)
-    ],
-    #doc{atts=OldAtts} = Doc,
-    OldAtts2 = lists:flatmap(
-        fun(#att{name=OldName}=Att) ->
-            case [1 || A <- UpdatedAtts, A#att.name == OldName] of
-            [] -> [Att]; % the attachment wasn't in the UpdatedAtts, return it
-            _ -> [] % the attachment was in the UpdatedAtts, drop it
-            end
-        end, OldAtts),
-    NewDoc = Doc#doc{
-        atts = UpdatedAtts ++ OldAtts2
-    },
-    update_doc(Req, Db, DocId, NewDoc);
-
-db_doc_req(#httpd{method='PUT'}=Req, Db, DocId) ->
-    couch_doc:validate_docid(DocId),
-
-    case couch_util:to_list(couch_httpd:header_value(Req, "Content-Type")) of
-    ("multipart/related;" ++ _) = ContentType ->
-        {ok, Doc0, WaitFun, Parser} = couch_doc:doc_from_multi_part_stream(
-            ContentType, fun() -> receive_request_data(Req) end),
-        Doc = couch_doc_from_req(Req, DocId, Doc0),
-        try
-            Result = update_doc(Req, Db, DocId, Doc),
-            WaitFun(),
-            Result
-        catch throw:Err ->
-            % Document rejected by a validate_doc_update function.
-            couch_doc:abort_multi_part_stream(Parser),
-            throw(Err)
-        end;
-    _Else ->
-        Body = couch_httpd:json_body(Req),
-        Doc = couch_doc_from_req(Req, DocId, Body),
-        update_doc(Req, Db, DocId, Doc)
-    end;
-
-db_doc_req(#httpd{method='COPY'}=Req, Db, SourceDocId) ->
-    SourceRev =
-    case extract_header_rev(Req, couch_httpd:qs_value(Req, "rev")) of
-        missing_rev -> nil;
-        Rev -> Rev
-    end,
-    {TargetDocId, TargetRevs} = parse_copy_destination_header(Req),
-    % open old doc
-    Doc = couch_doc_open(Db, SourceDocId, SourceRev, []),
-    % save new doc
-    update_doc(Req, Db, TargetDocId, Doc#doc{id=TargetDocId, revs=TargetRevs});
-
-db_doc_req(Req, _Db, _DocId) ->
-    send_method_not_allowed(Req, "DELETE,GET,HEAD,POST,PUT,COPY").
-
-
-send_doc(Req, Doc, Options) ->
-    case Doc#doc.meta of
-    [] ->
-        DiskEtag = couch_httpd:doc_etag(Doc),
-        % output etag only when we have no meta
-        couch_httpd:etag_respond(Req, DiskEtag, fun() ->
-            send_doc_efficiently(Req, Doc, [{"ETag", DiskEtag}], Options)
-        end);
-    _ ->
-        send_doc_efficiently(Req, Doc, [], Options)
-    end.
-
-
-send_doc_efficiently(Req, #doc{atts=[]}=Doc, Headers, Options) ->
-        send_json(Req, 200, Headers, couch_doc:to_json_obj(Doc, Options));
-send_doc_efficiently(#httpd{mochi_req = MochiReq} = Req,
-    #doc{atts = Atts} = Doc, Headers, Options) ->
-    case lists:member(attachments, Options) of
-    true ->
-        case MochiReq:accepts_content_type("multipart/related") of
-        false ->
-            send_json(Req, 200, Headers, couch_doc:to_json_obj(Doc, Options));
-        true ->
-            Boundary = couch_uuids:random(),
-            JsonBytes = ?JSON_ENCODE(couch_doc:to_json_obj(Doc,
-                    [attachments, follows, att_encoding_info | Options])),
-            {ContentType, Len} = couch_doc:len_doc_to_multi_part_stream(
-                    Boundary,JsonBytes, Atts, true),
-            CType = {"Content-Type", ?b2l(ContentType)},
-            {ok, Resp} = start_response_length(Req, 200, [CType|Headers], Len),
-            couch_doc:doc_to_multi_part_stream(Boundary,JsonBytes,Atts,
-                    fun(Data) -> couch_httpd:send(Resp, Data) end, true)
-        end;
-    false ->
-        send_json(Req, 200, Headers, couch_doc:to_json_obj(Doc, Options))
-    end.
-
-send_docs_multipart(Req, Results, Options1) ->
-    OuterBoundary = couch_uuids:random(),
-    InnerBoundary = couch_uuids:random(),
-    Options = [attachments, follows, att_encoding_info | Options1],
-    CType = {"Content-Type",
-        "multipart/mixed; boundary=\"" ++ ?b2l(OuterBoundary) ++ "\""},
-    {ok, Resp} = start_chunked_response(Req, 200, [CType]),
-    couch_httpd:send_chunk(Resp, <<"--", OuterBoundary/binary>>),
-    lists:foreach(
-        fun({ok, #doc{atts=Atts}=Doc}) ->
-            JsonBytes = ?JSON_ENCODE(couch_doc:to_json_obj(Doc, Options)),
-            {ContentType, _Len} = couch_doc:len_doc_to_multi_part_stream(
-                    InnerBoundary, JsonBytes, Atts, true),
-            couch_httpd:send_chunk(Resp, <<"\r\nContent-Type: ",
-                    ContentType/binary, "\r\n\r\n">>),
-            couch_doc:doc_to_multi_part_stream(InnerBoundary, JsonBytes, Atts,
-                    fun(Data) -> couch_httpd:send_chunk(Resp, Data)
-                    end, true),
-             couch_httpd:send_chunk(Resp, <<"\r\n--", OuterBoundary/binary>>);
-        ({{not_found, missing}, RevId}) ->
-             RevStr = couch_doc:rev_to_str(RevId),
-             Json = ?JSON_ENCODE({[{"missing", RevStr}]}),
-             couch_httpd:send_chunk(Resp,
-                [<<"\r\nContent-Type: application/json; error=\"true\"\r\n\r\n">>,
-                Json,
-                <<"\r\n--", OuterBoundary/binary>>])
-         end, Results),
-    couch_httpd:send_chunk(Resp, <<"--">>),
-    couch_httpd:last_chunk(Resp).
-
-send_ranges_multipart(Req, ContentType, Len, Att, Ranges) ->
-    Boundary = couch_uuids:random(),
-    CType = {"Content-Type",
-        "multipart/byteranges; boundary=\"" ++ ?b2l(Boundary) ++ "\""},
-    {ok, Resp} = start_chunked_response(Req, 206, [CType]),
-    couch_httpd:send_chunk(Resp, <<"--", Boundary/binary>>),
-    lists:foreach(fun({From, To}) ->
-        ContentRange = ?l2b(make_content_range(From, To, Len)),
-        couch_httpd:send_chunk(Resp,
-            <<"\r\nContent-Type: ", ContentType/binary, "\r\n",
-            "Content-Range: ", ContentRange/binary, "\r\n",
-           "\r\n">>),
-        couch_doc:range_att_foldl(Att, From, To + 1,
-            fun(Seg, _) -> send_chunk(Resp, Seg) end, {ok, Resp}),
-        couch_httpd:send_chunk(Resp, <<"\r\n--", Boundary/binary>>)
-    end, Ranges),
-    couch_httpd:send_chunk(Resp, <<"--">>),
-    couch_httpd:last_chunk(Resp),
-    {ok, Resp}.
-
-receive_request_data(Req) ->
-    receive_request_data(Req, couch_httpd:body_length(Req)).
-
-receive_request_data(Req, LenLeft) when LenLeft > 0 ->
-    Len = erlang:min(4096, LenLeft),
-    Data = couch_httpd:recv(Req, Len),
-    {Data, fun() -> receive_request_data(Req, LenLeft - iolist_size(Data)) end};
-receive_request_data(_Req, _) ->
-    throw(<<"expected more data">>).
-
-make_content_range(From, To, Len) ->
-    io_lib:format("bytes ~B-~B/~B", [From, To, Len]).
-
-update_doc_result_to_json({{Id, Rev}, Error}) ->
-        {_Code, Err, Msg} = couch_httpd:error_info(Error),
-        {[{id, Id}, {rev, couch_doc:rev_to_str(Rev)},
-            {error, Err}, {reason, Msg}]}.
-
-update_doc_result_to_json(#doc{id=DocId}, Result) ->
-    update_doc_result_to_json(DocId, Result);
-update_doc_result_to_json(DocId, {ok, NewRev}) ->
-    {[{ok, true}, {id, DocId}, {rev, couch_doc:rev_to_str(NewRev)}]};
-update_doc_result_to_json(DocId, Error) ->
-    {_Code, ErrorStr, Reason} = couch_httpd:error_info(Error),
-    {[{id, DocId}, {error, ErrorStr}, {reason, Reason}]}.
-
-
-update_doc(Req, Db, DocId, #doc{deleted=false}=Doc) ->
-    Loc = absolute_uri(Req, "/" ++ ?b2l(Db#db.name) ++ "/" ++ ?b2l(DocId)),
-    update_doc(Req, Db, DocId, Doc, [{"Location", Loc}]);
-update_doc(Req, Db, DocId, Doc) ->
-    update_doc(Req, Db, DocId, Doc, []).
-
-update_doc(Req, Db, DocId, Doc, Headers) ->
-    #doc_query_args{
-        update_type = UpdateType
-    } = parse_doc_query(Req),
-    update_doc(Req, Db, DocId, Doc, Headers, UpdateType).
-
-update_doc(Req, Db, DocId, #doc{deleted=Deleted}=Doc, Headers, UpdateType) ->
-    case couch_httpd:header_value(Req, "X-Couch-Full-Commit") of
-    "true" ->
-        Options = [full_commit];
-    "false" ->
-        Options = [delay_commit];
-    _ ->
-        Options = []
-    end,
-    case couch_httpd:qs_value(Req, "batch") of
-    "ok" ->
-        % async batching
-        spawn(fun() ->
-                case catch(couch_db:update_doc(Db, Doc, Options, UpdateType)) of
-                {ok, _} -> ok;
-                Error ->
-                    ?LOG_INFO("Batch doc error (~s): ~p",[DocId, Error])
-                end
-            end),
-        send_json(Req, 202, Headers, {[
-            {ok, true},
-            {id, DocId}
-        ]});
-    _Normal ->
-        % normal
-        {ok, NewRev} = couch_db:update_doc(Db, Doc, Options, UpdateType),
-        NewRevStr = couch_doc:rev_to_str(NewRev),
-        ResponseHeaders = [{"ETag", <<"\"", NewRevStr/binary, "\"">>}] ++ Headers,
-        send_json(Req,
-            if Deleted orelse Req#httpd.method == 'DELETE' -> 200;
-            true -> 201 end,
-            ResponseHeaders, {[
-                {ok, true},
-                {id, DocId},
-                {rev, NewRevStr}]})
-    end.
-
-couch_doc_from_req(Req, DocId, #doc{revs=Revs}=Doc) ->
-    validate_attachment_names(Doc),
-    Rev = case couch_httpd:qs_value(Req, "rev") of
-    undefined ->
-        undefined;
-    QSRev ->
-        couch_doc:parse_rev(QSRev)
-    end,
-    Revs2 =
-    case Revs of
-    {Start, [RevId|_]} ->
-        if Rev /= undefined andalso Rev /= {Start, RevId} ->
-            throw({bad_request, "Document rev from request body and query "
-                   "string have different values"});
-        true ->
-            case extract_header_rev(Req, {Start, RevId}) of
-            missing_rev -> {0, []};
-            _ -> Revs
-            end
-        end;
-    _ ->
-        case extract_header_rev(Req, Rev) of
-        missing_rev -> {0, []};
-        {Pos, RevId2} -> {Pos, [RevId2]}
-        end
-    end,
-    Doc#doc{id=DocId, revs=Revs2};
-couch_doc_from_req(Req, DocId, Json) ->
-    couch_doc_from_req(Req, DocId, couch_doc:from_json_obj(Json)).
-
-% Useful for debugging
-% couch_doc_open(Db, DocId) ->
-%   couch_doc_open(Db, DocId, nil, []).
-
-couch_doc_open(Db, DocId, Rev, Options) ->
-    case Rev of
-    nil -> % open most recent rev
-        case couch_db:open_doc(Db, DocId, Options) of
-        {ok, Doc} ->
-            Doc;
-         Error ->
-             throw(Error)
-         end;
-  _ -> % open a specific rev (deletions come back as stubs)
-      case couch_db:open_doc_revs(Db, DocId, [Rev], Options) of
-          {ok, [{ok, Doc}]} ->
-              Doc;
-          {ok, [{{not_found, missing}, Rev}]} ->
-              throw(not_found);
-          {ok, [Else]} ->
-              throw(Else)
-      end
-  end.
-
-% Attachment request handlers
-
-db_attachment_req(#httpd{method='GET',mochi_req=MochiReq}=Req, Db, DocId, FileNameParts) ->
-    FileName = list_to_binary(mochiweb_util:join(lists:map(fun binary_to_list/1, FileNameParts),"/")),
-    #doc_query_args{
-        rev=Rev,
-        options=Options
-    } = parse_doc_query(Req),
-    #doc{
-        atts=Atts
-    } = Doc = couch_doc_open(Db, DocId, Rev, Options),
-    case [A || A <- Atts, A#att.name == FileName] of
-    [] ->
-        throw({not_found, "Document is missing attachment"});
-    [#att{type=Type, encoding=Enc, disk_len=DiskLen, att_len=AttLen}=Att] ->
-        Etag = case Att#att.md5 of
-            <<>> -> couch_httpd:doc_etag(Doc);
-            Md5 -> "\"" ++ ?b2l(base64:encode(Md5)) ++ "\""
-        end,
-        ReqAcceptsAttEnc = lists:member(
-           atom_to_list(Enc),
-           couch_httpd:accepted_encodings(Req)
-        ),
-        Len = case {Enc, ReqAcceptsAttEnc} of
-        {identity, _} ->
-            % stored and served in identity form
-            DiskLen;
-        {_, false} when DiskLen =/= AttLen ->
-            % Stored encoded, but client doesn't accept the encoding we used,
-            % so we need to decode on the fly.  DiskLen is the identity length
-            % of the attachment.
-            DiskLen;
-        {_, true} ->
-            % Stored and served encoded.  AttLen is the encoded length.
-            AttLen;
-        _ ->
-            % We received an encoded attachment and stored it as such, so we
-            % don't know the identity length.  The client doesn't accept the
-            % encoding, and since we cannot serve a correct Content-Length
-            % header we'll fall back to a chunked response.
-            undefined
-        end,
-        Headers = [
-            {"ETag", Etag},
-            {"Cache-Control", "must-revalidate"},
-            {"Content-Type", binary_to_list(Type)}
-        ] ++ case ReqAcceptsAttEnc of
-        true when Enc =/= identity ->
-            % RFC 2616 says that the 'identify' encoding should not be used in
-            % the Content-Encoding header
-            [{"Content-Encoding", atom_to_list(Enc)}];
-        _ ->
-            []
-        end ++ case Enc of
-            identity ->
-                [{"Accept-Ranges", "bytes"}];
-            _ ->
-                [{"Accept-Ranges", "none"}]
-        end,
-        AttFun = case ReqAcceptsAttEnc of
-        false ->
-            fun couch_doc:att_foldl_decode/3;
-        true ->
-            fun couch_doc:att_foldl/3
-        end,
-        couch_httpd:etag_respond(
-            Req,
-            Etag,
-            fun() ->
-                case Len of
-                undefined ->
-                    {ok, Resp} = start_chunked_response(Req, 200, Headers),
-                    AttFun(Att, fun(Seg, _) -> send_chunk(Resp, Seg) end, {ok, Resp}),
-                    last_chunk(Resp);
-                _ ->
-                    Ranges = parse_ranges(MochiReq:get(range), Len),
-                    case {Enc, Ranges} of
-                        {identity, [{From, To}]} ->
-                            Headers1 = [{"Content-Range", make_content_range(From, To, Len)}]
-                                ++ Headers,
-                            {ok, Resp} = start_response_length(Req, 206, Headers1, To - From + 1),
-                            couch_doc:range_att_foldl(Att, From, To + 1,
-                                fun(Seg, _) -> send(Resp, Seg) end, {ok, Resp});
-                        {identity, Ranges} when is_list(Ranges) andalso length(Ranges) < 10 ->
-                            send_ranges_multipart(Req, Type, Len, Att, Ranges);
-                        _ ->
-                            Headers1 = Headers ++
-                                if Enc =:= identity orelse ReqAcceptsAttEnc =:= true ->
-                                    [{"Content-MD5", base64:encode(Att#att.md5)}];
-                                true ->
-                                    []
-                            end,
-                            {ok, Resp} = start_response_length(Req, 200, Headers1, Len),
-                            AttFun(Att, fun(Seg, _) -> send(Resp, Seg) end, {ok, Resp})
-                    end
-                end
-            end
-        )
-    end;
-
-
-db_attachment_req(#httpd{method=Method,mochi_req=MochiReq}=Req, Db, DocId, FileNameParts)
-        when (Method == 'PUT') or (Method == 'DELETE') ->
-    FileName = validate_attachment_name(
-                    mochiweb_util:join(
-                        lists:map(fun binary_to_list/1,
-                            FileNameParts),"/")),
-
-    NewAtt = case Method of
-        'DELETE' ->
-            [];
-        _ ->
-            [#att{
-                name = FileName,
-                type = case couch_httpd:header_value(Req,"Content-Type") of
-                    undefined ->
-                        % We could throw an error here or guess by the FileName.
-                        % Currently, just giving it a default.
-                        <<"application/octet-stream">>;
-                    CType ->
-                        list_to_binary(CType)
-                    end,
-                data = case couch_httpd:body_length(Req) of
-                    undefined ->
-                        <<"">>;
-                    {unknown_transfer_encoding, Unknown} ->
-                        exit({unknown_transfer_encoding, Unknown});
-                    chunked ->
-                        fun(MaxChunkSize, ChunkFun, InitState) ->
-                            couch_httpd:recv_chunked(Req, MaxChunkSize,
-                                ChunkFun, InitState)
-                        end;
-                    0 ->
-                        <<"">>;
-                    Length when is_integer(Length) ->
-                        Expect = case couch_httpd:header_value(Req, "expect") of
-                                     undefined ->
-                                         undefined;
-                                     Value when is_list(Value) ->
-                                         string:to_lower(Value)
-                                 end,
-                        case Expect of
-                            "100-continue" ->
-                                MochiReq:start_raw_response({100, gb_trees:empty()});
-                            _Else ->
-                                ok
-                        end,
-
-
-                        fun(Size) -> couch_httpd:recv(Req, Size) end
-                    end,
-                att_len = case couch_httpd:header_value(Req,"Content-Length") of
-                    undefined ->
-                        undefined;
-                    Length ->
-                        list_to_integer(Length)
-                    end,
-                md5 = get_md5_header(Req),
-                encoding = case string:to_lower(string:strip(
-                    couch_httpd:header_value(Req,"Content-Encoding","identity")
-                )) of
-                "identity" ->
-                   identity;
-                "gzip" ->
-                   gzip;
-                _ ->
-                   throw({
-                       bad_ctype,
-                       "Only gzip and identity content-encodings are supported"
-                   })
-                end
-            }]
-    end,
-
-    Doc = case extract_header_rev(Req, couch_httpd:qs_value(Req, "rev")) of
-        missing_rev -> % make the new doc
-            couch_doc:validate_docid(DocId),
-            #doc{id=DocId};
-        Rev ->
-            case couch_db:open_doc_revs(Db, DocId, [Rev], []) of
-                {ok, [{ok, Doc0}]} -> Doc0;
-                {ok, [{{not_found, missing}, Rev}]} -> throw(conflict);
-                {ok, [Error]} -> throw(Error)
-            end
-    end,
-
-    #doc{atts=Atts} = Doc,
-    DocEdited = Doc#doc{
-        atts = NewAtt ++ [A || A <- Atts, A#att.name /= FileName]
-    },
-
-    Headers = case Method of
-    'DELETE' ->
-        [];
-    _ ->
-        [{"Location", absolute_uri(Req, "/" ++
-            ?b2l(Db#db.name) ++ "/" ++
-            ?b2l(DocId) ++ "/" ++
-            ?b2l(FileName)
-        )}]
-    end,
-    update_doc(Req, Db, DocId, DocEdited, Headers);
-
-db_attachment_req(Req, _Db, _DocId, _FileNameParts) ->
-    send_method_not_allowed(Req, "DELETE,GET,HEAD,PUT").
-
-parse_ranges(undefined, _Len) ->
-    undefined;
-parse_ranges(fail, _Len) ->
-    undefined;
-parse_ranges(Ranges, Len) ->
-    parse_ranges(Ranges, Len, []).
-
-parse_ranges([], _Len, Acc) ->
-    lists:reverse(Acc);
-parse_ranges([{0, none}|_], _Len, _Acc) ->
-    undefined;
-parse_ranges([{From, To}|_], _Len, _Acc) when is_integer(From) andalso is_integer(To) andalso To < From ->
-    throw(requested_range_not_satisfiable);
-parse_ranges([{From, To}|Rest], Len, Acc) when is_integer(To) andalso To >= Len ->
-    parse_ranges([{From, Len-1}] ++ Rest, Len, Acc);
-parse_ranges([{none, To}|Rest], Len, Acc) ->
-    parse_ranges([{Len - To, Len - 1}] ++ Rest, Len, Acc);
-parse_ranges([{From, none}|Rest], Len, Acc) ->
-    parse_ranges([{From, Len - 1}] ++ Rest, Len, Acc);
-parse_ranges([{From,To}|Rest], Len, Acc) ->
-    parse_ranges(Rest, Len, [{From, To}] ++ Acc).
-
-get_md5_header(Req) ->
-    ContentMD5 = couch_httpd:header_value(Req, "Content-MD5"),
-    Length = couch_httpd:body_length(Req),
-    Trailer = couch_httpd:header_value(Req, "Trailer"),
-    case {ContentMD5, Length, Trailer} of
-        _ when is_list(ContentMD5) orelse is_binary(ContentMD5) ->
-            base64:decode(ContentMD5);
-        {_, chunked, undefined} ->
-            <<>>;
-        {_, chunked, _} ->
-            case re:run(Trailer, "\\bContent-MD5\\b", [caseless]) of
-                {match, _} ->
-                    md5_in_footer;
-                _ ->
-                    <<>>
-            end;
-        _ ->
-            <<>>
-    end.
-
-parse_doc_query(Req) ->
-    lists:foldl(fun({Key,Value}, Args) ->
-        case {Key, Value} of
-        {"attachments", "true"} ->
-            Options = [attachments | Args#doc_query_args.options],
-            Args#doc_query_args{options=Options};
-        {"meta", "true"} ->
-            Options = [revs_info, conflicts, deleted_conflicts | Args#doc_query_args.options],
-            Args#doc_query_args{options=Options};
-        {"revs", "true"} ->
-            Options = [revs | Args#doc_query_args.options],
-            Args#doc_query_args{options=Options};
-        {"local_seq", "true"} ->
-            Options = [local_seq | Args#doc_query_args.options],
-            Args#doc_query_args{options=Options};
-        {"revs_info", "true"} ->
-            Options = [revs_info | Args#doc_query_args.options],
-            Args#doc_query_args{options=Options};
-        {"conflicts", "true"} ->
-            Options = [conflicts | Args#doc_query_args.options],
-            Args#doc_query_args{options=Options};
-        {"deleted_conflicts", "true"} ->
-            Options = [deleted_conflicts | Args#doc_query_args.options],
-            Args#doc_query_args{options=Options};
-        {"rev", Rev} ->
-            Args#doc_query_args{rev=couch_doc:parse_rev(Rev)};
-        {"open_revs", "all"} ->
-            Args#doc_query_args{open_revs=all};
-        {"open_revs", RevsJsonStr} ->
-            JsonArray = ?JSON_DECODE(RevsJsonStr),
-            Args#doc_query_args{open_revs=couch_doc:parse_revs(JsonArray)};
-        {"latest", "true"} ->
-            Options = [latest | Args#doc_query_args.options],
-            Args#doc_query_args{options=Options};
-        {"atts_since", RevsJsonStr} ->
-            JsonArray = ?JSON_DECODE(RevsJsonStr),
-            Args#doc_query_args{atts_since = couch_doc:parse_revs(JsonArray)};
-        {"new_edits", "false"} ->
-            Args#doc_query_args{update_type=replicated_changes};
-        {"new_edits", "true"} ->
-            Args#doc_query_args{update_type=interactive_edit};
-        {"att_encoding_info", "true"} ->
-            Options = [att_encoding_info | Args#doc_query_args.options],
-            Args#doc_query_args{options=Options};
-        _Else -> % unknown key value pair, ignore.
-            Args
-        end
-    end, #doc_query_args{}, couch_httpd:qs(Req)).
-
-parse_changes_query(Req, Db) ->
-    ChangesArgs = lists:foldl(fun({Key, Value}, Args) ->
-        case {string:to_lower(Key), Value} of
-        {"feed", _} ->
-            Args#changes_args{feed=Value};
-        {"descending", "true"} ->
-            Args#changes_args{dir=rev};
-        {"since", "now"} ->
-            UpdateSeq = couch_util:with_db(Db#db.name, fun(WDb) ->
-                                        couch_db:get_update_seq(WDb)
-                                end),
-            Args#changes_args{since=UpdateSeq};
-        {"since", _} ->
-            Args#changes_args{since=list_to_integer(Value)};
-        {"last-event-id", _} ->
-            Args#changes_args{since=list_to_integer(Value)};
-        {"limit", _} ->
-            Args#changes_args{limit=list_to_integer(Value)};
-        {"style", _} ->
-            Args#changes_args{style=list_to_existing_atom(Value)};
-        {"heartbeat", "true"} ->
-            Args#changes_args{heartbeat=true};
-        {"heartbeat", _} ->
-            Args#changes_args{heartbeat=list_to_integer(Value)};
-        {"timeout", _} ->
-            Args#changes_args{timeout=list_to_integer(Value)};
-        {"include_docs", "true"} ->
-            Args#changes_args{include_docs=true};
-        {"attachments", "true"} ->
-            Opts = Args#changes_args.doc_options,
-            Args#changes_args{doc_options=[attachments|Opts]};
-        {"att_encoding_info", "true"} ->
-            Opts = Args#changes_args.doc_options,
-            Args#changes_args{doc_options=[att_encoding_info|Opts]};
-        {"conflicts", "true"} ->
-            Args#changes_args{conflicts=true};
-        {"filter", _} ->
-            Args#changes_args{filter=Value};
-        _Else -> % unknown key value pair, ignore.
-            Args
-        end
-    end, #changes_args{}, couch_httpd:qs(Req)),
-    %% if it's an EventSource request with a Last-event-ID header
-    %% that should override the `since` query string, since it's
-    %% probably the browser reconnecting.
-    case ChangesArgs#changes_args.feed of
-        "eventsource" ->
-            case couch_httpd:header_value(Req, "last-event-id") of
-                undefined ->
-                    ChangesArgs;
-                Value ->
-                    ChangesArgs#changes_args{since=list_to_integer(Value)}
-            end;
-        _ ->
-            ChangesArgs
-    end.
-
-extract_header_rev(Req, ExplicitRev) when is_binary(ExplicitRev) or is_list(ExplicitRev)->
-    extract_header_rev(Req, couch_doc:parse_rev(ExplicitRev));
-extract_header_rev(Req, ExplicitRev) ->
-    Etag = case couch_httpd:header_value(Req, "If-Match") of
-        undefined -> undefined;
-        Value -> couch_doc:parse_rev(string:strip(Value, both, $"))
-    end,
-    case {ExplicitRev, Etag} of
-    {undefined, undefined} -> missing_rev;
-    {_, undefined} -> ExplicitRev;
-    {undefined, _} -> Etag;
-    _ when ExplicitRev == Etag -> Etag;
-    _ ->
-        throw({bad_request, "Document rev and etag have different values"})
-    end.
-
-
-parse_copy_destination_header(Req) ->
-    case couch_httpd:header_value(Req, "Destination") of
-    undefined ->
-        throw({bad_request, "Destination header is mandatory for COPY."});
-    Destination ->
-        case re:run(Destination, "^https?://", [{capture, none}]) of
-        match ->
-            throw({bad_request, "Destination URL must be relative."});
-        nomatch ->
-            % see if ?rev=revid got appended to the Destination header
-            case re:run(Destination, "\\?", [{capture, none}]) of
-            nomatch ->
-                {list_to_binary(Destination), {0, []}};
-            match ->
-                [DocId, RevQs] = re:split(Destination, "\\?", [{return, list}]),
-                [_RevQueryKey, Rev] = re:split(RevQs, "=", [{return, list}]),
-                {Pos, RevId} = couch_doc:parse_rev(Rev),
-                {list_to_binary(DocId), {Pos, [RevId]}}
-            end
-        end
-    end.
-
-validate_attachment_names(Doc) ->
-    lists:foreach(fun(#att{name=Name}) ->
-        validate_attachment_name(Name)
-    end, Doc#doc.atts).
-
-validate_attachment_name(Name) when is_list(Name) ->
-    validate_attachment_name(list_to_binary(Name));
-validate_attachment_name(<<"_",_/binary>>) ->
-    throw({bad_request, <<"Attachment name can't start with '_'">>});
-validate_attachment_name(Name) ->
-    case couch_util:validate_utf8(Name) of
-        true -> Name;
-        false -> throw({bad_request, <<"Attachment name is not UTF-8 encoded">>})
-    end.
-

http://git-wip-us.apache.org/repos/asf/couchdb/blob/c0855434/apps/couch_httpd/src/couch_httpd_external.erl
----------------------------------------------------------------------
diff --git a/apps/couch_httpd/src/couch_httpd_external.erl b/apps/couch_httpd/src/couch_httpd_external.erl
deleted file mode 100644
index a5d4acc..0000000
--- a/apps/couch_httpd/src/couch_httpd_external.erl
+++ /dev/null
@@ -1,177 +0,0 @@
-% Licensed 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.
-
--module(couch_httpd_external).
-
--export([handle_external_req/2, handle_external_req/3]).
--export([send_external_response/2, json_req_obj/2, json_req_obj/3]).
--export([default_or_content_type/2, parse_external_response/1]).
-
--import(couch_httpd,[send_error/4]).
-
--include_lib("couch/include/couch_db.hrl").
-
-% handle_external_req/2
-% for the old type of config usage:
-% _external = {couch_httpd_external, handle_external_req}
-% with urls like
-% /db/_external/action/design/name
-handle_external_req(#httpd{
-                        path_parts=[_DbName, _External, UrlName | _Path]
-                    }=HttpReq, Db) ->
-    process_external_req(HttpReq, Db, UrlName);
-handle_external_req(#httpd{path_parts=[_, _]}=Req, _Db) ->
-    send_error(Req, 404, <<"external_server_error">>, <<"No server name specified.">>);
-handle_external_req(Req, _) ->
-    send_error(Req, 404, <<"external_server_error">>, <<"Broken assumption">>).
-
-% handle_external_req/3
-% for this type of config usage:
-% _action = {couch_httpd_external, handle_external_req, <<"action">>}
-% with urls like
-% /db/_action/design/name
-handle_external_req(HttpReq, Db, Name) ->
-    process_external_req(HttpReq, Db, Name).
-
-process_external_req(HttpReq, Db, Name) ->
-
-    Response = couch_external_manager:execute(binary_to_list(Name),
-        json_req_obj(HttpReq, Db)),
-
-    case Response of
-    {unknown_external_server, Msg} ->
-        send_error(HttpReq, 404, <<"external_server_error">>, Msg);
-    _ ->
-        send_external_response(HttpReq, Response)
-    end.
-json_req_obj(Req, Db) -> json_req_obj(Req, Db, null).
-json_req_obj(#httpd{mochi_req=Req,
-               method=Method,
-               requested_path_parts=RequestedPath,
-               path_parts=Path,
-               req_body=ReqBody
-            }, Db, DocId) ->
-    Body = case ReqBody of
-        undefined ->
-            MaxSize = list_to_integer(
-                couch_config:get("couchdb", "max_document_size", "4294967296")),
-            Req:recv_body(MaxSize);
-        Else -> Else
-    end,
-    ParsedForm = case Req:get_primary_header_value("content-type") of
-        "application/x-www-form-urlencoded" ++ _ ->
-            case Body of
-            undefined -> [];
-            _ -> mochiweb_util:parse_qs(Body)
-            end;
-        _ ->
-            []
-    end,
-    Headers = Req:get(headers),
-    Hlist = mochiweb_headers:to_list(Headers),
-    {ok, Info} = couch_db:get_db_info(Db),
-
-% add headers...
-    {[{<<"info">>, {Info}},
-        {<<"id">>, DocId},
-        {<<"uuid">>, couch_uuids:new()},
-        {<<"method">>, Method},
-        {<<"requested_path">>, RequestedPath},
-        {<<"path">>, Path},
-        {<<"raw_path">>, ?l2b(Req:get(raw_path))},
-        {<<"query">>, json_query_keys(to_json_terms(Req:parse_qs()))},
-        {<<"headers">>, to_json_terms(Hlist)},
-        {<<"body">>, Body},
-        {<<"peer">>, ?l2b(Req:get(peer))},
-        {<<"form">>, to_json_terms(ParsedForm)},
-        {<<"cookie">>, to_json_terms(Req:parse_cookie())},
-        {<<"userCtx">>, couch_util:json_user_ctx(Db)},
-        {<<"secObj">>, couch_db:get_security(Db)}]}.
-
-to_json_terms(Data) ->
-    to_json_terms(Data, []).
-
-to_json_terms([], Acc) ->
-    {lists:reverse(Acc)};
-to_json_terms([{Key, Value} | Rest], Acc) when is_atom(Key) ->
-    to_json_terms(Rest, [{list_to_binary(atom_to_list(Key)), list_to_binary(Value)} | Acc]);
-to_json_terms([{Key, Value} | Rest], Acc) ->
-    to_json_terms(Rest, [{list_to_binary(Key), list_to_binary(Value)} | Acc]).
-
-json_query_keys({Json}) ->
-    json_query_keys(Json, []).
-json_query_keys([], Acc) ->
-    {lists:reverse(Acc)};
-json_query_keys([{<<"startkey">>, Value} | Rest], Acc) ->
-    json_query_keys(Rest, [{<<"startkey">>, ?JSON_DECODE(Value)}|Acc]);
-json_query_keys([{<<"endkey">>, Value} | Rest], Acc) ->
-    json_query_keys(Rest, [{<<"endkey">>, ?JSON_DECODE(Value)}|Acc]);
-json_query_keys([{<<"key">>, Value} | Rest], Acc) ->
-    json_query_keys(Rest, [{<<"key">>, ?JSON_DECODE(Value)}|Acc]);
-json_query_keys([Term | Rest], Acc) ->
-    json_query_keys(Rest, [Term|Acc]).
-
-send_external_response(Req, Response) ->
-    #extern_resp_args{
-        code = Code,
-        data = Data,
-        ctype = CType,
-        headers = Headers,
-        json = Json
-    } = parse_external_response(Response),
-    Headers1 = default_or_content_type(CType, Headers),
-    case Json of
-    nil ->
-        couch_httpd:send_response(Req, Code, Headers1, Data);
-    Json ->
-        couch_httpd:send_json(Req, Code, Headers1, Json)
-    end.
-
-parse_external_response({Response}) ->
-    lists:foldl(fun({Key,Value}, Args) ->
-        case {Key, Value} of
-            {"", _} ->
-                Args;
-            {<<"code">>, Value} ->
-                Args#extern_resp_args{code=Value};
-            {<<"stop">>, true} ->
-                Args#extern_resp_args{stop=true};
-            {<<"json">>, Value} ->
-                Args#extern_resp_args{
-                    json=Value,
-                    ctype="application/json"};
-            {<<"body">>, Value} ->
-                Args#extern_resp_args{data=Value, ctype="text/html; charset=utf-8"};
-            {<<"base64">>, Value} ->
-                Args#extern_resp_args{
-                    data=base64:decode(Value),
-                    ctype="application/binary"
-                };
-            {<<"headers">>, {Headers}} ->
-                NewHeaders = lists:map(fun({Header, HVal}) ->
-                    {binary_to_list(Header), binary_to_list(HVal)}
-                end, Headers),
-                Args#extern_resp_args{headers=NewHeaders};
-            _ -> % unknown key
-                Msg = lists:flatten(io_lib:format("Invalid data from external server: ~p", [{Key, Value}])),
-                throw({external_response_error, Msg})
-            end
-        end, #extern_resp_args{}, Response).
-
-default_or_content_type(DefaultContentType, Headers) ->
-    IsContentType = fun({X, _}) -> string:to_lower(X) == "content-type" end,
-    case lists:any(IsContentType, Headers) of
-    false ->
-        [{"Content-Type", DefaultContentType} | Headers];
-    true ->
-        Headers
-    end.

http://git-wip-us.apache.org/repos/asf/couchdb/blob/c0855434/apps/couch_httpd/src/couch_httpd_misc_handlers.erl
----------------------------------------------------------------------
diff --git a/apps/couch_httpd/src/couch_httpd_misc_handlers.erl b/apps/couch_httpd/src/couch_httpd_misc_handlers.erl
deleted file mode 100644
index 293ef00..0000000
--- a/apps/couch_httpd/src/couch_httpd_misc_handlers.erl
+++ /dev/null
@@ -1,318 +0,0 @@
-% Licensed 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.
-
--module(couch_httpd_misc_handlers).
-
--export([handle_welcome_req/2,handle_favicon_req/2,handle_utils_dir_req/2,
-    handle_all_dbs_req/1,handle_restart_req/1,
-    handle_uuids_req/1,handle_config_req/1,handle_log_req/1,
-    handle_task_status_req/1, handle_file_req/2]).
-
--export([increment_update_seq_req/2]).
-
-
--include_lib("couch/include/couch_db.hrl").
-
--import(couch_httpd,
-    [send_json/2,send_json/3,send_json/4,send_method_not_allowed/2,
-    start_json_response/2,send_chunk/2,last_chunk/1,end_json_response/1,
-    start_chunked_response/3, send_error/4]).
-
-% httpd global handlers
-
-handle_welcome_req(#httpd{method='GET'}=Req, WelcomeMessage) ->
-    send_json(Req, {[
-        {couchdb, WelcomeMessage},
-        {uuid, couch_server:get_uuid()},
-        {version, list_to_binary(couch_server:get_version())}
-        ] ++ case couch_config:get("vendor") of
-        [] ->
-            [];
-        Properties ->
-            [{vendor, {[{?l2b(K), ?l2b(V)} || {K, V} <- Properties]}}]
-        end
-    });
-handle_welcome_req(Req, _) ->
-    send_method_not_allowed(Req, "GET,HEAD").
-
-handle_favicon_req(#httpd{method='GET'}=Req, DocumentRoot) ->
-    {{Year,Month,Day},Time} = erlang:universaltime(),
-    OneYearFromNow = {{Year+1,Month,Day},Time},
-    CachingHeaders = [
-        %favicon should expire a year from now
-        {"Cache-Control", "public, max-age=31536000"},
-        {"Expires", couch_util:rfc1123_date(OneYearFromNow)}
-    ],
-    couch_httpd:serve_file(Req, "favicon.ico", DocumentRoot, CachingHeaders);
-
-handle_favicon_req(Req, _) ->
-    send_method_not_allowed(Req, "GET,HEAD").
-
-handle_file_req(#httpd{method='GET'}=Req, Document) ->
-    couch_httpd:serve_file(Req, filename:basename(Document), filename:dirname(Document));
-
-handle_file_req(Req, _) ->
-    send_method_not_allowed(Req, "GET,HEAD").
-
-handle_utils_dir_req(#httpd{method='GET'}=Req, DocumentRoot) ->
-    "/" ++ UrlPath = couch_httpd:path(Req),
-    case couch_httpd:partition(UrlPath) of
-    {_ActionKey, "/", RelativePath} ->
-        % GET /_utils/path or GET /_utils/
-        CachingHeaders =
-                [{"Cache-Control", "private, must-revalidate"}],
-        couch_httpd:serve_file(Req, RelativePath, DocumentRoot, CachingHeaders);
-    {_ActionKey, "", _RelativePath} ->
-        % GET /_utils
-        RedirectPath = couch_httpd:path(Req) ++ "/",
-        couch_httpd:send_redirect(Req, RedirectPath)
-    end;
-handle_utils_dir_req(Req, _) ->
-    send_method_not_allowed(Req, "GET,HEAD").
-
-handle_all_dbs_req(#httpd{method='GET'}=Req) ->
-    {ok, DbNames} = couch_server:all_databases(),
-    send_json(Req, DbNames);
-handle_all_dbs_req(Req) ->
-    send_method_not_allowed(Req, "GET,HEAD").
-
-
-handle_task_status_req(#httpd{method='GET'}=Req) ->
-    ok = couch_httpd:verify_is_server_admin(Req),
-    % convert the list of prop lists to a list of json objects
-    send_json(Req, [{Props} || Props <- couch_task_status:all()]);
-handle_task_status_req(Req) ->
-    send_method_not_allowed(Req, "GET,HEAD").
-
-
-handle_restart_req(#httpd{method='POST'}=Req) ->
-    couch_httpd:validate_ctype(Req, "application/json"),
-    ok = couch_httpd:verify_is_server_admin(Req),
-    Result = send_json(Req, 202, {[{ok, true}]}),
-    couch_sup:restart_core_server(),
-    Result;
-handle_restart_req(Req) ->
-    send_method_not_allowed(Req, "POST").
-
-
-handle_uuids_req(#httpd{method='GET'}=Req) ->
-    Count = list_to_integer(couch_httpd:qs_value(Req, "count", "1")),
-    UUIDs = [couch_uuids:new() || _ <- lists:seq(1, Count)],
-    Etag = couch_httpd:make_etag(UUIDs),
-    couch_httpd:etag_respond(Req, Etag, fun() ->
-        CacheBustingHeaders = [
-            {"Date", couch_util:rfc1123_date()},
-            {"Cache-Control", "no-cache"},
-            % Past date, ON PURPOSE!
-            {"Expires", "Fri, 01 Jan 1990 00:00:00 GMT"},
-            {"Pragma", "no-cache"},
-            {"ETag", Etag}
-        ],
-        send_json(Req, 200, CacheBustingHeaders, {[{<<"uuids">>, UUIDs}]})
-    end);
-handle_uuids_req(Req) ->
-    send_method_not_allowed(Req, "GET").
-
-
-% Config request handler
-
-
-% GET /_config/
-% GET /_config
-handle_config_req(#httpd{method='GET', path_parts=[_]}=Req) ->
-    ok = couch_httpd:verify_is_server_admin(Req),
-    Grouped = lists:foldl(fun({{Section, Key}, Value}, Acc) ->
-        case dict:is_key(Section, Acc) of
-        true ->
-            dict:append(Section, {list_to_binary(Key), list_to_binary(Value)}, Acc);
-        false ->
-            dict:store(Section, [{list_to_binary(Key), list_to_binary(Value)}], Acc)
-        end
-    end, dict:new(), couch_config:all()),
-    KVs = dict:fold(fun(Section, Values, Acc) ->
-        [{list_to_binary(Section), {Values}} | Acc]
-    end, [], Grouped),
-    send_json(Req, 200, {KVs});
-% GET /_config/Section
-handle_config_req(#httpd{method='GET', path_parts=[_,Section]}=Req) ->
-    ok = couch_httpd:verify_is_server_admin(Req),
-    KVs = [{list_to_binary(Key), list_to_binary(Value)}
-            || {Key, Value} <- couch_config:get(Section)],
-    send_json(Req, 200, {KVs});
-% GET /_config/Section/Key
-handle_config_req(#httpd{method='GET', path_parts=[_, Section, Key]}=Req) ->
-    ok = couch_httpd:verify_is_server_admin(Req),
-    case couch_config:get(Section, Key, null) of
-    null ->
-        throw({not_found, unknown_config_value});
-    Value ->
-        send_json(Req, 200, list_to_binary(Value))
-    end;
-% PUT or DELETE /_config/Section/Key
-handle_config_req(#httpd{method=Method, path_parts=[_, Section, Key]}=Req)
-      when (Method == 'PUT') or (Method == 'DELETE') ->
-    ok = couch_httpd:verify_is_server_admin(Req),
-    Persist = couch_httpd:header_value(Req, "X-Couch-Persist") /= "false",
-    case couch_config:get(<<"httpd">>, <<"config_whitelist">>, null) of
-        null ->
-            % No whitelist; allow all changes.
-            handle_approved_config_req(Req, Persist);
-        WhitelistValue ->
-            % Provide a failsafe to protect against inadvertently locking
-            % onesself out of the config by supplying a syntactically-incorrect
-            % Erlang term. To intentionally lock down the whitelist, supply a
-            % well-formed list which does not include the whitelist config
-            % variable itself.
-            FallbackWhitelist = [{<<"httpd">>, <<"config_whitelist">>}],
-
-            Whitelist = case couch_util:parse_term(WhitelistValue) of
-                {ok, Value} when is_list(Value) ->
-                    Value;
-                {ok, _NonListValue} ->
-                    FallbackWhitelist;
-                {error, _} ->
-                    [{WhitelistSection, WhitelistKey}] = FallbackWhitelist,
-                    ?LOG_ERROR("Only whitelisting ~s/~s due to error parsing: ~p",
-                               [WhitelistSection, WhitelistKey, WhitelistValue]),
-                    FallbackWhitelist
-            end,
-
-            IsRequestedKeyVal = fun(Element) ->
-                case Element of
-                    {A, B} ->
-                        % For readability, tuples may be used instead of binaries
-                        % in the whitelist.
-                        case {couch_util:to_binary(A), couch_util:to_binary(B)} of
-                            {Section, Key} ->
-                                true;
-                            {Section, <<"*">>} ->
-                                true;
-                            _Else ->
-                                false
-                        end;
-                    _Else ->
-                        false
-                end
-            end,
-
-            case lists:any(IsRequestedKeyVal, Whitelist) of
-                true ->
-                    % Allow modifying this whitelisted variable.
-                    handle_approved_config_req(Req, Persist);
-                _NotWhitelisted ->
-                    % Disallow modifying this non-whitelisted variable.
-                    send_error(Req, 400, <<"modification_not_allowed">>,
-                               ?l2b("This config variable is read-only"))
-            end
-    end;
-handle_config_req(Req) ->
-    send_method_not_allowed(Req, "GET,PUT,DELETE").
-
-% PUT /_config/Section/Key
-% "value"
-handle_approved_config_req(Req, Persist) ->
-    Query = couch_httpd:qs(Req),
-    UseRawValue = case lists:keyfind("raw", 1, Query) of
-    false            -> false; % Not specified
-    {"raw", ""}      -> false; % Specified with no value, i.e. "?raw" and "?raw="
-    {"raw", "false"} -> false;
-    {"raw", "true"}  -> true;
-    {"raw", InvalidValue} -> InvalidValue
-    end,
-    handle_approved_config_req(Req, Persist, UseRawValue).
-
-handle_approved_config_req(#httpd{method='PUT', path_parts=[_, Section, Key]}=Req,
-                           Persist, UseRawValue)
-        when UseRawValue =:= false orelse UseRawValue =:= true ->
-    RawValue = couch_httpd:json_body(Req),
-    Value = case UseRawValue of
-    true ->
-        % Client requests no change to the provided value.
-        RawValue;
-    false ->
-        % Pre-process the value as necessary.
-        case Section of
-        <<"admins">> ->
-            couch_passwords:hash_admin_password(RawValue);
-        _ ->
-            RawValue
-        end
-    end,
-
-    OldValue = couch_config:get(Section, Key, ""),
-    case couch_config:set(Section, Key, ?b2l(Value), Persist) of
-    ok ->
-        send_json(Req, 200, list_to_binary(OldValue));
-    Error ->
-        throw(Error)
-    end;
-
-handle_approved_config_req(#httpd{method='PUT'}=Req, _Persist, UseRawValue) ->
-    Err = io_lib:format("Bad value for 'raw' option: ~s", [UseRawValue]),
-    send_json(Req, 400, {[{error, ?l2b(Err)}]});
-
-% DELETE /_config/Section/Key
-handle_approved_config_req(#httpd{method='DELETE',path_parts=[_,Section,Key]}=Req,
-                           Persist, _UseRawValue) ->
-    case couch_config:get(Section, Key, null) of
-    null ->
-        throw({not_found, unknown_config_value});
-    OldValue ->
-        couch_config:delete(Section, Key, Persist),
-        send_json(Req, 200, list_to_binary(OldValue))
-    end.
-
-
-% httpd db handlers
-
-increment_update_seq_req(#httpd{method='POST'}=Req, Db) ->
-    couch_httpd:validate_ctype(Req, "application/json"),
-    {ok, NewSeq} = couch_db:increment_update_seq(Db),
-    send_json(Req, {[{ok, true},
-        {update_seq, NewSeq}
-    ]});
-increment_update_seq_req(Req, _Db) ->
-    send_method_not_allowed(Req, "POST").
-
-% httpd log handlers
-
-handle_log_req(#httpd{method='GET'}=Req) ->
-    ok = couch_httpd:verify_is_server_admin(Req),
-    Bytes = list_to_integer(couch_httpd:qs_value(Req, "bytes", "1000")),
-    Offset = list_to_integer(couch_httpd:qs_value(Req, "offset", "0")),
-    Chunk = couch_log:read(Bytes, Offset),
-    {ok, Resp} = start_chunked_response(Req, 200, [
-        % send a plaintext response
-        {"Content-Type", "text/plain; charset=utf-8"},
-        {"Content-Length", integer_to_list(length(Chunk))}
-    ]),
-    send_chunk(Resp, Chunk),
-    last_chunk(Resp);
-handle_log_req(#httpd{method='POST'}=Req) ->
-    {PostBody} = couch_httpd:json_body_obj(Req),
-    Level = couch_util:get_value(<<"level">>, PostBody),
-    Message = ?b2l(couch_util:get_value(<<"message">>, PostBody)),
-    case Level of
-    <<"debug">> ->
-        ?LOG_DEBUG(Message, []),
-        send_json(Req, 200, {[{ok, true}]});
-    <<"info">> ->
-        ?LOG_INFO(Message, []),
-        send_json(Req, 200, {[{ok, true}]});
-    <<"error">> ->
-        ?LOG_ERROR(Message, []),
-        send_json(Req, 200, {[{ok, true}]});
-    _ ->
-        send_json(Req, 400, {[{error, ?l2b(io_lib:format("Unrecognized log level '~s'", [Level]))}]})
-    end;
-handle_log_req(Req) ->
-    send_method_not_allowed(Req, "GET,POST").


[03/57] [abbrv] remove couch_collate

Posted by be...@apache.org.
http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/utf8.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/utf8.h b/apps/couch_collate/platform/osx/icu/unicode/utf8.h
deleted file mode 100644
index 1142c44..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/utf8.h
+++ /dev/null
@@ -1,652 +0,0 @@
-/*
-*******************************************************************************
-*
-*   Copyright (C) 1999-2007, International Business Machines
-*   Corporation and others.  All Rights Reserved.
-*
-*******************************************************************************
-*   file name:  utf8.h
-*   encoding:   US-ASCII
-*   tab size:   8 (not used)
-*   indentation:4
-*
-*   created on: 1999sep13
-*   created by: Markus W. Scherer
-*/
-
-/**
- * \file
- * \brief C API: 8-bit Unicode handling macros
- * 
- * This file defines macros to deal with 8-bit Unicode (UTF-8) code units (bytes) and strings.
- * utf8.h is included by utf.h after unicode/umachine.h
- * and some common definitions.
- *
- * For more information see utf.h and the ICU User Guide Strings chapter
- * (http://icu-project.org/userguide/strings.html).
- *
- * <em>Usage:</em>
- * ICU coding guidelines for if() statements should be followed when using these macros.
- * Compound statements (curly braces {}) must be used  for if-else-while... 
- * bodies and all macro statements should be terminated with semicolon.
- */
-
-#ifndef __UTF8_H__
-#define __UTF8_H__
-
-/* utf.h must be included first. */
-#ifndef __UTF_H__
-#   include "unicode/utf.h"
-#endif
-
-/* internal definitions ----------------------------------------------------- */
-
-/**
- * \var utf8_countTrailBytes
- * Internal array with numbers of trail bytes for any given byte used in
- * lead byte position.
- * @internal
- */
-#ifdef U_UTF8_IMPL
-U_EXPORT const uint8_t 
-#elif defined(U_STATIC_IMPLEMENTATION) || defined(U_COMMON_IMPLEMENTATION)
-U_CFUNC const uint8_t
-#else
-U_CFUNC U_IMPORT const uint8_t /* U_IMPORT2? */ /*U_IMPORT*/ 
-#endif
-utf8_countTrailBytes[256];
-
-/**
- * Count the trail bytes for a UTF-8 lead byte.
- * @internal
- */
-#define U8_COUNT_TRAIL_BYTES(leadByte) (utf8_countTrailBytes[(uint8_t)leadByte])
-
-/**
- * Mask a UTF-8 lead byte, leave only the lower bits that form part of the code point value.
- * @internal
- */
-#define U8_MASK_LEAD_BYTE(leadByte, countTrailBytes) ((leadByte)&=(1<<(6-(countTrailBytes)))-1)
-
-/**
- * Function for handling "next code point" with error-checking.
- * @internal
- */
-U_INTERNAL UChar32 U_EXPORT2
-utf8_nextCharSafeBody(const uint8_t *s, int32_t *pi, int32_t length, UChar32 c, UBool strict);
-
-/**
- * Function for handling "append code point" with error-checking.
- * @internal
- */
-U_INTERNAL int32_t U_EXPORT2
-utf8_appendCharSafeBody(uint8_t *s, int32_t i, int32_t length, UChar32 c, UBool *pIsError);
-
-/**
- * Function for handling "previous code point" with error-checking.
- * @internal
- */
-U_INTERNAL UChar32 U_EXPORT2
-utf8_prevCharSafeBody(const uint8_t *s, int32_t start, int32_t *pi, UChar32 c, UBool strict);
-
-/**
- * Function for handling "skip backward one code point" with error-checking.
- * @internal
- */
-U_INTERNAL int32_t U_EXPORT2
-utf8_back1SafeBody(const uint8_t *s, int32_t start, int32_t i);
-
-/* single-code point definitions -------------------------------------------- */
-
-/**
- * Does this code unit (byte) encode a code point by itself (US-ASCII 0..0x7f)?
- * @param c 8-bit code unit (byte)
- * @return TRUE or FALSE
- * @stable ICU 2.4
- */
-#define U8_IS_SINGLE(c) (((c)&0x80)==0)
-
-/**
- * Is this code unit (byte) a UTF-8 lead byte?
- * @param c 8-bit code unit (byte)
- * @return TRUE or FALSE
- * @stable ICU 2.4
- */
-#define U8_IS_LEAD(c) ((uint8_t)((c)-0xc0)<0x3e)
-
-/**
- * Is this code unit (byte) a UTF-8 trail byte?
- * @param c 8-bit code unit (byte)
- * @return TRUE or FALSE
- * @stable ICU 2.4
- */
-#define U8_IS_TRAIL(c) (((c)&0xc0)==0x80)
-
-/**
- * How many code units (bytes) are used for the UTF-8 encoding
- * of this Unicode code point?
- * @param c 32-bit code point
- * @return 1..4, or 0 if c is a surrogate or not a Unicode code point
- * @stable ICU 2.4
- */
-#define U8_LENGTH(c) \
-    ((uint32_t)(c)<=0x7f ? 1 : \
-        ((uint32_t)(c)<=0x7ff ? 2 : \
-            ((uint32_t)(c)<=0xd7ff ? 3 : \
-                ((uint32_t)(c)<=0xdfff || (uint32_t)(c)>0x10ffff ? 0 : \
-                    ((uint32_t)(c)<=0xffff ? 3 : 4)\
-                ) \
-            ) \
-        ) \
-    )
-
-/**
- * The maximum number of UTF-8 code units (bytes) per Unicode code point (U+0000..U+10ffff).
- * @return 4
- * @stable ICU 2.4
- */
-#define U8_MAX_LENGTH 4
-
-/**
- * Get a code point from a string at a random-access offset,
- * without changing the offset.
- * The offset may point to either the lead byte or one of the trail bytes
- * for a code point, in which case the macro will read all of the bytes
- * for the code point.
- * The result is undefined if the offset points to an illegal UTF-8
- * byte sequence.
- * Iteration through a string is more efficient with U8_NEXT_UNSAFE or U8_NEXT.
- *
- * @param s const uint8_t * string
- * @param i string offset
- * @param c output UChar32 variable
- * @see U8_GET
- * @stable ICU 2.4
- */
-#define U8_GET_UNSAFE(s, i, c) { \
-    int32_t _u8_get_unsafe_index=(int32_t)(i); \
-    U8_SET_CP_START_UNSAFE(s, _u8_get_unsafe_index); \
-    U8_NEXT_UNSAFE(s, _u8_get_unsafe_index, c); \
-}
-
-/**
- * Get a code point from a string at a random-access offset,
- * without changing the offset.
- * The offset may point to either the lead byte or one of the trail bytes
- * for a code point, in which case the macro will read all of the bytes
- * for the code point.
- * If the offset points to an illegal UTF-8 byte sequence, then
- * c is set to a negative value.
- * Iteration through a string is more efficient with U8_NEXT_UNSAFE or U8_NEXT.
- *
- * @param s const uint8_t * string
- * @param start starting string offset
- * @param i string offset, must be start<=i<length
- * @param length string length
- * @param c output UChar32 variable, set to <0 in case of an error
- * @see U8_GET_UNSAFE
- * @stable ICU 2.4
- */
-#define U8_GET(s, start, i, length, c) { \
-    int32_t _u8_get_index=(int32_t)(i); \
-    U8_SET_CP_START(s, start, _u8_get_index); \
-    U8_NEXT(s, _u8_get_index, length, c); \
-}
-
-/* definitions with forward iteration --------------------------------------- */
-
-/**
- * Get a code point from a string at a code point boundary offset,
- * and advance the offset to the next code point boundary.
- * (Post-incrementing forward iteration.)
- * "Unsafe" macro, assumes well-formed UTF-8.
- *
- * The offset may point to the lead byte of a multi-byte sequence,
- * in which case the macro will read the whole sequence.
- * The result is undefined if the offset points to a trail byte
- * or an illegal UTF-8 sequence.
- *
- * @param s const uint8_t * string
- * @param i string offset
- * @param c output UChar32 variable
- * @see U8_NEXT
- * @stable ICU 2.4
- */
-#define U8_NEXT_UNSAFE(s, i, c) { \
-    (c)=(uint8_t)(s)[(i)++]; \
-    if((uint8_t)((c)-0xc0)<0x35) { \
-        uint8_t __count=U8_COUNT_TRAIL_BYTES(c); \
-        U8_MASK_LEAD_BYTE(c, __count); \
-        switch(__count) { \
-        /* each following branch falls through to the next one */ \
-        case 3: \
-            (c)=((c)<<6)|((s)[(i)++]&0x3f); \
-        case 2: \
-            (c)=((c)<<6)|((s)[(i)++]&0x3f); \
-        case 1: \
-            (c)=((c)<<6)|((s)[(i)++]&0x3f); \
-        /* no other branches to optimize switch() */ \
-            break; \
-        } \
-    } \
-}
-
-/**
- * Get a code point from a string at a code point boundary offset,
- * and advance the offset to the next code point boundary.
- * (Post-incrementing forward iteration.)
- * "Safe" macro, checks for illegal sequences and for string boundaries.
- *
- * The offset may point to the lead byte of a multi-byte sequence,
- * in which case the macro will read the whole sequence.
- * If the offset points to a trail byte or an illegal UTF-8 sequence, then
- * c is set to a negative value.
- *
- * @param s const uint8_t * string
- * @param i string offset, must be i<length
- * @param length string length
- * @param c output UChar32 variable, set to <0 in case of an error
- * @see U8_NEXT_UNSAFE
- * @stable ICU 2.4
- */
-#define U8_NEXT(s, i, length, c) { \
-    (c)=(uint8_t)(s)[(i)++]; \
-    if((c)>=0x80) { \
-        uint8_t __t1, __t2; \
-        if( /* handle U+1000..U+CFFF inline */ \
-            (0xe0<(c) && (c)<=0xec) && \
-            (((i)+1)<(length)) && \
-            (__t1=(uint8_t)((s)[i]-0x80))<=0x3f && \
-            (__t2=(uint8_t)((s)[(i)+1]-0x80))<= 0x3f \
-        ) { \
-            /* no need for (c&0xf) because the upper bits are truncated after <<12 in the cast to (UChar) */ \
-            (c)=(UChar)(((c)<<12)|(__t1<<6)|__t2); \
-            (i)+=2; \
-        } else if( /* handle U+0080..U+07FF inline */ \
-            ((c)<0xe0 && (c)>=0xc2) && \
-            ((i)<(length)) && \
-            (__t1=(uint8_t)((s)[i]-0x80))<=0x3f \
-        ) { \
-            (c)=(UChar)((((c)&0x1f)<<6)|__t1); \
-            ++(i); \
-        } else if(U8_IS_LEAD(c)) { \
-            /* function call for "complicated" and error cases */ \
-            (c)=utf8_nextCharSafeBody((const uint8_t *)s, &(i), (int32_t)(length), c, -1); \
-        } else { \
-            (c)=U_SENTINEL; \
-        } \
-    } \
-}
-
-/**
- * Append a code point to a string, overwriting 1 to 4 bytes.
- * The offset points to the current end of the string contents
- * and is advanced (post-increment).
- * "Unsafe" macro, assumes a valid code point and sufficient space in the string.
- * Otherwise, the result is undefined.
- *
- * @param s const uint8_t * string buffer
- * @param i string offset
- * @param c code point to append
- * @see U8_APPEND
- * @stable ICU 2.4
- */
-#define U8_APPEND_UNSAFE(s, i, c) { \
-    if((uint32_t)(c)<=0x7f) { \
-        (s)[(i)++]=(uint8_t)(c); \
-    } else { \
-        if((uint32_t)(c)<=0x7ff) { \
-            (s)[(i)++]=(uint8_t)(((c)>>6)|0xc0); \
-        } else { \
-            if((uint32_t)(c)<=0xffff) { \
-                (s)[(i)++]=(uint8_t)(((c)>>12)|0xe0); \
-            } else { \
-                (s)[(i)++]=(uint8_t)(((c)>>18)|0xf0); \
-                (s)[(i)++]=(uint8_t)((((c)>>12)&0x3f)|0x80); \
-            } \
-            (s)[(i)++]=(uint8_t)((((c)>>6)&0x3f)|0x80); \
-        } \
-        (s)[(i)++]=(uint8_t)(((c)&0x3f)|0x80); \
-    } \
-}
-
-/**
- * Append a code point to a string, overwriting 1 to 4 bytes.
- * The offset points to the current end of the string contents
- * and is advanced (post-increment).
- * "Safe" macro, checks for a valid code point.
- * If a non-ASCII code point is written, checks for sufficient space in the string.
- * If the code point is not valid or trail bytes do not fit,
- * then isError is set to TRUE.
- *
- * @param s const uint8_t * string buffer
- * @param i string offset, must be i<capacity
- * @param capacity size of the string buffer
- * @param c code point to append
- * @param isError output UBool set to TRUE if an error occurs, otherwise not modified
- * @see U8_APPEND_UNSAFE
- * @stable ICU 2.4
- */
-#define U8_APPEND(s, i, capacity, c, isError) { \
-    if((uint32_t)(c)<=0x7f) { \
-        (s)[(i)++]=(uint8_t)(c); \
-    } else if((uint32_t)(c)<=0x7ff && (i)+1<(capacity)) { \
-        (s)[(i)++]=(uint8_t)(((c)>>6)|0xc0); \
-        (s)[(i)++]=(uint8_t)(((c)&0x3f)|0x80); \
-    } else if((uint32_t)(c)<=0xd7ff && (i)+2<(capacity)) { \
-        (s)[(i)++]=(uint8_t)(((c)>>12)|0xe0); \
-        (s)[(i)++]=(uint8_t)((((c)>>6)&0x3f)|0x80); \
-        (s)[(i)++]=(uint8_t)(((c)&0x3f)|0x80); \
-    } else { \
-        (i)=utf8_appendCharSafeBody(s, (int32_t)(i), (int32_t)(capacity), c, &(isError)); \
-    } \
-}
-
-/**
- * Advance the string offset from one code point boundary to the next.
- * (Post-incrementing iteration.)
- * "Unsafe" macro, assumes well-formed UTF-8.
- *
- * @param s const uint8_t * string
- * @param i string offset
- * @see U8_FWD_1
- * @stable ICU 2.4
- */
-#define U8_FWD_1_UNSAFE(s, i) { \
-    (i)+=1+U8_COUNT_TRAIL_BYTES((s)[i]); \
-}
-
-/**
- * Advance the string offset from one code point boundary to the next.
- * (Post-incrementing iteration.)
- * "Safe" macro, checks for illegal sequences and for string boundaries.
- *
- * @param s const uint8_t * string
- * @param i string offset, must be i<length
- * @param length string length
- * @see U8_FWD_1_UNSAFE
- * @stable ICU 2.4
- */
-#define U8_FWD_1(s, i, length) { \
-    uint8_t __b=(uint8_t)(s)[(i)++]; \
-    if(U8_IS_LEAD(__b)) { \
-        uint8_t __count=U8_COUNT_TRAIL_BYTES(__b); \
-        if((i)+__count>(length)) { \
-            __count=(uint8_t)((length)-(i)); \
-        } \
-        while(__count>0 && U8_IS_TRAIL((s)[i])) { \
-            ++(i); \
-            --__count; \
-        } \
-    } \
-}
-
-/**
- * Advance the string offset from one code point boundary to the n-th next one,
- * i.e., move forward by n code points.
- * (Post-incrementing iteration.)
- * "Unsafe" macro, assumes well-formed UTF-8.
- *
- * @param s const uint8_t * string
- * @param i string offset
- * @param n number of code points to skip
- * @see U8_FWD_N
- * @stable ICU 2.4
- */
-#define U8_FWD_N_UNSAFE(s, i, n) { \
-    int32_t __N=(n); \
-    while(__N>0) { \
-        U8_FWD_1_UNSAFE(s, i); \
-        --__N; \
-    } \
-}
-
-/**
- * Advance the string offset from one code point boundary to the n-th next one,
- * i.e., move forward by n code points.
- * (Post-incrementing iteration.)
- * "Safe" macro, checks for illegal sequences and for string boundaries.
- *
- * @param s const uint8_t * string
- * @param i string offset, must be i<length
- * @param length string length
- * @param n number of code points to skip
- * @see U8_FWD_N_UNSAFE
- * @stable ICU 2.4
- */
-#define U8_FWD_N(s, i, length, n) { \
-    int32_t __N=(n); \
-    while(__N>0 && (i)<(length)) { \
-        U8_FWD_1(s, i, length); \
-        --__N; \
-    } \
-}
-
-/**
- * Adjust a random-access offset to a code point boundary
- * at the start of a code point.
- * If the offset points to a UTF-8 trail byte,
- * then the offset is moved backward to the corresponding lead byte.
- * Otherwise, it is not modified.
- * "Unsafe" macro, assumes well-formed UTF-8.
- *
- * @param s const uint8_t * string
- * @param i string offset
- * @see U8_SET_CP_START
- * @stable ICU 2.4
- */
-#define U8_SET_CP_START_UNSAFE(s, i) { \
-    while(U8_IS_TRAIL((s)[i])) { --(i); } \
-}
-
-/**
- * Adjust a random-access offset to a code point boundary
- * at the start of a code point.
- * If the offset points to a UTF-8 trail byte,
- * then the offset is moved backward to the corresponding lead byte.
- * Otherwise, it is not modified.
- * "Safe" macro, checks for illegal sequences and for string boundaries.
- *
- * @param s const uint8_t * string
- * @param start starting string offset (usually 0)
- * @param i string offset, must be start<=i
- * @see U8_SET_CP_START_UNSAFE
- * @stable ICU 2.4
- */
-#define U8_SET_CP_START(s, start, i) { \
-    if(U8_IS_TRAIL((s)[(i)])) { \
-        (i)=utf8_back1SafeBody(s, start, (int32_t)(i)); \
-    } \
-}
-
-/* definitions with backward iteration -------------------------------------- */
-
-/**
- * Move the string offset from one code point boundary to the previous one
- * and get the code point between them.
- * (Pre-decrementing backward iteration.)
- * "Unsafe" macro, assumes well-formed UTF-8.
- *
- * The input offset may be the same as the string length.
- * If the offset is behind a multi-byte sequence, then the macro will read
- * the whole sequence.
- * If the offset is behind a lead byte, then that itself
- * will be returned as the code point.
- * The result is undefined if the offset is behind an illegal UTF-8 sequence.
- *
- * @param s const uint8_t * string
- * @param i string offset
- * @param c output UChar32 variable
- * @see U8_PREV
- * @stable ICU 2.4
- */
-#define U8_PREV_UNSAFE(s, i, c) { \
-    (c)=(uint8_t)(s)[--(i)]; \
-    if(U8_IS_TRAIL(c)) { \
-        uint8_t __b, __count=1, __shift=6; \
-\
-        /* c is a trail byte */ \
-        (c)&=0x3f; \
-        for(;;) { \
-            __b=(uint8_t)(s)[--(i)]; \
-            if(__b>=0xc0) { \
-                U8_MASK_LEAD_BYTE(__b, __count); \
-                (c)|=(UChar32)__b<<__shift; \
-                break; \
-            } else { \
-                (c)|=(UChar32)(__b&0x3f)<<__shift; \
-                ++__count; \
-                __shift+=6; \
-            } \
-        } \
-    } \
-}
-
-/**
- * Move the string offset from one code point boundary to the previous one
- * and get the code point between them.
- * (Pre-decrementing backward iteration.)
- * "Safe" macro, checks for illegal sequences and for string boundaries.
- *
- * The input offset may be the same as the string length.
- * If the offset is behind a multi-byte sequence, then the macro will read
- * the whole sequence.
- * If the offset is behind a lead byte, then that itself
- * will be returned as the code point.
- * If the offset is behind an illegal UTF-8 sequence, then c is set to a negative value.
- *
- * @param s const uint8_t * string
- * @param start starting string offset (usually 0)
- * @param i string offset, must be start<i
- * @param c output UChar32 variable, set to <0 in case of an error
- * @see U8_PREV_UNSAFE
- * @stable ICU 2.4
- */
-#define U8_PREV(s, start, i, c) { \
-    (c)=(uint8_t)(s)[--(i)]; \
-    if((c)>=0x80) { \
-        if((c)<=0xbf) { \
-            (c)=utf8_prevCharSafeBody((const uint8_t *)s, start, &(i), c, -1); \
-        } else { \
-            (c)=U_SENTINEL; \
-        } \
-    } \
-}
-
-/**
- * Move the string offset from one code point boundary to the previous one.
- * (Pre-decrementing backward iteration.)
- * The input offset may be the same as the string length.
- * "Unsafe" macro, assumes well-formed UTF-8.
- *
- * @param s const uint8_t * string
- * @param i string offset
- * @see U8_BACK_1
- * @stable ICU 2.4
- */
-#define U8_BACK_1_UNSAFE(s, i) { \
-    while(U8_IS_TRAIL((s)[--(i)])) {} \
-}
-
-/**
- * Move the string offset from one code point boundary to the previous one.
- * (Pre-decrementing backward iteration.)
- * The input offset may be the same as the string length.
- * "Safe" macro, checks for illegal sequences and for string boundaries.
- *
- * @param s const uint8_t * string
- * @param start starting string offset (usually 0)
- * @param i string offset, must be start<i
- * @see U8_BACK_1_UNSAFE
- * @stable ICU 2.4
- */
-#define U8_BACK_1(s, start, i) { \
-    if(U8_IS_TRAIL((s)[--(i)])) { \
-        (i)=utf8_back1SafeBody(s, start, (int32_t)(i)); \
-    } \
-}
-
-/**
- * Move the string offset from one code point boundary to the n-th one before it,
- * i.e., move backward by n code points.
- * (Pre-decrementing backward iteration.)
- * The input offset may be the same as the string length.
- * "Unsafe" macro, assumes well-formed UTF-8.
- *
- * @param s const uint8_t * string
- * @param i string offset
- * @param n number of code points to skip
- * @see U8_BACK_N
- * @stable ICU 2.4
- */
-#define U8_BACK_N_UNSAFE(s, i, n) { \
-    int32_t __N=(n); \
-    while(__N>0) { \
-        U8_BACK_1_UNSAFE(s, i); \
-        --__N; \
-    } \
-}
-
-/**
- * Move the string offset from one code point boundary to the n-th one before it,
- * i.e., move backward by n code points.
- * (Pre-decrementing backward iteration.)
- * The input offset may be the same as the string length.
- * "Safe" macro, checks for illegal sequences and for string boundaries.
- *
- * @param s const uint8_t * string
- * @param start index of the start of the string
- * @param i string offset, must be start<i
- * @param n number of code points to skip
- * @see U8_BACK_N_UNSAFE
- * @stable ICU 2.4
- */
-#define U8_BACK_N(s, start, i, n) { \
-    int32_t __N=(n); \
-    while(__N>0 && (i)>(start)) { \
-        U8_BACK_1(s, start, i); \
-        --__N; \
-    } \
-}
-
-/**
- * Adjust a random-access offset to a code point boundary after a code point.
- * If the offset is behind a partial multi-byte sequence,
- * then the offset is incremented to behind the whole sequence.
- * Otherwise, it is not modified.
- * The input offset may be the same as the string length.
- * "Unsafe" macro, assumes well-formed UTF-8.
- *
- * @param s const uint8_t * string
- * @param i string offset
- * @see U8_SET_CP_LIMIT
- * @stable ICU 2.4
- */
-#define U8_SET_CP_LIMIT_UNSAFE(s, i) { \
-    U8_BACK_1_UNSAFE(s, i); \
-    U8_FWD_1_UNSAFE(s, i); \
-}
-
-/**
- * Adjust a random-access offset to a code point boundary after a code point.
- * If the offset is behind a partial multi-byte sequence,
- * then the offset is incremented to behind the whole sequence.
- * Otherwise, it is not modified.
- * The input offset may be the same as the string length.
- * "Safe" macro, checks for illegal sequences and for string boundaries.
- *
- * @param s const uint8_t * string
- * @param start starting string offset (usually 0)
- * @param i string offset, must be start<=i<=length
- * @param length string length
- * @see U8_SET_CP_LIMIT_UNSAFE
- * @stable ICU 2.4
- */
-#define U8_SET_CP_LIMIT(s, start, i, length) { \
-    if((start)<(i) && (i)<(length)) { \
-        U8_BACK_1(s, start, i); \
-        U8_FWD_1(s, i, length); \
-    } \
-}
-
-#endif

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/utf_old.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/utf_old.h b/apps/couch_collate/platform/osx/icu/unicode/utf_old.h
deleted file mode 100644
index 2397889..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/utf_old.h
+++ /dev/null
@@ -1,1171 +0,0 @@
-/*
-*******************************************************************************
-*
-*   Copyright (C) 2002-2005, International Business Machines
-*   Corporation and others.  All Rights Reserved.
-*
-*******************************************************************************
-*   file name:  utf.h
-*   encoding:   US-ASCII
-*   tab size:   8 (not used)
-*   indentation:4
-*
-*   created on: 2002sep21
-*   created by: Markus W. Scherer
-*/
-
-/**
- * \file 
- * \brief C API: Deprecated macros for Unicode string handling
- */
-
-/**
- * 
- * The macros in utf_old.h are all deprecated and their use discouraged.
- * Some of the design principles behind the set of UTF macros
- * have changed or proved impractical.
- * Almost all of the old "UTF macros" are at least renamed.
- * If you are looking for a new equivalent to an old macro, please see the
- * comment at the old one.
- *
- * utf_old.h is included by utf.h after unicode/umachine.h
- * and some common definitions, to not break old code.
- *
- * Brief summary of reasons for deprecation:
- * - Switch on UTF_SIZE (selection of UTF-8/16/32 default string processing)
- *   was impractical.
- * - Switch on UTF_SAFE etc. (selection of unsafe/safe/strict default string processing)
- *   was of little use and impractical.
- * - Whole classes of macros became obsolete outside of the UTF_SIZE/UTF_SAFE
- *   selection framework: UTF32_ macros (all trivial)
- *   and UTF_ default and intermediate macros (all aliases).
- * - The selection framework also caused many macro aliases.
- * - Change in Unicode standard: "irregular" sequences (3.0) became illegal (3.2).
- * - Change of language in Unicode standard:
- *   Growing distinction between internal x-bit Unicode strings and external UTF-x
- *   forms, with the former more lenient.
- *   Suggests renaming of UTF16_ macros to U16_.
- * - The prefix "UTF_" without a width number confused some users.
- * - "Safe" append macros needed the addition of an error indicator output.
- * - "Safe" UTF-8 macros used legitimate (if rarely used) code point values
- *   to indicate error conditions.
- * - The use of the "_CHAR" infix for code point operations confused some users.
- *
- * More details:
- *
- * Until ICU 2.2, utf.h theoretically allowed to choose among UTF-8/16/32
- * for string processing, and among unsafe/safe/strict default macros for that.
- *
- * It proved nearly impossible to write non-trivial, high-performance code
- * that is UTF-generic.
- * Unsafe default macros would be dangerous for default string processing,
- * and the main reason for the "strict" versions disappeared:
- * Between Unicode 3.0 and 3.2 all "irregular" UTF-8 sequences became illegal.
- * The only other conditions that "strict" checked for were non-characters,
- * which are valid during processing. Only during text input/output should they
- * be checked, and at that time other well-formedness checks may be
- * necessary or useful as well.
- * This can still be done by using U16_NEXT and U_IS_UNICODE_NONCHAR
- * or U_IS_UNICODE_CHAR.
- *
- * The old UTF8_..._SAFE macros also used some normal Unicode code points
- * to indicate malformed sequences.
- * The new UTF8_ macros without suffix use negative values instead.
- *
- * The entire contents of utf32.h was moved here without replacement
- * because all those macros were trivial and
- * were meaningful only in the framework of choosing the UTF size.
- *
- * See Jitterbug 2150 and its discussion on the ICU mailing list
- * in September 2002.
- *
- * <hr>
- *
- * <em>Obsolete part</em> of pre-ICU 2.4 utf.h file documentation:
- *
- * <p>The original concept for these files was for ICU to allow
- * in principle to set which UTF (UTF-8/16/32) is used internally
- * by defining UTF_SIZE to either 8, 16, or 32. utf.h would then define the UChar type
- * accordingly. UTF-16 was the default.</p>
- *
- * <p>This concept has been abandoned.
- * A lot of the ICU source code assumes UChar strings are in UTF-16.
- * This is especially true for low-level code like
- * conversion, normalization, and collation.
- * The utf.h header enforces the default of UTF-16.
- * The UTF-8 and UTF-32 macros remain for now for completeness and backward compatibility.</p>
- *
- * <p>Accordingly, utf.h defines UChar to be an unsigned 16-bit integer. If this matches wchar_t, then
- * UChar is defined to be exactly wchar_t, otherwise uint16_t.</p>
- *
- * <p>UChar32 is defined to be a signed 32-bit integer (int32_t), large enough for a 21-bit
- * Unicode code point (Unicode scalar value, 0..0x10ffff).
- * Before ICU 2.4, the definition of UChar32 was similarly platform-dependent as
- * the definition of UChar. For details see the documentation for UChar32 itself.</p>
- *
- * <p>utf.h also defines a number of C macros for handling single Unicode code points and
- * for using UTF Unicode strings. It includes utf8.h, utf16.h, and utf32.h for the actual
- * implementations of those macros and then aliases one set of them (for UTF-16) for general use.
- * The UTF-specific macros have the UTF size in the macro name prefixes (UTF16_...), while
- * the general alias macros always begin with UTF_...</p>
- *
- * <p>Many string operations can be done with or without error checking.
- * Where such a distinction is useful, there are two versions of the macros, "unsafe" and "safe"
- * ones with ..._UNSAFE and ..._SAFE suffixes. The unsafe macros are fast but may cause
- * program failures if the strings are not well-formed. The safe macros have an additional, boolean
- * parameter "strict". If strict is FALSE, then only illegal sequences are detected.
- * Otherwise, irregular sequences and non-characters are detected as well (like single surrogates).
- * Safe macros return special error code points for illegal/irregular sequences:
- * Typically, U+ffff, or values that would result in a code unit sequence of the same length
- * as the erroneous input sequence.<br>
- * Note that _UNSAFE macros have fewer parameters: They do not have the strictness parameter, and
- * they do not have start/length parameters for boundary checking.</p>
- *
- * <p>Here, the macros are aliased in two steps:
- * In the first step, the UTF-specific macros with UTF16_ prefix and _UNSAFE and _SAFE suffixes are
- * aliased according to the UTF_SIZE to macros with UTF_ prefix and the same suffixes and signatures.
- * Then, in a second step, the default, general alias macros are set to use either the unsafe or
- * the safe/not strict (default) or the safe/strict macro;
- * these general macros do not have a strictness parameter.</p>
- *
- * <p>It is possible to change the default choice for the general alias macros to be unsafe, safe/not strict or safe/strict.
- * The default is safe/not strict. It is not recommended to select the unsafe macros as the basis for
- * Unicode string handling in ICU! To select this, define UTF_SAFE, UTF_STRICT, or UTF_UNSAFE.</p>
- *
- * <p>For general use, one should use the default, general macros with UTF_ prefix and no _SAFE/_UNSAFE suffix.
- * Only in some cases it may be necessary to control the choice of macro directly and use a less generic alias.
- * For example, if it can be assumed that a string is well-formed and the index will stay within the bounds,
- * then the _UNSAFE version may be used.
- * If a UTF-8 string is to be processed, then the macros with UTF8_ prefixes need to be used.</p>
- *
- * <hr>
- *
- * @deprecated ICU 2.4. Use the macros in utf.h, utf16.h, utf8.h instead.
- */
-
-#ifndef __UTF_OLD_H__
-#define __UTF_OLD_H__
-
-#ifndef U_HIDE_DEPRECATED_API
-
-/* utf.h must be included first. */
-#ifndef __UTF_H__
-#   include "unicode/utf.h"
-#endif
-
-/* Formerly utf.h, part 1 --------------------------------------------------- */
-
-#ifdef U_USE_UTF_DEPRECATES
-/**
- * Unicode string and array offset and index type.
- * ICU always counts Unicode code units (UChars) for
- * string offsets, indexes, and lengths, not Unicode code points.
- *
- * @obsolete ICU 2.6. Use int32_t directly instead since this API will be removed in that release.
- */
-typedef int32_t UTextOffset;
-#endif
-
-/** Number of bits in a Unicode string code unit - ICU uses 16-bit Unicode. @deprecated ICU 2.4. Obsolete, see utf_old.h. */
-#define UTF_SIZE 16
-
-/**
- * The default choice for general Unicode string macros is to use the ..._SAFE macro implementations
- * with strict=FALSE.
- *
- * @deprecated ICU 2.4. Obsolete, see utf_old.h.
- */
-#define UTF_SAFE
-/** @deprecated ICU 2.4. Obsolete, see utf_old.h. */
-#undef UTF_UNSAFE
-/** @deprecated ICU 2.4. Obsolete, see utf_old.h. */
-#undef UTF_STRICT
-
-/**
- * <p>UTF8_ERROR_VALUE_1 and UTF8_ERROR_VALUE_2 are special error values for UTF-8,
- * which need 1 or 2 bytes in UTF-8:<br>
- * U+0015 = NAK = Negative Acknowledge, C0 control character<br>
- * U+009f = highest C1 control character</p>
- *
- * <p>These are used by UTF8_..._SAFE macros so that they can return an error value
- * that needs the same number of code units (bytes) as were seen by
- * a macro. They should be tested with UTF_IS_ERROR() or UTF_IS_VALID().</p>
- *
- * @deprecated ICU 2.4. Obsolete, see utf_old.h.
- */
-#define UTF8_ERROR_VALUE_1 0x15
-
-/**
- * See documentation on UTF8_ERROR_VALUE_1 for details.
- *
- * @deprecated ICU 2.4. Obsolete, see utf_old.h.
- */
-#define UTF8_ERROR_VALUE_2 0x9f
-
-/**
- * Error value for all UTFs. This code point value will be set by macros with error
- * checking if an error is detected.
- *
- * @deprecated ICU 2.4. Obsolete, see utf_old.h.
- */
-#define UTF_ERROR_VALUE 0xffff
-
-/**
- * Is a given 32-bit code an error value
- * as returned by one of the macros for any UTF?
- *
- * @deprecated ICU 2.4. Obsolete, see utf_old.h.
- */
-#define UTF_IS_ERROR(c) \
-    (((c)&0xfffe)==0xfffe || (c)==UTF8_ERROR_VALUE_1 || (c)==UTF8_ERROR_VALUE_2)
-
-/**
- * This is a combined macro: Is c a valid Unicode value _and_ not an error code?
- *
- * @deprecated ICU 2.4. Obsolete, see utf_old.h.
- */
-#define UTF_IS_VALID(c) \
-    (UTF_IS_UNICODE_CHAR(c) && \
-     (c)!=UTF8_ERROR_VALUE_1 && (c)!=UTF8_ERROR_VALUE_2)
-
-/**
- * Is this code unit or code point a surrogate (U+d800..U+dfff)?
- * @deprecated ICU 2.4. Renamed to U_IS_SURROGATE and U16_IS_SURROGATE, see utf_old.h.
- */
-#define UTF_IS_SURROGATE(uchar) (((uchar)&0xfffff800)==0xd800)
-
-/**
- * Is a given 32-bit code point a Unicode noncharacter?
- *
- * @deprecated ICU 2.4. Renamed to U_IS_UNICODE_NONCHAR, see utf_old.h.
- */
-#define UTF_IS_UNICODE_NONCHAR(c) \
-    ((c)>=0xfdd0 && \
-     ((uint32_t)(c)<=0xfdef || ((c)&0xfffe)==0xfffe) && \
-     (uint32_t)(c)<=0x10ffff)
-
-/**
- * Is a given 32-bit value a Unicode code point value (0..U+10ffff)
- * that can be assigned a character?
- *
- * Code points that are not characters include:
- * - single surrogate code points (U+d800..U+dfff, 2048 code points)
- * - the last two code points on each plane (U+__fffe and U+__ffff, 34 code points)
- * - U+fdd0..U+fdef (new with Unicode 3.1, 32 code points)
- * - the highest Unicode code point value is U+10ffff
- *
- * This means that all code points below U+d800 are character code points,
- * and that boundary is tested first for performance.
- *
- * @deprecated ICU 2.4. Renamed to U_IS_UNICODE_CHAR, see utf_old.h.
- */
-#define UTF_IS_UNICODE_CHAR(c) \
-    ((uint32_t)(c)<0xd800 || \
-        ((uint32_t)(c)>0xdfff && \
-         (uint32_t)(c)<=0x10ffff && \
-         !UTF_IS_UNICODE_NONCHAR(c)))
-
-/* Formerly utf8.h ---------------------------------------------------------- */
-
-/**
- * Count the trail bytes for a UTF-8 lead byte.
- * @deprecated ICU 2.4. Renamed to U8_COUNT_TRAIL_BYTES, see utf_old.h.
- */
-#define UTF8_COUNT_TRAIL_BYTES(leadByte) (utf8_countTrailBytes[(uint8_t)leadByte])
-
-/**
- * Mask a UTF-8 lead byte, leave only the lower bits that form part of the code point value.
- * @deprecated ICU 2.4. Renamed to U8_MASK_LEAD_BYTE, see utf_old.h.
- */
-#define UTF8_MASK_LEAD_BYTE(leadByte, countTrailBytes) ((leadByte)&=(1<<(6-(countTrailBytes)))-1)
-
-/** Is this this code point a single code unit (byte)? @deprecated ICU 2.4. Renamed to U8_IS_SINGLE, see utf_old.h. */
-#define UTF8_IS_SINGLE(uchar) (((uchar)&0x80)==0)
-/** Is this this code unit the lead code unit (byte) of a code point? @deprecated ICU 2.4. Renamed to U8_IS_LEAD, see utf_old.h. */
-#define UTF8_IS_LEAD(uchar) ((uint8_t)((uchar)-0xc0)<0x3e)
-/** Is this this code unit a trailing code unit (byte) of a code point? @deprecated ICU 2.4. Renamed to U8_IS_TRAIL, see utf_old.h. */
-#define UTF8_IS_TRAIL(uchar) (((uchar)&0xc0)==0x80)
-
-/** Does this scalar Unicode value need multiple code units for storage? @deprecated ICU 2.4. Use U8_LENGTH or test ((uint32_t)(c)>0x7f) instead, see utf_old.h. */
-#define UTF8_NEED_MULTIPLE_UCHAR(c) ((uint32_t)(c)>0x7f)
-
-/**
- * Given the lead character, how many bytes are taken by this code point.
- * ICU does not deal with code points >0x10ffff
- * unless necessary for advancing in the byte stream.
- *
- * These length macros take into account that for values >0x10ffff
- * the UTF8_APPEND_CHAR_SAFE macros would write the error code point 0xffff
- * with 3 bytes.
- * Code point comparisons need to be in uint32_t because UChar32
- * may be a signed type, and negative values must be recognized.
- *
- * @deprecated ICU 2.4. Use U8_LENGTH instead, see utf_old.h.
- */
-#if 1
-#   define UTF8_CHAR_LENGTH(c) \
-        ((uint32_t)(c)<=0x7f ? 1 : \
-            ((uint32_t)(c)<=0x7ff ? 2 : \
-                ((uint32_t)((c)-0x10000)>0xfffff ? 3 : 4) \
-            ) \
-        )
-#else
-#   define UTF8_CHAR_LENGTH(c) \
-        ((uint32_t)(c)<=0x7f ? 1 : \
-            ((uint32_t)(c)<=0x7ff ? 2 : \
-                ((uint32_t)(c)<=0xffff ? 3 : \
-                    ((uint32_t)(c)<=0x10ffff ? 4 : \
-                        ((uint32_t)(c)<=0x3ffffff ? 5 : \
-                            ((uint32_t)(c)<=0x7fffffff ? 6 : 3) \
-                        ) \
-                    ) \
-                ) \
-            ) \
-        )
-#endif
-
-/** The maximum number of bytes per code point. @deprecated ICU 2.4. Renamed to U8_MAX_LENGTH, see utf_old.h. */
-#define UTF8_MAX_CHAR_LENGTH 4
-
-/** Average number of code units compared to UTF-16. @deprecated ICU 2.4. Obsolete, see utf_old.h. */
-#define UTF8_ARRAY_SIZE(size) ((5*(size))/2)
-
-/** @deprecated ICU 2.4. Renamed to U8_GET_UNSAFE, see utf_old.h. */
-#define UTF8_GET_CHAR_UNSAFE(s, i, c) { \
-    int32_t _utf8_get_char_unsafe_index=(int32_t)(i); \
-    UTF8_SET_CHAR_START_UNSAFE(s, _utf8_get_char_unsafe_index); \
-    UTF8_NEXT_CHAR_UNSAFE(s, _utf8_get_char_unsafe_index, c); \
-}
-
-/** @deprecated ICU 2.4. Use U8_GET instead, see utf_old.h. */
-#define UTF8_GET_CHAR_SAFE(s, start, i, length, c, strict) { \
-    int32_t _utf8_get_char_safe_index=(int32_t)(i); \
-    UTF8_SET_CHAR_START_SAFE(s, start, _utf8_get_char_safe_index); \
-    UTF8_NEXT_CHAR_SAFE(s, _utf8_get_char_safe_index, length, c, strict); \
-}
-
-/** @deprecated ICU 2.4. Renamed to U8_NEXT_UNSAFE, see utf_old.h. */
-#define UTF8_NEXT_CHAR_UNSAFE(s, i, c) { \
-    (c)=(s)[(i)++]; \
-    if((uint8_t)((c)-0xc0)<0x35) { \
-        uint8_t __count=UTF8_COUNT_TRAIL_BYTES(c); \
-        UTF8_MASK_LEAD_BYTE(c, __count); \
-        switch(__count) { \
-        /* each following branch falls through to the next one */ \
-        case 3: \
-            (c)=((c)<<6)|((s)[(i)++]&0x3f); \
-        case 2: \
-            (c)=((c)<<6)|((s)[(i)++]&0x3f); \
-        case 1: \
-            (c)=((c)<<6)|((s)[(i)++]&0x3f); \
-        /* no other branches to optimize switch() */ \
-            break; \
-        } \
-    } \
-}
-
-/** @deprecated ICU 2.4. Renamed to U8_APPEND_UNSAFE, see utf_old.h. */
-#define UTF8_APPEND_CHAR_UNSAFE(s, i, c) { \
-    if((uint32_t)(c)<=0x7f) { \
-        (s)[(i)++]=(uint8_t)(c); \
-    } else { \
-        if((uint32_t)(c)<=0x7ff) { \
-            (s)[(i)++]=(uint8_t)(((c)>>6)|0xc0); \
-        } else { \
-            if((uint32_t)(c)<=0xffff) { \
-                (s)[(i)++]=(uint8_t)(((c)>>12)|0xe0); \
-            } else { \
-                (s)[(i)++]=(uint8_t)(((c)>>18)|0xf0); \
-                (s)[(i)++]=(uint8_t)((((c)>>12)&0x3f)|0x80); \
-            } \
-            (s)[(i)++]=(uint8_t)((((c)>>6)&0x3f)|0x80); \
-        } \
-        (s)[(i)++]=(uint8_t)(((c)&0x3f)|0x80); \
-    } \
-}
-
-/** @deprecated ICU 2.4. Renamed to U8_FWD_1_UNSAFE, see utf_old.h. */
-#define UTF8_FWD_1_UNSAFE(s, i) { \
-    (i)+=1+UTF8_COUNT_TRAIL_BYTES((s)[i]); \
-}
-
-/** @deprecated ICU 2.4. Renamed to U8_FWD_N_UNSAFE, see utf_old.h. */
-#define UTF8_FWD_N_UNSAFE(s, i, n) { \
-    int32_t __N=(n); \
-    while(__N>0) { \
-        UTF8_FWD_1_UNSAFE(s, i); \
-        --__N; \
-    } \
-}
-
-/** @deprecated ICU 2.4. Renamed to U8_SET_CP_START_UNSAFE, see utf_old.h. */
-#define UTF8_SET_CHAR_START_UNSAFE(s, i) { \
-    while(UTF8_IS_TRAIL((s)[i])) { --(i); } \
-}
-
-/** @deprecated ICU 2.4. Use U8_NEXT instead, see utf_old.h. */
-#define UTF8_NEXT_CHAR_SAFE(s, i, length, c, strict) { \
-    (c)=(s)[(i)++]; \
-    if((c)>=0x80) { \
-        if(UTF8_IS_LEAD(c)) { \
-            (c)=utf8_nextCharSafeBody(s, &(i), (int32_t)(length), c, strict); \
-        } else { \
-            (c)=UTF8_ERROR_VALUE_1; \
-        } \
-    } \
-}
-
-/** @deprecated ICU 2.4. Use U8_APPEND instead, see utf_old.h. */
-#define UTF8_APPEND_CHAR_SAFE(s, i, length, c)  { \
-    if((uint32_t)(c)<=0x7f) { \
-        (s)[(i)++]=(uint8_t)(c); \
-    } else { \
-        (i)=utf8_appendCharSafeBody(s, (int32_t)(i), (int32_t)(length), c, NULL); \
-    } \
-}
-
-/** @deprecated ICU 2.4. Renamed to U8_FWD_1, see utf_old.h. */
-#define UTF8_FWD_1_SAFE(s, i, length) U8_FWD_1(s, i, length)
-
-/** @deprecated ICU 2.4. Renamed to U8_FWD_N, see utf_old.h. */
-#define UTF8_FWD_N_SAFE(s, i, length, n) U8_FWD_N(s, i, length, n)
-
-/** @deprecated ICU 2.4. Renamed to U8_SET_CP_START, see utf_old.h. */
-#define UTF8_SET_CHAR_START_SAFE(s, start, i) U8_SET_CP_START(s, start, i)
-
-/** @deprecated ICU 2.4. Renamed to U8_PREV_UNSAFE, see utf_old.h. */
-#define UTF8_PREV_CHAR_UNSAFE(s, i, c) { \
-    (c)=(s)[--(i)]; \
-    if(UTF8_IS_TRAIL(c)) { \
-        uint8_t __b, __count=1, __shift=6; \
-\
-        /* c is a trail byte */ \
-        (c)&=0x3f; \
-        for(;;) { \
-            __b=(s)[--(i)]; \
-            if(__b>=0xc0) { \
-                UTF8_MASK_LEAD_BYTE(__b, __count); \
-                (c)|=(UChar32)__b<<__shift; \
-                break; \
-            } else { \
-                (c)|=(UChar32)(__b&0x3f)<<__shift; \
-                ++__count; \
-                __shift+=6; \
-            } \
-        } \
-    } \
-}
-
-/** @deprecated ICU 2.4. Renamed to U8_BACK_1_UNSAFE, see utf_old.h. */
-#define UTF8_BACK_1_UNSAFE(s, i) { \
-    while(UTF8_IS_TRAIL((s)[--(i)])) {} \
-}
-
-/** @deprecated ICU 2.4. Renamed to U8_BACK_N_UNSAFE, see utf_old.h. */
-#define UTF8_BACK_N_UNSAFE(s, i, n) { \
-    int32_t __N=(n); \
-    while(__N>0) { \
-        UTF8_BACK_1_UNSAFE(s, i); \
-        --__N; \
-    } \
-}
-
-/** @deprecated ICU 2.4. Renamed to U8_SET_CP_LIMIT_UNSAFE, see utf_old.h. */
-#define UTF8_SET_CHAR_LIMIT_UNSAFE(s, i) { \
-    UTF8_BACK_1_UNSAFE(s, i); \
-    UTF8_FWD_1_UNSAFE(s, i); \
-}
-
-/** @deprecated ICU 2.4. Use U8_PREV instead, see utf_old.h. */
-#define UTF8_PREV_CHAR_SAFE(s, start, i, c, strict) { \
-    (c)=(s)[--(i)]; \
-    if((c)>=0x80) { \
-        if((c)<=0xbf) { \
-            (c)=utf8_prevCharSafeBody(s, start, &(i), c, strict); \
-        } else { \
-            (c)=UTF8_ERROR_VALUE_1; \
-        } \
-    } \
-}
-
-/** @deprecated ICU 2.4. Renamed to U8_BACK_1, see utf_old.h. */
-#define UTF8_BACK_1_SAFE(s, start, i) U8_BACK_1(s, start, i)
-
-/** @deprecated ICU 2.4. Renamed to U8_BACK_N, see utf_old.h. */
-#define UTF8_BACK_N_SAFE(s, start, i, n) U8_BACK_N(s, start, i, n)
-
-/** @deprecated ICU 2.4. Renamed to U8_SET_CP_LIMIT, see utf_old.h. */
-#define UTF8_SET_CHAR_LIMIT_SAFE(s, start, i, length) U8_SET_CP_LIMIT(s, start, i, length)
-
-/* Formerly utf16.h --------------------------------------------------------- */
-
-/** Is uchar a first/lead surrogate? @deprecated ICU 2.4. Renamed to U_IS_LEAD and U16_IS_LEAD, see utf_old.h. */
-#define UTF_IS_FIRST_SURROGATE(uchar) (((uchar)&0xfffffc00)==0xd800)
-
-/** Is uchar a second/trail surrogate? @deprecated ICU 2.4. Renamed to U_IS_TRAIL and U16_IS_TRAIL, see utf_old.h. */
-#define UTF_IS_SECOND_SURROGATE(uchar) (((uchar)&0xfffffc00)==0xdc00)
-
-/** Assuming c is a surrogate, is it a first/lead surrogate? @deprecated ICU 2.4. Renamed to U_IS_SURROGATE_LEAD and U16_IS_SURROGATE_LEAD, see utf_old.h. */
-#define UTF_IS_SURROGATE_FIRST(c) (((c)&0x400)==0)
-
-/** Helper constant for UTF16_GET_PAIR_VALUE. @deprecated ICU 2.4. Renamed to U16_SURROGATE_OFFSET, see utf_old.h. */
-#define UTF_SURROGATE_OFFSET ((0xd800<<10UL)+0xdc00-0x10000)
-
-/** Get the UTF-32 value from the surrogate code units. @deprecated ICU 2.4. Renamed to U16_GET_SUPPLEMENTARY, see utf_old.h. */
-#define UTF16_GET_PAIR_VALUE(first, second) \
-    (((first)<<10UL)+(second)-UTF_SURROGATE_OFFSET)
-
-/** @deprecated ICU 2.4. Renamed to U16_LEAD, see utf_old.h. */
-#define UTF_FIRST_SURROGATE(supplementary) (UChar)(((supplementary)>>10)+0xd7c0)
-
-/** @deprecated ICU 2.4. Renamed to U16_TRAIL, see utf_old.h. */
-#define UTF_SECOND_SURROGATE(supplementary) (UChar)(((supplementary)&0x3ff)|0xdc00)
-
-/** @deprecated ICU 2.4. Renamed to U16_LEAD, see utf_old.h. */
-#define UTF16_LEAD(supplementary) UTF_FIRST_SURROGATE(supplementary)
-
-/** @deprecated ICU 2.4. Renamed to U16_TRAIL, see utf_old.h. */
-#define UTF16_TRAIL(supplementary) UTF_SECOND_SURROGATE(supplementary)
-
-/** @deprecated ICU 2.4. Renamed to U16_IS_SINGLE, see utf_old.h. */
-#define UTF16_IS_SINGLE(uchar) !UTF_IS_SURROGATE(uchar)
-
-/** @deprecated ICU 2.4. Renamed to U16_IS_LEAD, see utf_old.h. */
-#define UTF16_IS_LEAD(uchar) UTF_IS_FIRST_SURROGATE(uchar)
-
-/** @deprecated ICU 2.4. Renamed to U16_IS_TRAIL, see utf_old.h. */
-#define UTF16_IS_TRAIL(uchar) UTF_IS_SECOND_SURROGATE(uchar)
-
-/** Does this scalar Unicode value need multiple code units for storage? @deprecated ICU 2.4. Use U16_LENGTH or test ((uint32_t)(c)>0xffff) instead, see utf_old.h. */
-#define UTF16_NEED_MULTIPLE_UCHAR(c) ((uint32_t)(c)>0xffff)
-
-/** @deprecated ICU 2.4. Renamed to U16_LENGTH, see utf_old.h. */
-#define UTF16_CHAR_LENGTH(c) ((uint32_t)(c)<=0xffff ? 1 : 2)
-
-/** @deprecated ICU 2.4. Renamed to U16_MAX_LENGTH, see utf_old.h. */
-#define UTF16_MAX_CHAR_LENGTH 2
-
-/** Average number of code units compared to UTF-16. @deprecated ICU 2.4. Obsolete, see utf_old.h. */
-#define UTF16_ARRAY_SIZE(size) (size)
-
-/**
- * Get a single code point from an offset that points to any
- * of the code units that belong to that code point.
- * Assume 0<=i<length.
- *
- * This could be used for iteration together with
- * UTF16_CHAR_LENGTH() and UTF_IS_ERROR(),
- * but the use of UTF16_NEXT_CHAR[_UNSAFE]() and
- * UTF16_PREV_CHAR[_UNSAFE]() is more efficient for that.
- * @deprecated ICU 2.4. Renamed to U16_GET_UNSAFE, see utf_old.h.
- */
-#define UTF16_GET_CHAR_UNSAFE(s, i, c) { \
-    (c)=(s)[i]; \
-    if(UTF_IS_SURROGATE(c)) { \
-        if(UTF_IS_SURROGATE_FIRST(c)) { \
-            (c)=UTF16_GET_PAIR_VALUE((c), (s)[(i)+1]); \
-        } else { \
-            (c)=UTF16_GET_PAIR_VALUE((s)[(i)-1], (c)); \
-        } \
-    } \
-}
-
-/** @deprecated ICU 2.4. Use U16_GET instead, see utf_old.h. */
-#define UTF16_GET_CHAR_SAFE(s, start, i, length, c, strict) { \
-    (c)=(s)[i]; \
-    if(UTF_IS_SURROGATE(c)) { \
-        uint16_t __c2; \
-        if(UTF_IS_SURROGATE_FIRST(c)) { \
-            if((i)+1<(length) && UTF_IS_SECOND_SURROGATE(__c2=(s)[(i)+1])) { \
-                (c)=UTF16_GET_PAIR_VALUE((c), __c2); \
-                /* strict: ((c)&0xfffe)==0xfffe is caught by UTF_IS_ERROR() and UTF_IS_UNICODE_CHAR() */ \
-            } else if(strict) {\
-                /* unmatched first surrogate */ \
-                (c)=UTF_ERROR_VALUE; \
-            } \
-        } else { \
-            if((i)-1>=(start) && UTF_IS_FIRST_SURROGATE(__c2=(s)[(i)-1])) { \
-                (c)=UTF16_GET_PAIR_VALUE(__c2, (c)); \
-                /* strict: ((c)&0xfffe)==0xfffe is caught by UTF_IS_ERROR() and UTF_IS_UNICODE_CHAR() */ \
-            } else if(strict) {\
-                /* unmatched second surrogate */ \
-                (c)=UTF_ERROR_VALUE; \
-            } \
-        } \
-    } else if((strict) && !UTF_IS_UNICODE_CHAR(c)) { \
-        (c)=UTF_ERROR_VALUE; \
-    } \
-}
-
-/** @deprecated ICU 2.4. Renamed to U16_NEXT_UNSAFE, see utf_old.h. */
-#define UTF16_NEXT_CHAR_UNSAFE(s, i, c) { \
-    (c)=(s)[(i)++]; \
-    if(UTF_IS_FIRST_SURROGATE(c)) { \
-        (c)=UTF16_GET_PAIR_VALUE((c), (s)[(i)++]); \
-    } \
-}
-
-/** @deprecated ICU 2.4. Renamed to U16_APPEND_UNSAFE, see utf_old.h. */
-#define UTF16_APPEND_CHAR_UNSAFE(s, i, c) { \
-    if((uint32_t)(c)<=0xffff) { \
-        (s)[(i)++]=(uint16_t)(c); \
-    } else { \
-        (s)[(i)++]=(uint16_t)(((c)>>10)+0xd7c0); \
-        (s)[(i)++]=(uint16_t)(((c)&0x3ff)|0xdc00); \
-    } \
-}
-
-/** @deprecated ICU 2.4. Renamed to U16_FWD_1_UNSAFE, see utf_old.h. */
-#define UTF16_FWD_1_UNSAFE(s, i) { \
-    if(UTF_IS_FIRST_SURROGATE((s)[(i)++])) { \
-        ++(i); \
-    } \
-}
-
-/** @deprecated ICU 2.4. Renamed to U16_FWD_N_UNSAFE, see utf_old.h. */
-#define UTF16_FWD_N_UNSAFE(s, i, n) { \
-    int32_t __N=(n); \
-    while(__N>0) { \
-        UTF16_FWD_1_UNSAFE(s, i); \
-        --__N; \
-    } \
-}
-
-/** @deprecated ICU 2.4. Renamed to U16_SET_CP_START_UNSAFE, see utf_old.h. */
-#define UTF16_SET_CHAR_START_UNSAFE(s, i) { \
-    if(UTF_IS_SECOND_SURROGATE((s)[i])) { \
-        --(i); \
-    } \
-}
-
-/** @deprecated ICU 2.4. Use U16_NEXT instead, see utf_old.h. */
-#define UTF16_NEXT_CHAR_SAFE(s, i, length, c, strict) { \
-    (c)=(s)[(i)++]; \
-    if(UTF_IS_FIRST_SURROGATE(c)) { \
-        uint16_t __c2; \
-        if((i)<(length) && UTF_IS_SECOND_SURROGATE(__c2=(s)[(i)])) { \
-            ++(i); \
-            (c)=UTF16_GET_PAIR_VALUE((c), __c2); \
-            /* strict: ((c)&0xfffe)==0xfffe is caught by UTF_IS_ERROR() and UTF_IS_UNICODE_CHAR() */ \
-        } else if(strict) {\
-            /* unmatched first surrogate */ \
-            (c)=UTF_ERROR_VALUE; \
-        } \
-    } else if((strict) && !UTF_IS_UNICODE_CHAR(c)) { \
-        /* unmatched second surrogate or other non-character */ \
-        (c)=UTF_ERROR_VALUE; \
-    } \
-}
-
-/** @deprecated ICU 2.4. Use U16_APPEND instead, see utf_old.h. */
-#define UTF16_APPEND_CHAR_SAFE(s, i, length, c) { \
-    if((uint32_t)(c)<=0xffff) { \
-        (s)[(i)++]=(uint16_t)(c); \
-    } else if((uint32_t)(c)<=0x10ffff) { \
-        if((i)+1<(length)) { \
-            (s)[(i)++]=(uint16_t)(((c)>>10)+0xd7c0); \
-            (s)[(i)++]=(uint16_t)(((c)&0x3ff)|0xdc00); \
-        } else /* not enough space */ { \
-            (s)[(i)++]=UTF_ERROR_VALUE; \
-        } \
-    } else /* c>0x10ffff, write error value */ { \
-        (s)[(i)++]=UTF_ERROR_VALUE; \
-    } \
-}
-
-/** @deprecated ICU 2.4. Renamed to U16_FWD_1, see utf_old.h. */
-#define UTF16_FWD_1_SAFE(s, i, length) U16_FWD_1(s, i, length)
-
-/** @deprecated ICU 2.4. Renamed to U16_FWD_N, see utf_old.h. */
-#define UTF16_FWD_N_SAFE(s, i, length, n) U16_FWD_N(s, i, length, n)
-
-/** @deprecated ICU 2.4. Renamed to U16_SET_CP_START, see utf_old.h. */
-#define UTF16_SET_CHAR_START_SAFE(s, start, i) U16_SET_CP_START(s, start, i)
-
-/** @deprecated ICU 2.4. Renamed to U16_PREV_UNSAFE, see utf_old.h. */
-#define UTF16_PREV_CHAR_UNSAFE(s, i, c) { \
-    (c)=(s)[--(i)]; \
-    if(UTF_IS_SECOND_SURROGATE(c)) { \
-        (c)=UTF16_GET_PAIR_VALUE((s)[--(i)], (c)); \
-    } \
-}
-
-/** @deprecated ICU 2.4. Renamed to U16_BACK_1_UNSAFE, see utf_old.h. */
-#define UTF16_BACK_1_UNSAFE(s, i) { \
-    if(UTF_IS_SECOND_SURROGATE((s)[--(i)])) { \
-        --(i); \
-    } \
-}
-
-/** @deprecated ICU 2.4. Renamed to U16_BACK_N_UNSAFE, see utf_old.h. */
-#define UTF16_BACK_N_UNSAFE(s, i, n) { \
-    int32_t __N=(n); \
-    while(__N>0) { \
-        UTF16_BACK_1_UNSAFE(s, i); \
-        --__N; \
-    } \
-}
-
-/** @deprecated ICU 2.4. Renamed to U16_SET_CP_LIMIT_UNSAFE, see utf_old.h. */
-#define UTF16_SET_CHAR_LIMIT_UNSAFE(s, i) { \
-    if(UTF_IS_FIRST_SURROGATE((s)[(i)-1])) { \
-        ++(i); \
-    } \
-}
-
-/** @deprecated ICU 2.4. Use U16_PREV instead, see utf_old.h. */
-#define UTF16_PREV_CHAR_SAFE(s, start, i, c, strict) { \
-    (c)=(s)[--(i)]; \
-    if(UTF_IS_SECOND_SURROGATE(c)) { \
-        uint16_t __c2; \
-        if((i)>(start) && UTF_IS_FIRST_SURROGATE(__c2=(s)[(i)-1])) { \
-            --(i); \
-            (c)=UTF16_GET_PAIR_VALUE(__c2, (c)); \
-            /* strict: ((c)&0xfffe)==0xfffe is caught by UTF_IS_ERROR() and UTF_IS_UNICODE_CHAR() */ \
-        } else if(strict) {\
-            /* unmatched second surrogate */ \
-            (c)=UTF_ERROR_VALUE; \
-        } \
-    } else if((strict) && !UTF_IS_UNICODE_CHAR(c)) { \
-        /* unmatched first surrogate or other non-character */ \
-        (c)=UTF_ERROR_VALUE; \
-    } \
-}
-
-/** @deprecated ICU 2.4. Renamed to U16_BACK_1, see utf_old.h. */
-#define UTF16_BACK_1_SAFE(s, start, i) U16_BACK_1(s, start, i)
-
-/** @deprecated ICU 2.4. Renamed to U16_BACK_N, see utf_old.h. */
-#define UTF16_BACK_N_SAFE(s, start, i, n) U16_BACK_N(s, start, i, n)
-
-/** @deprecated ICU 2.4. Renamed to U16_SET_CP_LIMIT, see utf_old.h. */
-#define UTF16_SET_CHAR_LIMIT_SAFE(s, start, i, length) U16_SET_CP_LIMIT(s, start, i, length)
-
-/* Formerly utf32.h --------------------------------------------------------- */
-
-/*
-* Old documentation:
-*
-*   This file defines macros to deal with UTF-32 code units and code points.
-*   Signatures and semantics are the same as for the similarly named macros
-*   in utf16.h.
-*   utf32.h is included by utf.h after unicode/umachine.h</p>
-*   and some common definitions.
-*   <p><b>Usage:</b>  ICU coding guidelines for if() statements should be followed when using these macros.
-*                  Compound statements (curly braces {}) must be used  for if-else-while...
-*                  bodies and all macro statements should be terminated with semicolon.</p>
-*/
-
-/* internal definitions ----------------------------------------------------- */
-
-/** @deprecated ICU 2.4. Obsolete, see utf_old.h. */
-#define UTF32_IS_SAFE(c, strict) \
-    (!(strict) ? \
-        (uint32_t)(c)<=0x10ffff : \
-        UTF_IS_UNICODE_CHAR(c))
-
-/*
- * For the semantics of all of these macros, see utf16.h.
- * The UTF-32 versions are trivial because any code point is
- * encoded using exactly one code unit.
- */
-
-/* single-code point definitions -------------------------------------------- */
-
-/* classes of code unit values */
-
-/** @deprecated ICU 2.4. Obsolete, see utf_old.h. */
-#define UTF32_IS_SINGLE(uchar) 1
-/** @deprecated ICU 2.4. Obsolete, see utf_old.h. */
-#define UTF32_IS_LEAD(uchar) 0
-/** @deprecated ICU 2.4. Obsolete, see utf_old.h. */
-#define UTF32_IS_TRAIL(uchar) 0
-
-/* number of code units per code point */
-
-/** @deprecated ICU 2.4. Obsolete, see utf_old.h. */
-#define UTF32_NEED_MULTIPLE_UCHAR(c) 0
-/** @deprecated ICU 2.4. Obsolete, see utf_old.h. */
-#define UTF32_CHAR_LENGTH(c) 1
-/** @deprecated ICU 2.4. Obsolete, see utf_old.h. */
-#define UTF32_MAX_CHAR_LENGTH 1
-
-/* average number of code units compared to UTF-16 */
-
-/** @deprecated ICU 2.4. Obsolete, see utf_old.h. */
-#define UTF32_ARRAY_SIZE(size) (size)
-
-/** @deprecated ICU 2.4. Obsolete, see utf_old.h. */
-#define UTF32_GET_CHAR_UNSAFE(s, i, c) { \
-    (c)=(s)[i]; \
-}
-
-/** @deprecated ICU 2.4. Obsolete, see utf_old.h. */
-#define UTF32_GET_CHAR_SAFE(s, start, i, length, c, strict) { \
-    (c)=(s)[i]; \
-    if(!UTF32_IS_SAFE(c, strict)) { \
-        (c)=UTF_ERROR_VALUE; \
-    } \
-}
-
-/* definitions with forward iteration --------------------------------------- */
-
-/** @deprecated ICU 2.4. Obsolete, see utf_old.h. */
-#define UTF32_NEXT_CHAR_UNSAFE(s, i, c) { \
-    (c)=(s)[(i)++]; \
-}
-
-/** @deprecated ICU 2.4. Obsolete, see utf_old.h. */
-#define UTF32_APPEND_CHAR_UNSAFE(s, i, c) { \
-    (s)[(i)++]=(c); \
-}
-
-/** @deprecated ICU 2.4. Obsolete, see utf_old.h. */
-#define UTF32_FWD_1_UNSAFE(s, i) { \
-    ++(i); \
-}
-
-/** @deprecated ICU 2.4. Obsolete, see utf_old.h. */
-#define UTF32_FWD_N_UNSAFE(s, i, n) { \
-    (i)+=(n); \
-}
-
-/** @deprecated ICU 2.4. Obsolete, see utf_old.h. */
-#define UTF32_SET_CHAR_START_UNSAFE(s, i) { \
-}
-
-/** @deprecated ICU 2.4. Obsolete, see utf_old.h. */
-#define UTF32_NEXT_CHAR_SAFE(s, i, length, c, strict) { \
-    (c)=(s)[(i)++]; \
-    if(!UTF32_IS_SAFE(c, strict)) { \
-        (c)=UTF_ERROR_VALUE; \
-    } \
-}
-
-/** @deprecated ICU 2.4. Obsolete, see utf_old.h. */
-#define UTF32_APPEND_CHAR_SAFE(s, i, length, c) { \
-    if((uint32_t)(c)<=0x10ffff) { \
-        (s)[(i)++]=(c); \
-    } else /* c>0x10ffff, write 0xfffd */ { \
-        (s)[(i)++]=0xfffd; \
-    } \
-}
-
-/** @deprecated ICU 2.4. Obsolete, see utf_old.h. */
-#define UTF32_FWD_1_SAFE(s, i, length) { \
-    ++(i); \
-}
-
-/** @deprecated ICU 2.4. Obsolete, see utf_old.h. */
-#define UTF32_FWD_N_SAFE(s, i, length, n) { \
-    if(((i)+=(n))>(length)) { \
-        (i)=(length); \
-    } \
-}
-
-/** @deprecated ICU 2.4. Obsolete, see utf_old.h. */
-#define UTF32_SET_CHAR_START_SAFE(s, start, i) { \
-}
-
-/* definitions with backward iteration -------------------------------------- */
-
-/** @deprecated ICU 2.4. Obsolete, see utf_old.h. */
-#define UTF32_PREV_CHAR_UNSAFE(s, i, c) { \
-    (c)=(s)[--(i)]; \
-}
-
-/** @deprecated ICU 2.4. Obsolete, see utf_old.h. */
-#define UTF32_BACK_1_UNSAFE(s, i) { \
-    --(i); \
-}
-
-/** @deprecated ICU 2.4. Obsolete, see utf_old.h. */
-#define UTF32_BACK_N_UNSAFE(s, i, n) { \
-    (i)-=(n); \
-}
-
-/** @deprecated ICU 2.4. Obsolete, see utf_old.h. */
-#define UTF32_SET_CHAR_LIMIT_UNSAFE(s, i) { \
-}
-
-/** @deprecated ICU 2.4. Obsolete, see utf_old.h. */
-#define UTF32_PREV_CHAR_SAFE(s, start, i, c, strict) { \
-    (c)=(s)[--(i)]; \
-    if(!UTF32_IS_SAFE(c, strict)) { \
-        (c)=UTF_ERROR_VALUE; \
-    } \
-}
-
-/** @deprecated ICU 2.4. Obsolete, see utf_old.h. */
-#define UTF32_BACK_1_SAFE(s, start, i) { \
-    --(i); \
-}
-
-/** @deprecated ICU 2.4. Obsolete, see utf_old.h. */
-#define UTF32_BACK_N_SAFE(s, start, i, n) { \
-    (i)-=(n); \
-    if((i)<(start)) { \
-        (i)=(start); \
-    } \
-}
-
-/** @deprecated ICU 2.4. Obsolete, see utf_old.h. */
-#define UTF32_SET_CHAR_LIMIT_SAFE(s, i, length) { \
-}
-
-/* Formerly utf.h, part 2 --------------------------------------------------- */
-
-/**
- * Estimate the number of code units for a string based on the number of UTF-16 code units.
- *
- * @deprecated ICU 2.4. Obsolete, see utf_old.h.
- */
-#define UTF_ARRAY_SIZE(size) UTF16_ARRAY_SIZE(size)
-
-/** @deprecated ICU 2.4. Renamed to U16_GET_UNSAFE, see utf_old.h. */
-#define UTF_GET_CHAR_UNSAFE(s, i, c)                 UTF16_GET_CHAR_UNSAFE(s, i, c)
-
-/** @deprecated ICU 2.4. Use U16_GET instead, see utf_old.h. */
-#define UTF_GET_CHAR_SAFE(s, start, i, length, c, strict) UTF16_GET_CHAR_SAFE(s, start, i, length, c, strict)
-
-
-/** @deprecated ICU 2.4. Renamed to U16_NEXT_UNSAFE, see utf_old.h. */
-#define UTF_NEXT_CHAR_UNSAFE(s, i, c)                UTF16_NEXT_CHAR_UNSAFE(s, i, c)
-
-/** @deprecated ICU 2.4. Use U16_NEXT instead, see utf_old.h. */
-#define UTF_NEXT_CHAR_SAFE(s, i, length, c, strict)  UTF16_NEXT_CHAR_SAFE(s, i, length, c, strict)
-
-
-/** @deprecated ICU 2.4. Renamed to U16_APPEND_UNSAFE, see utf_old.h. */
-#define UTF_APPEND_CHAR_UNSAFE(s, i, c)              UTF16_APPEND_CHAR_UNSAFE(s, i, c)
-
-/** @deprecated ICU 2.4. Use U16_APPEND instead, see utf_old.h. */
-#define UTF_APPEND_CHAR_SAFE(s, i, length, c)        UTF16_APPEND_CHAR_SAFE(s, i, length, c)
-
-
-/** @deprecated ICU 2.4. Renamed to U16_FWD_1_UNSAFE, see utf_old.h. */
-#define UTF_FWD_1_UNSAFE(s, i)                       UTF16_FWD_1_UNSAFE(s, i)
-
-/** @deprecated ICU 2.4. Renamed to U16_FWD_1, see utf_old.h. */
-#define UTF_FWD_1_SAFE(s, i, length)                 UTF16_FWD_1_SAFE(s, i, length)
-
-
-/** @deprecated ICU 2.4. Renamed to U16_FWD_N_UNSAFE, see utf_old.h. */
-#define UTF_FWD_N_UNSAFE(s, i, n)                    UTF16_FWD_N_UNSAFE(s, i, n)
-
-/** @deprecated ICU 2.4. Renamed to U16_FWD_N, see utf_old.h. */
-#define UTF_FWD_N_SAFE(s, i, length, n)              UTF16_FWD_N_SAFE(s, i, length, n)
-
-
-/** @deprecated ICU 2.4. Renamed to U16_SET_CP_START_UNSAFE, see utf_old.h. */
-#define UTF_SET_CHAR_START_UNSAFE(s, i)              UTF16_SET_CHAR_START_UNSAFE(s, i)
-
-/** @deprecated ICU 2.4. Renamed to U16_SET_CP_START, see utf_old.h. */
-#define UTF_SET_CHAR_START_SAFE(s, start, i)         UTF16_SET_CHAR_START_SAFE(s, start, i)
-
-
-/** @deprecated ICU 2.4. Renamed to U16_PREV_UNSAFE, see utf_old.h. */
-#define UTF_PREV_CHAR_UNSAFE(s, i, c)                UTF16_PREV_CHAR_UNSAFE(s, i, c)
-
-/** @deprecated ICU 2.4. Use U16_PREV instead, see utf_old.h. */
-#define UTF_PREV_CHAR_SAFE(s, start, i, c, strict)   UTF16_PREV_CHAR_SAFE(s, start, i, c, strict)
-
-
-/** @deprecated ICU 2.4. Renamed to U16_BACK_1_UNSAFE, see utf_old.h. */
-#define UTF_BACK_1_UNSAFE(s, i)                      UTF16_BACK_1_UNSAFE(s, i)
-
-/** @deprecated ICU 2.4. Renamed to U16_BACK_1, see utf_old.h. */
-#define UTF_BACK_1_SAFE(s, start, i)                 UTF16_BACK_1_SAFE(s, start, i)
-
-
-/** @deprecated ICU 2.4. Renamed to U16_BACK_N_UNSAFE, see utf_old.h. */
-#define UTF_BACK_N_UNSAFE(s, i, n)                   UTF16_BACK_N_UNSAFE(s, i, n)
-
-/** @deprecated ICU 2.4. Renamed to U16_BACK_N, see utf_old.h. */
-#define UTF_BACK_N_SAFE(s, start, i, n)              UTF16_BACK_N_SAFE(s, start, i, n)
-
-
-/** @deprecated ICU 2.4. Renamed to U16_SET_CP_LIMIT_UNSAFE, see utf_old.h. */
-#define UTF_SET_CHAR_LIMIT_UNSAFE(s, i)              UTF16_SET_CHAR_LIMIT_UNSAFE(s, i)
-
-/** @deprecated ICU 2.4. Renamed to U16_SET_CP_LIMIT, see utf_old.h. */
-#define UTF_SET_CHAR_LIMIT_SAFE(s, start, i, length) UTF16_SET_CHAR_LIMIT_SAFE(s, start, i, length)
-
-/* Define default macros (UTF-16 "safe") ------------------------------------ */
-
-/**
- * Does this code unit alone encode a code point (BMP, not a surrogate)?
- * Same as UTF16_IS_SINGLE.
- * @deprecated ICU 2.4. Renamed to U_IS_SINGLE and U16_IS_SINGLE, see utf_old.h.
- */
-#define UTF_IS_SINGLE(uchar) U16_IS_SINGLE(uchar)
-
-/**
- * Is this code unit the first one of several (a lead surrogate)?
- * Same as UTF16_IS_LEAD.
- * @deprecated ICU 2.4. Renamed to U_IS_LEAD and U16_IS_LEAD, see utf_old.h.
- */
-#define UTF_IS_LEAD(uchar) U16_IS_LEAD(uchar)
-
-/**
- * Is this code unit one of several but not the first one (a trail surrogate)?
- * Same as UTF16_IS_TRAIL.
- * @deprecated ICU 2.4. Renamed to U_IS_TRAIL and U16_IS_TRAIL, see utf_old.h.
- */
-#define UTF_IS_TRAIL(uchar) U16_IS_TRAIL(uchar)
-
-/**
- * Does this code point require multiple code units (is it a supplementary code point)?
- * Same as UTF16_NEED_MULTIPLE_UCHAR.
- * @deprecated ICU 2.4. Use U16_LENGTH or test ((uint32_t)(c)>0xffff) instead.
- */
-#define UTF_NEED_MULTIPLE_UCHAR(c) UTF16_NEED_MULTIPLE_UCHAR(c)
-
-/**
- * How many code units are used to encode this code point (1 or 2)?
- * Same as UTF16_CHAR_LENGTH.
- * @deprecated ICU 2.4. Renamed to U16_LENGTH, see utf_old.h.
- */
-#define UTF_CHAR_LENGTH(c) U16_LENGTH(c)
-
-/**
- * How many code units are used at most for any Unicode code point (2)?
- * Same as UTF16_MAX_CHAR_LENGTH.
- * @deprecated ICU 2.4. Renamed to U16_MAX_LENGTH, see utf_old.h.
- */
-#define UTF_MAX_CHAR_LENGTH U16_MAX_LENGTH
-
-/**
- * Set c to the code point that contains the code unit i.
- * i could point to the lead or the trail surrogate for the code point.
- * i is not modified.
- * Same as UTF16_GET_CHAR.
- * \pre 0<=i<length
- *
- * @deprecated ICU 2.4. Renamed to U16_GET, see utf_old.h.
- */
-#define UTF_GET_CHAR(s, start, i, length, c) U16_GET(s, start, i, length, c)
-
-/**
- * Set c to the code point that starts at code unit i
- * and advance i to beyond the code units of this code point (post-increment).
- * i must point to the first code unit of a code point.
- * Otherwise c is set to the trail unit (surrogate) itself.
- * Same as UTF16_NEXT_CHAR.
- * \pre 0<=i<length
- * \post 0<i<=length
- *
- * @deprecated ICU 2.4. Renamed to U16_NEXT, see utf_old.h.
- */
-#define UTF_NEXT_CHAR(s, i, length, c) U16_NEXT(s, i, length, c)
-
-/**
- * Append the code units of code point c to the string at index i
- * and advance i to beyond the new code units (post-increment).
- * The code units beginning at index i will be overwritten.
- * Same as UTF16_APPEND_CHAR.
- * \pre 0<=c<=0x10ffff
- * \pre 0<=i<length
- * \post 0<i<=length
- *
- * @deprecated ICU 2.4. Use U16_APPEND instead, see utf_old.h.
- */
-#define UTF_APPEND_CHAR(s, i, length, c) UTF16_APPEND_CHAR_SAFE(s, i, length, c)
-
-/**
- * Advance i to beyond the code units of the code point that begins at i.
- * I.e., advance i by one code point.
- * Same as UTF16_FWD_1.
- * \pre 0<=i<length
- * \post 0<i<=length
- *
- * @deprecated ICU 2.4. Renamed to U16_FWD_1, see utf_old.h.
- */
-#define UTF_FWD_1(s, i, length) U16_FWD_1(s, i, length)
-
-/**
- * Advance i to beyond the code units of the n code points where the first one begins at i.
- * I.e., advance i by n code points.
- * Same as UT16_FWD_N.
- * \pre 0<=i<length
- * \post 0<i<=length
- *
- * @deprecated ICU 2.4. Renamed to U16_FWD_N, see utf_old.h.
- */
-#define UTF_FWD_N(s, i, length, n) U16_FWD_N(s, i, length, n)
-
-/**
- * Take the random-access index i and adjust it so that it points to the beginning
- * of a code point.
- * The input index points to any code unit of a code point and is moved to point to
- * the first code unit of the same code point. i is never incremented.
- * In other words, if i points to a trail surrogate that is preceded by a matching
- * lead surrogate, then i is decremented. Otherwise it is not modified.
- * This can be used to start an iteration with UTF_NEXT_CHAR() from a random index.
- * Same as UTF16_SET_CHAR_START.
- * \pre start<=i<length
- * \post start<=i<length
- *
- * @deprecated ICU 2.4. Renamed to U16_SET_CP_START, see utf_old.h.
- */
-#define UTF_SET_CHAR_START(s, start, i) U16_SET_CP_START(s, start, i)
-
-/**
- * Set c to the code point that has code units before i
- * and move i backward (towards the beginning of the string)
- * to the first code unit of this code point (pre-increment).
- * i must point to the first code unit after the last unit of a code point (i==length is allowed).
- * Same as UTF16_PREV_CHAR.
- * \pre start<i<=length
- * \post start<=i<length
- *
- * @deprecated ICU 2.4. Renamed to U16_PREV, see utf_old.h.
- */
-#define UTF_PREV_CHAR(s, start, i, c) U16_PREV(s, start, i, c)
-
-/**
- * Move i backward (towards the beginning of the string)
- * to the first code unit of the code point that has code units before i.
- * I.e., move i backward by one code point.
- * i must point to the first code unit after the last unit of a code point (i==length is allowed).
- * Same as UTF16_BACK_1.
- * \pre start<i<=length
- * \post start<=i<length
- *
- * @deprecated ICU 2.4. Renamed to U16_BACK_1, see utf_old.h.
- */
-#define UTF_BACK_1(s, start, i) U16_BACK_1(s, start, i)
-
-/**
- * Move i backward (towards the beginning of the string)
- * to the first code unit of the n code points that have code units before i.
- * I.e., move i backward by n code points.
- * i must point to the first code unit after the last unit of a code point (i==length is allowed).
- * Same as UTF16_BACK_N.
- * \pre start<i<=length
- * \post start<=i<length
- *
- * @deprecated ICU 2.4. Renamed to U16_BACK_N, see utf_old.h.
- */
-#define UTF_BACK_N(s, start, i, n) U16_BACK_N(s, start, i, n)
-
-/**
- * Take the random-access index i and adjust it so that it points beyond
- * a code point. The input index points beyond any code unit
- * of a code point and is moved to point beyond the last code unit of the same
- * code point. i is never decremented.
- * In other words, if i points to a trail surrogate that is preceded by a matching
- * lead surrogate, then i is incremented. Otherwise it is not modified.
- * This can be used to start an iteration with UTF_PREV_CHAR() from a random index.
- * Same as UTF16_SET_CHAR_LIMIT.
- * \pre start<i<=length
- * \post start<i<=length
- *
- * @deprecated ICU 2.4. Renamed to U16_SET_CP_LIMIT, see utf_old.h.
- */
-#define UTF_SET_CHAR_LIMIT(s, start, i, length) U16_SET_CP_LIMIT(s, start, i, length)
-
-#endif /* U_HIDE_DEPRECATED_API */
-
-#endif
-

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/utmscale.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/utmscale.h b/apps/couch_collate/platform/osx/icu/unicode/utmscale.h
deleted file mode 100644
index 368e426..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/utmscale.h
+++ /dev/null
@@ -1,481 +0,0 @@
-/*
-*******************************************************************************
-* Copyright (C) 2004 - 2008, International Business Machines Corporation and
-* others. All Rights Reserved.
-*******************************************************************************
-*/
-
-#ifndef UTMSCALE_H
-#define UTMSCALE_H
-
-#include "unicode/utypes.h"
-
-#if !UCONFIG_NO_FORMATTING
-
-/** 
- * \file
- * \brief C API: Universal Time Scale
- *
- * There are quite a few different conventions for binary datetime, depending on different
- * platforms and protocols. Some of these have severe drawbacks. For example, people using
- * Unix time (seconds since Jan 1, 1970) think that they are safe until near the year 2038.
- * But cases can and do arise where arithmetic manipulations causes serious problems. Consider
- * the computation of the average of two datetimes, for example: if one calculates them with
- * <code>averageTime = (time1 + time2)/2</code>, there will be overflow even with dates
- * around the present. Moreover, even if these problems don't occur, there is the issue of
- * conversion back and forth between different systems.
- *
- * <p>
- * Binary datetimes differ in a number of ways: the datatype, the unit,
- * and the epoch (origin). We'll refer to these as time scales. For example:
- *
- * <table border="1" cellspacing="0" cellpadding="4">
- *  <caption>Table 1: Binary Time Scales</caption>
- *  <tr>
- *    <th align="left">Source</th>
- *    <th align="left">Datatype</th>
- *    <th align="left">Unit</th>
- *    <th align="left">Epoch</th>
- *  </tr>
- *
- *  <tr>
- *    <td>UDTS_JAVA_TIME</td>
- *    <td>int64_t</td>
- *    <td>milliseconds</td>
- *    <td>Jan 1, 1970</td>
- *  </tr>
- *  <tr>
- *
- *    <td>UDTS_UNIX_TIME</td>
- *    <td>int32_t or int64_t</td>
- *    <td>seconds</td>
- *    <td>Jan 1, 1970</td>
- *  </tr>
- *  <tr>
- *    <td>UDTS_ICU4C_TIME</td>
- *
- *    <td>double</td>
- *    <td>milliseconds</td>
- *    <td>Jan 1, 1970</td>
- *  </tr>
- *  <tr>
- *    <td>UDTS_WINDOWS_FILE_TIME</td>
- *    <td>int64_t</td>
- *
- *    <td>ticks (100 nanoseconds)</td>
- *    <td>Jan 1, 1601</td>
- *  </tr>
- *  <tr>
- *    <td>UDTS_DOTNET_DATE_TIME</td>
- *    <td>int64_t</td>
- *    <td>ticks (100 nanoseconds)</td>
- *
- *    <td>Jan 1, 0001</td>
- *  </tr>
- *  <tr>
- *    <td>UDTS_MAC_OLD_TIME</td>
- *    <td>int32_t or int64_t</td>
- *    <td>seconds</td>
- *    <td>Jan 1, 1904</td>
- *
- *  </tr>
- *  <tr>
- *    <td>UDTS_MAC_TIME</td>
- *    <td>double</td>
- *    <td>seconds</td>
- *    <td>Jan 1, 2001</td>
- *  </tr>
- *
- *  <tr>
- *    <td>UDTS_EXCEL_TIME</td>
- *    <td>?</td>
- *    <td>days</td>
- *    <td>Dec 31, 1899</td>
- *  </tr>
- *  <tr>
- *
- *    <td>UDTS_DB2_TIME</td>
- *    <td>?</td>
- *    <td>days</td>
- *    <td>Dec 31, 1899</td>
- *  </tr>
- *
- *  <tr>
- *    <td>UDTS_UNIX_MICROSECONDS_TIME</td>
- *    <td>int64_t</td>
- *    <td>microseconds</td>
- *    <td>Jan 1, 1970</td>
- *  </tr>
- * </table>
- *
- * <p>
- * All of the epochs start at 00:00 am (the earliest possible time on the day in question),
- * and are assumed to be UTC.
- *
- * <p>
- * The ranges for different datatypes are given in the following table (all values in years).
- * The range of years includes the entire range expressible with positive and negative
- * values of the datatype. The range of years for double is the range that would be allowed
- * without losing precision to the corresponding unit.
- *
- * <table border="1" cellspacing="0" cellpadding="4">
- *  <tr>
- *    <th align="left">Units</th>
- *    <th align="left">int64_t</th>
- *    <th align="left">double</th>
- *    <th align="left">int32_t</th>
- *  </tr>
- *
- *  <tr>
- *    <td>1 sec</td>
- *    <td align="right">5.84542x10<sup>11</sup></td>
- *    <td align="right">285,420,920.94</td>
- *    <td align="right">136.10</td>
- *  </tr>
- *  <tr>
- *
- *    <td>1 millisecond</td>
- *    <td align="right">584,542,046.09</td>
- *    <td align="right">285,420.92</td>
- *    <td align="right">0.14</td>
- *  </tr>
- *  <tr>
- *    <td>1 microsecond</td>
- *
- *    <td align="right">584,542.05</td>
- *    <td align="right">285.42</td>
- *    <td align="right">0.00</td>
- *  </tr>
- *  <tr>
- *    <td>100 nanoseconds (tick)</td>
- *    <td align="right">58,454.20</td>
- *    <td align="right">28.54</td>
- *    <td align="right">0.00</td>
- *  </tr>
- *  <tr>
- *    <td>1 nanosecond</td>
- *    <td align="right">584.5420461</td>
- *    <td align="right">0.2854</td>
- *    <td align="right">0.00</td>
- *  </tr>
- * </table>
- *
- * <p>
- * These functions implement a universal time scale which can be used as a 'pivot',
- * and provide conversion functions to and from all other major time scales.
- * This datetimes to be converted to the pivot time, safely manipulated,
- * and converted back to any other datetime time scale.
- *
- *<p>
- * So what to use for this pivot? Java time has plenty of range, but cannot represent
- * .NET <code>System.DateTime</code> values without severe loss of precision. ICU4C time addresses this by using a
- * <code>double</code> that is otherwise equivalent to the Java time. However, there are disadvantages
- * with <code>doubles</code>. They provide for much more graceful degradation in arithmetic operations.
- * But they only have 53 bits of accuracy, which means that they will lose precision when
- * converting back and forth to ticks. What would really be nice would be a
- * <code>long double</code> (80 bits -- 64 bit mantissa), but that is not supported on most systems.
- *
- *<p>
- * The Unix extended time uses a structure with two components: time in seconds and a
- * fractional field (microseconds). However, this is clumsy, slow, and
- * prone to error (you always have to keep track of overflow and underflow in the
- * fractional field). <code>BigDecimal</code> would allow for arbitrary precision and arbitrary range,
- * but we do not want to use this as the normal type, because it is slow and does not
- * have a fixed size.
- *
- *<p>
- * Because of these issues, we ended up concluding that the .NET framework's
- * <code>System.DateTime</code> would be the best pivot. However, we use the full range
- * allowed by the datatype, allowing for datetimes back to 29,000 BC and up to 29,000 AD.
- * This time scale is very fine grained, does not lose precision, and covers a range that
- * will meet almost all requirements. It will not handle the range that Java times do,
- * but frankly, being able to handle dates before 29,000 BC or after 29,000 AD is of very limited interest.
- *
- */
-
-/**
- * <code>UDateTimeScale</code> values are used to specify the time scale used for
- * conversion into or out if the universal time scale.
- *
- * @stable ICU 3.2
- */
-typedef enum UDateTimeScale {
-    /**
-     * Used in the JDK. Data is a Java <code>long</code> (<code>int64_t</code>). Value
-     * is milliseconds since January 1, 1970.
-     *
-     * @stable ICU 3.2
-     */
-    UDTS_JAVA_TIME = 0,
-
-    /**
-     * Used on Unix systems. Data is <code>int32_t</code> or <code>int64_t</code>. Value
-     * is seconds since January 1, 1970.
-     *
-     * @stable ICU 3.2
-     */
-    UDTS_UNIX_TIME,
-    
-    /**
-     * Used in IUC4C. Data is a <code>double</code>. Value
-     * is milliseconds since January 1, 1970.
-     *
-     * @stable ICU 3.2
-     */
-    UDTS_ICU4C_TIME,
-    
-    /**
-     * Used in Windows for file times. Data is an <code>int64_t</code>. Value
-     * is ticks (1 tick == 100 nanoseconds) since January 1, 1601.
-     *
-     * @stable ICU 3.2
-     */
-    UDTS_WINDOWS_FILE_TIME,
-    
-    /**
-     * Used in the .NET framework's <code>System.DateTime</code> structure. Data is an <code>int64_t</code>. Value
-     * is ticks (1 tick == 100 nanoseconds) since January 1, 0001.
-     *
-     * @stable ICU 3.2
-     */
-    UDTS_DOTNET_DATE_TIME,
-    
-    /**
-     * Used in older Macintosh systems. Data is <code>int32_t</code> or <code>int64_t</code>. Value
-     * is seconds since January 1, 1904.
-     *
-     * @stable ICU 3.2
-     */
-    UDTS_MAC_OLD_TIME,
-    
-    /**
-     * Used in newer Macintosh systems. Data is a <code>double</code>. Value
-     * is seconds since January 1, 2001.
-     *
-     * @stable ICU 3.2
-     */
-    UDTS_MAC_TIME,
-    
-    /**
-     * Used in Excel. Data is an <code>?unknown?</code>. Value
-     * is days since December 31, 1899.
-     *
-     * @stable ICU 3.2
-     */
-    UDTS_EXCEL_TIME,
-    
-    /**
-     * Used in DB2. Data is an <code>?unknown?</code>. Value
-     * is days since December 31, 1899.
-     *
-     * @stable ICU 3.2
-     */
-    UDTS_DB2_TIME,
-
-    /**
-     * Data is a <code>long</code>. Value is microseconds since January 1, 1970.
-     * Similar to Unix time (linear value from 1970) and struct timeval
-     * (microseconds resolution).
-     *
-     * @stable ICU 4.0
-     */
-    UDTS_UNIX_MICROSECONDS_TIME,
-
-    /**
-     * The first unused time scale value. The limit of this enum
-     */
-    UDTS_MAX_SCALE
-} UDateTimeScale;
-
-/**
- * <code>UTimeScaleValue</code> values are used to specify the time scale values
- * to <code>utmscale_getTimeScaleValue</code>.
- *
- * @see utmscale_getTimeScaleValue
- *
- * @stable ICU 3.2
- */
-typedef enum UTimeScaleValue {
-    /**
-     * The constant used to select the units vale
-     * for a time scale.
-     * 
-     * @see utmscale_getTimeScaleValue
-     *
-     * @stable ICU 3.2
-     */
-    UTSV_UNITS_VALUE = 0,
-
-    /**
-     * The constant used to select the epoch offset value
-     * for a time scale.
-     * 
-     * @see utmscale_getTimeScaleValue
-     *
-     * @stable ICU 3.2
-     */
-    UTSV_EPOCH_OFFSET_VALUE=1,
-
-    /**
-     * The constant used to select the minimum from value
-     * for a time scale.
-     * 
-     * @see utmscale_getTimeScaleValue
-     *
-     * @stable ICU 3.2
-     */
-    UTSV_FROM_MIN_VALUE=2,
-
-    /**
-     * The constant used to select the maximum from value
-     * for a time scale.
-     * 
-     * @see utmscale_getTimeScaleValue
-     *
-     * @stable ICU 3.2
-     */
-    UTSV_FROM_MAX_VALUE=3,
-
-    /**
-     * The constant used to select the minimum to value
-     * for a time scale.
-     * 
-     * @see utmscale_getTimeScaleValue
-     *
-     * @stable ICU 3.2
-     */
-    UTSV_TO_MIN_VALUE=4,
-
-    /**
-     * The constant used to select the maximum to value
-     * for a time scale.
-     * 
-     * @see utmscale_getTimeScaleValue
-     *
-     * @stable ICU 3.2
-     */
-    UTSV_TO_MAX_VALUE=5,
-
-#ifndef U_HIDE_INTERNAL_API
-    /**
-     * The constant used to select the epoch plus one value
-     * for a time scale.
-     * 
-     * NOTE: This is an internal value. DO NOT USE IT. May not
-     * actually be equal to the epoch offset value plus one.
-     * 
-     * @see utmscale_getTimeScaleValue
-     *
-     * @internal ICU 3.2
-     */
-    UTSV_EPOCH_OFFSET_PLUS_1_VALUE=6,
-
-    /**
-     * The constant used to select the epoch plus one value
-     * for a time scale.
-     * 
-     * NOTE: This is an internal value. DO NOT USE IT. May not
-     * actually be equal to the epoch offset value plus one.
-     * 
-     * @see utmscale_getTimeScaleValue
-     *
-     * @internal ICU 3.2
-     */
-    UTSV_EPOCH_OFFSET_MINUS_1_VALUE=7,
-
-    /**
-     * The constant used to select the units round value
-     * for a time scale.
-     * 
-     * NOTE: This is an internal value. DO NOT USE IT.
-     * 
-     * @see utmscale_getTimeScaleValue
-     *
-     * @internal ICU 3.2
-     */
-    UTSV_UNITS_ROUND_VALUE=8,
-
-    /**
-     * The constant used to select the minimum safe rounding value
-     * for a time scale.
-     * 
-     * NOTE: This is an internal value. DO NOT USE IT.
-     * 
-     * @see utmscale_getTimeScaleValue
-     *
-     * @internal ICU 3.2
-     */
-    UTSV_MIN_ROUND_VALUE=9,
-
-    /**
-     * The constant used to select the maximum safe rounding value
-     * for a time scale.
-     * 
-     * NOTE: This is an internal value. DO NOT USE IT.
-     * 
-     * @see utmscale_getTimeScaleValue
-     *
-     * @internal ICU 3.2
-     */
-    UTSV_MAX_ROUND_VALUE=10,
-
-#endif /* U_HIDE_INTERNAL_API */
-
-    /**
-     * The number of time scale values, in other words limit of this enum.
-     * 
-     * @see utmscale_getTimeScaleValue
-     */
-    UTSV_MAX_SCALE_VALUE=11
-
-} UTimeScaleValue;
-
-/**
- * Get a value associated with a particular time scale.
- * 
- * @param timeScale The time scale
- * @param value A constant representing the value to get
- * @param status The status code. Set to <code>U_ILLEGAL_ARGUMENT_ERROR</code> if arguments are invalid.
- * @return - the value.
- * 
- * @stable ICU 3.2
- */
-U_STABLE int64_t U_EXPORT2
-    utmscale_getTimeScaleValue(UDateTimeScale timeScale, UTimeScaleValue value, UErrorCode *status);
-
-/* Conversion to 'universal time scale' */
-
-/**
- * Convert a <code>int64_t</code> datetime from the given time scale to the universal time scale.
- *
- * @param otherTime The <code>int64_t</code> datetime
- * @param timeScale The time scale to convert from
- * @param status The status code. Set to <code>U_ILLEGAL_ARGUMENT_ERROR</code> if the conversion is out of range.
- * 
- * @return The datetime converted to the universal time scale
- *
- * @stable ICU 3.2
- */
-U_STABLE int64_t U_EXPORT2
-    utmscale_fromInt64(int64_t otherTime, UDateTimeScale timeScale, UErrorCode *status);
-
-/* Conversion from 'universal time scale' */
-
-/**
- * Convert a datetime from the universal time scale to a <code>int64_t</code> in the given time scale.
- *
- * @param universalTime The datetime in the universal time scale
- * @param timeScale The time scale to convert to
- * @param status The status code. Set to <code>U_ILLEGAL_ARGUMENT_ERROR</code> if the conversion is out of range.
- * 
- * @return The datetime converted to the given time scale
- *
- * @stable ICU 3.2
- */
-U_STABLE int64_t U_EXPORT2
-    utmscale_toInt64(int64_t universalTime, UDateTimeScale timeScale, UErrorCode *status);
-
-#endif /* #if !UCONFIG_NO_FORMATTING */
-
-#endif
-


[28/57] [abbrv] remove couch_collate

Posted by be...@apache.org.
http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/schriter.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/schriter.h b/apps/couch_collate/platform/osx/icu/unicode/schriter.h
deleted file mode 100644
index d0b5e22..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/schriter.h
+++ /dev/null
@@ -1,187 +0,0 @@
-/*
-******************************************************************************
-*
-*   Copyright (C) 1998-2005, International Business Machines
-*   Corporation and others.  All Rights Reserved.
-*
-******************************************************************************
-*
-* File schriter.h
-*
-* Modification History:
-*
-*   Date        Name        Description
-*  05/05/99     stephen     Cleaned up.
-******************************************************************************
-*/
-
-#ifndef SCHRITER_H
-#define SCHRITER_H
-
-#include "unicode/utypes.h"
-#include "unicode/chariter.h"
-#include "unicode/uchriter.h"
-
-/**
- * \file 
- * \brief C++ API: String Character Iterator
- */
- 
-U_NAMESPACE_BEGIN
-/**
- * A concrete subclass of CharacterIterator that iterates over the
- * characters (code units or code points) in a UnicodeString.
- * It's possible not only to create an
- * iterator that iterates over an entire UnicodeString, but also to
- * create one that iterates over only a subrange of a UnicodeString
- * (iterators over different subranges of the same UnicodeString don't
- * compare equal).
- * @see CharacterIterator
- * @see ForwardCharacterIterator
- * @stable ICU 2.0
- */
-class U_COMMON_API StringCharacterIterator : public UCharCharacterIterator {
-public:
-  /**
-   * Create an iterator over the UnicodeString referred to by "textStr".
-   * The UnicodeString object is copied.
-   * The iteration range is the whole string, and the starting position is 0.
-   * @param textStr The unicode string used to create an iterator
-   * @stable ICU 2.0
-   */
-  StringCharacterIterator(const UnicodeString& textStr);
-
-  /**
-   * Create an iterator over the UnicodeString referred to by "textStr".
-   * The iteration range is the whole string, and the starting
-   * position is specified by "textPos".  If "textPos" is outside the valid
-   * iteration range, the behavior of this object is undefined.
-   * @param textStr The unicode string used to create an iterator
-   * @param textPos The starting position of the iteration
-   * @stable ICU 2.0
-   */
-  StringCharacterIterator(const UnicodeString&    textStr,
-              int32_t              textPos);
-
-  /**
-   * Create an iterator over the UnicodeString referred to by "textStr".
-   * The UnicodeString object is copied.
-   * The iteration range begins with the code unit specified by
-   * "textBegin" and ends with the code unit BEFORE the code unit specfied
-   * by "textEnd".  The starting position is specified by "textPos".  If
-   * "textBegin" and "textEnd" don't form a valid range on "text" (i.e.,
-   * textBegin >= textEnd or either is negative or greater than text.size()),
-   * or "textPos" is outside the range defined by "textBegin" and "textEnd",
-   * the behavior of this iterator is undefined.
-   * @param textStr    The unicode string used to create the StringCharacterIterator
-   * @param textBegin  The begin position of the iteration range
-   * @param textEnd    The end position of the iteration range
-   * @param textPos    The starting position of the iteration
-   * @stable ICU 2.0
-   */
-  StringCharacterIterator(const UnicodeString&    textStr,
-              int32_t              textBegin,
-              int32_t              textEnd,
-              int32_t              textPos);
-
-  /**
-   * Copy constructor.  The new iterator iterates over the same range
-   * of the same string as "that", and its initial position is the
-   * same as "that"'s current position.
-   * The UnicodeString object in "that" is copied.
-   * @param that The StringCharacterIterator to be copied
-   * @stable ICU 2.0
-   */
-  StringCharacterIterator(const StringCharacterIterator&  that);
-
-  /**
-   * Destructor.
-   * @stable ICU 2.0
-   */
-  virtual ~StringCharacterIterator();
-
-  /**
-   * Assignment operator.  *this is altered to iterate over the same
-   * range of the same string as "that", and refers to the same
-   * character within that string as "that" does.
-   * @param that The object to be copied.
-   * @return the newly created object.
-   * @stable ICU 2.0
-   */
-  StringCharacterIterator&
-  operator=(const StringCharacterIterator&    that);
-
-  /**
-   * Returns true if the iterators iterate over the same range of the
-   * same string and are pointing at the same character.
-   * @param that The ForwardCharacterIterator to be compared for equality
-   * @return true if the iterators iterate over the same range of the
-   * same string and are pointing at the same character.
-   * @stable ICU 2.0
-   */
-  virtual UBool          operator==(const ForwardCharacterIterator& that) const;
-
-  /**
-   * Returns a new StringCharacterIterator referring to the same
-   * character in the same range of the same string as this one.  The
-   * caller must delete the new iterator.
-   * @return the newly cloned object.
-   * @stable ICU 2.0
-   */
-  virtual CharacterIterator* clone(void) const;
-
-  /**
-   * Sets the iterator to iterate over the provided string.
-   * @param newText The string to be iterated over
-   * @stable ICU 2.0
-   */
-  void setText(const UnicodeString& newText);
-
-  /**
-   * Copies the UnicodeString under iteration into the UnicodeString
-   * referred to by "result".  Even if this iterator iterates across
-   * only a part of this string, the whole string is copied.
-   * @param result Receives a copy of the text under iteration.
-   * @stable ICU 2.0
-   */
-  virtual void            getText(UnicodeString& result);
-
-  /**
-   * Return a class ID for this object (not really public)
-   * @return a class ID for this object.
-   * @stable ICU 2.0
-   */
-  virtual UClassID         getDynamicClassID(void) const;
-
-  /**
-   * Return a class ID for this class (not really public)
-   * @return a class ID for this class
-   * @stable ICU 2.0
-   */
-  static UClassID   U_EXPORT2 getStaticClassID(void);
-
-protected:
-  /**
-   * Default constructor, iteration over empty string.
-   * @stable ICU 2.0
-   */
-  StringCharacterIterator();
-
-  /**
-   * Sets the iterator to iterate over the provided string.
-   * @param newText The string to be iterated over
-   * @param newTextLength The length of the String
-   * @stable ICU 2.0
-   */
-  void setText(const UChar* newText, int32_t newTextLength);
-
-  /**
-   * Copy of the iterated string object.
-   * @stable ICU 2.0
-   */
-  UnicodeString            text;
-
-};
-
-U_NAMESPACE_END
-#endif

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/search.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/search.h b/apps/couch_collate/platform/osx/icu/unicode/search.h
deleted file mode 100644
index 8b82906..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/search.h
+++ /dev/null
@@ -1,569 +0,0 @@
-/*
-**********************************************************************
-*   Copyright (C) 2001-2008 IBM and others. All rights reserved.
-**********************************************************************
-*   Date        Name        Description
-*  03/22/2000   helena      Creation.
-**********************************************************************
-*/
-
-#ifndef SEARCH_H
-#define SEARCH_H
-
-#include "unicode/utypes.h"
-
-/**
- * \file 
- * \brief C++ API: SearchIterator object.
- */
- 
-#if !UCONFIG_NO_COLLATION && !UCONFIG_NO_BREAK_ITERATION
-
-#include "unicode/uobject.h"
-#include "unicode/unistr.h"
-#include "unicode/chariter.h"
-#include "unicode/brkiter.h"
-#include "unicode/usearch.h"
-
-/**
-* @stable ICU 2.0
-*/
-struct USearch;
-/**
-* @stable ICU 2.0
-*/
-typedef struct USearch USearch;
-
-U_NAMESPACE_BEGIN
-
-/**
- *
- * <tt>SearchIterator</tt> is an abstract base class that provides 
- * methods to search for a pattern within a text string. Instances of
- * <tt>SearchIterator</tt> maintain a current position and scans over the 
- * target text, returning the indices the pattern is matched and the length 
- * of each match.
- * <p>
- * <tt>SearchIterator</tt> defines a protocol for text searching. 
- * Subclasses provide concrete implementations of various search algorithms. 
- * For example, <tt>StringSearch</tt> implements language-sensitive pattern 
- * matching based on the comparison rules defined in a 
- * <tt>RuleBasedCollator</tt> object. 
- * <p> 
- * Other options for searching includes using a BreakIterator to restrict 
- * the points at which matches are detected.
- * <p>
- * <tt>SearchIterator</tt> provides an API that is similar to that of
- * other text iteration classes such as <tt>BreakIterator</tt>. Using 
- * this class, it is easy to scan through text looking for all occurances of 
- * a given pattern. The following example uses a <tt>StringSearch</tt> 
- * object to find all instances of "fox" in the target string. Any other 
- * subclass of <tt>SearchIterator</tt> can be used in an identical 
- * manner.
- * <pre><code>
- * UnicodeString target("The quick brown fox jumped over the lazy fox");
- * UnicodeString pattern("fox");
- *
- * SearchIterator *iter  = new StringSearch(pattern, target);
- * UErrorCode      error = U_ZERO_ERROR;
- * for (int pos = iter->first(error); pos != USEARCH_DONE; 
- *                               pos = iter->next(error)) {
- *     printf("Found match at %d pos, length is %d\n", pos, 
- *                                             iter.getMatchLength());
- * }
- * </code></pre>
- *
- * @see StringSearch
- * @see RuleBasedCollator
- */
-class U_I18N_API SearchIterator : public UObject {
-
-public:
-
-    // public constructors and destructors -------------------------------
-
-    /** 
-    * Copy constructor that creates a SearchIterator instance with the same 
-    * behavior, and iterating over the same text. 
-    * @param other the SearchIterator instance to be copied.
-    * @stable ICU 2.0
-    */
-    SearchIterator(const SearchIterator &other);
-
-    /**
-     * Destructor. Cleans up the search iterator data struct.
-     * @stable ICU 2.0
-     */
-    virtual ~SearchIterator();
-
-    // public get and set methods ----------------------------------------
-
-    /**
-     * Sets the index to point to the given position, and clears any state 
-     * that's affected.
-     * <p>
-     * This method takes the argument index and sets the position in the text 
-     * string accordingly without checking if the index is pointing to a 
-     * valid starting point to begin searching. 
-     * @param position within the text to be set. If position is less
-     *             than or greater than the text range for searching, 
-     *          an U_INDEX_OUTOFBOUNDS_ERROR will be returned
-     * @param status for errors if it occurs
-     * @stable ICU 2.0
-     */
-    virtual void setOffset(int32_t position, UErrorCode &status) = 0;
-
-    /**
-     * Return the current index in the text being searched.
-     * If the iteration has gone past the end of the text
-     * (or past the beginning for a backwards search), USEARCH_DONE
-     * is returned.
-     * @return current index in the text being searched.
-     * @stable ICU 2.0
-     */
-    virtual int32_t getOffset(void) const = 0;
-
-    /**
-    * Sets the text searching attributes located in the enum 
-    * USearchAttribute with values from the enum USearchAttributeValue.
-    * USEARCH_DEFAULT can be used for all attributes for resetting.
-    * @param attribute text attribute (enum USearchAttribute) to be set
-    * @param value text attribute value
-    * @param status for errors if it occurs
-    * @stable ICU 2.0
-    */
-    void setAttribute(USearchAttribute       attribute,
-                      USearchAttributeValue  value,
-                      UErrorCode            &status);
-
-    /**    
-    * Gets the text searching attributes
-    * @param attribute text attribute (enum USearchAttribute) to be retrieve
-    * @return text attribute value
-    * @stable ICU 2.0
-    */
-    USearchAttributeValue getAttribute(USearchAttribute  attribute) const;
-    
-    /**
-    * Returns the index to the match in the text string that was searched.
-    * This call returns a valid result only after a successful call to 
-    * <tt>first</tt>, <tt>next</tt>, <tt>previous</tt>, or <tt>last</tt>.
-    * Just after construction, or after a searching method returns 
-    * <tt>USEARCH_DONE</tt>, this method will return <tt>USEARCH_DONE</tt>.
-    * <p>
-    * Use getMatchedLength to get the matched string length.
-    * @return index of a substring within the text string that is being 
-    *         searched.
-    * @see #first
-    * @see #next
-    * @see #previous
-    * @see #last
-    * @stable ICU 2.0
-    */
-    int32_t getMatchedStart(void) const;
-
-    /**
-     * Returns the length of text in the string which matches the search 
-     * pattern. This call returns a valid result only after a successful call 
-     * to <tt>first</tt>, <tt>next</tt>, <tt>previous</tt>, or <tt>last</tt>.
-     * Just after construction, or after a searching method returns 
-     * <tt>USEARCH_DONE</tt>, this method will return 0.
-     * @return The length of the match in the target text, or 0 if there
-     *         is no match currently.
-     * @see #first
-     * @see #next
-     * @see #previous
-     * @see #last
-     * @stable ICU 2.0
-     */
-    int32_t getMatchedLength(void) const;
-    
-    /**
-     * Returns the text that was matched by the most recent call to 
-     * <tt>first</tt>, <tt>next</tt>, <tt>previous</tt>, or <tt>last</tt>.
-     * If the iterator is not pointing at a valid match (e.g. just after 
-     * construction or after <tt>USEARCH_DONE</tt> has been returned, 
-     * returns an empty string. 
-     * @param result stores the matched string or an empty string if a match
-     *        is not found.
-     * @see #first
-     * @see #next
-     * @see #previous
-     * @see #last
-     * @stable ICU 2.0
-     */
-    void getMatchedText(UnicodeString &result) const;
-    
-    /**
-     * Set the BreakIterator that will be used to restrict the points
-     * at which matches are detected. The user is responsible for deleting 
-     * the breakiterator.
-     * @param breakiter A BreakIterator that will be used to restrict the 
-     *                points at which matches are detected. If a match is 
-     *                found, but the match's start or end index is not a 
-     *                boundary as determined by the <tt>BreakIterator</tt>, 
-     *                the match will be rejected and another will be searched 
-     *                for. If this parameter is <tt>NULL</tt>, no break
-     *                detection is attempted.
-     * @param status for errors if it occurs
-     * @see BreakIterator
-     * @stable ICU 2.0
-     */
-    void setBreakIterator(BreakIterator *breakiter, UErrorCode &status);
-    
-    /**
-     * Returns the BreakIterator that is used to restrict the points at 
-     * which matches are detected.  This will be the same object that was 
-     * passed to the constructor or to <tt>setBreakIterator</tt>.
-     * Note that <tt>NULL</tt> is a legal value; it means that break
-     * detection should not be attempted.
-     * @return BreakIterator used to restrict matchings.
-     * @see #setBreakIterator
-     * @stable ICU 2.0
-     */
-    const BreakIterator * getBreakIterator(void) const;
-
-    /**
-     * Set the string text to be searched. Text iteration will hence begin at 
-     * the start of the text string. This method is useful if you want to 
-     * re-use an iterator to search for the same pattern within a different 
-     * body of text. The user is responsible for deleting the text.
-     * @param text string to be searched.
-     * @param status for errors. If the text length is 0, 
-     *        an U_ILLEGAL_ARGUMENT_ERROR is returned.
-     * @stable ICU 2.0
-     */
-    virtual void setText(const UnicodeString &text, UErrorCode &status);    
-
-    /**
-     * Set the string text to be searched. Text iteration will hence begin at 
-     * the start of the text string. This method is useful if you want to 
-     * re-use an iterator to search for the same pattern within a different 
-     * body of text.
-     * <p>
-     * Note: No parsing of the text within the <tt>CharacterIterator</tt> 
-     * will be done during searching for this version. The block of text 
-     * in <tt>CharacterIterator</tt> will be used as it is.
-     * The user is responsible for deleting the text.
-     * @param text string iterator to be searched.
-     * @param status for errors if any. If the text length is 0 then an 
-     *        U_ILLEGAL_ARGUMENT_ERROR is returned.
-     * @stable ICU 2.0
-     */
-    virtual void setText(CharacterIterator &text, UErrorCode &status);
-    
-    /**
-     * Return the string text to be searched.
-     * @return text string to be searched.
-     * @stable ICU 2.0
-     */
-    const UnicodeString & getText(void) const;
-
-    // operator overloading ----------------------------------------------
-
-    /**
-     * Equality operator. 
-     * @param that SearchIterator instance to be compared.
-     * @return TRUE if both BreakIterators are of the same class, have the 
-     *         same behavior, terates over the same text and have the same
-     *         attributes. FALSE otherwise.
-     * @stable ICU 2.0
-     */
-    virtual UBool operator==(const SearchIterator &that) const;
-
-    /**
-     * Not-equal operator. 
-     * @param that SearchIterator instance to be compared.
-     * @return FALSE if operator== returns TRUE, and vice versa.
-     * @stable ICU 2.0
-     */
-    UBool operator!=(const SearchIterator &that) const;
-
-    // public methods ----------------------------------------------------
-
-    /**
-     * Returns a copy of SearchIterator with the same behavior, and 
-     * iterating over the same text, as this one. Note that all data will be
-     * replicated, except for the text string to be searched.
-     * @return cloned object
-     * @stable ICU 2.0
-     */
-    virtual SearchIterator* safeClone(void) const = 0;
-
-    /**
-     * Returns the first index at which the string text matches the search 
-     * pattern. The iterator is adjusted so that its current index (as 
-     * returned by <tt>getOffset</tt>) is the match position if one 
-     * was found.
-     * If a match is not found, <tt>USEARCH_DONE</tt> will be returned and
-     * the iterator will be adjusted to the index USEARCH_DONE
-     * @param  status for errors if it occurs
-     * @return The character index of the first match, or 
-     *         <tt>USEARCH_DONE</tt> if there are no matches.
-     * @see #getOffset
-     * @stable ICU 2.0
-     */
-    int32_t first(UErrorCode &status);
-
-    /**
-     * Returns the first index greater than <tt>position</tt> at which the 
-     * string text matches the search pattern. The iterator is adjusted so 
-     * that its current index (as returned by <tt>getOffset</tt>) is the 
-     * match position if one was found. If a match is not found, 
-     * <tt>USEARCH_DONE</tt> will be returned and the iterator will be 
-     * adjusted to the index USEARCH_DONE
-     * @param  position where search if to start from. If position is less
-     *             than or greater than the text range for searching, 
-     *          an U_INDEX_OUTOFBOUNDS_ERROR will be returned
-     * @param  status for errors if it occurs
-     * @return The character index of the first match following 
-     *         <tt>position</tt>, or <tt>USEARCH_DONE</tt> if there are no 
-     *         matches.
-     * @see #getOffset
-     * @stable ICU 2.0
-     */
-    int32_t following(int32_t position, UErrorCode &status);
-    
-    /**
-     * Returns the last index in the target text at which it matches the 
-     * search pattern. The iterator is adjusted so that its current index 
-     * (as returned by <tt>getOffset</tt>) is the match position if one was 
-     * found.
-     * If a match is not found, <tt>USEARCH_DONE</tt> will be returned and
-     * the iterator will be adjusted to the index USEARCH_DONE.
-     * @param  status for errors if it occurs
-     * @return The index of the first match, or <tt>USEARCH_DONE</tt> if 
-     *         there are no matches.
-     * @see #getOffset
-     * @stable ICU 2.0
-     */
-    int32_t last(UErrorCode &status);
-
-    /**
-     * Returns the first index less than <tt>position</tt> at which the string 
-     * text matches the search pattern. The iterator is adjusted so that its 
-     * current index (as returned by <tt>getOffset</tt>) is the match 
-     * position if one was found. If a match is not found, 
-     * <tt>USEARCH_DONE</tt> will be returned and the iterator will be 
-     * adjusted to the index USEARCH_DONE
-     * @param  position where search is to start from. If position is less
-     *             than or greater than the text range for searching, 
-     *          an U_INDEX_OUTOFBOUNDS_ERROR will be returned
-     * @param  status for errors if it occurs
-     * @return The character index of the first match preceding 
-     *         <tt>position</tt>, or <tt>USEARCH_DONE</tt> if there are 
-     *         no matches.
-     * @see #getOffset
-     * @stable ICU 2.0
-     */
-    int32_t preceding(int32_t position, UErrorCode &status);
-
-    /**
-     * Returns the index of the next point at which the text matches the
-     * search pattern, starting from the current position
-     * The iterator is adjusted so that its current index (as returned by 
-     * <tt>getOffset</tt>) is the match position if one was found.
-     * If a match is not found, <tt>USEARCH_DONE</tt> will be returned and
-     * the iterator will be adjusted to a position after the end of the text 
-     * string.
-     * @param  status for errors if it occurs
-     * @return The index of the next match after the current position,
-     *          or <tt>USEARCH_DONE</tt> if there are no more matches.
-     * @see #getOffset
-     * @stable ICU 2.0
-     */
-     int32_t next(UErrorCode &status);
-
-    /**
-     * Returns the index of the previous point at which the string text 
-     * matches the search pattern, starting at the current position.
-     * The iterator is adjusted so that its current index (as returned by 
-     * <tt>getOffset</tt>) is the match position if one was found.
-     * If a match is not found, <tt>USEARCH_DONE</tt> will be returned and
-     * the iterator will be adjusted to the index USEARCH_DONE
-     * @param  status for errors if it occurs
-     * @return The index of the previous match before the current position,
-     *          or <tt>USEARCH_DONE</tt> if there are no more matches.
-     * @see #getOffset
-     * @stable ICU 2.0
-     */
-    int32_t previous(UErrorCode &status);
-
-    /** 
-    * Resets the iteration.
-    * Search will begin at the start of the text string if a forward 
-    * iteration is initiated before a backwards iteration. Otherwise if a 
-    * backwards iteration is initiated before a forwards iteration, the 
-    * search will begin at the end of the text string.    
-    * @stable ICU 2.0
-    */
-    virtual void reset();
-
-protected:
-    // protected data members ---------------------------------------------
-
-    /**
-    * C search data struct
-    * @stable ICU 2.0
-    */
-    USearch *m_search_;
-
-    /**
-    * Break iterator.
-    * Currently the C++ breakiterator does not have getRules etc to reproduce
-    * another in C. Hence we keep the original around and do the verification
-    * at the end of the match. The user is responsible for deleting this
-    * break iterator.
-    * @stable ICU 2.0
-    */
-    BreakIterator *m_breakiterator_;
-    
-    /**
-    * Unicode string version of the search text
-    * @stable ICU 2.0
-    */
-    UnicodeString  m_text_;
-
-    // protected constructors and destructors -----------------------------
-
-    /**
-    * Default constructor.
-    * Initializes data to the default values.
-    * @stable ICU 2.0
-    */
-    SearchIterator();
-
-    /**
-     * Constructor for use by subclasses.
-     * @param text The target text to be searched.
-     * @param breakiter A {@link BreakIterator} that is used to restrict the 
-     *                points at which matches are detected. If 
-     *                <tt>handleNext</tt> or <tt>handlePrev</tt> finds a 
-     *                match, but the match's start or end index is not a 
-     *                boundary as determined by the <tt>BreakIterator</tt>, 
-     *                the match is rejected and <tt>handleNext</tt> or 
-     *                <tt>handlePrev</tt> is called again. If this parameter 
-     *                is <tt>NULL</tt>, no break detection is attempted.  
-     * @see #handleNext
-     * @see #handlePrev
-     * @stable ICU 2.0
-     */
-    SearchIterator(const UnicodeString &text, 
-                         BreakIterator *breakiter = NULL);
-
-    /**
-     * Constructor for use by subclasses.
-     * <p>
-     * Note: No parsing of the text within the <tt>CharacterIterator</tt> 
-     * will be done during searching for this version. The block of text 
-     * in <tt>CharacterIterator</tt> will be used as it is.
-     * @param text The target text to be searched.
-     * @param breakiter A {@link BreakIterator} that is used to restrict the 
-     *                points at which matches are detected. If 
-     *                <tt>handleNext</tt> or <tt>handlePrev</tt> finds a 
-     *                match, but the match's start or end index is not a 
-     *                boundary as determined by the <tt>BreakIterator</tt>, 
-     *                the match is rejected and <tt>handleNext</tt> or 
-     *                <tt>handlePrev</tt> is called again. If this parameter 
-     *                is <tt>NULL</tt>, no break detection is attempted.
-     * @see #handleNext
-     * @see #handlePrev
-     * @stable ICU 2.0
-     */
-    SearchIterator(CharacterIterator &text, BreakIterator *breakiter = NULL);
-
-    // protected methods --------------------------------------------------
-
-    /**
-     * Assignment operator. Sets this iterator to have the same behavior,
-     * and iterate over the same text, as the one passed in.
-     * @param that instance to be copied.
-     * @stable ICU 2.0
-     */
-    SearchIterator & operator=(const SearchIterator &that);
-
-    /**
-     * Abstract method which subclasses override to provide the mechanism
-     * for finding the next match in the target text. This allows different
-     * subclasses to provide different search algorithms.
-     * <p>
-     * If a match is found, the implementation should return the index at
-     * which the match starts and should call 
-     * <tt>setMatchLength</tt> with the number of characters 
-     * in the target text that make up the match. If no match is found, the 
-     * method should return USEARCH_DONE.
-     * <p>
-     * @param position The index in the target text at which the search 
-     *                 should start.
-     * @param status for error codes if it occurs.
-     * @return index at which the match starts, else if match is not found 
-     *         USEARCH_DONE is returned
-     * @see #setMatchLength
-     * @stable ICU 2.0
-     */
-    virtual int32_t handleNext(int32_t position, UErrorCode &status) 
-                                                                         = 0;
-
-    /**
-     * Abstract method which subclasses override to provide the mechanism for
-     * finding the previous match in the target text. This allows different
-     * subclasses to provide different search algorithms.
-     * <p>
-     * If a match is found, the implementation should return the index at
-     * which the match starts and should call 
-     * <tt>setMatchLength</tt> with the number of characters 
-     * in the target text that make up the match. If no match is found, the 
-     * method should return USEARCH_DONE.
-     * <p>
-     * @param position The index in the target text at which the search 
-     *                 should start.
-     * @param status for error codes if it occurs.
-     * @return index at which the match starts, else if match is not found 
-     *         USEARCH_DONE is returned
-     * @see #setMatchLength
-     * @stable ICU 2.0
-     */
-     virtual int32_t handlePrev(int32_t position, UErrorCode &status) 
-                                                                         = 0;
-
-    /**
-     * Sets the length of the currently matched string in the text string to
-     * be searched.
-     * Subclasses' <tt>handleNext</tt> and <tt>handlePrev</tt>
-     * methods should call this when they find a match in the target text.
-     * @param length length of the matched text.
-     * @see #handleNext
-     * @see #handlePrev
-     * @stable ICU 2.0
-     */
-    virtual void setMatchLength(int32_t length);
-
-    /**
-     * Sets the offset of the currently matched string in the text string to
-     * be searched.
-     * Subclasses' <tt>handleNext</tt> and <tt>handlePrev</tt>
-     * methods should call this when they find a match in the target text.
-     * @param position start offset of the matched text.
-     * @see #handleNext
-     * @see #handlePrev
-     * @stable ICU 2.0
-     */
-    virtual void setMatchStart(int32_t position);
-
-    /**
-    * sets match not found 
-    * @stable ICU 2.0
-    */
-    void setMatchNotFound();
-};
-
-inline UBool SearchIterator::operator!=(const SearchIterator &that) const
-{
-   return !operator==(that); 
-}
-U_NAMESPACE_END
-
-#endif /* #if !UCONFIG_NO_COLLATION */
-
-#endif
-

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/simpletz.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/simpletz.h b/apps/couch_collate/platform/osx/icu/unicode/simpletz.h
deleted file mode 100644
index 5b85c8d..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/simpletz.h
+++ /dev/null
@@ -1,927 +0,0 @@
-/*
- ********************************************************************************
- * Copyright (C) 1997-2008, International Business Machines                     *
- * Corporation and others. All Rights Reserved.                                 *
- ********************************************************************************
- *
- * File SIMPLETZ.H
- *
- * Modification History:
- *
- *   Date        Name        Description
- *   04/21/97    aliu        Overhauled header.
- *   08/10/98    stephen     JDK 1.2 sync
- *                           Added setStartRule() / setEndRule() overloads
- *                           Added hasSameRules()
- *   09/02/98    stephen     Added getOffset(monthLen)
- *                           Changed getOffset() to take UErrorCode
- *   07/09/99    stephen     Removed millisPerHour (unused, for HP compiler)
- *   12/02/99    aliu        Added TimeMode and constructor and setStart/EndRule
- *                           methods that take TimeMode. Added to docs.
- ********************************************************************************
- */
-
-#ifndef SIMPLETZ_H
-#define SIMPLETZ_H
-
-#include "unicode/utypes.h"
-
-/**
- * \file 
- * \brief C++ API: SimpleTimeZone is a concrete subclass of TimeZone.
- */
- 
-#if !UCONFIG_NO_FORMATTING
-
-#include "unicode/basictz.h"
-
-U_NAMESPACE_BEGIN
-
-// forward declaration
-class InitialTimeZoneRule;
-class TimeZoneTransition;
-class AnnualTimeZoneRule;
-
-/**
- * <code>SimpleTimeZone</code> is a concrete subclass of <code>TimeZone</code>
- * that represents a time zone for use with a Gregorian calendar. This
- * class does not handle historical changes.
- * <P>
- * When specifying daylight-savings-time begin and end dates, use a negative value for
- * <code>dayOfWeekInMonth</code> to indicate that <code>SimpleTimeZone</code> should
- * count from the end of the month backwards. For example, in the U.S., Daylight Savings
- * Time ends at the last (dayOfWeekInMonth = -1) Sunday in October, at 2 AM in standard
- * time.
- *
- * @see      Calendar
- * @see      GregorianCalendar
- * @see      TimeZone
- * @author   D. Goldsmith, Mark Davis, Chen-Lieh Huang, Alan Liu
- */
-class U_I18N_API SimpleTimeZone: public BasicTimeZone {
-public:
-
-    /**
-     * TimeMode is used, together with a millisecond offset after
-     * midnight, to specify a rule transition time.  Most rules
-     * transition at a local wall time, that is, according to the
-     * current time in effect, either standard, or DST.  However, some
-     * rules transition at local standard time, and some at a specific
-     * UTC time.  Although it might seem that all times could be
-     * converted to wall time, thus eliminating the need for this
-     * parameter, this is not the case.
-     * @stable ICU 2.0
-     */
-    enum TimeMode {
-        WALL_TIME = 0,
-        STANDARD_TIME,
-        UTC_TIME
-    };
-
-    /**
-     * Copy constructor
-     * @param source the object to be copied.
-     * @stable ICU 2.0
-     */
-    SimpleTimeZone(const SimpleTimeZone& source);
-
-    /**
-     * Default assignment operator
-     * @param right    the object to be copied.
-     * @stable ICU 2.0
-     */
-    SimpleTimeZone& operator=(const SimpleTimeZone& right);
-
-    /**
-     * Destructor
-     * @stable ICU 2.0
-     */
-    virtual ~SimpleTimeZone();
-
-    /**
-     * Returns true if the two TimeZone objects are equal; that is, they have
-     * the same ID, raw GMT offset, and DST rules.
-     *
-     * @param that  The SimpleTimeZone object to be compared with.
-     * @return      True if the given time zone is equal to this time zone; false
-     *              otherwise.
-     * @stable ICU 2.0
-     */
-    virtual UBool operator==(const TimeZone& that) const;
-
-    /**
-     * Constructs a SimpleTimeZone with the given raw GMT offset and time zone ID,
-     * and which doesn't observe daylight savings time.  Normally you should use
-     * TimeZone::createInstance() to create a TimeZone instead of creating a
-     * SimpleTimeZone directly with this constructor.
-     *
-     * @param rawOffsetGMT  The given base time zone offset to GMT.
-     * @param ID         The timezone ID which is obtained from
-     *                   TimeZone.getAvailableIDs.
-     * @stable ICU 2.0
-     */
-    SimpleTimeZone(int32_t rawOffsetGMT, const UnicodeString& ID);
-
-    /**
-     * Construct a SimpleTimeZone with the given raw GMT offset, time zone ID,
-     * and times to start and end daylight savings time. To create a TimeZone that
-     * doesn't observe daylight savings time, don't use this constructor; use
-     * SimpleTimeZone(rawOffset, ID) instead. Normally, you should use
-     * TimeZone.createInstance() to create a TimeZone instead of creating a
-     * SimpleTimeZone directly with this constructor.
-     * <P>
-     * Various types of daylight-savings time rules can be specfied by using different
-     * values for startDay and startDayOfWeek and endDay and endDayOfWeek.  For a
-     * complete explanation of how these parameters work, see the documentation for
-     * setStartRule().
-     *
-     * @param rawOffsetGMT      The new SimpleTimeZone's raw GMT offset
-     * @param ID                The new SimpleTimeZone's time zone ID.
-     * @param savingsStartMonth The daylight savings starting month. Month is
-     *                          0-based. eg, 0 for January.
-     * @param savingsStartDayOfWeekInMonth   The daylight savings starting
-     *                          day-of-week-in-month. See setStartRule() for a
-     *                          complete explanation.
-     * @param savingsStartDayOfWeek The daylight savings starting day-of-week.
-     *                          See setStartRule() for a complete explanation.
-     * @param savingsStartTime  The daylight savings starting time, expressed as the
-     *                          number of milliseconds after midnight.
-     * @param savingsEndMonth   The daylight savings ending month. Month is
-     *                          0-based. eg, 0 for January.
-     * @param savingsEndDayOfWeekInMonth     The daylight savings ending day-of-week-in-month.
-     *                          See setStartRule() for a complete explanation.
-     * @param savingsEndDayOfWeek The daylight savings ending day-of-week.
-     *                          See setStartRule() for a complete explanation.
-     * @param savingsEndTime    The daylight savings ending time, expressed as the
-     *                          number of milliseconds after midnight.
-     * @param status            An UErrorCode to receive the status.
-     * @stable ICU 2.0
-     */
-    SimpleTimeZone(int32_t rawOffsetGMT, const UnicodeString& ID,
-        int8_t savingsStartMonth, int8_t savingsStartDayOfWeekInMonth,
-        int8_t savingsStartDayOfWeek, int32_t savingsStartTime,
-        int8_t savingsEndMonth, int8_t savingsEndDayOfWeekInMonth,
-        int8_t savingsEndDayOfWeek, int32_t savingsEndTime,
-        UErrorCode& status);
-    /**
-     * Construct a SimpleTimeZone with the given raw GMT offset, time zone ID,
-     * and times to start and end daylight savings time. To create a TimeZone that
-     * doesn't observe daylight savings time, don't use this constructor; use
-     * SimpleTimeZone(rawOffset, ID) instead. Normally, you should use
-     * TimeZone.createInstance() to create a TimeZone instead of creating a
-     * SimpleTimeZone directly with this constructor.
-     * <P>
-     * Various types of daylight-savings time rules can be specfied by using different
-     * values for startDay and startDayOfWeek and endDay and endDayOfWeek.  For a
-     * complete explanation of how these parameters work, see the documentation for
-     * setStartRule().
-     *
-     * @param rawOffsetGMT      The new SimpleTimeZone's raw GMT offset
-     * @param ID                The new SimpleTimeZone's time zone ID.
-     * @param savingsStartMonth The daylight savings starting month. Month is
-     *                          0-based. eg, 0 for January.
-     * @param savingsStartDayOfWeekInMonth   The daylight savings starting
-     *                          day-of-week-in-month. See setStartRule() for a
-     *                          complete explanation.
-     * @param savingsStartDayOfWeek The daylight savings starting day-of-week.
-     *                          See setStartRule() for a complete explanation.
-     * @param savingsStartTime  The daylight savings starting time, expressed as the
-     *                          number of milliseconds after midnight.
-     * @param savingsEndMonth   The daylight savings ending month. Month is
-     *                          0-based. eg, 0 for January.
-     * @param savingsEndDayOfWeekInMonth     The daylight savings ending day-of-week-in-month.
-     *                          See setStartRule() for a complete explanation.
-     * @param savingsEndDayOfWeek The daylight savings ending day-of-week.
-     *                          See setStartRule() for a complete explanation.
-     * @param savingsEndTime    The daylight savings ending time, expressed as the
-     *                          number of milliseconds after midnight.
-     * @param savingsDST        The number of milliseconds added to standard time
-     *                          to get DST time. Default is one hour.
-     * @param status            An UErrorCode to receive the status.
-     * @stable ICU 2.0
-     */
-    SimpleTimeZone(int32_t rawOffsetGMT, const UnicodeString& ID,
-        int8_t savingsStartMonth, int8_t savingsStartDayOfWeekInMonth,
-        int8_t savingsStartDayOfWeek, int32_t savingsStartTime,
-        int8_t savingsEndMonth, int8_t savingsEndDayOfWeekInMonth,
-        int8_t savingsEndDayOfWeek, int32_t savingsEndTime,
-        int32_t savingsDST, UErrorCode& status);
-
-    /**
-     * Construct a SimpleTimeZone with the given raw GMT offset, time zone ID,
-     * and times to start and end daylight savings time. To create a TimeZone that
-     * doesn't observe daylight savings time, don't use this constructor; use
-     * SimpleTimeZone(rawOffset, ID) instead. Normally, you should use
-     * TimeZone.createInstance() to create a TimeZone instead of creating a
-     * SimpleTimeZone directly with this constructor.
-     * <P>
-     * Various types of daylight-savings time rules can be specfied by using different
-     * values for startDay and startDayOfWeek and endDay and endDayOfWeek.  For a
-     * complete explanation of how these parameters work, see the documentation for
-     * setStartRule().
-     *
-     * @param rawOffsetGMT      The new SimpleTimeZone's raw GMT offset
-     * @param ID                The new SimpleTimeZone's time zone ID.
-     * @param savingsStartMonth The daylight savings starting month. Month is
-     *                          0-based. eg, 0 for January.
-     * @param savingsStartDayOfWeekInMonth   The daylight savings starting
-     *                          day-of-week-in-month. See setStartRule() for a
-     *                          complete explanation.
-     * @param savingsStartDayOfWeek The daylight savings starting day-of-week.
-     *                          See setStartRule() for a complete explanation.
-     * @param savingsStartTime  The daylight savings starting time, expressed as the
-     *                          number of milliseconds after midnight.
-     * @param savingsStartTimeMode Whether the start time is local wall time, local
-     *                          standard time, or UTC time. Default is local wall time.
-     * @param savingsEndMonth   The daylight savings ending month. Month is
-     *                          0-based. eg, 0 for January.
-     * @param savingsEndDayOfWeekInMonth     The daylight savings ending day-of-week-in-month.
-     *                          See setStartRule() for a complete explanation.
-     * @param savingsEndDayOfWeek The daylight savings ending day-of-week.
-     *                          See setStartRule() for a complete explanation.
-     * @param savingsEndTime    The daylight savings ending time, expressed as the
-     *                          number of milliseconds after midnight.
-     * @param savingsEndTimeMode Whether the end time is local wall time, local
-     *                          standard time, or UTC time. Default is local wall time.
-     * @param savingsDST        The number of milliseconds added to standard time
-     *                          to get DST time. Default is one hour.
-     * @param status            An UErrorCode to receive the status.
-     * @stable ICU 2.0
-     */
-    SimpleTimeZone(int32_t rawOffsetGMT, const UnicodeString& ID,
-        int8_t savingsStartMonth, int8_t savingsStartDayOfWeekInMonth,
-        int8_t savingsStartDayOfWeek, int32_t savingsStartTime,
-        TimeMode savingsStartTimeMode,
-        int8_t savingsEndMonth, int8_t savingsEndDayOfWeekInMonth,
-        int8_t savingsEndDayOfWeek, int32_t savingsEndTime, TimeMode savingsEndTimeMode,
-        int32_t savingsDST, UErrorCode& status);
-
-    /**
-     * Sets the daylight savings starting year, that is, the year this time zone began
-     * observing its specified daylight savings time rules.  The time zone is considered
-     * not to observe daylight savings time prior to that year; SimpleTimeZone doesn't
-     * support historical daylight-savings-time rules.
-     * @param year the daylight savings starting year.
-     * @stable ICU 2.0
-     */
-    void setStartYear(int32_t year);
-
-    /**
-     * Sets the daylight savings starting rule. For example, in the U.S., Daylight Savings
-     * Time starts at the first Sunday in April, at 2 AM in standard time.
-     * Therefore, you can set the start rule by calling:
-     * setStartRule(TimeFields.APRIL, 1, TimeFields.SUNDAY, 2*60*60*1000);
-     * The dayOfWeekInMonth and dayOfWeek parameters together specify how to calculate
-     * the exact starting date.  Their exact meaning depend on their respective signs,
-     * allowing various types of rules to be constructed, as follows:
-     * <ul>
-     *   <li>If both dayOfWeekInMonth and dayOfWeek are positive, they specify the
-     *       day of week in the month (e.g., (2, WEDNESDAY) is the second Wednesday
-     *       of the month).</li>
-     *   <li>If dayOfWeek is positive and dayOfWeekInMonth is negative, they specify
-     *       the day of week in the month counting backward from the end of the month.
-     *       (e.g., (-1, MONDAY) is the last Monday in the month)</li>
-     *   <li>If dayOfWeek is zero and dayOfWeekInMonth is positive, dayOfWeekInMonth
-     *       specifies the day of the month, regardless of what day of the week it is.
-     *       (e.g., (10, 0) is the tenth day of the month)</li>
-     *   <li>If dayOfWeek is zero and dayOfWeekInMonth is negative, dayOfWeekInMonth
-     *       specifies the day of the month counting backward from the end of the
-     *       month, regardless of what day of the week it is (e.g., (-2, 0) is the
-     *       next-to-last day of the month).</li>
-     *   <li>If dayOfWeek is negative and dayOfWeekInMonth is positive, they specify the
-     *       first specified day of the week on or after the specfied day of the month.
-     *       (e.g., (15, -SUNDAY) is the first Sunday after the 15th of the month
-     *       [or the 15th itself if the 15th is a Sunday].)</li>
-     *   <li>If dayOfWeek and DayOfWeekInMonth are both negative, they specify the
-     *       last specified day of the week on or before the specified day of the month.
-     *       (e.g., (-20, -TUESDAY) is the last Tuesday before the 20th of the month
-     *       [or the 20th itself if the 20th is a Tuesday].)</li>
-     * </ul>
-     * @param month the daylight savings starting month. Month is 0-based.
-     * eg, 0 for January.
-     * @param dayOfWeekInMonth the daylight savings starting
-     * day-of-week-in-month. Please see the member description for an example.
-     * @param dayOfWeek the daylight savings starting day-of-week. Please see
-     * the member description for an example.
-     * @param time the daylight savings starting time. Please see the member
-     * description for an example.
-     * @param status An UErrorCode
-     * @stable ICU 2.0
-     */
-    void setStartRule(int32_t month, int32_t dayOfWeekInMonth, int32_t dayOfWeek,
-                      int32_t time, UErrorCode& status);
-    /**
-     * Sets the daylight savings starting rule. For example, in the U.S., Daylight Savings
-     * Time starts at the first Sunday in April, at 2 AM in standard time.
-     * Therefore, you can set the start rule by calling:
-     * setStartRule(TimeFields.APRIL, 1, TimeFields.SUNDAY, 2*60*60*1000);
-     * The dayOfWeekInMonth and dayOfWeek parameters together specify how to calculate
-     * the exact starting date.  Their exact meaning depend on their respective signs,
-     * allowing various types of rules to be constructed, as follows:
-     * <ul>
-     *   <li>If both dayOfWeekInMonth and dayOfWeek are positive, they specify the
-     *       day of week in the month (e.g., (2, WEDNESDAY) is the second Wednesday
-     *       of the month).</li>
-     *   <li>If dayOfWeek is positive and dayOfWeekInMonth is negative, they specify
-     *       the day of week in the month counting backward from the end of the month.
-     *       (e.g., (-1, MONDAY) is the last Monday in the month)</li>
-     *   <li>If dayOfWeek is zero and dayOfWeekInMonth is positive, dayOfWeekInMonth
-     *       specifies the day of the month, regardless of what day of the week it is.
-     *       (e.g., (10, 0) is the tenth day of the month)</li>
-     *   <li>If dayOfWeek is zero and dayOfWeekInMonth is negative, dayOfWeekInMonth
-     *       specifies the day of the month counting backward from the end of the
-     *       month, regardless of what day of the week it is (e.g., (-2, 0) is the
-     *       next-to-last day of the month).</li>
-     *   <li>If dayOfWeek is negative and dayOfWeekInMonth is positive, they specify the
-     *       first specified day of the week on or after the specfied day of the month.
-     *       (e.g., (15, -SUNDAY) is the first Sunday after the 15th of the month
-     *       [or the 15th itself if the 15th is a Sunday].)</li>
-     *   <li>If dayOfWeek and DayOfWeekInMonth are both negative, they specify the
-     *       last specified day of the week on or before the specified day of the month.
-     *       (e.g., (-20, -TUESDAY) is the last Tuesday before the 20th of the month
-     *       [or the 20th itself if the 20th is a Tuesday].)</li>
-     * </ul>
-     * @param month the daylight savings starting month. Month is 0-based.
-     * eg, 0 for January.
-     * @param dayOfWeekInMonth the daylight savings starting
-     * day-of-week-in-month. Please see the member description for an example.
-     * @param dayOfWeek the daylight savings starting day-of-week. Please see
-     * the member description for an example.
-     * @param time the daylight savings starting time. Please see the member
-     * description for an example.
-     * @param mode whether the time is local wall time, local standard time,
-     * or UTC time. Default is local wall time.
-     * @param status An UErrorCode
-     * @stable ICU 2.0
-     */
-    void setStartRule(int32_t month, int32_t dayOfWeekInMonth, int32_t dayOfWeek,
-                      int32_t time, TimeMode mode, UErrorCode& status);
-
-    /**
-     * Sets the DST start rule to a fixed date within a month.
-     *
-     * @param month         The month in which this rule occurs (0-based).
-     * @param dayOfMonth    The date in that month (1-based).
-     * @param time          The time of that day (number of millis after midnight)
-     *                      when DST takes effect in local wall time, which is
-     *                      standard time in this case.
-     * @param status An UErrorCode
-     * @stable ICU 2.0
-     */
-    void setStartRule(int32_t month, int32_t dayOfMonth, int32_t time,
-                      UErrorCode& status);
-    /**
-     * Sets the DST start rule to a fixed date within a month.
-     *
-     * @param month         The month in which this rule occurs (0-based).
-     * @param dayOfMonth    The date in that month (1-based).
-     * @param time          The time of that day (number of millis after midnight)
-     *                      when DST takes effect in local wall time, which is
-     *                      standard time in this case.
-     * @param mode whether the time is local wall time, local standard time,
-     * or UTC time. Default is local wall time.
-     * @param status An UErrorCode
-     * @stable ICU 2.0
-     */
-    void setStartRule(int32_t month, int32_t dayOfMonth, int32_t time,
-                      TimeMode mode, UErrorCode& status);
-
-    /**
-     * Sets the DST start rule to a weekday before or after a give date within
-     * a month, e.g., the first Monday on or after the 8th.
-     *
-     * @param month         The month in which this rule occurs (0-based).
-     * @param dayOfMonth    A date within that month (1-based).
-     * @param dayOfWeek     The day of the week on which this rule occurs.
-     * @param time          The time of that day (number of millis after midnight)
-     *                      when DST takes effect in local wall time, which is
-     *                      standard time in this case.
-     * @param after         If true, this rule selects the first dayOfWeek on
-     *                      or after dayOfMonth.  If false, this rule selects
-     *                      the last dayOfWeek on or before dayOfMonth.
-     * @param status An UErrorCode
-     * @stable ICU 2.0
-     */
-    void setStartRule(int32_t month, int32_t dayOfMonth, int32_t dayOfWeek,
-                      int32_t time, UBool after, UErrorCode& status);
-    /**
-     * Sets the DST start rule to a weekday before or after a give date within
-     * a month, e.g., the first Monday on or after the 8th.
-     *
-     * @param month         The month in which this rule occurs (0-based).
-     * @param dayOfMonth    A date within that month (1-based).
-     * @param dayOfWeek     The day of the week on which this rule occurs.
-     * @param time          The time of that day (number of millis after midnight)
-     *                      when DST takes effect in local wall time, which is
-     *                      standard time in this case.
-     * @param mode whether the time is local wall time, local standard time,
-     * or UTC time. Default is local wall time.
-     * @param after         If true, this rule selects the first dayOfWeek on
-     *                      or after dayOfMonth.  If false, this rule selects
-     *                      the last dayOfWeek on or before dayOfMonth.
-     * @param status An UErrorCode
-     * @stable ICU 2.0
-     */
-    void setStartRule(int32_t month, int32_t dayOfMonth, int32_t dayOfWeek,
-                      int32_t time, TimeMode mode, UBool after, UErrorCode& status);
-
-    /**
-     * Sets the daylight savings ending rule. For example, in the U.S., Daylight
-     * Savings Time ends at the last (-1) Sunday in October, at 2 AM in standard time.
-     * Therefore, you can set the end rule by calling:
-     * <pre>
-     * .   setEndRule(TimeFields.OCTOBER, -1, TimeFields.SUNDAY, 2*60*60*1000);
-     * </pre>
-     * Various other types of rules can be specified by manipulating the dayOfWeek
-     * and dayOfWeekInMonth parameters.  For complete details, see the documentation
-     * for setStartRule().
-     *
-     * @param month the daylight savings ending month. Month is 0-based.
-     * eg, 0 for January.
-     * @param dayOfWeekInMonth the daylight savings ending
-     * day-of-week-in-month. See setStartRule() for a complete explanation.
-     * @param dayOfWeek the daylight savings ending day-of-week. See setStartRule()
-     * for a complete explanation.
-     * @param time the daylight savings ending time. Please see the member
-     * description for an example.
-     * @param status An UErrorCode
-     * @stable ICU 2.0
-     */
-    void setEndRule(int32_t month, int32_t dayOfWeekInMonth, int32_t dayOfWeek,
-                    int32_t time, UErrorCode& status);
-
-    /**
-     * Sets the daylight savings ending rule. For example, in the U.S., Daylight
-     * Savings Time ends at the last (-1) Sunday in October, at 2 AM in standard time.
-     * Therefore, you can set the end rule by calling:
-     * <pre>
-     * .   setEndRule(TimeFields.OCTOBER, -1, TimeFields.SUNDAY, 2*60*60*1000);
-     * </pre>
-     * Various other types of rules can be specified by manipulating the dayOfWeek
-     * and dayOfWeekInMonth parameters.  For complete details, see the documentation
-     * for setStartRule().
-     *
-     * @param month the daylight savings ending month. Month is 0-based.
-     * eg, 0 for January.
-     * @param dayOfWeekInMonth the daylight savings ending
-     * day-of-week-in-month. See setStartRule() for a complete explanation.
-     * @param dayOfWeek the daylight savings ending day-of-week. See setStartRule()
-     * for a complete explanation.
-     * @param time the daylight savings ending time. Please see the member
-     * description for an example.
-     * @param mode whether the time is local wall time, local standard time,
-     * or UTC time. Default is local wall time.
-     * @param status An UErrorCode
-     * @stable ICU 2.0
-     */
-    void setEndRule(int32_t month, int32_t dayOfWeekInMonth, int32_t dayOfWeek,
-                    int32_t time, TimeMode mode, UErrorCode& status);
-
-    /**
-     * Sets the DST end rule to a fixed date within a month.
-     *
-     * @param month         The month in which this rule occurs (0-based).
-     * @param dayOfMonth    The date in that month (1-based).
-     * @param time          The time of that day (number of millis after midnight)
-     *                      when DST ends in local wall time, which is daylight
-     *                      time in this case.
-     * @param status An UErrorCode
-     * @stable ICU 2.0
-     */
-    void setEndRule(int32_t month, int32_t dayOfMonth, int32_t time, UErrorCode& status);
-
-    /**
-     * Sets the DST end rule to a fixed date within a month.
-     *
-     * @param month         The month in which this rule occurs (0-based).
-     * @param dayOfMonth    The date in that month (1-based).
-     * @param time          The time of that day (number of millis after midnight)
-     *                      when DST ends in local wall time, which is daylight
-     *                      time in this case.
-     * @param mode whether the time is local wall time, local standard time,
-     * or UTC time. Default is local wall time.
-     * @param status An UErrorCode
-     * @stable ICU 2.0
-     */
-    void setEndRule(int32_t month, int32_t dayOfMonth, int32_t time,
-                    TimeMode mode, UErrorCode& status);
-
-    /**
-     * Sets the DST end rule to a weekday before or after a give date within
-     * a month, e.g., the first Monday on or after the 8th.
-     *
-     * @param month         The month in which this rule occurs (0-based).
-     * @param dayOfMonth    A date within that month (1-based).
-     * @param dayOfWeek     The day of the week on which this rule occurs.
-     * @param time          The time of that day (number of millis after midnight)
-     *                      when DST ends in local wall time, which is daylight
-     *                      time in this case.
-     * @param after         If true, this rule selects the first dayOfWeek on
-     *                      or after dayOfMonth.  If false, this rule selects
-     *                      the last dayOfWeek on or before dayOfMonth.
-     * @param status An UErrorCode
-     * @stable ICU 2.0
-     */
-    void setEndRule(int32_t month, int32_t dayOfMonth, int32_t dayOfWeek,
-                    int32_t time, UBool after, UErrorCode& status);
-
-    /**
-     * Sets the DST end rule to a weekday before or after a give date within
-     * a month, e.g., the first Monday on or after the 8th.
-     *
-     * @param month         The month in which this rule occurs (0-based).
-     * @param dayOfMonth    A date within that month (1-based).
-     * @param dayOfWeek     The day of the week on which this rule occurs.
-     * @param time          The time of that day (number of millis after midnight)
-     *                      when DST ends in local wall time, which is daylight
-     *                      time in this case.
-     * @param mode whether the time is local wall time, local standard time,
-     * or UTC time. Default is local wall time.
-     * @param after         If true, this rule selects the first dayOfWeek on
-     *                      or after dayOfMonth.  If false, this rule selects
-     *                      the last dayOfWeek on or before dayOfMonth.
-     * @param status An UErrorCode
-     * @stable ICU 2.0
-     */
-    void setEndRule(int32_t month, int32_t dayOfMonth, int32_t dayOfWeek,
-                    int32_t time, TimeMode mode, UBool after, UErrorCode& status);
-
-    /**
-     * Returns the TimeZone's adjusted GMT offset (i.e., the number of milliseconds to add
-     * to GMT to get local time in this time zone, taking daylight savings time into
-     * account) as of a particular reference date.  The reference date is used to determine
-     * whether daylight savings time is in effect and needs to be figured into the offset
-     * that is returned (in other words, what is the adjusted GMT offset in this time zone
-     * at this particular date and time?).  For the time zones produced by createTimeZone(),
-     * the reference data is specified according to the Gregorian calendar, and the date
-     * and time fields are in GMT, NOT local time.
-     *
-     * @param era        The reference date's era
-     * @param year       The reference date's year
-     * @param month      The reference date's month (0-based; 0 is January)
-     * @param day        The reference date's day-in-month (1-based)
-     * @param dayOfWeek  The reference date's day-of-week (1-based; 1 is Sunday)
-     * @param millis     The reference date's milliseconds in day, UTT (NOT local time).
-     * @param status     An UErrorCode to receive the status.
-     * @return           The offset in milliseconds to add to GMT to get local time.
-     * @stable ICU 2.0
-     */
-    virtual int32_t getOffset(uint8_t era, int32_t year, int32_t month, int32_t day,
-                              uint8_t dayOfWeek, int32_t millis, UErrorCode& status) const;
-
-    /**
-     * Gets the time zone offset, for current date, modified in case of
-     * daylight savings. This is the offset to add *to* UTC to get local time.
-     * @param era the era of the given date.
-     * @param year the year in the given date.
-     * @param month the month in the given date.
-     * Month is 0-based. e.g., 0 for January.
-     * @param day the day-in-month of the given date.
-     * @param dayOfWeek the day-of-week of the given date.
-     * @param milliseconds the millis in day in <em>standard</em> local time.
-     * @param monthLength the length of the given month in days.
-     * @param status     An UErrorCode to receive the status.
-     * @return the offset to add *to* GMT to get local time.
-     * @stable ICU 2.0
-     */
-    virtual int32_t getOffset(uint8_t era, int32_t year, int32_t month, int32_t day,
-                           uint8_t dayOfWeek, int32_t milliseconds,
-                           int32_t monthLength, UErrorCode& status) const;
-    /**
-     * Gets the time zone offset, for current date, modified in case of
-     * daylight savings. This is the offset to add *to* UTC to get local time.
-     * @param era the era of the given date.
-     * @param year the year in the given date.
-     * @param month the month in the given date.
-     * Month is 0-based. e.g., 0 for January.
-     * @param day the day-in-month of the given date.
-     * @param dayOfWeek the day-of-week of the given date.
-     * @param milliseconds the millis in day in <em>standard</em> local time.
-     * @param monthLength the length of the given month in days.
-     * @param prevMonthLength length of the previous month in days.
-     * @param status     An UErrorCode to receive the status.
-     * @return the offset to add *to* GMT to get local time.
-     * @stable ICU 2.0
-     */
-    virtual int32_t getOffset(uint8_t era, int32_t year, int32_t month, int32_t day,
-                              uint8_t dayOfWeek, int32_t milliseconds,
-                              int32_t monthLength, int32_t prevMonthLength,
-                              UErrorCode& status) const;
-
-    /**
-     * Redeclared TimeZone method.  This implementation simply calls
-     * the base class method, which otherwise would be hidden.
-     * @stable ICU 2.8
-     */
-    virtual void getOffset(UDate date, UBool local, int32_t& rawOffset,
-                           int32_t& dstOffset, UErrorCode& ec) const;
-
-    /**
-     * Get time zone offsets from local wall time.
-     * @internal
-     */
-    virtual void getOffsetFromLocal(UDate date, int32_t nonExistingTimeOpt, int32_t duplicatedTimeOpt,
-        int32_t& rawOffset, int32_t& dstOffset, UErrorCode& status) /*const*/;
-
-    /**
-     * Returns the TimeZone's raw GMT offset (i.e., the number of milliseconds to add
-     * to GMT to get local time, before taking daylight savings time into account).
-     *
-     * @return   The TimeZone's raw GMT offset.
-     * @stable ICU 2.0
-     */
-    virtual int32_t getRawOffset(void) const;
-
-    /**
-     * Sets the TimeZone's raw GMT offset (i.e., the number of milliseconds to add
-     * to GMT to get local time, before taking daylight savings time into account).
-     *
-     * @param offsetMillis  The new raw GMT offset for this time zone.
-     * @stable ICU 2.0
-     */
-    virtual void setRawOffset(int32_t offsetMillis);
-
-    /**
-     * Sets the amount of time in ms that the clock is advanced during DST.
-     * @param millisSavedDuringDST the number of milliseconds the time is
-     * advanced with respect to standard time when the daylight savings rules
-     * are in effect. A positive number, typically one hour (3600000).
-     * @param status  An UErrorCode to receive the status.
-     * @stable ICU 2.0
-     */
-    void setDSTSavings(int32_t millisSavedDuringDST, UErrorCode& status);
-
-    /**
-     * Returns the amount of time in ms that the clock is advanced during DST.
-     * @return the number of milliseconds the time is
-     * advanced with respect to standard time when the daylight savings rules
-     * are in effect. A positive number, typically one hour (3600000).
-     * @stable ICU 2.0
-     */
-    virtual int32_t getDSTSavings(void) const;
-
-    /**
-     * Queries if this TimeZone uses Daylight Savings Time.
-     *
-     * @return   True if this TimeZone uses Daylight Savings Time; false otherwise.
-     * @stable ICU 2.0
-     */
-    virtual UBool useDaylightTime(void) const;
-
-    /**
-     * Returns true if the given date is within the period when daylight savings time
-     * is in effect; false otherwise.  If the TimeZone doesn't observe daylight savings
-     * time, this functions always returns false.
-     * This method is wasteful since it creates a new GregorianCalendar and
-     * deletes it each time it is called. This is a deprecated method
-     * and provided only for Java compatibility.
-     *
-     * @param date The date to test.
-     * @param status  An UErrorCode to receive the status.
-     * @return true if the given date is in Daylight Savings Time;
-     * false otherwise.
-     * @deprecated ICU 2.4. Use Calendar::inDaylightTime() instead.
-     */
-    virtual UBool inDaylightTime(UDate date, UErrorCode& status) const;
-
-    /**
-     * Return true if this zone has the same rules and offset as another zone.
-     * @param other the TimeZone object to be compared with
-     * @return true if the given zone has the same rules and offset as this one
-     * @stable ICU 2.0
-     */
-    UBool hasSameRules(const TimeZone& other) const;
-
-    /**
-     * Clones TimeZone objects polymorphically. Clients are responsible for deleting
-     * the TimeZone object cloned.
-     *
-     * @return   A new copy of this TimeZone object.
-     * @stable ICU 2.0
-     */
-    virtual TimeZone* clone(void) const;
-
-    /**
-     * Gets the first time zone transition after the base time.
-     * @param base      The base time.
-     * @param inclusive Whether the base time is inclusive or not.
-     * @param result    Receives the first transition after the base time.
-     * @return  TRUE if the transition is found.
-     * @stable ICU 4.0
-     */
-    virtual UBool getNextTransition(UDate base, UBool inclusive, TimeZoneTransition& result) /*const*/;
-
-    /**
-     * Gets the most recent time zone transition before the base time.
-     * @param base      The base time.
-     * @param inclusive Whether the base time is inclusive or not.
-     * @param result    Receives the most recent transition before the base time.
-     * @return  TRUE if the transition is found.
-     * @stable ICU 4.0
-     */
-    virtual UBool getPreviousTransition(UDate base, UBool inclusive, TimeZoneTransition& result) /*const*/;
-
-    /**
-     * Returns the number of <code>TimeZoneRule</code>s which represents time transitions,
-     * for this time zone, that is, all <code>TimeZoneRule</code>s for this time zone except
-     * <code>InitialTimeZoneRule</code>.  The return value range is 0 or any positive value.
-     * @param status    Receives error status code.
-     * @return The number of <code>TimeZoneRule</code>s representing time transitions.
-     * @stable ICU 4.0
-     */
-    virtual int32_t countTransitionRules(UErrorCode& status) /*const*/;
-
-    /**
-     * Gets the <code>InitialTimeZoneRule</code> and the set of <code>TimeZoneRule</code>
-     * which represent time transitions for this time zone.  On successful return,
-     * the argument initial points to non-NULL <code>InitialTimeZoneRule</code> and
-     * the array trsrules is filled with 0 or multiple <code>TimeZoneRule</code>
-     * instances up to the size specified by trscount.  The results are referencing the
-     * rule instance held by this time zone instance.  Therefore, after this time zone
-     * is destructed, they are no longer available.
-     * @param initial       Receives the initial timezone rule
-     * @param trsrules      Receives the timezone transition rules
-     * @param trscount      On input, specify the size of the array 'transitions' receiving
-     *                      the timezone transition rules.  On output, actual number of
-     *                      rules filled in the array will be set.
-     * @param status        Receives error status code.
-     * @stable ICU 4.0
-     */
-    virtual void getTimeZoneRules(const InitialTimeZoneRule*& initial,
-        const TimeZoneRule* trsrules[], int32_t& trscount, UErrorCode& status) /*const*/;
-
-
-public:
-
-    /**
-     * Override TimeZone Returns a unique class ID POLYMORPHICALLY. Pure virtual
-     * override. This method is to implement a simple version of RTTI, since not all C++
-     * compilers support genuine RTTI. Polymorphic operator==() and clone() methods call
-     * this method.
-     *
-     * @return   The class ID for this object. All objects of a given class have the
-     *           same class ID. Objects of other classes have different class IDs.
-     * @stable ICU 2.0
-     */
-    virtual UClassID getDynamicClassID(void) const;
-
-    /**
-     * Return the class ID for this class. This is useful only for comparing to a return
-     * value from getDynamicClassID(). For example:
-     * <pre>
-     * .   Base* polymorphic_pointer = createPolymorphicObject();
-     * .   if (polymorphic_pointer->getDynamicClassID() ==
-     * .       Derived::getStaticClassID()) ...
-     * </pre>
-     * @return   The class ID for all objects of this class.
-     * @stable ICU 2.0
-     */
-    static UClassID U_EXPORT2 getStaticClassID(void);
-
-private:
-    /**
-     * Constants specifying values of startMode and endMode.
-     */
-    enum EMode
-    {
-        DOM_MODE = 1,
-        DOW_IN_MONTH_MODE,
-        DOW_GE_DOM_MODE,
-        DOW_LE_DOM_MODE
-    };
-
-    SimpleTimeZone(); // default constructor not implemented
-
-    /**
-     * Internal construction method.
-     * @param rawOffsetGMT    The new SimpleTimeZone's raw GMT offset
-     * @param startMonth      the month DST starts
-     * @param startDay        the day DST starts
-     * @param startDayOfWeek  the DOW DST starts
-     * @param startTime       the time DST starts
-     * @param startTimeMode   Whether the start time is local wall time, local
-     *                        standard time, or UTC time. Default is local wall time.
-     * @param endMonth        the month DST ends
-     * @param endDay          the day DST ends
-     * @param endDayOfWeek    the DOW DST ends
-     * @param endTime         the time DST ends
-     * @param endTimeMode     Whether the end time is local wall time, local
-     *                        standard time, or UTC time. Default is local wall time.
-     * @param savingsDST      The number of milliseconds added to standard time
-     *                        to get DST time. Default is one hour.
-     * @param status          An UErrorCode to receive the status.
-     */
-    void construct(int32_t rawOffsetGMT,
-                   int8_t startMonth, int8_t startDay, int8_t startDayOfWeek,
-                   int32_t startTime, TimeMode startTimeMode,
-                   int8_t endMonth, int8_t endDay, int8_t endDayOfWeek,
-                   int32_t endTime, TimeMode endTimeMode,
-                   int32_t dstSavings, UErrorCode& status);
-
-    /**
-     * Compare a given date in the year to a rule. Return 1, 0, or -1, depending
-     * on whether the date is after, equal to, or before the rule date. The
-     * millis are compared directly against the ruleMillis, so any
-     * standard-daylight adjustments must be handled by the caller.
-     *
-     * @return  1 if the date is after the rule date, -1 if the date is before
-     *          the rule date, or 0 if the date is equal to the rule date.
-     */
-    static int32_t compareToRule(int8_t month, int8_t monthLen, int8_t prevMonthLen,
-                                 int8_t dayOfMonth,
-                                 int8_t dayOfWeek, int32_t millis, int32_t millisDelta,
-                                 EMode ruleMode, int8_t ruleMonth, int8_t ruleDayOfWeek,
-                                 int8_t ruleDay, int32_t ruleMillis);
-
-    /**
-     * Given a set of encoded rules in startDay and startDayOfMonth, decode
-     * them and set the startMode appropriately.  Do the same for endDay and
-     * endDayOfMonth.
-     * <P>
-     * Upon entry, the day of week variables may be zero or
-     * negative, in order to indicate special modes.  The day of month
-     * variables may also be negative.
-     * <P>
-     * Upon exit, the mode variables will be
-     * set, and the day of week and day of month variables will be positive.
-     * <P>
-     * This method also recognizes a startDay or endDay of zero as indicating
-     * no DST.
-     */
-    void decodeRules(UErrorCode& status);
-    void decodeStartRule(UErrorCode& status);
-    void decodeEndRule(UErrorCode& status);
-
-    int8_t startMonth, startDay, startDayOfWeek;   // the month, day, DOW, and time DST starts
-    int32_t startTime;
-    TimeMode startTimeMode, endTimeMode; // Mode for startTime, endTime; see TimeMode
-    int8_t endMonth, endDay, endDayOfWeek; // the month, day, DOW, and time DST ends
-    int32_t endTime;
-    int32_t startYear;  // the year these DST rules took effect
-    int32_t rawOffset;  // the TimeZone's raw GMT offset
-    UBool useDaylight; // flag indicating whether this TimeZone uses DST
-    static const int8_t STATICMONTHLENGTH[12]; // lengths of the months
-    EMode startMode, endMode;   // flags indicating what kind of rules the DST rules are
-
-    /**
-     * A positive value indicating the amount of time saved during DST in ms.
-     * Typically one hour; sometimes 30 minutes.
-     */
-    int32_t dstSavings;
-
-    /* Private for BasicTimeZone implementation */
-    void initTransitionRules(UErrorCode& status);
-    void clearTransitionRules(void);
-    void deleteTransitionRules(void);
-    UBool   transitionRulesInitialized;
-    InitialTimeZoneRule*    initialRule;
-    TimeZoneTransition*     firstTransition;
-    AnnualTimeZoneRule*     stdRule;
-    AnnualTimeZoneRule*     dstRule;
-};
-
-inline void SimpleTimeZone::setStartRule(int32_t month, int32_t dayOfWeekInMonth,
-                                         int32_t dayOfWeek,
-                                         int32_t time, UErrorCode& status) {
-    setStartRule(month, dayOfWeekInMonth, dayOfWeek, time, WALL_TIME, status);
-}
-
-inline void SimpleTimeZone::setStartRule(int32_t month, int32_t dayOfMonth,
-                                         int32_t time,
-                                         UErrorCode& status) {
-    setStartRule(month, dayOfMonth, time, WALL_TIME, status);
-}
-
-inline void SimpleTimeZone::setStartRule(int32_t month, int32_t dayOfMonth,
-                                         int32_t dayOfWeek,
-                                         int32_t time, UBool after, UErrorCode& status) {
-    setStartRule(month, dayOfMonth, dayOfWeek, time, WALL_TIME, after, status);
-}
-
-inline void SimpleTimeZone::setEndRule(int32_t month, int32_t dayOfWeekInMonth,
-                                       int32_t dayOfWeek,
-                                       int32_t time, UErrorCode& status) {
-    setEndRule(month, dayOfWeekInMonth, dayOfWeek, time, WALL_TIME, status);
-}
-
-inline void SimpleTimeZone::setEndRule(int32_t month, int32_t dayOfMonth,
-                                       int32_t time, UErrorCode& status) {
-    setEndRule(month, dayOfMonth, time, WALL_TIME, status);
-}
-
-inline void SimpleTimeZone::setEndRule(int32_t month, int32_t dayOfMonth, int32_t dayOfWeek,
-                                       int32_t time, UBool after, UErrorCode& status) {
-    setEndRule(month, dayOfMonth, dayOfWeek, time, WALL_TIME, after, status);
-}
-
-inline void
-SimpleTimeZone::getOffset(UDate date, UBool local, int32_t& rawOffsetRef,
-                          int32_t& dstOffsetRef, UErrorCode& ec) const {
-    TimeZone::getOffset(date, local, rawOffsetRef, dstOffsetRef, ec);
-}
-
-U_NAMESPACE_END
-
-#endif /* #if !UCONFIG_NO_FORMATTING */
-
-#endif // _SIMPLETZ


[20/57] [abbrv] remove couch_collate

Posted by be...@apache.org.
http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/uchar.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/uchar.h b/apps/couch_collate/platform/osx/icu/unicode/uchar.h
deleted file mode 100644
index 0f629c0..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/uchar.h
+++ /dev/null
@@ -1,3062 +0,0 @@
-/*
-**********************************************************************
-*   Copyright (C) 1997-2008, International Business Machines
-*   Corporation and others.  All Rights Reserved.
-**********************************************************************
-*
-* File UCHAR.H
-*
-* Modification History:
-*
-*   Date        Name        Description
-*   04/02/97    aliu        Creation.
-*   03/29/99    helena      Updated for C APIs.
-*   4/15/99     Madhu       Updated for C Implementation and Javadoc
-*   5/20/99     Madhu       Added the function u_getVersion()
-*   8/19/1999   srl         Upgraded scripts to Unicode 3.0
-*   8/27/1999   schererm    UCharDirection constants: U_...
-*   11/11/1999  weiv        added u_isalnum(), cleaned comments
-*   01/11/2000  helena      Renamed u_getVersion to u_getUnicodeVersion().
-******************************************************************************
-*/
-
-#ifndef UCHAR_H
-#define UCHAR_H
-
-#include "unicode/utypes.h"
-
-U_CDECL_BEGIN
-
-/*==========================================================================*/
-/* Unicode version number                                                   */
-/*==========================================================================*/
-/**
- * Unicode version number, default for the current ICU version.
- * The actual Unicode Character Database (UCD) data is stored in uprops.dat
- * and may be generated from UCD files from a different Unicode version.
- * Call u_getUnicodeVersion to get the actual Unicode version of the data.
- *
- * @see u_getUnicodeVersion
- * @stable ICU 2.0
- */
-#define U_UNICODE_VERSION "5.1"
-
-/**
- * \file
- * \brief C API: Unicode Properties
- *
- * This C API provides low-level access to the Unicode Character Database.
- * In addition to raw property values, some convenience functions calculate
- * derived properties, for example for Java-style programming.
- *
- * Unicode assigns each code point (not just assigned character) values for
- * many properties.
- * Most of them are simple boolean flags, or constants from a small enumerated list.
- * For some properties, values are strings or other relatively more complex types.
- *
- * For more information see
- * "About the Unicode Character Database" (http://www.unicode.org/ucd/)
- * and the ICU User Guide chapter on Properties (http://icu-project.org/userguide/properties.html).
- *
- * Many functions are designed to match java.lang.Character functions.
- * See the individual function documentation,
- * and see the JDK 1.4 java.lang.Character documentation
- * at http://java.sun.com/j2se/1.4/docs/api/java/lang/Character.html
- *
- * There are also functions that provide easy migration from C/POSIX functions
- * like isblank(). Their use is generally discouraged because the C/POSIX
- * standards do not define their semantics beyond the ASCII range, which means
- * that different implementations exhibit very different behavior.
- * Instead, Unicode properties should be used directly.
- *
- * There are also only a few, broad C/POSIX character classes, and they tend
- * to be used for conflicting purposes. For example, the "isalpha()" class
- * is sometimes used to determine word boundaries, while a more sophisticated
- * approach would at least distinguish initial letters from continuation
- * characters (the latter including combining marks).
- * (In ICU, BreakIterator is the most sophisticated API for word boundaries.)
- * Another example: There is no "istitle()" class for titlecase characters.
- *
- * ICU 3.4 and later provides API access for all twelve C/POSIX character classes.
- * ICU implements them according to the Standard Recommendations in
- * Annex C: Compatibility Properties of UTS #18 Unicode Regular Expressions
- * (http://www.unicode.org/reports/tr18/#Compatibility_Properties).
- *
- * API access for C/POSIX character classes is as follows:
- * - alpha:     u_isUAlphabetic(c) or u_hasBinaryProperty(c, UCHAR_ALPHABETIC)
- * - lower:     u_isULowercase(c) or u_hasBinaryProperty(c, UCHAR_LOWERCASE)
- * - upper:     u_isUUppercase(c) or u_hasBinaryProperty(c, UCHAR_UPPERCASE)
- * - punct:     u_ispunct(c)
- * - digit:     u_isdigit(c) or u_charType(c)==U_DECIMAL_DIGIT_NUMBER
- * - xdigit:    u_isxdigit(c) or u_hasBinaryProperty(c, UCHAR_POSIX_XDIGIT)
- * - alnum:     u_hasBinaryProperty(c, UCHAR_POSIX_ALNUM)
- * - space:     u_isUWhiteSpace(c) or u_hasBinaryProperty(c, UCHAR_WHITE_SPACE)
- * - blank:     u_isblank(c) or u_hasBinaryProperty(c, UCHAR_POSIX_BLANK)
- * - cntrl:     u_charType(c)==U_CONTROL_CHAR
- * - graph:     u_hasBinaryProperty(c, UCHAR_POSIX_GRAPH)
- * - print:     u_hasBinaryProperty(c, UCHAR_POSIX_PRINT)
- *
- * Note: Some of the u_isxyz() functions in uchar.h predate, and do not match,
- * the Standard Recommendations in UTS #18. Instead, they match Java
- * functions according to their API documentation.
- *
- * \htmlonly
- * The C/POSIX character classes are also available in UnicodeSet patterns,
- * using patterns like [:graph:] or \p{graph}.
- * \endhtmlonly
- *
- * Note: There are several ICU whitespace functions.
- * Comparison:
- * - u_isUWhiteSpace=UCHAR_WHITE_SPACE: Unicode White_Space property;
- *       most of general categories "Z" (separators) + most whitespace ISO controls
- *       (including no-break spaces, but excluding IS1..IS4 and ZWSP)
- * - u_isWhitespace: Java isWhitespace; Z + whitespace ISO controls but excluding no-break spaces
- * - u_isJavaSpaceChar: Java isSpaceChar; just Z (including no-break spaces)
- * - u_isspace: Z + whitespace ISO controls (including no-break spaces)
- * - u_isblank: "horizontal spaces" = TAB + Zs - ZWSP
- */
-
-/**
- * Constants.
- */
-
-/** The lowest Unicode code point value. Code points are non-negative. @stable ICU 2.0 */
-#define UCHAR_MIN_VALUE 0
-
-/**
- * The highest Unicode code point value (scalar value) according to
- * The Unicode Standard. This is a 21-bit value (20.1 bits, rounded up).
- * For a single character, UChar32 is a simple type that can hold any code point value.
- *
- * @see UChar32
- * @stable ICU 2.0
- */
-#define UCHAR_MAX_VALUE 0x10ffff
-
-/**
- * Get a single-bit bit set (a flag) from a bit number 0..31.
- * @stable ICU 2.1
- */
-#define U_MASK(x) ((uint32_t)1<<(x))
-
-/*
- * !! Note: Several comments in this file are machine-read by the
- * genpname tool.  These comments describe the correspondence between
- * icu enum constants and UCD entities.  Do not delete them.  Update
- * these comments as needed.
- *
- * Any comment of the form "/ *[name]* /" (spaces added) is such
- * a comment.
- *
- * The U_JG_* and U_GC_*_MASK constants are matched by their symbolic
- * name, which must match PropertyValueAliases.txt.
- */
-
-/**
- * Selection constants for Unicode properties.
- * These constants are used in functions like u_hasBinaryProperty to select
- * one of the Unicode properties.
- *
- * The properties APIs are intended to reflect Unicode properties as defined
- * in the Unicode Character Database (UCD) and Unicode Technical Reports (UTR).
- * For details about the properties see http://www.unicode.org/ucd/ .
- * For names of Unicode properties see the UCD file PropertyAliases.txt.
- *
- * Important: If ICU is built with UCD files from Unicode versions below, e.g., 3.2,
- * then properties marked with "new in Unicode 3.2" are not or not fully available.
- * Check u_getUnicodeVersion to be sure.
- *
- * @see u_hasBinaryProperty
- * @see u_getIntPropertyValue
- * @see u_getUnicodeVersion
- * @stable ICU 2.1
- */
-typedef enum UProperty {
-    /*  See note !!.  Comments of the form "Binary property Dash",
-        "Enumerated property Script", "Double property Numeric_Value",
-        and "String property Age" are read by genpname. */
-
-    /*  Note: Place UCHAR_ALPHABETIC before UCHAR_BINARY_START so that
-    debuggers display UCHAR_ALPHABETIC as the symbolic name for 0,
-    rather than UCHAR_BINARY_START.  Likewise for other *_START
-    identifiers. */
-
-    /** Binary property Alphabetic. Same as u_isUAlphabetic, different from u_isalpha.
-        Lu+Ll+Lt+Lm+Lo+Nl+Other_Alphabetic @stable ICU 2.1 */
-    UCHAR_ALPHABETIC=0,
-    /** First constant for binary Unicode properties. @stable ICU 2.1 */
-    UCHAR_BINARY_START=UCHAR_ALPHABETIC,
-    /** Binary property ASCII_Hex_Digit. 0-9 A-F a-f @stable ICU 2.1 */
-    UCHAR_ASCII_HEX_DIGIT=1,
-    /** Binary property Bidi_Control.
-        Format controls which have specific functions
-        in the Bidi Algorithm. @stable ICU 2.1 */
-    UCHAR_BIDI_CONTROL=2,
-    /** Binary property Bidi_Mirrored.
-        Characters that may change display in RTL text.
-        Same as u_isMirrored.
-        See Bidi Algorithm, UTR 9. @stable ICU 2.1 */
-    UCHAR_BIDI_MIRRORED=3,
-    /** Binary property Dash. Variations of dashes. @stable ICU 2.1 */
-    UCHAR_DASH=4,
-    /** Binary property Default_Ignorable_Code_Point (new in Unicode 3.2).
-        Ignorable in most processing.
-        <2060..206F, FFF0..FFFB, E0000..E0FFF>+Other_Default_Ignorable_Code_Point+(Cf+Cc+Cs-White_Space) @stable ICU 2.1 */
-    UCHAR_DEFAULT_IGNORABLE_CODE_POINT=5,
-    /** Binary property Deprecated (new in Unicode 3.2).
-        The usage of deprecated characters is strongly discouraged. @stable ICU 2.1 */
-    UCHAR_DEPRECATED=6,
-    /** Binary property Diacritic. Characters that linguistically modify
-        the meaning of another character to which they apply. @stable ICU 2.1 */
-    UCHAR_DIACRITIC=7,
-    /** Binary property Extender.
-        Extend the value or shape of a preceding alphabetic character,
-        e.g., length and iteration marks. @stable ICU 2.1 */
-    UCHAR_EXTENDER=8,
-    /** Binary property Full_Composition_Exclusion.
-        CompositionExclusions.txt+Singleton Decompositions+
-        Non-Starter Decompositions. @stable ICU 2.1 */
-    UCHAR_FULL_COMPOSITION_EXCLUSION=9,
-    /** Binary property Grapheme_Base (new in Unicode 3.2).
-        For programmatic determination of grapheme cluster boundaries.
-        [0..10FFFF]-Cc-Cf-Cs-Co-Cn-Zl-Zp-Grapheme_Link-Grapheme_Extend-CGJ @stable ICU 2.1 */
-    UCHAR_GRAPHEME_BASE=10,
-    /** Binary property Grapheme_Extend (new in Unicode 3.2).
-        For programmatic determination of grapheme cluster boundaries.
-        Me+Mn+Mc+Other_Grapheme_Extend-Grapheme_Link-CGJ @stable ICU 2.1 */
-    UCHAR_GRAPHEME_EXTEND=11,
-    /** Binary property Grapheme_Link (new in Unicode 3.2).
-        For programmatic determination of grapheme cluster boundaries. @stable ICU 2.1 */
-    UCHAR_GRAPHEME_LINK=12,
-    /** Binary property Hex_Digit.
-        Characters commonly used for hexadecimal numbers. @stable ICU 2.1 */
-    UCHAR_HEX_DIGIT=13,
-    /** Binary property Hyphen. Dashes used to mark connections
-        between pieces of words, plus the Katakana middle dot. @stable ICU 2.1 */
-    UCHAR_HYPHEN=14,
-    /** Binary property ID_Continue.
-        Characters that can continue an identifier.
-        DerivedCoreProperties.txt also says "NOTE: Cf characters should be filtered out."
-        ID_Start+Mn+Mc+Nd+Pc @stable ICU 2.1 */
-    UCHAR_ID_CONTINUE=15,
-    /** Binary property ID_Start.
-        Characters that can start an identifier.
-        Lu+Ll+Lt+Lm+Lo+Nl @stable ICU 2.1 */
-    UCHAR_ID_START=16,
-    /** Binary property Ideographic.
-        CJKV ideographs. @stable ICU 2.1 */
-    UCHAR_IDEOGRAPHIC=17,
-    /** Binary property IDS_Binary_Operator (new in Unicode 3.2).
-        For programmatic determination of
-        Ideographic Description Sequences. @stable ICU 2.1 */
-    UCHAR_IDS_BINARY_OPERATOR=18,
-    /** Binary property IDS_Trinary_Operator (new in Unicode 3.2).
-        For programmatic determination of
-        Ideographic Description Sequences. @stable ICU 2.1 */
-    UCHAR_IDS_TRINARY_OPERATOR=19,
-    /** Binary property Join_Control.
-        Format controls for cursive joining and ligation. @stable ICU 2.1 */
-    UCHAR_JOIN_CONTROL=20,
-    /** Binary property Logical_Order_Exception (new in Unicode 3.2).
-        Characters that do not use logical order and
-        require special handling in most processing. @stable ICU 2.1 */
-    UCHAR_LOGICAL_ORDER_EXCEPTION=21,
-    /** Binary property Lowercase. Same as u_isULowercase, different from u_islower.
-        Ll+Other_Lowercase @stable ICU 2.1 */
-    UCHAR_LOWERCASE=22,
-    /** Binary property Math. Sm+Other_Math @stable ICU 2.1 */
-    UCHAR_MATH=23,
-    /** Binary property Noncharacter_Code_Point.
-        Code points that are explicitly defined as illegal
-        for the encoding of characters. @stable ICU 2.1 */
-    UCHAR_NONCHARACTER_CODE_POINT=24,
-    /** Binary property Quotation_Mark. @stable ICU 2.1 */
-    UCHAR_QUOTATION_MARK=25,
-    /** Binary property Radical (new in Unicode 3.2).
-        For programmatic determination of
-        Ideographic Description Sequences. @stable ICU 2.1 */
-    UCHAR_RADICAL=26,
-    /** Binary property Soft_Dotted (new in Unicode 3.2).
-        Characters with a "soft dot", like i or j.
-        An accent placed on these characters causes
-        the dot to disappear. @stable ICU 2.1 */
-    UCHAR_SOFT_DOTTED=27,
-    /** Binary property Terminal_Punctuation.
-        Punctuation characters that generally mark
-        the end of textual units. @stable ICU 2.1 */
-    UCHAR_TERMINAL_PUNCTUATION=28,
-    /** Binary property Unified_Ideograph (new in Unicode 3.2).
-        For programmatic determination of
-        Ideographic Description Sequences. @stable ICU 2.1 */
-    UCHAR_UNIFIED_IDEOGRAPH=29,
-    /** Binary property Uppercase. Same as u_isUUppercase, different from u_isupper.
-        Lu+Other_Uppercase @stable ICU 2.1 */
-    UCHAR_UPPERCASE=30,
-    /** Binary property White_Space.
-        Same as u_isUWhiteSpace, different from u_isspace and u_isWhitespace.
-        Space characters+TAB+CR+LF-ZWSP-ZWNBSP @stable ICU 2.1 */
-    UCHAR_WHITE_SPACE=31,
-    /** Binary property XID_Continue.
-        ID_Continue modified to allow closure under
-        normalization forms NFKC and NFKD. @stable ICU 2.1 */
-    UCHAR_XID_CONTINUE=32,
-    /** Binary property XID_Start. ID_Start modified to allow
-        closure under normalization forms NFKC and NFKD. @stable ICU 2.1 */
-    UCHAR_XID_START=33,
-    /** Binary property Case_Sensitive. Either the source of a case
-        mapping or _in_ the target of a case mapping. Not the same as
-        the general category Cased_Letter. @stable ICU 2.6 */
-   UCHAR_CASE_SENSITIVE=34,
-    /** Binary property STerm (new in Unicode 4.0.1).
-        Sentence Terminal. Used in UAX #29: Text Boundaries
-        (http://www.unicode.org/reports/tr29/)
-        @stable ICU 3.0 */
-    UCHAR_S_TERM=35,
-    /** Binary property Variation_Selector (new in Unicode 4.0.1).
-        Indicates all those characters that qualify as Variation Selectors.
-        For details on the behavior of these characters,
-        see StandardizedVariants.html and 15.6 Variation Selectors.
-        @stable ICU 3.0 */
-    UCHAR_VARIATION_SELECTOR=36,
-    /** Binary property NFD_Inert.
-        ICU-specific property for characters that are inert under NFD,
-        i.e., they do not interact with adjacent characters.
-        Used for example in normalizing transforms in incremental mode
-        to find the boundary of safely normalizable text despite possible
-        text additions.
-
-        There is one such property per normalization form.
-        These properties are computed as follows - an inert character is:
-        a) unassigned, or ALL of the following:
-        b) of combining class 0.
-        c) not decomposed by this normalization form.
-        AND if NFC or NFKC,
-        d) can never compose with a previous character.
-        e) can never compose with a following character.
-        f) can never change if another character is added.
-           Example: a-breve might satisfy all but f, but if you
-           add an ogonek it changes to a-ogonek + breve
-
-        See also com.ibm.text.UCD.NFSkippable in the ICU4J repository,
-        and icu/source/common/unormimp.h .
-        @stable ICU 3.0 */
-    UCHAR_NFD_INERT=37,
-    /** Binary property NFKD_Inert.
-        ICU-specific property for characters that are inert under NFKD,
-        i.e., they do not interact with adjacent characters.
-        Used for example in normalizing transforms in incremental mode
-        to find the boundary of safely normalizable text despite possible
-        text additions.
-        @see UCHAR_NFD_INERT
-        @stable ICU 3.0 */
-    UCHAR_NFKD_INERT=38,
-    /** Binary property NFC_Inert.
-        ICU-specific property for characters that are inert under NFC,
-        i.e., they do not interact with adjacent characters.
-        Used for example in normalizing transforms in incremental mode
-        to find the boundary of safely normalizable text despite possible
-        text additions.
-        @see UCHAR_NFD_INERT
-        @stable ICU 3.0 */
-    UCHAR_NFC_INERT=39,
-    /** Binary property NFKC_Inert.
-        ICU-specific property for characters that are inert under NFKC,
-        i.e., they do not interact with adjacent characters.
-        Used for example in normalizing transforms in incremental mode
-        to find the boundary of safely normalizable text despite possible
-        text additions.
-        @see UCHAR_NFD_INERT
-        @stable ICU 3.0 */
-    UCHAR_NFKC_INERT=40,
-    /** Binary Property Segment_Starter.
-        ICU-specific property for characters that are starters in terms of
-        Unicode normalization and combining character sequences.
-        They have ccc=0 and do not occur in non-initial position of the
-        canonical decomposition of any character
-        (like " in NFD(a-umlaut) and a Jamo T in an NFD(Hangul LVT)).
-        ICU uses this property for segmenting a string for generating a set of
-        canonically equivalent strings, e.g. for canonical closure while
-        processing collation tailoring rules.
-        @stable ICU 3.0 */
-    UCHAR_SEGMENT_STARTER=41,
-    /** Binary property Pattern_Syntax (new in Unicode 4.1).
-        See UAX #31 Identifier and Pattern Syntax
-        (http://www.unicode.org/reports/tr31/)
-        @stable ICU 3.4 */
-    UCHAR_PATTERN_SYNTAX=42,
-    /** Binary property Pattern_White_Space (new in Unicode 4.1).
-        See UAX #31 Identifier and Pattern Syntax
-        (http://www.unicode.org/reports/tr31/)
-        @stable ICU 3.4 */
-    UCHAR_PATTERN_WHITE_SPACE=43,
-    /** Binary property alnum (a C/POSIX character class).
-        Implemented according to the UTS #18 Annex C Standard Recommendation.
-        See the uchar.h file documentation.
-        @stable ICU 3.4 */
-    UCHAR_POSIX_ALNUM=44,
-    /** Binary property blank (a C/POSIX character class).
-        Implemented according to the UTS #18 Annex C Standard Recommendation.
-        See the uchar.h file documentation.
-        @stable ICU 3.4 */
-    UCHAR_POSIX_BLANK=45,
-    /** Binary property graph (a C/POSIX character class).
-        Implemented according to the UTS #18 Annex C Standard Recommendation.
-        See the uchar.h file documentation.
-        @stable ICU 3.4 */
-    UCHAR_POSIX_GRAPH=46,
-    /** Binary property print (a C/POSIX character class).
-        Implemented according to the UTS #18 Annex C Standard Recommendation.
-        See the uchar.h file documentation.
-        @stable ICU 3.4 */
-    UCHAR_POSIX_PRINT=47,
-    /** Binary property xdigit (a C/POSIX character class).
-        Implemented according to the UTS #18 Annex C Standard Recommendation.
-        See the uchar.h file documentation.
-        @stable ICU 3.4 */
-    UCHAR_POSIX_XDIGIT=48,
-    /** One more than the last constant for binary Unicode properties. @stable ICU 2.1 */
-    UCHAR_BINARY_LIMIT=49,
-
-    /** Enumerated property Bidi_Class.
-        Same as u_charDirection, returns UCharDirection values. @stable ICU 2.2 */
-    UCHAR_BIDI_CLASS=0x1000,
-    /** First constant for enumerated/integer Unicode properties. @stable ICU 2.2 */
-    UCHAR_INT_START=UCHAR_BIDI_CLASS,
-    /** Enumerated property Block.
-        Same as ublock_getCode, returns UBlockCode values. @stable ICU 2.2 */
-    UCHAR_BLOCK=0x1001,
-    /** Enumerated property Canonical_Combining_Class.
-        Same as u_getCombiningClass, returns 8-bit numeric values. @stable ICU 2.2 */
-    UCHAR_CANONICAL_COMBINING_CLASS=0x1002,
-    /** Enumerated property Decomposition_Type.
-        Returns UDecompositionType values. @stable ICU 2.2 */
-    UCHAR_DECOMPOSITION_TYPE=0x1003,
-    /** Enumerated property East_Asian_Width.
-        See http://www.unicode.org/reports/tr11/
-        Returns UEastAsianWidth values. @stable ICU 2.2 */
-    UCHAR_EAST_ASIAN_WIDTH=0x1004,
-    /** Enumerated property General_Category.
-        Same as u_charType, returns UCharCategory values. @stable ICU 2.2 */
-    UCHAR_GENERAL_CATEGORY=0x1005,
-    /** Enumerated property Joining_Group.
-        Returns UJoiningGroup values. @stable ICU 2.2 */
-    UCHAR_JOINING_GROUP=0x1006,
-    /** Enumerated property Joining_Type.
-        Returns UJoiningType values. @stable ICU 2.2 */
-    UCHAR_JOINING_TYPE=0x1007,
-    /** Enumerated property Line_Break.
-        Returns ULineBreak values. @stable ICU 2.2 */
-    UCHAR_LINE_BREAK=0x1008,
-    /** Enumerated property Numeric_Type.
-        Returns UNumericType values. @stable ICU 2.2 */
-    UCHAR_NUMERIC_TYPE=0x1009,
-    /** Enumerated property Script.
-        Same as uscript_getScript, returns UScriptCode values. @stable ICU 2.2 */
-    UCHAR_SCRIPT=0x100A,
-    /** Enumerated property Hangul_Syllable_Type, new in Unicode 4.
-        Returns UHangulSyllableType values. @stable ICU 2.6 */
-    UCHAR_HANGUL_SYLLABLE_TYPE=0x100B,
-    /** Enumerated property NFD_Quick_Check.
-        Returns UNormalizationCheckResult values. @stable ICU 3.0 */
-    UCHAR_NFD_QUICK_CHECK=0x100C,
-    /** Enumerated property NFKD_Quick_Check.
-        Returns UNormalizationCheckResult values. @stable ICU 3.0 */
-    UCHAR_NFKD_QUICK_CHECK=0x100D,
-    /** Enumerated property NFC_Quick_Check.
-        Returns UNormalizationCheckResult values. @stable ICU 3.0 */
-    UCHAR_NFC_QUICK_CHECK=0x100E,
-    /** Enumerated property NFKC_Quick_Check.
-        Returns UNormalizationCheckResult values. @stable ICU 3.0 */
-    UCHAR_NFKC_QUICK_CHECK=0x100F,
-    /** Enumerated property Lead_Canonical_Combining_Class.
-        ICU-specific property for the ccc of the first code point
-        of the decomposition, or lccc(c)=ccc(NFD(c)[0]).
-        Useful for checking for canonically ordered text;
-        see UNORM_FCD and http://www.unicode.org/notes/tn5/#FCD .
-        Returns 8-bit numeric values like UCHAR_CANONICAL_COMBINING_CLASS. @stable ICU 3.0 */
-    UCHAR_LEAD_CANONICAL_COMBINING_CLASS=0x1010,
-    /** Enumerated property Trail_Canonical_Combining_Class.
-        ICU-specific property for the ccc of the last code point
-        of the decomposition, or tccc(c)=ccc(NFD(c)[last]).
-        Useful for checking for canonically ordered text;
-        see UNORM_FCD and http://www.unicode.org/notes/tn5/#FCD .
-        Returns 8-bit numeric values like UCHAR_CANONICAL_COMBINING_CLASS. @stable ICU 3.0 */
-    UCHAR_TRAIL_CANONICAL_COMBINING_CLASS=0x1011,
-    /** Enumerated property Grapheme_Cluster_Break (new in Unicode 4.1).
-        Used in UAX #29: Text Boundaries
-        (http://www.unicode.org/reports/tr29/)
-        Returns UGraphemeClusterBreak values. @stable ICU 3.4 */
-    UCHAR_GRAPHEME_CLUSTER_BREAK=0x1012,
-    /** Enumerated property Sentence_Break (new in Unicode 4.1).
-        Used in UAX #29: Text Boundaries
-        (http://www.unicode.org/reports/tr29/)
-        Returns USentenceBreak values. @stable ICU 3.4 */
-    UCHAR_SENTENCE_BREAK=0x1013,
-    /** Enumerated property Word_Break (new in Unicode 4.1).
-        Used in UAX #29: Text Boundaries
-        (http://www.unicode.org/reports/tr29/)
-        Returns UWordBreakValues values. @stable ICU 3.4 */
-    UCHAR_WORD_BREAK=0x1014,
-    /** One more than the last constant for enumerated/integer Unicode properties. @stable ICU 2.2 */
-    UCHAR_INT_LIMIT=0x1015,
-
-    /** Bitmask property General_Category_Mask.
-        This is the General_Category property returned as a bit mask.
-        When used in u_getIntPropertyValue(c), same as U_MASK(u_charType(c)),
-        returns bit masks for UCharCategory values where exactly one bit is set.
-        When used with u_getPropertyValueName() and u_getPropertyValueEnum(),
-        a multi-bit mask is used for sets of categories like "Letters".
-        Mask values should be cast to uint32_t.
-        @stable ICU 2.4 */
-    UCHAR_GENERAL_CATEGORY_MASK=0x2000,
-    /** First constant for bit-mask Unicode properties. @stable ICU 2.4 */
-    UCHAR_MASK_START=UCHAR_GENERAL_CATEGORY_MASK,
-    /** One more than the last constant for bit-mask Unicode properties. @stable ICU 2.4 */
-    UCHAR_MASK_LIMIT=0x2001,
-
-    /** Double property Numeric_Value.
-        Corresponds to u_getNumericValue. @stable ICU 2.4 */
-    UCHAR_NUMERIC_VALUE=0x3000,
-    /** First constant for double Unicode properties. @stable ICU 2.4 */
-    UCHAR_DOUBLE_START=UCHAR_NUMERIC_VALUE,
-    /** One more than the last constant for double Unicode properties. @stable ICU 2.4 */
-    UCHAR_DOUBLE_LIMIT=0x3001,
-
-    /** String property Age.
-        Corresponds to u_charAge. @stable ICU 2.4 */
-    UCHAR_AGE=0x4000,
-    /** First constant for string Unicode properties. @stable ICU 2.4 */
-    UCHAR_STRING_START=UCHAR_AGE,
-    /** String property Bidi_Mirroring_Glyph.
-        Corresponds to u_charMirror. @stable ICU 2.4 */
-    UCHAR_BIDI_MIRRORING_GLYPH=0x4001,
-    /** String property Case_Folding.
-        Corresponds to u_strFoldCase in ustring.h. @stable ICU 2.4 */
-    UCHAR_CASE_FOLDING=0x4002,
-    /** String property ISO_Comment.
-        Corresponds to u_getISOComment. @stable ICU 2.4 */
-    UCHAR_ISO_COMMENT=0x4003,
-    /** String property Lowercase_Mapping.
-        Corresponds to u_strToLower in ustring.h. @stable ICU 2.4 */
-    UCHAR_LOWERCASE_MAPPING=0x4004,
-    /** String property Name.
-        Corresponds to u_charName. @stable ICU 2.4 */
-    UCHAR_NAME=0x4005,
-    /** String property Simple_Case_Folding.
-        Corresponds to u_foldCase. @stable ICU 2.4 */
-    UCHAR_SIMPLE_CASE_FOLDING=0x4006,
-    /** String property Simple_Lowercase_Mapping.
-        Corresponds to u_tolower. @stable ICU 2.4 */
-    UCHAR_SIMPLE_LOWERCASE_MAPPING=0x4007,
-    /** String property Simple_Titlecase_Mapping.
-        Corresponds to u_totitle. @stable ICU 2.4 */
-    UCHAR_SIMPLE_TITLECASE_MAPPING=0x4008,
-    /** String property Simple_Uppercase_Mapping.
-        Corresponds to u_toupper. @stable ICU 2.4 */
-    UCHAR_SIMPLE_UPPERCASE_MAPPING=0x4009,
-    /** String property Titlecase_Mapping.
-        Corresponds to u_strToTitle in ustring.h. @stable ICU 2.4 */
-    UCHAR_TITLECASE_MAPPING=0x400A,
-    /** String property Unicode_1_Name.
-        Corresponds to u_charName. @stable ICU 2.4 */
-    UCHAR_UNICODE_1_NAME=0x400B,
-    /** String property Uppercase_Mapping.
-        Corresponds to u_strToUpper in ustring.h. @stable ICU 2.4 */
-    UCHAR_UPPERCASE_MAPPING=0x400C,
-    /** One more than the last constant for string Unicode properties. @stable ICU 2.4 */
-    UCHAR_STRING_LIMIT=0x400D,
-
-    /** Represents a nonexistent or invalid property or property value. @stable ICU 2.4 */
-    UCHAR_INVALID_CODE = -1
-} UProperty;
-
-/**
- * Data for enumerated Unicode general category types.
- * See http://www.unicode.org/Public/UNIDATA/UnicodeData.html .
- * @stable ICU 2.0
- */
-typedef enum UCharCategory
-{
-    /** See note !!.  Comments of the form "Cn" are read by genpname. */
-
-    /** Non-category for unassigned and non-character code points. @stable ICU 2.0 */
-    U_UNASSIGNED              = 0,
-    /** Cn "Other, Not Assigned (no characters in [UnicodeData.txt] have this property)" (same as U_UNASSIGNED!) @stable ICU 2.0 */
-    U_GENERAL_OTHER_TYPES     = 0,
-    /** Lu @stable ICU 2.0 */
-    U_UPPERCASE_LETTER        = 1,
-    /** Ll @stable ICU 2.0 */
-    U_LOWERCASE_LETTER        = 2,
-    /** Lt @stable ICU 2.0 */
-    U_TITLECASE_LETTER        = 3,
-    /** Lm @stable ICU 2.0 */
-    U_MODIFIER_LETTER         = 4,
-    /** Lo @stable ICU 2.0 */
-    U_OTHER_LETTER            = 5,
-    /** Mn @stable ICU 2.0 */
-    U_NON_SPACING_MARK        = 6,
-    /** Me @stable ICU 2.0 */
-    U_ENCLOSING_MARK          = 7,
-    /** Mc @stable ICU 2.0 */
-    U_COMBINING_SPACING_MARK  = 8,
-    /** Nd @stable ICU 2.0 */
-    U_DECIMAL_DIGIT_NUMBER    = 9,
-    /** Nl @stable ICU 2.0 */
-    U_LETTER_NUMBER           = 10,
-    /** No @stable ICU 2.0 */
-    U_OTHER_NUMBER            = 11,
-    /** Zs @stable ICU 2.0 */
-    U_SPACE_SEPARATOR         = 12,
-    /** Zl @stable ICU 2.0 */
-    U_LINE_SEPARATOR          = 13,
-    /** Zp @stable ICU 2.0 */
-    U_PARAGRAPH_SEPARATOR     = 14,
-    /** Cc @stable ICU 2.0 */
-    U_CONTROL_CHAR            = 15,
-    /** Cf @stable ICU 2.0 */
-    U_FORMAT_CHAR             = 16,
-    /** Co @stable ICU 2.0 */
-    U_PRIVATE_USE_CHAR        = 17,
-    /** Cs @stable ICU 2.0 */
-    U_SURROGATE               = 18,
-    /** Pd @stable ICU 2.0 */
-    U_DASH_PUNCTUATION        = 19,
-    /** Ps @stable ICU 2.0 */
-    U_START_PUNCTUATION       = 20,
-    /** Pe @stable ICU 2.0 */
-    U_END_PUNCTUATION         = 21,
-    /** Pc @stable ICU 2.0 */
-    U_CONNECTOR_PUNCTUATION   = 22,
-    /** Po @stable ICU 2.0 */
-    U_OTHER_PUNCTUATION       = 23,
-    /** Sm @stable ICU 2.0 */
-    U_MATH_SYMBOL             = 24,
-    /** Sc @stable ICU 2.0 */
-    U_CURRENCY_SYMBOL         = 25,
-    /** Sk @stable ICU 2.0 */
-    U_MODIFIER_SYMBOL         = 26,
-    /** So @stable ICU 2.0 */
-    U_OTHER_SYMBOL            = 27,
-    /** Pi @stable ICU 2.0 */
-    U_INITIAL_PUNCTUATION     = 28,
-    /** Pf @stable ICU 2.0 */
-    U_FINAL_PUNCTUATION       = 29,
-    /** One higher than the last enum UCharCategory constant. @stable ICU 2.0 */
-    U_CHAR_CATEGORY_COUNT
-} UCharCategory;
-
-/**
- * U_GC_XX_MASK constants are bit flags corresponding to Unicode
- * general category values.
- * For each category, the nth bit is set if the numeric value of the
- * corresponding UCharCategory constant is n.
- *
- * There are also some U_GC_Y_MASK constants for groups of general categories
- * like L for all letter categories.
- *
- * @see u_charType
- * @see U_GET_GC_MASK
- * @see UCharCategory
- * @stable ICU 2.1
- */
-#define U_GC_CN_MASK    U_MASK(U_GENERAL_OTHER_TYPES)
-
-/** Mask constant for a UCharCategory. @stable ICU 2.1 */
-#define U_GC_LU_MASK    U_MASK(U_UPPERCASE_LETTER)
-/** Mask constant for a UCharCategory. @stable ICU 2.1 */
-#define U_GC_LL_MASK    U_MASK(U_LOWERCASE_LETTER)
-/** Mask constant for a UCharCategory. @stable ICU 2.1 */
-#define U_GC_LT_MASK    U_MASK(U_TITLECASE_LETTER)
-/** Mask constant for a UCharCategory. @stable ICU 2.1 */
-#define U_GC_LM_MASK    U_MASK(U_MODIFIER_LETTER)
-/** Mask constant for a UCharCategory. @stable ICU 2.1 */
-#define U_GC_LO_MASK    U_MASK(U_OTHER_LETTER)
-
-/** Mask constant for a UCharCategory. @stable ICU 2.1 */
-#define U_GC_MN_MASK    U_MASK(U_NON_SPACING_MARK)
-/** Mask constant for a UCharCategory. @stable ICU 2.1 */
-#define U_GC_ME_MASK    U_MASK(U_ENCLOSING_MARK)
-/** Mask constant for a UCharCategory. @stable ICU 2.1 */
-#define U_GC_MC_MASK    U_MASK(U_COMBINING_SPACING_MARK)
-
-/** Mask constant for a UCharCategory. @stable ICU 2.1 */
-#define U_GC_ND_MASK    U_MASK(U_DECIMAL_DIGIT_NUMBER)
-/** Mask constant for a UCharCategory. @stable ICU 2.1 */
-#define U_GC_NL_MASK    U_MASK(U_LETTER_NUMBER)
-/** Mask constant for a UCharCategory. @stable ICU 2.1 */
-#define U_GC_NO_MASK    U_MASK(U_OTHER_NUMBER)
-
-/** Mask constant for a UCharCategory. @stable ICU 2.1 */
-#define U_GC_ZS_MASK    U_MASK(U_SPACE_SEPARATOR)
-/** Mask constant for a UCharCategory. @stable ICU 2.1 */
-#define U_GC_ZL_MASK    U_MASK(U_LINE_SEPARATOR)
-/** Mask constant for a UCharCategory. @stable ICU 2.1 */
-#define U_GC_ZP_MASK    U_MASK(U_PARAGRAPH_SEPARATOR)
-
-/** Mask constant for a UCharCategory. @stable ICU 2.1 */
-#define U_GC_CC_MASK    U_MASK(U_CONTROL_CHAR)
-/** Mask constant for a UCharCategory. @stable ICU 2.1 */
-#define U_GC_CF_MASK    U_MASK(U_FORMAT_CHAR)
-/** Mask constant for a UCharCategory. @stable ICU 2.1 */
-#define U_GC_CO_MASK    U_MASK(U_PRIVATE_USE_CHAR)
-/** Mask constant for a UCharCategory. @stable ICU 2.1 */
-#define U_GC_CS_MASK    U_MASK(U_SURROGATE)
-
-/** Mask constant for a UCharCategory. @stable ICU 2.1 */
-#define U_GC_PD_MASK    U_MASK(U_DASH_PUNCTUATION)
-/** Mask constant for a UCharCategory. @stable ICU 2.1 */
-#define U_GC_PS_MASK    U_MASK(U_START_PUNCTUATION)
-/** Mask constant for a UCharCategory. @stable ICU 2.1 */
-#define U_GC_PE_MASK    U_MASK(U_END_PUNCTUATION)
-/** Mask constant for a UCharCategory. @stable ICU 2.1 */
-#define U_GC_PC_MASK    U_MASK(U_CONNECTOR_PUNCTUATION)
-/** Mask constant for a UCharCategory. @stable ICU 2.1 */
-#define U_GC_PO_MASK    U_MASK(U_OTHER_PUNCTUATION)
-
-/** Mask constant for a UCharCategory. @stable ICU 2.1 */
-#define U_GC_SM_MASK    U_MASK(U_MATH_SYMBOL)
-/** Mask constant for a UCharCategory. @stable ICU 2.1 */
-#define U_GC_SC_MASK    U_MASK(U_CURRENCY_SYMBOL)
-/** Mask constant for a UCharCategory. @stable ICU 2.1 */
-#define U_GC_SK_MASK    U_MASK(U_MODIFIER_SYMBOL)
-/** Mask constant for a UCharCategory. @stable ICU 2.1 */
-#define U_GC_SO_MASK    U_MASK(U_OTHER_SYMBOL)
-
-/** Mask constant for a UCharCategory. @stable ICU 2.1 */
-#define U_GC_PI_MASK    U_MASK(U_INITIAL_PUNCTUATION)
-/** Mask constant for a UCharCategory. @stable ICU 2.1 */
-#define U_GC_PF_MASK    U_MASK(U_FINAL_PUNCTUATION)
-
-
-/** Mask constant for multiple UCharCategory bits (L Letters). @stable ICU 2.1 */
-#define U_GC_L_MASK \
-            (U_GC_LU_MASK|U_GC_LL_MASK|U_GC_LT_MASK|U_GC_LM_MASK|U_GC_LO_MASK)
-
-/** Mask constant for multiple UCharCategory bits (LC Cased Letters). @stable ICU 2.1 */
-#define U_GC_LC_MASK \
-            (U_GC_LU_MASK|U_GC_LL_MASK|U_GC_LT_MASK)
-
-/** Mask constant for multiple UCharCategory bits (M Marks). @stable ICU 2.1 */
-#define U_GC_M_MASK (U_GC_MN_MASK|U_GC_ME_MASK|U_GC_MC_MASK)
-
-/** Mask constant for multiple UCharCategory bits (N Numbers). @stable ICU 2.1 */
-#define U_GC_N_MASK (U_GC_ND_MASK|U_GC_NL_MASK|U_GC_NO_MASK)
-
-/** Mask constant for multiple UCharCategory bits (Z Separators). @stable ICU 2.1 */
-#define U_GC_Z_MASK (U_GC_ZS_MASK|U_GC_ZL_MASK|U_GC_ZP_MASK)
-
-/** Mask constant for multiple UCharCategory bits (C Others). @stable ICU 2.1 */
-#define U_GC_C_MASK \
-            (U_GC_CN_MASK|U_GC_CC_MASK|U_GC_CF_MASK|U_GC_CO_MASK|U_GC_CS_MASK)
-
-/** Mask constant for multiple UCharCategory bits (P Punctuation). @stable ICU 2.1 */
-#define U_GC_P_MASK \
-            (U_GC_PD_MASK|U_GC_PS_MASK|U_GC_PE_MASK|U_GC_PC_MASK|U_GC_PO_MASK| \
-             U_GC_PI_MASK|U_GC_PF_MASK)
-
-/** Mask constant for multiple UCharCategory bits (S Symbols). @stable ICU 2.1 */
-#define U_GC_S_MASK (U_GC_SM_MASK|U_GC_SC_MASK|U_GC_SK_MASK|U_GC_SO_MASK)
-
-/**
- * This specifies the language directional property of a character set.
- * @stable ICU 2.0
- */
-typedef enum UCharDirection {
-    /** See note !!.  Comments of the form "EN" are read by genpname. */
-
-    /** L @stable ICU 2.0 */
-    U_LEFT_TO_RIGHT               = 0,
-    /** R @stable ICU 2.0 */
-    U_RIGHT_TO_LEFT               = 1,
-    /** EN @stable ICU 2.0 */
-    U_EUROPEAN_NUMBER             = 2,
-    /** ES @stable ICU 2.0 */
-    U_EUROPEAN_NUMBER_SEPARATOR   = 3,
-    /** ET @stable ICU 2.0 */
-    U_EUROPEAN_NUMBER_TERMINATOR  = 4,
-    /** AN @stable ICU 2.0 */
-    U_ARABIC_NUMBER               = 5,
-    /** CS @stable ICU 2.0 */
-    U_COMMON_NUMBER_SEPARATOR     = 6,
-    /** B @stable ICU 2.0 */
-    U_BLOCK_SEPARATOR             = 7,
-    /** S @stable ICU 2.0 */
-    U_SEGMENT_SEPARATOR           = 8,
-    /** WS @stable ICU 2.0 */
-    U_WHITE_SPACE_NEUTRAL         = 9,
-    /** ON @stable ICU 2.0 */
-    U_OTHER_NEUTRAL               = 10,
-    /** LRE @stable ICU 2.0 */
-    U_LEFT_TO_RIGHT_EMBEDDING     = 11,
-    /** LRO @stable ICU 2.0 */
-    U_LEFT_TO_RIGHT_OVERRIDE      = 12,
-    /** AL @stable ICU 2.0 */
-    U_RIGHT_TO_LEFT_ARABIC        = 13,
-    /** RLE @stable ICU 2.0 */
-    U_RIGHT_TO_LEFT_EMBEDDING     = 14,
-    /** RLO @stable ICU 2.0 */
-    U_RIGHT_TO_LEFT_OVERRIDE      = 15,
-    /** PDF @stable ICU 2.0 */
-    U_POP_DIRECTIONAL_FORMAT      = 16,
-    /** NSM @stable ICU 2.0 */
-    U_DIR_NON_SPACING_MARK        = 17,
-    /** BN @stable ICU 2.0 */
-    U_BOUNDARY_NEUTRAL            = 18,
-    /** @stable ICU 2.0 */
-    U_CHAR_DIRECTION_COUNT
-} UCharDirection;
-
-/**
- * Constants for Unicode blocks, see the Unicode Data file Blocks.txt
- * @stable ICU 2.0
- */
-enum UBlockCode {
-
-    /** New No_Block value in Unicode 4. @stable ICU 2.6 */
-    UBLOCK_NO_BLOCK = 0, /*[none]*/ /* Special range indicating No_Block */
-
-    /** @stable ICU 2.0 */
-    UBLOCK_BASIC_LATIN = 1, /*[0000]*/ /*See note !!*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_LATIN_1_SUPPLEMENT=2, /*[0080]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_LATIN_EXTENDED_A =3, /*[0100]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_LATIN_EXTENDED_B =4, /*[0180]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_IPA_EXTENSIONS =5, /*[0250]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_SPACING_MODIFIER_LETTERS =6, /*[02B0]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_COMBINING_DIACRITICAL_MARKS =7, /*[0300]*/
-
-    /**
-     * Unicode 3.2 renames this block to "Greek and Coptic".
-     * @stable ICU 2.0
-     */
-    UBLOCK_GREEK =8, /*[0370]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_CYRILLIC =9, /*[0400]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_ARMENIAN =10, /*[0530]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_HEBREW =11, /*[0590]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_ARABIC =12, /*[0600]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_SYRIAC =13, /*[0700]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_THAANA =14, /*[0780]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_DEVANAGARI =15, /*[0900]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_BENGALI =16, /*[0980]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_GURMUKHI =17, /*[0A00]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_GUJARATI =18, /*[0A80]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_ORIYA =19, /*[0B00]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_TAMIL =20, /*[0B80]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_TELUGU =21, /*[0C00]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_KANNADA =22, /*[0C80]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_MALAYALAM =23, /*[0D00]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_SINHALA =24, /*[0D80]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_THAI =25, /*[0E00]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_LAO =26, /*[0E80]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_TIBETAN =27, /*[0F00]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_MYANMAR =28, /*[1000]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_GEORGIAN =29, /*[10A0]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_HANGUL_JAMO =30, /*[1100]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_ETHIOPIC =31, /*[1200]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_CHEROKEE =32, /*[13A0]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_UNIFIED_CANADIAN_ABORIGINAL_SYLLABICS =33, /*[1400]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_OGHAM =34, /*[1680]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_RUNIC =35, /*[16A0]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_KHMER =36, /*[1780]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_MONGOLIAN =37, /*[1800]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_LATIN_EXTENDED_ADDITIONAL =38, /*[1E00]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_GREEK_EXTENDED =39, /*[1F00]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_GENERAL_PUNCTUATION =40, /*[2000]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_SUPERSCRIPTS_AND_SUBSCRIPTS =41, /*[2070]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_CURRENCY_SYMBOLS =42, /*[20A0]*/
-
-    /**
-     * Unicode 3.2 renames this block to "Combining Diacritical Marks for Symbols".
-     * @stable ICU 2.0
-     */
-    UBLOCK_COMBINING_MARKS_FOR_SYMBOLS =43, /*[20D0]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_LETTERLIKE_SYMBOLS =44, /*[2100]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_NUMBER_FORMS =45, /*[2150]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_ARROWS =46, /*[2190]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_MATHEMATICAL_OPERATORS =47, /*[2200]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_MISCELLANEOUS_TECHNICAL =48, /*[2300]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_CONTROL_PICTURES =49, /*[2400]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_OPTICAL_CHARACTER_RECOGNITION =50, /*[2440]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_ENCLOSED_ALPHANUMERICS =51, /*[2460]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_BOX_DRAWING =52, /*[2500]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_BLOCK_ELEMENTS =53, /*[2580]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_GEOMETRIC_SHAPES =54, /*[25A0]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_MISCELLANEOUS_SYMBOLS =55, /*[2600]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_DINGBATS =56, /*[2700]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_BRAILLE_PATTERNS =57, /*[2800]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_CJK_RADICALS_SUPPLEMENT =58, /*[2E80]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_KANGXI_RADICALS =59, /*[2F00]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_IDEOGRAPHIC_DESCRIPTION_CHARACTERS =60, /*[2FF0]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_CJK_SYMBOLS_AND_PUNCTUATION =61, /*[3000]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_HIRAGANA =62, /*[3040]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_KATAKANA =63, /*[30A0]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_BOPOMOFO =64, /*[3100]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_HANGUL_COMPATIBILITY_JAMO =65, /*[3130]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_KANBUN =66, /*[3190]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_BOPOMOFO_EXTENDED =67, /*[31A0]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_ENCLOSED_CJK_LETTERS_AND_MONTHS =68, /*[3200]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_CJK_COMPATIBILITY =69, /*[3300]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_CJK_UNIFIED_IDEOGRAPHS_EXTENSION_A =70, /*[3400]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_CJK_UNIFIED_IDEOGRAPHS =71, /*[4E00]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_YI_SYLLABLES =72, /*[A000]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_YI_RADICALS =73, /*[A490]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_HANGUL_SYLLABLES =74, /*[AC00]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_HIGH_SURROGATES =75, /*[D800]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_HIGH_PRIVATE_USE_SURROGATES =76, /*[DB80]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_LOW_SURROGATES =77, /*[DC00]*/
-
-    /**
-     * Same as UBLOCK_PRIVATE_USE_AREA.
-     * Until Unicode 3.1.1, the corresponding block name was "Private Use",
-     * and multiple code point ranges had this block.
-     * Unicode 3.2 renames the block for the BMP PUA to "Private Use Area" and
-     * adds separate blocks for the supplementary PUAs.
-     *
-     * @stable ICU 2.0
-     */
-    UBLOCK_PRIVATE_USE = 78,
-    /**
-     * Same as UBLOCK_PRIVATE_USE.
-     * Until Unicode 3.1.1, the corresponding block name was "Private Use",
-     * and multiple code point ranges had this block.
-     * Unicode 3.2 renames the block for the BMP PUA to "Private Use Area" and
-     * adds separate blocks for the supplementary PUAs.
-     *
-     * @stable ICU 2.0
-     */
-    UBLOCK_PRIVATE_USE_AREA =UBLOCK_PRIVATE_USE, /*[E000]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_CJK_COMPATIBILITY_IDEOGRAPHS =79, /*[F900]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_ALPHABETIC_PRESENTATION_FORMS =80, /*[FB00]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_ARABIC_PRESENTATION_FORMS_A =81, /*[FB50]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_COMBINING_HALF_MARKS =82, /*[FE20]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_CJK_COMPATIBILITY_FORMS =83, /*[FE30]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_SMALL_FORM_VARIANTS =84, /*[FE50]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_ARABIC_PRESENTATION_FORMS_B =85, /*[FE70]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_SPECIALS =86, /*[FFF0]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_HALFWIDTH_AND_FULLWIDTH_FORMS =87, /*[FF00]*/
-
-    /* New blocks in Unicode 3.1 */
-
-    /** @stable ICU 2.0 */
-    UBLOCK_OLD_ITALIC = 88  , /*[10300]*/
-    /** @stable ICU 2.0 */
-    UBLOCK_GOTHIC = 89 , /*[10330]*/
-    /** @stable ICU 2.0 */
-    UBLOCK_DESERET = 90 , /*[10400]*/
-    /** @stable ICU 2.0 */
-    UBLOCK_BYZANTINE_MUSICAL_SYMBOLS = 91 , /*[1D000]*/
-    /** @stable ICU 2.0 */
-    UBLOCK_MUSICAL_SYMBOLS = 92 , /*[1D100]*/
-    /** @stable ICU 2.0 */
-    UBLOCK_MATHEMATICAL_ALPHANUMERIC_SYMBOLS = 93  , /*[1D400]*/
-    /** @stable ICU 2.0 */
-    UBLOCK_CJK_UNIFIED_IDEOGRAPHS_EXTENSION_B  = 94 , /*[20000]*/
-    /** @stable ICU 2.0 */
-    UBLOCK_CJK_COMPATIBILITY_IDEOGRAPHS_SUPPLEMENT = 95 , /*[2F800]*/
-    /** @stable ICU 2.0 */
-    UBLOCK_TAGS = 96, /*[E0000]*/
-
-    /* New blocks in Unicode 3.2 */
-
-    /**
-     * Unicode 4.0.1 renames the "Cyrillic Supplementary" block to "Cyrillic Supplement".
-     * @stable ICU 2.2
-     */
-    UBLOCK_CYRILLIC_SUPPLEMENTARY = 97, 
-    /** @stable ICU 3.0  */
-    UBLOCK_CYRILLIC_SUPPLEMENT = UBLOCK_CYRILLIC_SUPPLEMENTARY, /*[0500]*/
-    /** @stable ICU 2.2 */
-    UBLOCK_TAGALOG = 98, /*[1700]*/
-    /** @stable ICU 2.2 */
-    UBLOCK_HANUNOO = 99, /*[1720]*/
-    /** @stable ICU 2.2 */
-    UBLOCK_BUHID = 100, /*[1740]*/
-    /** @stable ICU 2.2 */
-    UBLOCK_TAGBANWA = 101, /*[1760]*/
-    /** @stable ICU 2.2 */
-    UBLOCK_MISCELLANEOUS_MATHEMATICAL_SYMBOLS_A = 102, /*[27C0]*/
-    /** @stable ICU 2.2 */
-    UBLOCK_SUPPLEMENTAL_ARROWS_A = 103, /*[27F0]*/
-    /** @stable ICU 2.2 */
-    UBLOCK_SUPPLEMENTAL_ARROWS_B = 104, /*[2900]*/
-    /** @stable ICU 2.2 */
-    UBLOCK_MISCELLANEOUS_MATHEMATICAL_SYMBOLS_B = 105, /*[2980]*/
-    /** @stable ICU 2.2 */
-    UBLOCK_SUPPLEMENTAL_MATHEMATICAL_OPERATORS = 106, /*[2A00]*/
-    /** @stable ICU 2.2 */
-    UBLOCK_KATAKANA_PHONETIC_EXTENSIONS = 107, /*[31F0]*/
-    /** @stable ICU 2.2 */
-    UBLOCK_VARIATION_SELECTORS = 108, /*[FE00]*/
-    /** @stable ICU 2.2 */
-    UBLOCK_SUPPLEMENTARY_PRIVATE_USE_AREA_A = 109, /*[F0000]*/
-    /** @stable ICU 2.2 */
-    UBLOCK_SUPPLEMENTARY_PRIVATE_USE_AREA_B = 110, /*[100000]*/
-
-    /* New blocks in Unicode 4 */
-
-    /** @stable ICU 2.6 */
-    UBLOCK_LIMBU = 111, /*[1900]*/
-    /** @stable ICU 2.6 */
-    UBLOCK_TAI_LE = 112, /*[1950]*/
-    /** @stable ICU 2.6 */
-    UBLOCK_KHMER_SYMBOLS = 113, /*[19E0]*/
-    /** @stable ICU 2.6 */
-    UBLOCK_PHONETIC_EXTENSIONS = 114, /*[1D00]*/
-    /** @stable ICU 2.6 */
-    UBLOCK_MISCELLANEOUS_SYMBOLS_AND_ARROWS = 115, /*[2B00]*/
-    /** @stable ICU 2.6 */
-    UBLOCK_YIJING_HEXAGRAM_SYMBOLS = 116, /*[4DC0]*/
-    /** @stable ICU 2.6 */
-    UBLOCK_LINEAR_B_SYLLABARY = 117, /*[10000]*/
-    /** @stable ICU 2.6 */
-    UBLOCK_LINEAR_B_IDEOGRAMS = 118, /*[10080]*/
-    /** @stable ICU 2.6 */
-    UBLOCK_AEGEAN_NUMBERS = 119, /*[10100]*/
-    /** @stable ICU 2.6 */
-    UBLOCK_UGARITIC = 120, /*[10380]*/
-    /** @stable ICU 2.6 */
-    UBLOCK_SHAVIAN = 121, /*[10450]*/
-    /** @stable ICU 2.6 */
-    UBLOCK_OSMANYA = 122, /*[10480]*/
-    /** @stable ICU 2.6 */
-    UBLOCK_CYPRIOT_SYLLABARY = 123, /*[10800]*/
-    /** @stable ICU 2.6 */
-    UBLOCK_TAI_XUAN_JING_SYMBOLS = 124, /*[1D300]*/
-    /** @stable ICU 2.6 */
-    UBLOCK_VARIATION_SELECTORS_SUPPLEMENT = 125, /*[E0100]*/
-
-    /* New blocks in Unicode 4.1 */
-
-    /** @stable ICU 3.4 */
-    UBLOCK_ANCIENT_GREEK_MUSICAL_NOTATION = 126, /*[1D200]*/
-    /** @stable ICU 3.4 */
-    UBLOCK_ANCIENT_GREEK_NUMBERS = 127, /*[10140]*/
-    /** @stable ICU 3.4 */
-    UBLOCK_ARABIC_SUPPLEMENT = 128, /*[0750]*/
-    /** @stable ICU 3.4 */
-    UBLOCK_BUGINESE = 129, /*[1A00]*/
-    /** @stable ICU 3.4 */
-    UBLOCK_CJK_STROKES = 130, /*[31C0]*/
-    /** @stable ICU 3.4 */
-    UBLOCK_COMBINING_DIACRITICAL_MARKS_SUPPLEMENT = 131, /*[1DC0]*/
-    /** @stable ICU 3.4 */
-    UBLOCK_COPTIC = 132, /*[2C80]*/
-    /** @stable ICU 3.4 */
-    UBLOCK_ETHIOPIC_EXTENDED = 133, /*[2D80]*/
-    /** @stable ICU 3.4 */
-    UBLOCK_ETHIOPIC_SUPPLEMENT = 134, /*[1380]*/
-    /** @stable ICU 3.4 */
-    UBLOCK_GEORGIAN_SUPPLEMENT = 135, /*[2D00]*/
-    /** @stable ICU 3.4 */
-    UBLOCK_GLAGOLITIC = 136, /*[2C00]*/
-    /** @stable ICU 3.4 */
-    UBLOCK_KHAROSHTHI = 137, /*[10A00]*/
-    /** @stable ICU 3.4 */
-    UBLOCK_MODIFIER_TONE_LETTERS = 138, /*[A700]*/
-    /** @stable ICU 3.4 */
-    UBLOCK_NEW_TAI_LUE = 139, /*[1980]*/
-    /** @stable ICU 3.4 */
-    UBLOCK_OLD_PERSIAN = 140, /*[103A0]*/
-    /** @stable ICU 3.4 */
-    UBLOCK_PHONETIC_EXTENSIONS_SUPPLEMENT = 141, /*[1D80]*/
-    /** @stable ICU 3.4 */
-    UBLOCK_SUPPLEMENTAL_PUNCTUATION = 142, /*[2E00]*/
-    /** @stable ICU 3.4 */
-    UBLOCK_SYLOTI_NAGRI = 143, /*[A800]*/
-    /** @stable ICU 3.4 */
-    UBLOCK_TIFINAGH = 144, /*[2D30]*/
-    /** @stable ICU 3.4 */
-    UBLOCK_VERTICAL_FORMS = 145, /*[FE10]*/
-
-    /* New blocks in Unicode 5.0 */
-
-    /** @stable ICU 3.6 */
-    UBLOCK_NKO = 146, /*[07C0]*/
-    /** @stable ICU 3.6 */
-    UBLOCK_BALINESE = 147, /*[1B00]*/
-    /** @stable ICU 3.6 */
-    UBLOCK_LATIN_EXTENDED_C = 148, /*[2C60]*/
-    /** @stable ICU 3.6 */
-    UBLOCK_LATIN_EXTENDED_D = 149, /*[A720]*/
-    /** @stable ICU 3.6 */
-    UBLOCK_PHAGS_PA = 150, /*[A840]*/
-    /** @stable ICU 3.6 */
-    UBLOCK_PHOENICIAN = 151, /*[10900]*/
-    /** @stable ICU 3.6 */
-    UBLOCK_CUNEIFORM = 152, /*[12000]*/
-    /** @stable ICU 3.6 */
-    UBLOCK_CUNEIFORM_NUMBERS_AND_PUNCTUATION = 153, /*[12400]*/
-    /** @stable ICU 3.6 */
-    UBLOCK_COUNTING_ROD_NUMERALS = 154, /*[1D360]*/
-
-    /* New blocks in Unicode 5.1 */
-
-    /** @draft ICU 4.0 */
-    UBLOCK_SUNDANESE = 155, /*[1B80]*/
-    /** @draft ICU 4.0 */
-    UBLOCK_LEPCHA = 156, /*[1C00]*/
-    /** @draft ICU 4.0 */
-    UBLOCK_OL_CHIKI = 157, /*[1C50]*/
-    /** @draft ICU 4.0 */
-    UBLOCK_CYRILLIC_EXTENDED_A = 158, /*[2DE0]*/
-    /** @draft ICU 4.0 */
-    UBLOCK_VAI = 159, /*[A500]*/
-    /** @draft ICU 4.0 */
-    UBLOCK_CYRILLIC_EXTENDED_B = 160, /*[A640]*/
-    /** @draft ICU 4.0 */
-    UBLOCK_SAURASHTRA = 161, /*[A880]*/
-    /** @draft ICU 4.0 */
-    UBLOCK_KAYAH_LI = 162, /*[A900]*/
-    /** @draft ICU 4.0 */
-    UBLOCK_REJANG = 163, /*[A930]*/
-    /** @draft ICU 4.0 */
-    UBLOCK_CHAM = 164, /*[AA00]*/
-    /** @draft ICU 4.0 */
-    UBLOCK_ANCIENT_SYMBOLS = 165, /*[10190]*/
-    /** @draft ICU 4.0 */
-    UBLOCK_PHAISTOS_DISC = 166, /*[101D0]*/
-    /** @draft ICU 4.0 */
-    UBLOCK_LYCIAN = 167, /*[10280]*/
-    /** @draft ICU 4.0 */
-    UBLOCK_CARIAN = 168, /*[102A0]*/
-    /** @draft ICU 4.0 */
-    UBLOCK_LYDIAN = 169, /*[10920]*/
-    /** @draft ICU 4.0 */
-    UBLOCK_MAHJONG_TILES = 170, /*[1F000]*/
-    /** @draft ICU 4.0 */
-    UBLOCK_DOMINO_TILES = 171, /*[1F030]*/
-
-    /** @stable ICU 2.0 */
-    UBLOCK_COUNT = 172,
-
-    /** @stable ICU 2.0 */
-    UBLOCK_INVALID_CODE=-1
-};
-
-/** @stable ICU 2.0 */
-typedef enum UBlockCode UBlockCode;
-
-/**
- * East Asian Width constants.
- *
- * @see UCHAR_EAST_ASIAN_WIDTH
- * @see u_getIntPropertyValue
- * @stable ICU 2.2
- */
-typedef enum UEastAsianWidth {
-    U_EA_NEUTRAL,   /*[N]*/ /*See note !!*/
-    U_EA_AMBIGUOUS, /*[A]*/
-    U_EA_HALFWIDTH, /*[H]*/
-    U_EA_FULLWIDTH, /*[F]*/
-    U_EA_NARROW,    /*[Na]*/
-    U_EA_WIDE,      /*[W]*/
-    U_EA_COUNT
-} UEastAsianWidth;
-/*
- * Implementation note:
- * Keep UEastAsianWidth constant values in sync with names list in genprops/props2.c.
- */
-
-/**
- * Selector constants for u_charName().
- * u_charName() returns the "modern" name of a
- * Unicode character; or the name that was defined in
- * Unicode version 1.0, before the Unicode standard merged
- * with ISO-10646; or an "extended" name that gives each
- * Unicode code point a unique name.
- *
- * @see u_charName
- * @stable ICU 2.0
- */
-typedef enum UCharNameChoice {
-    U_UNICODE_CHAR_NAME,
-    U_UNICODE_10_CHAR_NAME,
-    U_EXTENDED_CHAR_NAME,
-    U_CHAR_NAME_CHOICE_COUNT
-} UCharNameChoice;
-
-/**
- * Selector constants for u_getPropertyName() and
- * u_getPropertyValueName().  These selectors are used to choose which
- * name is returned for a given property or value.  All properties and
- * values have a long name.  Most have a short name, but some do not.
- * Unicode allows for additional names, beyond the long and short
- * name, which would be indicated by U_LONG_PROPERTY_NAME + i, where
- * i=1, 2,...
- *
- * @see u_getPropertyName()
- * @see u_getPropertyValueName()
- * @stable ICU 2.4
- */
-typedef enum UPropertyNameChoice {
-    U_SHORT_PROPERTY_NAME,
-    U_LONG_PROPERTY_NAME,
-    U_PROPERTY_NAME_CHOICE_COUNT
-} UPropertyNameChoice;
-
-/**
- * Decomposition Type constants.
- *
- * @see UCHAR_DECOMPOSITION_TYPE
- * @stable ICU 2.2
- */
-typedef enum UDecompositionType {
-    U_DT_NONE,              /*[none]*/ /*See note !!*/
-    U_DT_CANONICAL,         /*[can]*/
-    U_DT_COMPAT,            /*[com]*/
-    U_DT_CIRCLE,            /*[enc]*/
-    U_DT_FINAL,             /*[fin]*/
-    U_DT_FONT,              /*[font]*/
-    U_DT_FRACTION,          /*[fra]*/
-    U_DT_INITIAL,           /*[init]*/
-    U_DT_ISOLATED,          /*[iso]*/
-    U_DT_MEDIAL,            /*[med]*/
-    U_DT_NARROW,            /*[nar]*/
-    U_DT_NOBREAK,           /*[nb]*/
-    U_DT_SMALL,             /*[sml]*/
-    U_DT_SQUARE,            /*[sqr]*/
-    U_DT_SUB,               /*[sub]*/
-    U_DT_SUPER,             /*[sup]*/
-    U_DT_VERTICAL,          /*[vert]*/
-    U_DT_WIDE,              /*[wide]*/
-    U_DT_COUNT /* 18 */
-} UDecompositionType;
-
-/**
- * Joining Type constants.
- *
- * @see UCHAR_JOINING_TYPE
- * @stable ICU 2.2
- */
-typedef enum UJoiningType {
-    U_JT_NON_JOINING,       /*[U]*/ /*See note !!*/
-    U_JT_JOIN_CAUSING,      /*[C]*/
-    U_JT_DUAL_JOINING,      /*[D]*/
-    U_JT_LEFT_JOINING,      /*[L]*/
-    U_JT_RIGHT_JOINING,     /*[R]*/
-    U_JT_TRANSPARENT,       /*[T]*/
-    U_JT_COUNT /* 6 */
-} UJoiningType;
-
-/**
- * Joining Group constants.
- *
- * @see UCHAR_JOINING_GROUP
- * @stable ICU 2.2
- */
-typedef enum UJoiningGroup {
-    U_JG_NO_JOINING_GROUP,
-    U_JG_AIN,
-    U_JG_ALAPH,
-    U_JG_ALEF,
-    U_JG_BEH,
-    U_JG_BETH,
-    U_JG_DAL,
-    U_JG_DALATH_RISH,
-    U_JG_E,
-    U_JG_FEH,
-    U_JG_FINAL_SEMKATH,
-    U_JG_GAF,
-    U_JG_GAMAL,
-    U_JG_HAH,
-    U_JG_HAMZA_ON_HEH_GOAL,
-    U_JG_HE,
-    U_JG_HEH,
-    U_JG_HEH_GOAL,
-    U_JG_HETH,
-    U_JG_KAF,
-    U_JG_KAPH,
-    U_JG_KNOTTED_HEH,
-    U_JG_LAM,
-    U_JG_LAMADH,
-    U_JG_MEEM,
-    U_JG_MIM,
-    U_JG_NOON,
-    U_JG_NUN,
-    U_JG_PE,
-    U_JG_QAF,
-    U_JG_QAPH,
-    U_JG_REH,
-    U_JG_REVERSED_PE,
-    U_JG_SAD,
-    U_JG_SADHE,
-    U_JG_SEEN,
-    U_JG_SEMKATH,
-    U_JG_SHIN,
-    U_JG_SWASH_KAF,
-    U_JG_SYRIAC_WAW,
-    U_JG_TAH,
-    U_JG_TAW,
-    U_JG_TEH_MARBUTA,
-    U_JG_TETH,
-    U_JG_WAW,
-    U_JG_YEH,
-    U_JG_YEH_BARREE,
-    U_JG_YEH_WITH_TAIL,
-    U_JG_YUDH,
-    U_JG_YUDH_HE,
-    U_JG_ZAIN,
-    U_JG_FE,        /**< @stable ICU 2.6 */
-    U_JG_KHAPH,     /**< @stable ICU 2.6 */
-    U_JG_ZHAIN,     /**< @stable ICU 2.6 */
-    U_JG_BURUSHASKI_YEH_BARREE, /**< @draft ICU 4.0 */
-    U_JG_COUNT
-} UJoiningGroup;
-
-/**
- * Grapheme Cluster Break constants.
- *
- * @see UCHAR_GRAPHEME_CLUSTER_BREAK
- * @stable ICU 3.4
- */
-typedef enum UGraphemeClusterBreak {
-    U_GCB_OTHER = 0,            /*[XX]*/ /*See note !!*/
-    U_GCB_CONTROL = 1,          /*[CN]*/
-    U_GCB_CR = 2,               /*[CR]*/
-    U_GCB_EXTEND = 3,           /*[EX]*/
-    U_GCB_L = 4,                /*[L]*/
-    U_GCB_LF = 5,               /*[LF]*/
-    U_GCB_LV = 6,               /*[LV]*/
-    U_GCB_LVT = 7,              /*[LVT]*/
-    U_GCB_T = 8,                /*[T]*/
-    U_GCB_V = 9,                /*[V]*/
-    U_GCB_SPACING_MARK = 10,    /*[SM]*/ /* from here on: new in Unicode 5.1/ICU 4.0 */
-    U_GCB_PREPEND = 11,         /*[PP]*/
-    U_GCB_COUNT = 12
-} UGraphemeClusterBreak;
-
-/**
- * Word Break constants.
- * (UWordBreak is a pre-existing enum type in ubrk.h for word break status tags.)
- *
- * @see UCHAR_WORD_BREAK
- * @stable ICU 3.4
- */
-typedef enum UWordBreakValues {
-    U_WB_OTHER = 0,             /*[XX]*/ /*See note !!*/
-    U_WB_ALETTER = 1,           /*[LE]*/
-    U_WB_FORMAT = 2,            /*[FO]*/
-    U_WB_KATAKANA = 3,          /*[KA]*/
-    U_WB_MIDLETTER = 4,         /*[ML]*/
-    U_WB_MIDNUM = 5,            /*[MN]*/
-    U_WB_NUMERIC = 6,           /*[NU]*/
-    U_WB_EXTENDNUMLET = 7,      /*[EX]*/
-    U_WB_CR = 8,                /*[CR]*/ /* from here on: new in Unicode 5.1/ICU 4.0 */
-    U_WB_EXTEND = 9,            /*[Extend]*/
-    U_WB_LF = 10,               /*[LF]*/
-    U_WB_MIDNUMLET =11,         /*[MB]*/
-    U_WB_NEWLINE =12,           /*[NL]*/
-    U_WB_COUNT = 13
-} UWordBreakValues;
-
-/**
- * Sentence Break constants.
- *
- * @see UCHAR_SENTENCE_BREAK
- * @stable ICU 3.4
- */
-typedef enum USentenceBreak {
-    U_SB_OTHER = 0,             /*[XX]*/ /*See note !!*/
-    U_SB_ATERM = 1,             /*[AT]*/
-    U_SB_CLOSE = 2,             /*[CL]*/
-    U_SB_FORMAT = 3,            /*[FO]*/
-    U_SB_LOWER = 4,             /*[LO]*/
-    U_SB_NUMERIC = 5,           /*[NU]*/
-    U_SB_OLETTER = 6,           /*[LE]*/
-    U_SB_SEP = 7,               /*[SE]*/
-    U_SB_SP = 8,                /*[SP]*/
-    U_SB_STERM = 9,             /*[ST]*/
-    U_SB_UPPER = 10,            /*[UP]*/
-    U_SB_CR = 11,               /*[CR]*/ /* from here on: new in Unicode 5.1/ICU 4.0 */
-    U_SB_EXTEND = 12,           /*[EX]*/
-    U_SB_LF = 13,               /*[LF]*/
-    U_SB_SCONTINUE = 14,        /*[SC]*/
-    U_SB_COUNT = 15
-} USentenceBreak;
-
-/**
- * Line Break constants.
- *
- * @see UCHAR_LINE_BREAK
- * @stable ICU 2.2
- */
-typedef enum ULineBreak {
-    U_LB_UNKNOWN = 0,           /*[XX]*/ /*See note !!*/
-    U_LB_AMBIGUOUS = 1,         /*[AI]*/
-    U_LB_ALPHABETIC = 2,        /*[AL]*/
-    U_LB_BREAK_BOTH = 3,        /*[B2]*/
-    U_LB_BREAK_AFTER = 4,       /*[BA]*/
-    U_LB_BREAK_BEFORE = 5,      /*[BB]*/
-    U_LB_MANDATORY_BREAK = 6,   /*[BK]*/
-    U_LB_CONTINGENT_BREAK = 7,  /*[CB]*/
-    U_LB_CLOSE_PUNCTUATION = 8, /*[CL]*/
-    U_LB_COMBINING_MARK = 9,    /*[CM]*/
-    U_LB_CARRIAGE_RETURN = 10,   /*[CR]*/
-    U_LB_EXCLAMATION = 11,       /*[EX]*/
-    U_LB_GLUE = 12,              /*[GL]*/
-    U_LB_HYPHEN = 13,            /*[HY]*/
-    U_LB_IDEOGRAPHIC = 14,       /*[ID]*/
-    U_LB_INSEPERABLE = 15,
-    /** Renamed from the misspelled "inseperable" in Unicode 4.0.1/ICU 3.0 @stable ICU 3.0 */
-    U_LB_INSEPARABLE=U_LB_INSEPERABLE,/*[IN]*/
-    U_LB_INFIX_NUMERIC = 16,     /*[IS]*/
-    U_LB_LINE_FEED = 17,         /*[LF]*/
-    U_LB_NONSTARTER = 18,        /*[NS]*/
-    U_LB_NUMERIC = 19,           /*[NU]*/
-    U_LB_OPEN_PUNCTUATION = 20,  /*[OP]*/
-    U_LB_POSTFIX_NUMERIC = 21,   /*[PO]*/
-    U_LB_PREFIX_NUMERIC = 22,    /*[PR]*/
-    U_LB_QUOTATION = 23,         /*[QU]*/
-    U_LB_COMPLEX_CONTEXT = 24,   /*[SA]*/
-    U_LB_SURROGATE = 25,         /*[SG]*/
-    U_LB_SPACE = 26,             /*[SP]*/
-    U_LB_BREAK_SYMBOLS = 27,     /*[SY]*/
-    U_LB_ZWSPACE = 28,           /*[ZW]*/
-    U_LB_NEXT_LINE = 29,         /*[NL]*/ /* from here on: new in Unicode 4/ICU 2.6 */
-    U_LB_WORD_JOINER = 30,       /*[WJ]*/
-    U_LB_H2 = 31,                /*[H2]*/ /* from here on: new in Unicode 4.1/ICU 3.4 */
-    U_LB_H3 = 32,                /*[H3]*/
-    U_LB_JL = 33,                /*[JL]*/
-    U_LB_JT = 34,                /*[JT]*/
-    U_LB_JV = 35,                /*[JV]*/
-    U_LB_COUNT = 36
-} ULineBreak;
-
-/**
- * Numeric Type constants.
- *
- * @see UCHAR_NUMERIC_TYPE
- * @stable ICU 2.2
- */
-typedef enum UNumericType {
-    U_NT_NONE,              /*[None]*/ /*See note !!*/
-    U_NT_DECIMAL,           /*[de]*/
-    U_NT_DIGIT,             /*[di]*/
-    U_NT_NUMERIC,           /*[nu]*/
-    U_NT_COUNT
-} UNumericType;
-
-/**
- * Hangul Syllable Type constants.
- *
- * @see UCHAR_HANGUL_SYLLABLE_TYPE
- * @stable ICU 2.6
- */
-typedef enum UHangulSyllableType {
-    U_HST_NOT_APPLICABLE,   /*[NA]*/ /*See note !!*/
-    U_HST_LEADING_JAMO,     /*[L]*/
-    U_HST_VOWEL_JAMO,       /*[V]*/
-    U_HST_TRAILING_JAMO,    /*[T]*/
-    U_HST_LV_SYLLABLE,      /*[LV]*/
-    U_HST_LVT_SYLLABLE,     /*[LVT]*/
-    U_HST_COUNT
-} UHangulSyllableType;
-
-/**
- * Check a binary Unicode property for a code point.
- *
- * Unicode, especially in version 3.2, defines many more properties than the
- * original set in UnicodeData.txt.
- *
- * The properties APIs are intended to reflect Unicode properties as defined
- * in the Unicode Character Database (UCD) and Unicode Technical Reports (UTR).
- * For details about the properties see http://www.unicode.org/ucd/ .
- * For names of Unicode properties see the UCD file PropertyAliases.txt.
- *
- * Important: If ICU is built with UCD files from Unicode versions below 3.2,
- * then properties marked with "new in Unicode 3.2" are not or not fully available.
- *
- * @param c Code point to test.
- * @param which UProperty selector constant, identifies which binary property to check.
- *        Must be UCHAR_BINARY_START<=which<UCHAR_BINARY_LIMIT.
- * @return TRUE or FALSE according to the binary Unicode property value for c.
- *         Also FALSE if 'which' is out of bounds or if the Unicode version
- *         does not have data for the property at all, or not for this code point.
- *
- * @see UProperty
- * @see u_getIntPropertyValue
- * @see u_getUnicodeVersion
- * @stable ICU 2.1
- */
-U_STABLE UBool U_EXPORT2
-u_hasBinaryProperty(UChar32 c, UProperty which);
-
-/**
- * Check if a code point has the Alphabetic Unicode property.
- * Same as u_hasBinaryProperty(c, UCHAR_ALPHABETIC).
- * This is different from u_isalpha!
- * @param c Code point to test
- * @return true if the code point has the Alphabetic Unicode property, false otherwise
- *
- * @see UCHAR_ALPHABETIC
- * @see u_isalpha
- * @see u_hasBinaryProperty
- * @stable ICU 2.1
- */
-U_STABLE UBool U_EXPORT2
-u_isUAlphabetic(UChar32 c);
-
-/**
- * Check if a code point has the Lowercase Unicode property.
- * Same as u_hasBinaryProperty(c, UCHAR_LOWERCASE).
- * This is different from u_islower!
- * @param c Code point to test
- * @return true if the code point has the Lowercase Unicode property, false otherwise
- *
- * @see UCHAR_LOWERCASE
- * @see u_islower
- * @see u_hasBinaryProperty
- * @stable ICU 2.1
- */
-U_STABLE UBool U_EXPORT2
-u_isULowercase(UChar32 c);
-
-/**
- * Check if a code point has the Uppercase Unicode property.
- * Same as u_hasBinaryProperty(c, UCHAR_UPPERCASE).
- * This is different from u_isupper!
- * @param c Code point to test
- * @return true if the code point has the Uppercase Unicode property, false otherwise
- *
- * @see UCHAR_UPPERCASE
- * @see u_isupper
- * @see u_hasBinaryProperty
- * @stable ICU 2.1
- */
-U_STABLE UBool U_EXPORT2
-u_isUUppercase(UChar32 c);
-
-/**
- * Check if a code point has the White_Space Unicode property.
- * Same as u_hasBinaryProperty(c, UCHAR_WHITE_SPACE).
- * This is different from both u_isspace and u_isWhitespace!
- *
- * Note: There are several ICU whitespace functions; please see the uchar.h
- * file documentation for a detailed comparison.
- *
- * @param c Code point to test
- * @return true if the code point has the White_Space Unicode property, false otherwise.
- *
- * @see UCHAR_WHITE_SPACE
- * @see u_isWhitespace
- * @see u_isspace
- * @see u_isJavaSpaceChar
- * @see u_hasBinaryProperty
- * @stable ICU 2.1
- */
-U_STABLE UBool U_EXPORT2
-u_isUWhiteSpace(UChar32 c);
-
-/**
- * Get the property value for an enumerated or integer Unicode property for a code point.
- * Also returns binary and mask property values.
- *
- * Unicode, especially in version 3.2, defines many more properties than the
- * original set in UnicodeData.txt.
- *
- * The properties APIs are intended to reflect Unicode properties as defined
- * in the Unicode Character Database (UCD) and Unicode Technical Reports (UTR).
- * For details about the properties see http://www.unicode.org/ .
- * For names of Unicode properties see the UCD file PropertyAliases.txt.
- *
- * Sample usage:
- * UEastAsianWidth ea=(UEastAsianWidth)u_getIntPropertyValue(c, UCHAR_EAST_ASIAN_WIDTH);
- * UBool b=(UBool)u_getIntPropertyValue(c, UCHAR_IDEOGRAPHIC);
- *
- * @param c Code point to test.
- * @param which UProperty selector constant, identifies which property to check.
- *        Must be UCHAR_BINARY_START<=which<UCHAR_BINARY_LIMIT
- *        or UCHAR_INT_START<=which<UCHAR_INT_LIMIT
- *        or UCHAR_MASK_START<=which<UCHAR_MASK_LIMIT.
- * @return Numeric value that is directly the property value or,
- *         for enumerated properties, corresponds to the numeric value of the enumerated
- *         constant of the respective property value enumeration type
- *         (cast to enum type if necessary).
- *         Returns 0 or 1 (for FALSE/TRUE) for binary Unicode properties.
- *         Returns a bit-mask for mask properties.
- *         Returns 0 if 'which' is out of bounds or if the Unicode version
- *         does not have data for the property at all, or not for this code point.
- *
- * @see UProperty
- * @see u_hasBinaryProperty
- * @see u_getIntPropertyMinValue
- * @see u_getIntPropertyMaxValue
- * @see u_getUnicodeVersion
- * @stable ICU 2.2
- */
-U_STABLE int32_t U_EXPORT2
-u_getIntPropertyValue(UChar32 c, UProperty which);
-
-/**
- * Get the minimum value for an enumerated/integer/binary Unicode property.
- * Can be used together with u_getIntPropertyMaxValue
- * to allocate arrays of UnicodeSet or similar.
- *
- * @param which UProperty selector constant, identifies which binary property to check.
- *        Must be UCHAR_BINARY_START<=which<UCHAR_BINARY_LIMIT
- *        or UCHAR_INT_START<=which<UCHAR_INT_LIMIT.
- * @return Minimum value returned by u_getIntPropertyValue for a Unicode property.
- *         0 if the property selector is out of range.
- *
- * @see UProperty
- * @see u_hasBinaryProperty
- * @see u_getUnicodeVersion
- * @see u_getIntPropertyMaxValue
- * @see u_getIntPropertyValue
- * @stable ICU 2.2
- */
-U_STABLE int32_t U_EXPORT2
-u_getIntPropertyMinValue(UProperty which);
-
-/**
- * Get the maximum value for an enumerated/integer/binary Unicode property.
- * Can be used together with u_getIntPropertyMinValue
- * to allocate arrays of UnicodeSet or similar.
- *
- * Examples for min/max values (for Unicode 3.2):
- *
- * - UCHAR_BIDI_CLASS:    0/18 (U_LEFT_TO_RIGHT/U_BOUNDARY_NEUTRAL)
- * - UCHAR_SCRIPT:        0/45 (USCRIPT_COMMON/USCRIPT_TAGBANWA)
- * - UCHAR_IDEOGRAPHIC:   0/1  (FALSE/TRUE)
- *
- * For undefined UProperty constant values, min/max values will be 0/-1.
- *
- * @param which UProperty selector constant, identifies which binary property to check.
- *        Must be UCHAR_BINARY_START<=which<UCHAR_BINARY_LIMIT
- *        or UCHAR_INT_START<=which<UCHAR_INT_LIMIT.
- * @return Maximum value returned by u_getIntPropertyValue for a Unicode property.
- *         <=0 if the property selector is out of range.
- *
- * @see UProperty
- * @see u_hasBinaryProperty
- * @see u_getUnicodeVersion
- * @see u_getIntPropertyMaxValue
- * @see u_getIntPropertyValue
- * @stable ICU 2.2
- */
-U_STABLE int32_t U_EXPORT2
-u_getIntPropertyMaxValue(UProperty which);
-
-/**
- * Get the numeric value for a Unicode code point as defined in the
- * Unicode Character Database.
- *
- * A "double" return type is necessary because
- * some numeric values are fractions, negative, or too large for int32_t.
- *
- * For characters without any numeric values in the Unicode Character Database,
- * this function will return U_NO_NUMERIC_VALUE.
- *
- * Similar to java.lang.Character.getNumericValue(), but u_getNumericValue()
- * also supports negative values, large values, and fractions,
- * while Java's getNumericValue() returns values 10..35 for ASCII letters.
- *
- * @param c Code point to get the numeric value for.
- * @return Numeric value of c, or U_NO_NUMERIC_VALUE if none is defined.
- *
- * @see U_NO_NUMERIC_VALUE
- * @stable ICU 2.2
- */
-U_STABLE double U_EXPORT2
-u_getNumericValue(UChar32 c);
-
-/**
- * Special value that is returned by u_getNumericValue when
- * no numeric value is defined for a code point.
- *
- * @see u_getNumericValue
- * @stable ICU 2.2
- */
-#define U_NO_NUMERIC_VALUE ((double)-123456789.)
-
-/**
- * Determines whether the specified code point has the general category "Ll"
- * (lowercase letter).
- *
- * Same as java.lang.Character.isLowerCase().
- *
- * This misses some characters that are also lowercase but
- * have a different general category value.
- * In order to include those, use UCHAR_LOWERCASE.
- *
- * In addition to being equivalent to a Java function, this also serves
- * as a C/POSIX migration function.
- * See the comments about C/POSIX character classification functions in the
- * documentation at the top of this header file.
- *
- * @param c the code point to be tested
- * @return TRUE if the code point is an Ll lowercase letter
- *
- * @see UCHAR_LOWERCASE
- * @see u_isupper
- * @see u_istitle
- * @stable ICU 2.0
- */
-U_STABLE UBool U_EXPORT2
-u_islower(UChar32 c);
-
-/**
- * Determines whether the specified code point has the general category "Lu"
- * (uppercase letter).
- *
- * Same as java.lang.Character.isUpperCase().
- *
- * This misses some characters that are also uppercase but
- * have a different general category value.
- * In order to include those, use UCHAR_UPPERCASE.
- *
- * In addition to being equivalent to a Java function, this also serves
- * as a C/POSIX migration function.
- * See the comments about C/POSIX character classification functions in the
- * documentation at the top of this header file.
- *
- * @param c the code point to be tested
- * @return TRUE if the code point is an Lu uppercase letter
- *
- * @see UCHAR_UPPERCASE
- * @see u_islower
- * @see u_istitle
- * @see u_tolower
- * @stable ICU 2.0
- */
-U_STABLE UBool U_EXPORT2
-u_isupper(UChar32 c);
-
-/**
- * Determines whether the specified code point is a titlecase letter.
- * True for general category "Lt" (titlecase letter).
- *
- * Same as java.lang.Character.isTitleCase().
- *
- * @param c the code point to be tested
- * @return TRUE if the code point is an Lt titlecase letter
- *
- * @see u_isupper
- * @see u_islower
- * @see u_totitle
- * @stable ICU 2.0
- */
-U_STABLE UBool U_EXPORT2
-u_istitle(UChar32 c);
-
-/**
- * Determines whether the specified code point is a digit character according to Java.
- * True for characters with general category "Nd" (decimal digit numbers).
- * Beginning with Unicode 4, this is the same as
- * testing for the Numeric_Type of Decimal.
- *
- * Same as java.lang.Character.isDigit().
- *
- * In addition to being equivalent to a Java function, this also serves
- * as a C/POSIX migration function.
- * See the comments about C/POSIX character classification functions in the
- * documentation at the top of this header file.
- *
- * @param c the code point to be tested
- * @return TRUE if the code point is a digit character according to Character.isDigit()
- *
- * @stable ICU 2.0
- */
-U_STABLE UBool U_EXPORT2
-u_isdigit(UChar32 c);
-
-/**
- * Determines whether the specified code point is a letter character.
- * True for general categories "L" (letters).
- *
- * Same as java.lang.Character.isLetter().
- *
- * In addition to being equivalent to a Java function, this also serves
- * as a C/POSIX migration function.
- * See the comments about C/POSIX character classification functions in the
- * documentation at the top of this header file.
- *
- * @param c the code point to be tested
- * @return TRUE if the code point is a letter character
- *
- * @see u_isdigit
- * @see u_isalnum
- * @stable ICU 2.0
- */
-U_STABLE UBool U_EXPORT2
-u_isalpha(UChar32 c);
-
-/**
- * Determines whether the specified code point is an alphanumeric character
- * (letter or digit) according to Java.
- * True for characters with general categories
- * "L" (letters) and "Nd" (decimal digit numbers).
- *
- * Same as java.lang.Character.isLetterOrDigit().
- *
- * In addition to being equivalent to a Java function, this also serves
- * as a C/POSIX migration function.
- * See the comments about C/POSIX character classification functions in the
- * documentation at the top of this header file.
- *
- * @param c the code point to be tested
- * @return TRUE if the code point is an alphanumeric character according to Character.isLetterOrDigit()
- *
- * @stable ICU 2.0
- */
-U_STABLE UBool U_EXPORT2
-u_isalnum(UChar32 c);
-
-/**
- * Determines whether the specified code point is a hexadecimal digit.
- * This is equivalent to u_digit(c, 16)>=0.
- * True for characters with general category "Nd" (decimal digit numbers)
- * as well as Latin letters a-f and A-F in both ASCII and Fullwidth ASCII.
- * (That is, for letters with code points
- * 0041..0046, 0061..0066, FF21..FF26, FF41..FF46.)
- *
- * In order to narrow the definition of hexadecimal digits to only ASCII
- * characters, use (c<=0x7f && u_isxdigit(c)).
- *
- * This is a C/POSIX migration function.
- * See the comments about C/POSIX character classification functions in the
- * documentation at the top of this header file.
- *
- * @param c the code point to be tested
- * @return TRUE if the code point is a hexadecimal digit
- *
- * @stable ICU 2.6
- */
-U_STABLE UBool U_EXPORT2
-u_isxdigit(UChar32 c);
-
-/**
- * Determines whether the specified code point is a punctuation character.
- * True for characters with general categories "P" (punctuation).
- *
- * This is a C/POSIX migration function.
- * See the comments about C/POSIX character classification functions in the
- * documentation at the top of this header file.
- *
- * @param c the code point to be tested
- * @return TRUE if the code point is a punctuation character
- *
- * @stable ICU 2.6
- */
-U_STABLE UBool U_EXPORT2
-u_ispunct(UChar32 c);
-
-/**
- * Determines whether the specified code point is a "graphic" character
- * (printable, excluding spaces).
- * TRUE for all characters except those with general categories
- * "Cc" (control codes), "Cf" (format controls), "Cs" (surrogates),
- * "Cn" (unassigned), and "Z" (separators).
- *
- * This is a C/POSIX migration function.
- * See the comments about C/POSIX character classification functions in the
- * documentation at the top of this header file.
- *
- * @param c the code point to be tested
- * @return TRUE if the code point is a "graphic" character
- *
- * @stable ICU 2.6
- */
-U_STABLE UBool U_EXPORT2
-u_isgraph(UChar32 c);
-
-/**
- * Determines whether the specified code point is a "blank" or "horizontal space",
- * a character that visibly separates words on a line.
- * The following are equivalent definitions:
- *
- * TRUE for Unicode White_Space characters except for "vertical space controls"
- * where "vertical space controls" are the following characters:
- * U+000A (LF) U+000B (VT) U+000C (FF) U+000D (CR) U+0085 (NEL) U+2028 (LS) U+2029 (PS)
- *
- * same as
- *
- * TRUE for U+0009 (TAB) and characters with general category "Zs" (space separators)
- * except Zero Width Space (ZWSP, U+200B).
- *
- * Note: There are several ICU whitespace functions; please see the uchar.h
- * file documentation for a detailed comparison.
- *
- * This is a C/POSIX migration function.
- * See the comments about C/POSIX character classification functions in the
- * documentation at the top of this header file.
- *
- * @param c the code point to be tested
- * @return TRUE if the code point is a "blank"
- *
- * @stable ICU 2.6
- */
-U_STABLE UBool U_EXPORT2
-u_isblank(UChar32 c);
-
-/**
- * Determines whether the specified code point is "defined",
- * which usually means that it is assigned a character.
- * True for general categories other than "Cn" (other, not assigned),
- * i.e., true for all code points mentioned in UnicodeData.txt.
- *
- * Note that non-character code points (e.g., U+FDD0) are not "defined"
- * (they are Cn), but surrogate code points are "defined" (Cs).
- *
- * Same as java.lang.Character.isDefined().
- *
- * @param c the code point to be tested
- * @return TRUE if the code point is assigned a character
- *
- * @see u_isdigit
- * @see u_isalpha
- * @see u_isalnum
- * @see u_isupper
- * @see u_islower
- * @see u_istitle
- * @stable ICU 2.0
- */
-U_STABLE UBool U_EXPORT2
-u_isdefined(UChar32 c);
-
-/**
- * Determines if the specified character is a space character or not.
- *
- * Note: There are several ICU whitespace functions; please see the uchar.h
- * file documentation for a detailed comparison.
- *
- * This is a C/POSIX migration function.
- * See the comments about C/POSIX character classification functions in the
- * documentation at the top of this header file.
- *
- * @param c    the character to be tested
- * @return  true if the character is a space character; false otherwise.
- *
- * @see u_isJavaSpaceChar
- * @see u_isWhitespace
- * @see u_isUWhiteSpace
- * @stable ICU 2.0
- */
-U_STABLE UBool U_EXPORT2
-u_isspace(UChar32 c);
-
-/**
- * Determine if the specified code point is a space character according to Java.
- * True for characters with general categories "Z" (separators),
- * which does not include control codes (e.g., TAB or Line Feed).
- *
- * Same as java.lang.Character.isSpaceChar().
- *
- * Note: There are several ICU whitespace functions; please see the uchar.h
- * file documentation for a detailed comparison.
- *
- * @param c the code point to be tested
- * @return TRUE if the code point is a space character according to Character.isSpaceChar()
- *
- * @see u_isspace
- * @see u_isWhitespace
- * @see u_isUWhiteSpace
- * @stable ICU 2.6
- */
-U_STABLE UBool U_EXPORT2
-u_isJavaSpaceChar(UChar32 c);
-
-/**
- * Determines if the specified code point is a whitespace character according to Java/ICU.
- * A character is considered to be a Java whitespace character if and only
- * if it satisfies one of the following criteria:
- *
- * - It is a Unicode separator (categories "Z"), but is not
- *      a no-break space (U+00A0 NBSP or U+2007 Figure Space or U+202F Narrow NBSP).
- * - It is U+0009 HORIZONTAL TABULATION.
- * - It is U+000A LINE FEED.
- * - It is U+000B VERTICAL TABULATION.
- * - It is U+000C FORM FEED.
- * - It is U+000D CARRIAGE RETURN.
- * - It is U+001C FILE SEPARATOR.
- * - It is U+001D GROUP SEPARATOR.
- * - It is U+001E RECORD SEPARATOR.
- * - It is U+001F UNIT SEPARATOR.
- * - It is U+0085 NEXT LINE.
- *
- * Same as java.lang.Character.isWhitespace() except that Java omits U+0085.
- *
- * Note: There are several ICU whitespace functions; please see the uchar.h
- * file documentation for a detailed comparison.
- *
- * @param c the code point to be tested
- * @return TRUE if the code point is a whitespace character according to Java/ICU
- *
- * @see u_isspace
- * @see u_isJavaSpaceChar
- * @see u_isUWhiteSpace
- * @stable ICU 2.0
- */
-U_STABLE UBool U_EXPORT2
-u_isWhitespace(UChar32 c);
-
-/**
- * Determines whether the specified code point is a control character
- * (as defined by this function).
- * A control character is one of the following:
- * - ISO 8-bit control character (U+0000..U+001f and U+007f..U+009f)
- * - U_CONTROL_CHAR (Cc)
- * - U_FORMAT_CHAR (Cf)
- * - U_LINE_SEPARATOR (Zl)
- * - U_PARAGRAPH_SEPARATOR (Zp)
- *
- * This is a C/POSIX migration function.
- * See the comments about C/POSIX character classification functions in the
- * documentation at the top of this header file.
- *
- * @param c the code point to be tested
- * @return TRUE if the code point is a control character
- *
- * @see UCHAR_DEFAULT_IGNORABLE_CODE_POINT
- * @see u_isprint
- * @stable ICU 2.0
- */
-U_STABLE UBool U_EXPORT2
-u_iscntrl(UChar32 c);
-
-/**
- * Determines whether the specified code point is an ISO control code.
- * True for U+0000..U+001f and U+007f..U+009f (general category "Cc").
- *
- * Same as java.lang.Character.isISOControl().
- *
- * @param c the code point to be tested
- * @return TRUE if the code point is an ISO control code
- *
- * @see u_iscntrl
- * @stable ICU 2.6
- */
-U_STABLE UBool U_EXPORT2
-u_isISOControl(UChar32 c);
-
-/**
- * Determines whether the specified code point is a printable character.
- * True for general categories <em>other</em> than "C" (controls).
- *
- * This is a C/POSIX migration function.
- * See the comments about C/POSIX character classification functions in the
- * documentation at the top of this header file.
- *
- * @param c the code point to be tested
- * @return TRUE if the code point is a printable character
- *
- * @see UCHAR_DEFAULT_IGNORABLE_CODE_POINT
- * @see u_iscntrl
- * @stable ICU 2.0
- */
-U_STABLE UBool U_EXPORT2
-u_isprint(UChar32 c);
-
-/**
- * Determines whether the specified code point is a base character.
- * True for general categories "L" (letters), "N" (numbers),
- * "Mc" (spacing combining marks), and "Me" (enclosing marks).
- *
- * Note that this is different from the Unicode definition in
- * chapter 3.5, conformance clause D13,
- * which defines base characters to be all characters (not Cn)
- * that do not graphically combine with preceding characters (M)
- * and that are neither control (Cc) or format (Cf) characters.
- *
- * @param c the code point to be tested
- * @return TRUE if the code point is a base character according to this function
- *
- * @see u_isalpha
- * @see u_isdigit
- * @stable ICU 2.0
- */
-U_STABLE UBool U_EXPORT2
-u_isbase(UChar32 c);
-
-/**
- * Returns the bidirectional category value for the code point,
- * which is used in the Unicode bidirectional algorithm
- * (UAX #9 http://www.unicode.org/reports/tr9/).
- * Note that some <em>unassigned</em> code points have bidi values
- * of R or AL because they are in blocks that are reserved
- * for Right-To-Left scripts.
- *
- * Same as java.lang.Character.getDirectionality()
- *
- * @param c the code point to be tested
- * @return the bidirectional category (UCharDirection) value
- *
- * @see UCharDirection
- * @stable ICU 2.0
- */
-U_STABLE UCharDirection U_EXPORT2
-u_charDirection(UChar32 c);
-
-/**
- * Determines whether the code point has the Bidi_Mirrored property.
- * This property is set for characters that are commonly used in
- * Right-To-Left contexts and need to be displayed with a "mirrored"
- * glyph.
- *
- * Same as java.lang.Character.isMirrored().
- * Same as UCHAR_BIDI_MIRRORED
- *
- * @param c the code point to be tested
- * @return TRUE if the character has the Bidi_Mirrored property
- *
- * @see UCHAR_BIDI_MIRRORED
- * @stable ICU 2.0
- */
-U_STABLE UBool U_EXPORT2
-u_isMirrored(UChar32 c);
-
-/**
- * Maps the specified character to a "mirror-image" character.
- * For characters with the Bidi_Mirrored property, implementations
- * sometimes need a "poor man's" mapping to another Unicode
- * character (code point) such that the default glyph may serve
- * as the mirror-image of the default glyph of the specified
- * character. This is useful for text conversion to and from
- * codepages with visual order, and for displays without glyph
- * selecetion capabilities.
- *
- * @param c the code point to be mapped
- * @return another Unicode code point that may serve as a mirror-image
- *         substitute, or c itself if there is no such mapping or c
- *         does not have the Bidi_Mirrored property
- *
- * @see UCHAR_BIDI_MIRRORED
- * @see u_isMirrored
- * @stable ICU 2.0
- */
-U_STABLE UChar32 U_EXPORT2
-u_charMirror(UChar32 c);
-
-/**
- * Returns the general category value for the code point.
- *
- * Same as java.lang.Character.getType().
- *
- * @param c the code point to be tested
- * @return the general category (UCharCategory) value
- *
- * @see UCharCategory
- * @stable ICU 2.0
- */
-U_STABLE int8_t U_EXPORT2
-u_charType(UChar32 c);
-
-/**
- * Get a single-bit bit set for the general category of a character.
- * This bit set can be compared bitwise with U_GC_SM_MASK, U_GC_L_MASK, etc.
- * Same as U_MASK(u_charType(c)).
- *
- * @param c the code point to be tested
- * @return a single-bit mask corresponding to the general category (UCharCategory) value
- *
- * @see u_charType
- * @see UCharCategory
- * @see U_GC_CN_MASK
- * @stable ICU 2.1
- */
-#define U_GET_GC_MASK(c) U_MASK(u_charType(c))
-
-/**
- * Callback from u_enumCharTypes(), is called for each contiguous range
- * of code points c (where start<=c<limit)
- * with the same Unicode general category ("character type").
- *
- * The callback function can stop the enumeration by returning FALSE.
- *
- * @param context an opaque pointer, as passed into utrie_enum()
- * @param start the first code point in a contiguous range with value
- * @param limit one past the last code point in a contiguous range with value
- * @param type the general category for all code points in [start..limit[
- * @return FALSE to stop the enumeration
- *
- * @stable ICU 2.1
- * @see UCharCategory
- * @see u_enumCharTypes
- */
-typedef UBool U_CALLCONV
-UCharEnumTypeRange(const void *context, UChar32 start, UChar32 limit, UCharCategory type);
-
-/**
- * Enumerate efficiently all code points with their Unicode general categories.
- *
- * This is useful for building data structures (e.g., UnicodeSet's),
- * for enumerating all assigned code points (type!=U_UNASSIGNED), etc.
- *
- * For each contiguous range of code points with a given general category ("character type"),
- * the UCharEnumTypeRange function is called.
- * Adjacent ranges have different types.
- * The Unicode Standard guarantees that the numeric value of the type is 0..31.
- *
- * @param enumRange a pointer to a function that is called for each contiguous range
- *                  of code points with the same general category
- * @param context an opaque pointer that is passed on to the callback function
- *
- * @stable ICU 2.1
- * @see UCharCategory
- * @see UCharEnumTypeRange
- */
-U_STABLE void U_EXPORT2
-u_enumCharTypes(UCharEnumTypeRange *enumRange, const void *context);
-
-#if !UCONFIG_NO_NORMALIZATION
-
-/**
- * Returns the combining class of the code point as specified in UnicodeData.txt.
- *
- * @param c the code point of the character
- * @return the combining class of the character
- * @stable ICU 2.0
- */
-U_STABLE uint8_t U_EXPORT2
-u_getCombiningClass(UChar32 c);
-
-#endif
-
-/**
- * Returns the decimal digit value of a decimal digit character.
- * Such characters have the general category "Nd" (decimal digit numbers)
- * and a Numeric_Type of Decimal.
- *
- * Unlike ICU releases before 2.6, no digit values are returned for any
- * Han characters because Han number characters are often used with a special
- * Chinese-style number format (with characters for powers of 10 in between)
- * instead of in decimal-positional notation.
- * Unicode 4 explicitly assigns Han number characters the Numeric_Type
- * Numeric instead of Decimal.
- * See Jitterbug 1483 for more details.
- *
- * Use u_getIntPropertyValue(c, UCHAR_NUMERIC_TYPE) and u_getNumericValue()
- * for complete numeric Unicode properties.
- *
- * @param c the code point for which to get the decimal digit value
- * @return the decimal digit value of c,
- *         or -1 if c is not a decimal digit character
- *
- * @see u_getNumericValue
- * @stable ICU 2.0
- */
-U_STABLE int32_t U_EXPORT2
-u_charDigitValue(UChar32 c);
-
-/**
- * Returns the Unicode allocation block that contains the character.
- *
- * @param c the code point to be tested
- * @return the block value (UBlockCode) for c
- *
- * @see UBlockCode
- * @stable ICU 2.0
- */
-U_STABLE UBlockCode U_EXPORT2
-ublock_getCode(UChar32 c);
-
-/**
- * Retrieve the name of a Unicode character.
- * Depending on <code>nameChoice</code>, the character name written
- * into the buffer is the "modern" name or the name that was defined
- * in Unicode version 1.0.
- * The name contains only "invariant" characters
- * like A-Z, 0-9, space, and '-'.
- * Unicode 1.0 names are only retrieved if they are different from the modern
- * names and if the data file contains the data for them. gennames may or may
- * not be called with a command line option to include 1.0 names in unames.dat.
- *
- * @param code The character (code point) for which to get the name.
- *             It must be <code>0<=code<=0x10ffff</code>.
- * @param nameChoice Selector for which name to get.
- * @param buffer Destination address for copying the name.
- *               The name will always be zero-terminated.
- *            

<TRUNCATED>

[33/57] [abbrv] remove couch_collate

Posted by be...@apache.org.
http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/msgfmt.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/msgfmt.h b/apps/couch_collate/platform/osx/icu/unicode/msgfmt.h
deleted file mode 100644
index 67e17cf..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/msgfmt.h
+++ /dev/null
@@ -1,940 +0,0 @@
-/*
-* Copyright (C) 2007-2008, International Business Machines Corporation and others. All Rights Reserved.
-********************************************************************************
-*
-* File MSGFMT.H
-*
-* Modification History:
-*
-*   Date        Name        Description
-*   02/19/97    aliu        Converted from java.
-*   03/20/97    helena      Finished first cut of implementation.
-*   07/22/98    stephen     Removed operator!= (defined in Format)
-*   08/19/2002  srl         Removing Javaisms
-********************************************************************************
-*/
-
-#ifndef MSGFMT_H
-#define MSGFMT_H
-
-#include "unicode/utypes.h"
-
-/**
- * \file 
- * \brief C++ API: Formats messages in a language-neutral way.
- */
- 
-#if !UCONFIG_NO_FORMATTING
-
-#include "unicode/format.h"
-#include "unicode/locid.h"
-#include "unicode/parseerr.h"
-#include "unicode/uchar.h"
-
-U_NAMESPACE_BEGIN
-
-class NumberFormat;
-class DateFormat;
-
-/**
- *
- * A MessageFormat produces concatenated messages in a
- * language-neutral way.  It should be used for all string
- * concatenations that are visible to end users.
- * <P>
- * A MessageFormat contains an array of <EM>subformats</EM> arranged
- * within a <EM>template string</EM>.  Together, the subformats and
- * template string determine how the MessageFormat will operate during
- * formatting and parsing.
- * <P>
- * Typically, both the subformats and the template string are
- * specified at once in a <EM>pattern</EM>.  By using different
- * patterns for different locales, messages may be localized.
- * <P>
- * During formatting, the MessageFormat takes an array of arguments
- * and produces a user-readable string.  Each argument is a
- * Formattable object; they may be passed in in an array, or as a
- * single Formattable object which itself contains an array.  Each
- * argument is matched up with its corresponding subformat, which then
- * formats it into a string.  The resultant strings are then assembled
- * within the string template of the MessageFormat to produce the
- * final output string.
- * <p>
- * <strong>Note:</strong>
- * In ICU 4.0 MessageFormat supports named arguments.  If a named argument
- * is used, all arguments must be named.  Names start with a character in 
- * <code>UCHAR_ID_START</code> and continue with characters in 
- * <code>UCHARID_CONTINUE</code>, in particular they do not start with a digit.
- * If named arguments are used, {@link #usesNamedArguments()} will return true.
- * <p>
- * The other new methods supporting named arguments are 
- * {@link #getFormatNames(UErrorCode& status)},
- * {@link #getFormat(const UnicodeString& formatName, UErrorCode& status)}
- * {@link #setFormat(const UnicodeString& formatName, const Format& format, UErrorCode& status)},
- * {@link #adoptFormat(const UnicodeString& formatName, Format* formatToAdopt, UErrorCode& status)},
- * {@link #format(const Formattable* arguments, const UnicodeString *argumentNames, int32_t cnt, UnicodeString& appendTo, FieldPosition& status, int32_t recursionProtection, UErrorCode& success)},
- * {@link #format(const UnicodeString* argumentNames, const Formattable* arguments, int32_t count, UnicodeString& appendTo,UErrorCode& status)}.
- * These methods are all compatible with patterns that do not used named arguments-- 
- * in these cases the keys in the input or output use <code>UnicodeString</code>s 
- * that name the argument indices, e.g. "0", "1", "2"... etc.
- * <p>
- * When named arguments are used, certain methods on MessageFormat that take or
- * return arrays do not perform any action, since it is not possible to
- * identify positions in an array using a name.  UErrorCode is set to
- * U_ARGUMENT_TYPE_MISMATCH if there is a status/success field in the method.
- * These methods are 
- * {@link #adoptFormats(Format** newFormats, int32_t count)},
- * {@link #setFormats(const Format** newFormats,int32_t count)},
- * {@link #adoptFormat(int32_t n, Format *newFormat)},
- * {@link #getFormats(int32_t& cnt)},
- * {@link #format(const Formattable* source,int32_t cnt,UnicodeString& appendTo, FieldPosition& ignore, UErrorCode& success)},
- * {@link #format(const UnicodeString& pattern,const Formattable* arguments,int32_t cnt,UnicodeString& appendTo,UErrorCode& success)},
- * {@link #format(const Formattable& source, UnicodeString& appendTo,FieldPosition& ignore, UErrorCode& success)},
- * {@link #format(const Formattable* arguments, int32_t cnt, UnicodeString& appendTo, FieldPosition& status, int32_t recursionProtection,UErrorCode& success)},
- * {@link #parse(const UnicodeString& source, ParsePosition& pos,int32_t& count)},
- * {@link #parse(const UnicodeString& source, int32_t& cnt, UErrorCode& status)}
- * <p>
- *
- * <P>
- * During parsing, an input string is matched against the string
- * template of the MessageFormat to produce an array of Formattable
- * objects.  Plain text of the template string is matched directly
- * against intput text.  At each position in the template string where
- * a subformat is located, the subformat is called to parse the
- * corresponding segment of input text to produce an output argument.
- * In this way, an array of arguments is created which together
- * constitute the parse result.
- * <P>
- * Parsing may fail or produce unexpected results in a number of
- * circumstances.
- * <UL>
- * <LI>If one of the arguments does not occur in the pattern, it
- * will be returned as a default Formattable.
- * <LI>If the format of an argument is loses information, such as with
- * a choice format where a large number formats to "many", then the
- * parse may not correspond to the originally formatted argument.
- * <LI>MessageFormat does not handle ChoiceFormat recursion during
- * parsing; such parses will fail.
- * <LI>Parsing will not always find a match (or the correct match) if
- * some part of the parse is ambiguous.  For example, if the pattern
- * "{1},{2}" is used with the string arguments {"a,b", "c"}, it will
- * format as "a,b,c".  When the result is parsed, it will return {"a",
- * "b,c"}.
- * <LI>If a single argument is formatted more than once in the string,
- * then the rightmost subformat in the pattern string will produce the
- * parse result; prior subformats with the same argument index will
- * have no effect.
- * </UL>
- * Here are some examples of usage:
- * <P>
- * Example 1:
- * <pre>
- * \code
- *     UErrorCode success = U_ZERO_ERROR;
- *     GregorianCalendar cal(success);
- *     Formattable arguments[] = {
- *         7L,
- *         Formattable( (Date) cal.getTime(success), Formattable::kIsDate),
- *         "a disturbance in the Force"
- *     };
- *
- *     UnicodeString result;
- *     MessageFormat::format(
- *          "At {1,time} on {1,date}, there was {2} on planet {0,number}.",
- *          arguments, 3, result, success );
- *
- *     cout << "result: " << result << endl;
- *     //<output>: At 4:34:20 PM on 23-Mar-98, there was a disturbance
- *     //             in the Force on planet 7.
- * \endcode
- * </pre>
- * Typically, the message format will come from resources, and the
- * arguments will be dynamically set at runtime.
- * <P>
- * Example 2:
- * <pre>
- *  \code
- *     success = U_ZERO_ERROR;
- *     Formattable testArgs[] = {3L, "MyDisk"};
- *
- *     MessageFormat form(
- *         "The disk \"{1}\" contains {0} file(s).", success );
- *
- *     UnicodeString string;
- *     FieldPosition fpos = 0;
- *     cout << "format: " << form.format(testArgs, 2, string, fpos, success ) << endl;
- *
- *     // output, with different testArgs:
- *     // output: The disk "MyDisk" contains 0 file(s).
- *     // output: The disk "MyDisk" contains 1 file(s).
- *     // output: The disk "MyDisk" contains 1,273 file(s).
- *  \endcode
- *  </pre>
- *
- *  The pattern is of the following form.  Legend:
- *  <pre>
- * \code
- *       {optional item}
- *       (group that may be repeated)*
- * \endcode
- *  </pre>
- *  Do not confuse optional items with items inside quotes braces, such
- *  as this: "{".  Quoted braces are literals.
- *  <pre>
- *  \code
- *       messageFormatPattern := string ( "{" messageFormatElement "}" string )*
- *
- *       messageFormatElement := argumentIndex | argumentName { "," elementFormat }
- *
- *       elementFormat := "time" { "," datetimeStyle }
- *                      | "date" { "," datetimeStyle }
- *                      | "number" { "," numberStyle }
- *                      | "choice" "," choiceStyle
- *
- *       datetimeStyle := "short"
- *                      | "medium"
- *                      | "long"
- *                      | "full"
- *                      | dateFormatPattern
- *
- *       numberStyle :=   "currency"
- *                      | "percent"
- *                      | "integer"
- *                      | numberFormatPattern
- *
- *       choiceStyle :=   choiceFormatPattern
- * 
- *       pluralStyle := pluralFormatPattern
- * \endcode
- * </pre>
- * If there is no elementFormat, then the argument must be a string,
- * which is substituted. If there is no dateTimeStyle or numberStyle,
- * then the default format is used (e.g.  NumberFormat::createInstance(),
- * DateFormat::createTimeInstance(DateFormat::kDefault, ...) or DateFormat::createDateInstance(DateFormat::kDefault, ...). For
- * a ChoiceFormat, the pattern must always be specified, since there
- * is no default.
- * <P>
- * In strings, single quotes can be used to quote syntax characters.
- * A literal single quote is represented by '', both within and outside
- * of single-quoted segments.  Inside a
- * messageFormatElement, quotes are <EM>not</EM> removed. For example,
- * {1,number,$'#',##} will produce a number format with the pound-sign
- * quoted, with a result such as: "$#31,45".
- * <P>
- * If a pattern is used, then unquoted braces in the pattern, if any,
- * must match: that is, "ab {0} de" and "ab '}' de" are ok, but "ab
- * {0'}' de" and "ab } de" are not.
- * <p>
- * <dl><dt><b>Warning:</b><dd>The rules for using quotes within message
- * format patterns unfortunately have shown to be somewhat confusing.
- * In particular, it isn't always obvious to localizers whether single
- * quotes need to be doubled or not. Make sure to inform localizers about
- * the rules, and tell them (for example, by using comments in resource
- * bundle source files) which strings will be processed by MessageFormat.
- * Note that localizers may need to use single quotes in translated
- * strings where the original version doesn't have them.
- * <br>Note also that the simplest way to avoid the problem is to
- * use the real apostrophe (single quote) character U+2019 (') for
- * human-readable text, and to use the ASCII apostrophe (U+0027 ' )
- * only in program syntax, like quoting in MessageFormat.
- * See the annotations for U+0027 Apostrophe in The Unicode Standard.</p>
- * </dl>
- * <P>
- * The argumentIndex is a non-negative integer, which corresponds to the
- * index of the arguments presented in an array to be formatted.  The
- * first argument has argumentIndex 0.
- * <P>
- * It is acceptable to have unused arguments in the array.  With missing
- * arguments or arguments that are not of the right class for the
- * specified format, a failing UErrorCode result is set.
- * <P>
- * For more sophisticated patterns, you can use a ChoiceFormat to get
- * output:
- * <pre>
- * \code
- *     UErrorCode success = U_ZERO_ERROR;
- *     MessageFormat* form("The disk \"{1}\" contains {0}.", success);
- *     double filelimits[] = {0,1,2};
- *     UnicodeString filepart[] = {"no files","one file","{0,number} files"};
- *     ChoiceFormat* fileform = new ChoiceFormat(filelimits, filepart, 3);
- *     form.setFormat(1, *fileform); // NOT zero, see below
- *
- *     Formattable testArgs[] = {1273L, "MyDisk"};
- *
- *     UnicodeString string;
- *     FieldPosition fpos = 0;
- *     cout << form.format(testArgs, 2, string, fpos, success) << endl;
- *
- *     // output, with different testArgs
- *     // output: The disk "MyDisk" contains no files.
- *     // output: The disk "MyDisk" contains one file.
- *     // output: The disk "MyDisk" contains 1,273 files.
- * \endcode
- * </pre>
- * You can either do this programmatically, as in the above example,
- * or by using a pattern (see ChoiceFormat for more information) as in:
- * <pre>
- * \code
- *    form.applyPattern(
- *      "There {0,choice,0#are no files|1#is one file|1<are {0,number,integer} files}.");
- * \endcode
- * </pre>
- * <P>
- * <EM>Note:</EM> As we see above, the string produced by a ChoiceFormat in
- * MessageFormat is treated specially; occurences of '{' are used to
- * indicated subformats, and cause recursion.  If you create both a
- * MessageFormat and ChoiceFormat programmatically (instead of using
- * the string patterns), then be careful not to produce a format that
- * recurses on itself, which will cause an infinite loop.
- * <P>
- * <EM>Note:</EM> Subformats are numbered by their order in the pattern.
- * This is <EM>not</EM> the same as the argumentIndex.
- * <pre>
- * \code
- *    For example: with "abc{2}def{3}ghi{0}...",
- *
- *    format0 affects the first variable {2}
- *    format1 affects the second variable {3}
- *    format2 affects the second variable {0}
- * \endcode
- * </pre>
- *
- * <p><em>User subclasses are not supported.</em> While clients may write
- * subclasses, such code will not necessarily work and will not be
- * guaranteed to work stably from release to release.
- */
-class U_I18N_API MessageFormat : public Format {
-public:
-    /**
-     * Enum type for kMaxFormat.
-     * @obsolete ICU 3.0.  The 10-argument limit was removed as of ICU 2.6,
-     * rendering this enum type obsolete.
-     */
-    enum EFormatNumber {
-        /**
-         * The maximum number of arguments.
-         * @obsolete ICU 3.0.  The 10-argument limit was removed as of ICU 2.6,
-         * rendering this constant obsolete.
-         */
-        kMaxFormat = 10
-    };
-
-    /**
-     * Constructs a new MessageFormat using the given pattern and the
-     * default locale.
-     *
-     * @param pattern   Pattern used to construct object.
-     * @param status    Input/output error code.  If the
-     *                  pattern cannot be parsed, set to failure code.
-     * @stable ICU 2.0
-     */
-    MessageFormat(const UnicodeString& pattern,
-                  UErrorCode &status);
-
-    /**
-     * Constructs a new MessageFormat using the given pattern and locale.
-     * @param pattern   Pattern used to construct object.
-     * @param newLocale The locale to use for formatting dates and numbers.
-     * @param status    Input/output error code.  If the
-     *                  pattern cannot be parsed, set to failure code.
-     * @stable ICU 2.0
-     */
-    MessageFormat(const UnicodeString& pattern,
-                  const Locale& newLocale,
-                        UErrorCode& status);
-    /**
-     * Constructs a new MessageFormat using the given pattern and locale.
-     * @param pattern   Pattern used to construct object.
-     * @param newLocale The locale to use for formatting dates and numbers.
-     * @param parseError Struct to recieve information on position 
-     *                   of error within the pattern.
-     * @param status    Input/output error code.  If the
-     *                  pattern cannot be parsed, set to failure code.
-     * @stable ICU 2.0
-     */
-    MessageFormat(const UnicodeString& pattern,
-                  const Locale& newLocale,
-                  UParseError& parseError,
-                  UErrorCode& status);
-    /**
-     * Constructs a new MessageFormat from an existing one.
-     * @stable ICU 2.0
-     */
-    MessageFormat(const MessageFormat&);
-
-    /**
-     * Assignment operator.
-     * @stable ICU 2.0
-     */
-    const MessageFormat& operator=(const MessageFormat&);
-
-    /**
-     * Destructor.
-     * @stable ICU 2.0
-     */
-    virtual ~MessageFormat();
-
-    /**
-     * Clones this Format object polymorphically.  The caller owns the
-     * result and should delete it when done.
-     * @stable ICU 2.0
-     */
-    virtual Format* clone(void) const;
-
-    /**
-     * Returns true if the given Format objects are semantically equal.
-     * Objects of different subclasses are considered unequal.
-     * @param other  the object to be compared with.
-     * @return       true if the given Format objects are semantically equal.
-     * @stable ICU 2.0
-     */
-    virtual UBool operator==(const Format& other) const;
-
-    /**
-     * Sets the locale. This locale is used for fetching default number or date
-     * format information.
-     * @param theLocale    the new locale value to be set.
-     * @stable ICU 2.0
-     */
-    virtual void setLocale(const Locale& theLocale);
-
-    /**
-     * Gets the locale. This locale is used for fetching default number or date
-     * format information.
-     * @return    the locale of the object.
-     * @stable ICU 2.0
-     */
-    virtual const Locale& getLocale(void) const;
-
-    /**
-     * Applies the given pattern string to this message format.
-     *
-     * @param pattern   The pattern to be applied.
-     * @param status    Input/output error code.  If the
-     *                  pattern cannot be parsed, set to failure code.
-     * @stable ICU 2.0
-     */
-    virtual void applyPattern(const UnicodeString& pattern,
-                              UErrorCode& status);
-    /**
-     * Applies the given pattern string to this message format.
-     *
-     * @param pattern    The pattern to be applied.
-     * @param parseError Struct to recieve information on position 
-     *                   of error within pattern.
-     * @param status    Input/output error code.  If the
-     *                  pattern cannot be parsed, set to failure code.
-     * @stable ICU 2.0
-     */
-    virtual void applyPattern(const UnicodeString& pattern,
-                             UParseError& parseError,
-                             UErrorCode& status);
-
-    /**
-     * Returns a pattern that can be used to recreate this object.
-     *
-     * @param appendTo  Output parameter to receive the pattern.
-     *                  Result is appended to existing contents.
-     * @return          Reference to 'appendTo' parameter.
-     * @stable ICU 2.0
-     */
-    virtual UnicodeString& toPattern(UnicodeString& appendTo) const;
-
-    /**
-     * Sets subformats.
-     * See the class description about format numbering.
-     * The caller should not delete the Format objects after this call.
-     * <EM>The array formatsToAdopt is not itself adopted.</EM> Its
-     * ownership is retained by the caller. If the call fails because
-     * memory cannot be allocated, then the formats will be deleted
-     * by this method, and this object will remain unchanged.
-     * 
-     * @stable ICU 2.0
-     * @param formatsToAdopt    the format to be adopted.
-     * @param count             the size of the array.
-     */
-    virtual void adoptFormats(Format** formatsToAdopt, int32_t count);
-
-    /**
-     * Sets subformats.
-     * See the class description about format numbering.
-     * Each item in the array is cloned into the internal array.
-     * If the call fails because memory cannot be allocated, then this
-     * object will remain unchanged.
-     * 
-     * @stable ICU 2.0
-     * @param newFormats the new format to be set.
-     * @param cnt        the size of the array.
-     */
-    virtual void setFormats(const Format** newFormats, int32_t cnt);
-
-
-    /**
-     * Sets one subformat.
-     * See the class description about format numbering.
-     * The caller should not delete the Format object after this call.
-     * If the number is over the number of formats already set,
-     * the item will be deleted and ignored.
-     * @stable ICU 2.0
-     * @param formatNumber     index of the subformat.
-     * @param formatToAdopt    the format to be adopted.
-     */
-    virtual void adoptFormat(int32_t formatNumber, Format* formatToAdopt);
-
-    /**
-     * Sets one subformat.
-     * See the class description about format numbering.
-     * If the number is over the number of formats already set,
-     * the item will be ignored.
-     * @param formatNumber     index of the subformat.
-     * @param format    the format to be set.
-     * @stable ICU 2.0
-     */
-    virtual void setFormat(int32_t formatNumber, const Format& format);
-
-    /**
-     * Gets format names. This function returns formatNames in StringEnumerations
-     * which can be used with getFormat() and setFormat() to export formattable 
-     * array from current MessageFormat to another.  It is caller's resposibility 
-     * to delete the returned formatNames.
-     * @param status  output param set to success/failure code.
-     * @draft ICU 4.0
-     */
-    virtual StringEnumeration* getFormatNames(UErrorCode& status);
-    
-    /**
-     * Gets subformat pointer for given format name.   
-     * This function supports both named and numbered
-     * arguments-- if numbered, the formatName is the
-     * corresponding UnicodeStrings (e.g. "0", "1", "2"...).
-     * The returned Format object should not be deleted by the caller,
-     * nor should the ponter of other object .  The pointer and its 
-     * contents remain valid only until the next call to any method
-     * of this class is made with this object. 
-     * @param formatName the name or number specifying a format
-     * @param status  output param set to success/failure code.
-     * @draft ICU 4.0
-     */
-    virtual Format* getFormat(const UnicodeString& formatName, UErrorCode& status);
-    
-    /**
-     * Sets one subformat for given format name.
-     * See the class description about format name. 
-     * This function supports both named and numbered
-     * arguments-- if numbered, the formatName is the
-     * corresponding UnicodeStrings (e.g. "0", "1", "2"...).
-     * If there is no matched formatName or wrong type,
-     * the item will be ignored.
-     * @param formatName  Name of the subformat.
-     * @param format      the format to be set.
-     * @param status  output param set to success/failure code.
-     * @draft ICU 4.0
-     */
-    virtual void setFormat(const UnicodeString& formatName, const Format& format, UErrorCode& status);
-    
-    /**
-     * Sets one subformat for given format name.
-     * See the class description about format name. 
-     * This function supports both named and numbered
-     * arguments-- if numbered, the formatName is the
-     * corresponding UnicodeStrings (e.g. "0", "1", "2"...).
-     * If there is no matched formatName or wrong type,
-     * the item will be ignored.
-     * The caller should not delete the Format object after this call.
-     * @param formatName  Name of the subformat.
-     * @param formatToAdopt  Format to be adopted.
-     * @param status      output param set to success/failure code.
-     * @draft ICU 4.0
-     */
-    virtual void adoptFormat(const UnicodeString& formatName, Format* formatToAdopt, UErrorCode& status);
-
-
-    /**
-     * Gets an array of subformats of this object.  The returned array
-     * should not be deleted by the caller, nor should the pointers
-     * within the array.  The array and its contents remain valid only
-     * until the next call to any method of this class is made with
-     * this object.  See the class description about format numbering.
-     * @param count output parameter to receive the size of the array
-     * @return an array of count Format* objects, or NULL if out of
-     * memory.  Any or all of the array elements may be NULL.
-     * @stable ICU 2.0
-     */
-    virtual const Format** getFormats(int32_t& count) const;
-
-    /**
-     * Formats the given array of arguments into a user-readable string.
-     * Does not take ownership of the Formattable* array or its contents.
-     *
-     * @param source    An array of objects to be formatted.
-     * @param count     The number of elements of 'source'.
-     * @param appendTo  Output parameter to receive result.
-     *                  Result is appended to existing contents.
-     * @param ignore    Not used; inherited from base class API.
-     * @param status    Input/output error code.  If the
-     *                  pattern cannot be parsed, set to failure code.
-     * @return          Reference to 'appendTo' parameter.
-     * @stable ICU 2.0
-     */
-    UnicodeString& format(  const Formattable* source,
-                            int32_t count,
-                            UnicodeString& appendTo,
-                            FieldPosition& ignore,
-                            UErrorCode& status) const;
-
-    /**
-     * Formats the given array of arguments into a user-readable string
-     * using the given pattern.
-     *
-     * @param pattern   The pattern.
-     * @param arguments An array of objects to be formatted.
-     * @param count     The number of elements of 'source'.
-     * @param appendTo  Output parameter to receive result.
-     *                  Result is appended to existing contents.
-     * @param status    Input/output error code.  If the
-     *                  pattern cannot be parsed, set to failure code.
-     * @return          Reference to 'appendTo' parameter.
-     * @stable ICU 2.0
-     */
-    static UnicodeString& format(const UnicodeString& pattern,
-                                 const Formattable* arguments,
-                                 int32_t count,
-                                 UnicodeString& appendTo,
-                                 UErrorCode& status);
-
-    /**
-     * Formats the given array of arguments into a user-readable
-     * string.  The array must be stored within a single Formattable
-     * object of type kArray. If the Formattable object type is not of
-     * type kArray, then returns a failing UErrorCode.
-     *
-     * @param obj       A Formattable of type kArray containing
-     *                  arguments to be formatted.
-     * @param appendTo  Output parameter to receive result.
-     *                  Result is appended to existing contents.
-     * @param pos       On input: an alignment field, if desired.
-     *                  On output: the offsets of the alignment field.
-     * @param status    Input/output error code.  If the
-     *                  pattern cannot be parsed, set to failure code.
-     * @return          Reference to 'appendTo' parameter.
-     * @stable ICU 2.0
-     */
-    virtual UnicodeString& format(const Formattable& obj,
-                                  UnicodeString& appendTo,
-                                  FieldPosition& pos,
-                                  UErrorCode& status) const;
-
-    /**
-     * Formats the given array of arguments into a user-readable
-     * string.  The array must be stored within a single Formattable
-     * object of type kArray. If the Formattable object type is not of
-     * type kArray, then returns a failing UErrorCode.
-     *
-     * @param obj       The object to format
-     * @param appendTo  Output parameter to receive result.
-     *                  Result is appended to existing contents.
-     * @param status    Input/output error code.  If the
-     *                  pattern cannot be parsed, set to failure code.
-     * @return          Reference to 'appendTo' parameter.
-     * @stable ICU 2.0
-     */
-    UnicodeString& format(const Formattable& obj,
-                          UnicodeString& appendTo,
-                          UErrorCode& status) const;
-    
-
-    /**
-     * Formats the given array of arguments into a user-defined argument name
-     * array. This function supports both named and numbered
-     * arguments-- if numbered, the formatName is the
-     * corresponding UnicodeStrings (e.g. "0", "1", "2"...).
-     *
-     * @param argumentNames argument name array
-     * @param arguments An array of objects to be formatted.
-     * @param count     The number of elements of 'argumentNames' and 
-     *                  arguments.  The number of argumentNames and arguments
-     *                  must be the same.
-     * @param appendTo  Output parameter to receive result.
-     *                  Result is appended to existing contents.
-     * @param status    Input/output error code.  If the
-     *                  pattern cannot be parsed, set to failure code.
-     * @return          Reference to 'appendTo' parameter.
-     * @stable ICU 4.0
-     */
-    UnicodeString& format(const UnicodeString* argumentNames,
-                          const Formattable* arguments,
-                          int32_t count,
-                          UnicodeString& appendTo,
-                          UErrorCode& status) const;
-    /**
-     * Parses the given string into an array of output arguments.
-     *
-     * @param source    String to be parsed.
-     * @param pos       On input, starting position for parse. On output,
-     *                  final position after parse.  Unchanged if parse
-     *                  fails.
-     * @param count     Output parameter to receive the number of arguments
-     *                  parsed.
-     * @return an array of parsed arguments.  The caller owns both
-     * the array and its contents.
-     * @stable ICU 2.0
-     */
-    virtual Formattable* parse( const UnicodeString& source,
-                                ParsePosition& pos,
-                                int32_t& count) const;
-
-    /**
-     * Parses the given string into an array of output arguments.
-     *
-     * @param source    String to be parsed.
-     * @param count     Output param to receive size of returned array.
-     * @param status    Input/output error code.  If the
-     *                  pattern cannot be parsed, set to failure code. 
-     *                  If the MessageFormat is named argument, the status is 
-     *                  set to U_ARGUMENT_TYPE_MISMATCH.
-     * @return an array of parsed arguments.  The caller owns both
-     * the array and its contents. Return NULL if status is not U_ZERO_ERROR.
-     * 
-     * @stable ICU 2.0
-     */
-    virtual Formattable* parse( const UnicodeString& source,
-                                int32_t& count,
-                                UErrorCode& status) const;
-
-    /**
-     * Parses the given string into an array of output arguments
-     * stored within a single Formattable of type kArray.
-     *
-     * @param source    The string to be parsed into an object.
-     * @param result    Formattable to be set to the parse result.
-     *                  If parse fails, return contents are undefined.
-     * @param pos       On input, starting position for parse. On output,
-     *                  final position after parse.  Unchanged if parse
-     *                  fails.
-     * @stable ICU 2.0
-     */
-    virtual void parseObject(const UnicodeString& source,
-                             Formattable& result,
-                             ParsePosition& pos) const;
-
-    /**
-     * Convert an 'apostrophe-friendly' pattern into a standard
-     * pattern.  Standard patterns treat all apostrophes as
-     * quotes, which is problematic in some languages, e.g. 
-     * French, where apostrophe is commonly used.  This utility
-     * assumes that only an unpaired apostrophe immediately before
-     * a brace is a true quote.  Other unpaired apostrophes are paired,
-     * and the resulting standard pattern string is returned.
-     *
-     * <p><b>Note</b> it is not guaranteed that the returned pattern
-     * is indeed a valid pattern.  The only effect is to convert
-     * between patterns having different quoting semantics.
-     *
-     * @param pattern the 'apostrophe-friendly' patttern to convert
-     * @param status    Input/output error code.  If the pattern
-     *                  cannot be parsed, the failure code is set.
-     * @return the standard equivalent of the original pattern
-     * @stable ICU 3.4
-     */
-    static UnicodeString autoQuoteApostrophe(const UnicodeString& pattern, 
-        UErrorCode& status);
-    
-    /**
-     * Returns true if this MessageFormat uses named arguments,
-     * and false otherwise.  See class description.
-     *
-     * @return true if named arguments are used.
-     * @draft ICU 4.0
-     */
-    UBool usesNamedArguments() const;
-    
-    /**
-     * Returns a unique class ID POLYMORPHICALLY.  Pure virtual override.
-     * This method is to implement a simple version of RTTI, since not all
-     * C++ compilers support genuine RTTI.  Polymorphic operator==() and
-     * clone() methods call this method.
-     *
-     * @return          The class ID for this object. All objects of a
-     *                  given class have the same class ID.  Objects of
-     *                  other classes have different class IDs.
-     * @stable ICU 2.0
-     */
-    virtual UClassID getDynamicClassID(void) const;
-
-    /**
-     * Return the class ID for this class.  This is useful only for
-     * comparing to a return value from getDynamicClassID().  For example:
-     * <pre>
-     * .   Base* polymorphic_pointer = createPolymorphicObject();
-     * .   if (polymorphic_pointer->getDynamicClassID() ==
-     * .      Derived::getStaticClassID()) ...
-     * </pre>
-     * @return          The class ID for all objects of this class.
-     * @stable ICU 2.0
-     */
-    static UClassID U_EXPORT2 getStaticClassID(void);
-    
-private:
-
-    Locale              fLocale;
-    UnicodeString       fPattern;
-    Format**            formatAliases; // see getFormats
-    int32_t             formatAliasesCapacity;
-    UProperty           idStart;
-    UProperty           idContinue;
-
-    MessageFormat(); // default constructor not implemented
-
-    /*
-     * A structure representing one subformat of this MessageFormat.
-     * Each subformat has a Format object, an offset into the plain
-     * pattern text fPattern, and an argument number.  The argument
-     * number corresponds to the array of arguments to be formatted.
-     * @internal
-     */
-    class Subformat;
-
-    /**
-     * A MessageFormat contains an array of subformats.  This array
-     * needs to grow dynamically if the MessageFormat is modified.
-     */
-    Subformat* subformats;
-    int32_t    subformatCount;
-    int32_t    subformatCapacity;
-
-    /**
-     * A MessageFormat formats an array of arguments.  Each argument
-     * has an expected type, based on the pattern.  For example, if
-     * the pattern contains the subformat "{3,number,integer}", then
-     * we expect argument 3 to have type Formattable::kLong.  This
-     * array needs to grow dynamically if the MessageFormat is
-     * modified.
-     */
-    Formattable::Type* argTypes;
-    int32_t            argTypeCount;
-    int32_t            argTypeCapacity;
-
-    /**
-      * Is true iff all argument names are non-negative numbers.
-      * 
-      */
-    UBool isArgNumeric;
-
-    // Variable-size array management
-    UBool allocateSubformats(int32_t capacity);
-    UBool allocateArgTypes(int32_t capacity);
-
-    /**
-     * Default Format objects used when no format is specified and a
-     * numeric or date argument is formatted.  These are volatile
-     * cache objects maintained only for performance.  They do not
-     * participate in operator=(), copy constructor(), nor
-     * operator==().
-     */
-    NumberFormat* defaultNumberFormat;
-    DateFormat*   defaultDateFormat;
-
-    /**
-     * Method to retrieve default formats (or NULL on failure).
-     * These are semantically const, but may modify *this.
-     */
-    const NumberFormat* getDefaultNumberFormat(UErrorCode&) const;
-    const DateFormat*   getDefaultDateFormat(UErrorCode&) const;
-
-    /**
-     * Finds the word s, in the keyword list and returns the located index.
-     * @param s the keyword to be searched for.
-     * @param list the list of keywords to be searched with.
-     * @return the index of the list which matches the keyword s.
-     */
-    static int32_t findKeyword( const UnicodeString& s,
-                                const UChar * const *list);
-
-    /**
-     * Formats the array of arguments and copies the result into the
-     * result buffer, updates the field position.
-     *
-     * @param arguments The formattable objects array.
-     * @param cnt       The array count.
-     * @param appendTo  Output parameter to receive result.
-     *                  Result is appended to existing contents.
-     * @param status    Field position status.
-     * @param recursionProtection
-     *                  Initially zero. Bits 0..9 are used to indicate
-     *                  that a parameter has already been seen, to
-     *                  avoid recursion.  Currently unused.
-     * @param success   The error code status.
-     * @return          Reference to 'appendTo' parameter.
-     */
-    UnicodeString&  format( const Formattable* arguments,
-                            int32_t cnt,
-                            UnicodeString& appendTo,
-                            FieldPosition& status,
-                            int32_t recursionProtection,
-                            UErrorCode& success) const;
-    
-    UnicodeString&  format( const Formattable* arguments, 
-                            const UnicodeString *argumentNames,
-                            int32_t cnt,
-                            UnicodeString& appendTo,
-                            FieldPosition& status,
-                            int32_t recursionProtection,
-                            UErrorCode& success) const;
-
-    void             makeFormat(int32_t offsetNumber,
-                                UnicodeString* segments,
-                                UParseError& parseError,
-                                UErrorCode& success);
-
-    /**
-     * Convenience method that ought to be in NumberFormat
-     */
-    NumberFormat* createIntegerFormat(const Locale& locale, UErrorCode& status) const;
-
-    /**
-     * Checks the range of the source text to quote the special
-     * characters, { and ' and copy to target buffer.
-     * @param source
-     * @param start the text offset to start the process of in the source string
-     * @param end the text offset to end the process of in the source string
-     * @param appendTo  Output parameter to receive result.
-     *                  Result is appended to existing contents.
-     */
-    static void copyAndFixQuotes(const UnicodeString& appendTo, int32_t start, int32_t end, UnicodeString& target);
-
-    /**
-     * Returns array of argument types in the parsed pattern 
-     * for use in C API.  Only for the use of umsg_vformat().  Not
-     * for public consumption.
-     * @param listCount  Output parameter to receive the size of array
-     * @return           The array of formattable types in the pattern
-     * @internal
-     */
-    const Formattable::Type* getArgTypeList(int32_t& listCount) const {
-        listCount = argTypeCount;
-        return argTypes; 
-    }
-    
-    /**
-     * Returns FALSE if the argument name is not legal.
-     * @param  argName   argument name.
-     * @return TRUE if the argument name is legal, otherwise return FALSE.
-     */
-    UBool isLegalArgName(const UnicodeString& argName) const;
-    
-    friend class MessageFormatAdapter; // getFormatTypeList() access
-};
-
-inline UnicodeString&
-MessageFormat::format(const Formattable& obj,
-                      UnicodeString& appendTo,
-                      UErrorCode& status) const {
-    return Format::format(obj, appendTo, status);
-}
-U_NAMESPACE_END
-
-#endif /* #if !UCONFIG_NO_FORMATTING */
-
-#endif // _MSGFMT
-//eof
-

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/normlzr.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/normlzr.h b/apps/couch_collate/platform/osx/icu/unicode/normlzr.h
deleted file mode 100644
index 7974f1a..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/normlzr.h
+++ /dev/null
@@ -1,823 +0,0 @@
-/*
- ********************************************************************
- * COPYRIGHT:
- * Copyright (c) 1996-2006, International Business Machines Corporation and
- * others. All Rights Reserved.
- ********************************************************************
- */
-
-#ifndef NORMLZR_H
-#define NORMLZR_H
-
-#include "unicode/utypes.h"
-
-/**
- * \file 
- * \brief C++ API: Unicode Normalization
- */
- 
-#if !UCONFIG_NO_NORMALIZATION
-
-#include "unicode/uobject.h"
-#include "unicode/unistr.h"
-#include "unicode/chariter.h"
-#include "unicode/unorm.h"
-
-
-struct UCharIterator;
-typedef struct UCharIterator UCharIterator; /**< C typedef for struct UCharIterator. @stable ICU 2.1 */
-
-U_NAMESPACE_BEGIN
-/**
- * The Normalizer class supports the standard normalization forms described in
- * <a href="http://www.unicode.org/unicode/reports/tr15/" target="unicode">
- * Unicode Standard Annex #15: Unicode Normalization Forms</a>.
- *
- * The Normalizer class consists of two parts:
- * - static functions that normalize strings or test if strings are normalized
- * - a Normalizer object is an iterator that takes any kind of text and
- *   provides iteration over its normalized form
- *
- * The Normalizer class is not suitable for subclassing.
- *
- * The static functions are basically wrappers around the C implementation,
- * using UnicodeString instead of UChar*.
- * For basic information about normalization forms and details about the C API
- * please see the documentation in unorm.h.
- *
- * The iterator API with the Normalizer constructors and the non-static functions
- * uses a CharacterIterator as input. It is possible to pass a string which
- * is then internally wrapped in a CharacterIterator.
- * The input text is not normalized all at once, but incrementally where needed
- * (providing efficient random access).
- * This allows to pass in a large text but spend only a small amount of time
- * normalizing a small part of that text.
- * However, if the entire text is normalized, then the iterator will be
- * slower than normalizing the entire text at once and iterating over the result.
- * A possible use of the Normalizer iterator is also to report an index into the
- * original text that is close to where the normalized characters come from.
- *
- * <em>Important:</em> The iterator API was cleaned up significantly for ICU 2.0.
- * The earlier implementation reported the getIndex() inconsistently,
- * and previous() could not be used after setIndex(), next(), first(), and current().
- *
- * Normalizer allows to start normalizing from anywhere in the input text by
- * calling setIndexOnly(), first(), or last().
- * Without calling any of these, the iterator will start at the beginning of the text.
- *
- * At any time, next() returns the next normalized code point (UChar32),
- * with post-increment semantics (like CharacterIterator::next32PostInc()).
- * previous() returns the previous normalized code point (UChar32),
- * with pre-decrement semantics (like CharacterIterator::previous32()).
- *
- * current() returns the current code point
- * (respectively the one at the newly set index) without moving
- * the getIndex(). Note that if the text at the current position
- * needs to be normalized, then these functions will do that.
- * (This is why current() is not const.)
- * It is more efficient to call setIndexOnly() instead, which does not
- * normalize.
- *
- * getIndex() always refers to the position in the input text where the normalized
- * code points are returned from. It does not always change with each returned
- * code point.
- * The code point that is returned from any of the functions
- * corresponds to text at or after getIndex(), according to the
- * function's iteration semantics (post-increment or pre-decrement).
- *
- * next() returns a code point from at or after the getIndex()
- * from before the next() call. After the next() call, the getIndex()
- * might have moved to where the next code point will be returned from
- * (from a next() or current() call).
- * This is semantically equivalent to array access with array[index++]
- * (post-increment semantics).
- *
- * previous() returns a code point from at or after the getIndex()
- * from after the previous() call.
- * This is semantically equivalent to array access with array[--index]
- * (pre-decrement semantics).
- *
- * Internally, the Normalizer iterator normalizes a small piece of text
- * starting at the getIndex() and ending at a following "safe" index.
- * The normalized results is stored in an internal string buffer, and
- * the code points are iterated from there.
- * With multiple iteration calls, this is repeated until the next piece
- * of text needs to be normalized, and the getIndex() needs to be moved.
- *
- * The following "safe" index, the internal buffer, and the secondary
- * iteration index into that buffer are not exposed on the API.
- * This also means that it is currently not practical to return to
- * a particular, arbitrary position in the text because one would need to
- * know, and be able to set, in addition to the getIndex(), at least also the
- * current index into the internal buffer.
- * It is currently only possible to observe when getIndex() changes
- * (with careful consideration of the iteration semantics),
- * at which time the internal index will be 0.
- * For example, if getIndex() is different after next() than before it,
- * then the internal index is 0 and one can return to this getIndex()
- * later with setIndexOnly().
- *
- * @author Laura Werner, Mark Davis, Markus Scherer
- * @stable ICU 2.0
- */
-class U_COMMON_API Normalizer : public UObject {
-public:
-  /**
-   * If DONE is returned from an iteration function that returns a code point,
-   * then there are no more normalization results available.
-   * @stable ICU 2.0
-   */
-  enum {
-      DONE=0xffff
-  };
-
-  // Constructors
-
-  /**
-   * Creates a new <code>Normalizer</code> object for iterating over the
-   * normalized form of a given string.
-   * <p>
-   * @param str   The string to be normalized.  The normalization
-   *              will start at the beginning of the string.
-   *
-   * @param mode  The normalization mode.
-   * @stable ICU 2.0
-   */
-  Normalizer(const UnicodeString& str, UNormalizationMode mode);
-
-  /**
-   * Creates a new <code>Normalizer</code> object for iterating over the
-   * normalized form of a given string.
-   * <p>
-   * @param str   The string to be normalized.  The normalization
-   *              will start at the beginning of the string.
-   *
-   * @param length Length of the string, or -1 if NUL-terminated.
-   * @param mode  The normalization mode.
-   * @stable ICU 2.0
-   */
-  Normalizer(const UChar* str, int32_t length, UNormalizationMode mode);
-
-  /**
-   * Creates a new <code>Normalizer</code> object for iterating over the
-   * normalized form of the given text.
-   * <p>
-   * @param iter  The input text to be normalized.  The normalization
-   *              will start at the beginning of the string.
-   *
-   * @param mode  The normalization mode.
-   * @stable ICU 2.0
-   */
-  Normalizer(const CharacterIterator& iter, UNormalizationMode mode);
-
-  /**
-   * Copy constructor.
-   * @param copy The object to be copied.
-   * @stable ICU 2.0
-   */
-  Normalizer(const Normalizer& copy);
-
-  /**
-   * Destructor
-   * @stable ICU 2.0
-   */
-  virtual ~Normalizer();
-
-
-  //-------------------------------------------------------------------------
-  // Static utility methods
-  //-------------------------------------------------------------------------
-
-  /**
-   * Normalizes a <code>UnicodeString</code> according to the specified normalization mode.
-   * This is a wrapper for unorm_normalize(), using UnicodeString's.
-   *
-   * The <code>options</code> parameter specifies which optional
-   * <code>Normalizer</code> features are to be enabled for this operation.
-   *
-   * @param source    the input string to be normalized.
-   * @param mode      the normalization mode
-   * @param options   the optional features to be enabled (0 for no options)
-   * @param result    The normalized string (on output).
-   * @param status    The error code.
-   * @stable ICU 2.0
-   */
-  static void U_EXPORT2 normalize(const UnicodeString& source,
-                        UNormalizationMode mode, int32_t options,
-                        UnicodeString& result,
-                        UErrorCode &status);
-
-  /**
-   * Compose a <code>UnicodeString</code>.
-   * This is equivalent to normalize() with mode UNORM_NFC or UNORM_NFKC.
-   * This is a wrapper for unorm_normalize(), using UnicodeString's.
-   *
-   * The <code>options</code> parameter specifies which optional
-   * <code>Normalizer</code> features are to be enabled for this operation.
-   *
-   * @param source    the string to be composed.
-   * @param compat    Perform compatibility decomposition before composition.
-   *                  If this argument is <code>FALSE</code>, only canonical
-   *                  decomposition will be performed.
-   * @param options   the optional features to be enabled (0 for no options)
-   * @param result    The composed string (on output).
-   * @param status    The error code.
-   * @stable ICU 2.0
-   */
-  static void U_EXPORT2 compose(const UnicodeString& source,
-                      UBool compat, int32_t options,
-                      UnicodeString& result,
-                      UErrorCode &status);
-
-  /**
-   * Static method to decompose a <code>UnicodeString</code>.
-   * This is equivalent to normalize() with mode UNORM_NFD or UNORM_NFKD.
-   * This is a wrapper for unorm_normalize(), using UnicodeString's.
-   *
-   * The <code>options</code> parameter specifies which optional
-   * <code>Normalizer</code> features are to be enabled for this operation.
-   *
-   * @param source    the string to be decomposed.
-   * @param compat    Perform compatibility decomposition.
-   *                  If this argument is <code>FALSE</code>, only canonical
-   *                  decomposition will be performed.
-   * @param options   the optional features to be enabled (0 for no options)
-   * @param result    The decomposed string (on output).
-   * @param status    The error code.
-   * @stable ICU 2.0
-   */
-  static void U_EXPORT2 decompose(const UnicodeString& source,
-                        UBool compat, int32_t options,
-                        UnicodeString& result,
-                        UErrorCode &status);
-
-  /**
-   * Performing quick check on a string, to quickly determine if the string is
-   * in a particular normalization format.
-   * This is a wrapper for unorm_quickCheck(), using a UnicodeString.
-   *
-   * Three types of result can be returned UNORM_YES, UNORM_NO or
-   * UNORM_MAYBE. Result UNORM_YES indicates that the argument
-   * string is in the desired normalized format, UNORM_NO determines that
-   * argument string is not in the desired normalized format. A
-   * UNORM_MAYBE result indicates that a more thorough check is required,
-   * the user may have to put the string in its normalized form and compare the
-   * results.
-   * @param source       string for determining if it is in a normalized format
-   * @param mode         normalization format
-   * @param status A reference to a UErrorCode to receive any errors
-   * @return UNORM_YES, UNORM_NO or UNORM_MAYBE
-   *
-   * @see isNormalized
-   * @stable ICU 2.0
-   */
-  static inline UNormalizationCheckResult
-  quickCheck(const UnicodeString &source, UNormalizationMode mode, UErrorCode &status);
-
-  /**
-   * Performing quick check on a string; same as the other version of quickCheck
-   * but takes an extra options parameter like most normalization functions.
-   *
-   * @param source       string for determining if it is in a normalized format
-   * @param mode         normalization format
-   * @param options      the optional features to be enabled (0 for no options)
-   * @param status A reference to a UErrorCode to receive any errors
-   * @return UNORM_YES, UNORM_NO or UNORM_MAYBE
-   *
-   * @see isNormalized
-   * @stable ICU 2.6
-   */
-  static inline UNormalizationCheckResult
-  quickCheck(const UnicodeString &source, UNormalizationMode mode, int32_t options, UErrorCode &status);
-
-  /**
-   * Test if a string is in a given normalization form.
-   * This is semantically equivalent to source.equals(normalize(source, mode)) .
-   *
-   * Unlike unorm_quickCheck(), this function returns a definitive result,
-   * never a "maybe".
-   * For NFD, NFKD, and FCD, both functions work exactly the same.
-   * For NFC and NFKC where quickCheck may return "maybe", this function will
-   * perform further tests to arrive at a TRUE/FALSE result.
-   *
-   * @param src        String that is to be tested if it is in a normalization format.
-   * @param mode       Which normalization form to test for.
-   * @param errorCode  ICU error code in/out parameter.
-   *                   Must fulfill U_SUCCESS before the function call.
-   * @return Boolean value indicating whether the source string is in the
-   *         "mode" normalization form.
-   *
-   * @see quickCheck
-   * @stable ICU 2.2
-   */
-  static inline UBool
-  isNormalized(const UnicodeString &src, UNormalizationMode mode, UErrorCode &errorCode);
-
-  /**
-   * Test if a string is in a given normalization form; same as the other version of isNormalized
-   * but takes an extra options parameter like most normalization functions.
-   *
-   * @param src        String that is to be tested if it is in a normalization format.
-   * @param mode       Which normalization form to test for.
-   * @param options      the optional features to be enabled (0 for no options)
-   * @param errorCode  ICU error code in/out parameter.
-   *                   Must fulfill U_SUCCESS before the function call.
-   * @return Boolean value indicating whether the source string is in the
-   *         "mode" normalization form.
-   *
-   * @see quickCheck
-   * @stable ICU 2.6
-   */
-  static inline UBool
-  isNormalized(const UnicodeString &src, UNormalizationMode mode, int32_t options, UErrorCode &errorCode);
-
-  /**
-   * Concatenate normalized strings, making sure that the result is normalized as well.
-   *
-   * If both the left and the right strings are in
-   * the normalization form according to "mode/options",
-   * then the result will be
-   *
-   * \code
-   *     dest=normalize(left+right, mode, options)
-   * \endcode
-   *
-   * For details see unorm_concatenate in unorm.h.
-   *
-   * @param left Left source string.
-   * @param right Right source string.
-   * @param result The output string.
-   * @param mode The normalization mode.
-   * @param options A bit set of normalization options.
-   * @param errorCode ICU error code in/out parameter.
-   *                   Must fulfill U_SUCCESS before the function call.
-   * @return result
-   *
-   * @see unorm_concatenate
-   * @see normalize
-   * @see unorm_next
-   * @see unorm_previous
-   *
-   * @stable ICU 2.1
-   */
-  static UnicodeString &
-  U_EXPORT2 concatenate(UnicodeString &left, UnicodeString &right,
-              UnicodeString &result,
-              UNormalizationMode mode, int32_t options,
-              UErrorCode &errorCode);
-
-  /**
-   * Compare two strings for canonical equivalence.
-   * Further options include case-insensitive comparison and
-   * code point order (as opposed to code unit order).
-   *
-   * Canonical equivalence between two strings is defined as their normalized
-   * forms (NFD or NFC) being identical.
-   * This function compares strings incrementally instead of normalizing
-   * (and optionally case-folding) both strings entirely,
-   * improving performance significantly.
-   *
-   * Bulk normalization is only necessary if the strings do not fulfill the FCD
-   * conditions. Only in this case, and only if the strings are relatively long,
-   * is memory allocated temporarily.
-   * For FCD strings and short non-FCD strings there is no memory allocation.
-   *
-   * Semantically, this is equivalent to
-   *   strcmp[CodePointOrder](NFD(foldCase(s1)), NFD(foldCase(s2)))
-   * where code point order and foldCase are all optional.
-   *
-   * UAX 21 2.5 Caseless Matching specifies that for a canonical caseless match
-   * the case folding must be performed first, then the normalization.
-   *
-   * @param s1 First source string.
-   * @param s2 Second source string.
-   *
-   * @param options A bit set of options:
-   *   - U_FOLD_CASE_DEFAULT or 0 is used for default options:
-   *     Case-sensitive comparison in code unit order, and the input strings
-   *     are quick-checked for FCD.
-   *
-   *   - UNORM_INPUT_IS_FCD
-   *     Set if the caller knows that both s1 and s2 fulfill the FCD conditions.
-   *     If not set, the function will quickCheck for FCD
-   *     and normalize if necessary.
-   *
-   *   - U_COMPARE_CODE_POINT_ORDER
-   *     Set to choose code point order instead of code unit order
-   *     (see u_strCompare for details).
-   *
-   *   - U_COMPARE_IGNORE_CASE
-   *     Set to compare strings case-insensitively using case folding,
-   *     instead of case-sensitively.
-   *     If set, then the following case folding options are used.
-   *
-   *   - Options as used with case-insensitive comparisons, currently:
-   *
-   *   - U_FOLD_CASE_EXCLUDE_SPECIAL_I
-   *    (see u_strCaseCompare for details)
-   *
-   *   - regular normalization options shifted left by UNORM_COMPARE_NORM_OPTIONS_SHIFT
-   *
-   * @param errorCode ICU error code in/out parameter.
-   *                  Must fulfill U_SUCCESS before the function call.
-   * @return <0 or 0 or >0 as usual for string comparisons
-   *
-   * @see unorm_compare
-   * @see normalize
-   * @see UNORM_FCD
-   * @see u_strCompare
-   * @see u_strCaseCompare
-   *
-   * @stable ICU 2.2
-   */
-  static inline int32_t
-  compare(const UnicodeString &s1, const UnicodeString &s2,
-          uint32_t options,
-          UErrorCode &errorCode);
-
-  //-------------------------------------------------------------------------
-  // Iteration API
-  //-------------------------------------------------------------------------
-
-  /**
-   * Return the current character in the normalized text.
-   * current() may need to normalize some text at getIndex().
-   * The getIndex() is not changed.
-   *
-   * @return the current normalized code point
-   * @stable ICU 2.0
-   */
-  UChar32              current(void);
-
-  /**
-   * Return the first character in the normalized text.
-   * This is equivalent to setIndexOnly(startIndex()) followed by next().
-   * (Post-increment semantics.)
-   *
-   * @return the first normalized code point
-   * @stable ICU 2.0
-   */
-  UChar32              first(void);
-
-  /**
-   * Return the last character in the normalized text.
-   * This is equivalent to setIndexOnly(endIndex()) followed by previous().
-   * (Pre-decrement semantics.)
-   *
-   * @return the last normalized code point
-   * @stable ICU 2.0
-   */
-  UChar32              last(void);
-
-  /**
-   * Return the next character in the normalized text.
-   * (Post-increment semantics.)
-   * If the end of the text has already been reached, DONE is returned.
-   * The DONE value could be confused with a U+FFFF non-character code point
-   * in the text. If this is possible, you can test getIndex()<endIndex()
-   * before calling next(), or (getIndex()<endIndex() || last()!=DONE)
-   * after calling next(). (Calling last() will change the iterator state!)
-   *
-   * The C API unorm_next() is more efficient and does not have this ambiguity.
-   *
-   * @return the next normalized code point
-   * @stable ICU 2.0
-   */
-  UChar32              next(void);
-
-  /**
-   * Return the previous character in the normalized text and decrement.
-   * (Pre-decrement semantics.)
-   * If the beginning of the text has already been reached, DONE is returned.
-   * The DONE value could be confused with a U+FFFF non-character code point
-   * in the text. If this is possible, you can test
-   * (getIndex()>startIndex() || first()!=DONE). (Calling first() will change
-   * the iterator state!)
-   *
-   * The C API unorm_previous() is more efficient and does not have this ambiguity.
-   *
-   * @return the previous normalized code point
-   * @stable ICU 2.0
-   */
-  UChar32              previous(void);
-
-  /**
-   * Set the iteration position in the input text that is being normalized,
-   * without any immediate normalization.
-   * After setIndexOnly(), getIndex() will return the same index that is
-   * specified here.
-   *
-   * @param index the desired index in the input text.
-   * @stable ICU 2.0
-   */
-  void                 setIndexOnly(int32_t index);
-
-  /**
-   * Reset the index to the beginning of the text.
-   * This is equivalent to setIndexOnly(startIndex)).
-   * @stable ICU 2.0
-   */
-  void                reset(void);
-
-  /**
-   * Retrieve the current iteration position in the input text that is
-   * being normalized.
-   *
-   * A following call to next() will return a normalized code point from
-   * the input text at or after this index.
-   *
-   * After a call to previous(), getIndex() will point at or before the
-   * position in the input text where the normalized code point
-   * was returned from with previous().
-   *
-   * @return the current index in the input text
-   * @stable ICU 2.0
-   */
-  int32_t            getIndex(void) const;
-
-  /**
-   * Retrieve the index of the start of the input text. This is the begin index
-   * of the <code>CharacterIterator</code> or the start (i.e. index 0) of the string
-   * over which this <code>Normalizer</code> is iterating.
-   *
-   * @return the smallest index in the input text where the Normalizer operates
-   * @stable ICU 2.0
-   */
-  int32_t            startIndex(void) const;
-
-  /**
-   * Retrieve the index of the end of the input text. This is the end index
-   * of the <code>CharacterIterator</code> or the length of the string
-   * over which this <code>Normalizer</code> is iterating.
-   * This end index is exclusive, i.e., the Normalizer operates only on characters
-   * before this index.
-   *
-   * @return the first index in the input text where the Normalizer does not operate
-   * @stable ICU 2.0
-   */
-  int32_t            endIndex(void) const;
-
-  /**
-   * Returns TRUE when both iterators refer to the same character in the same
-   * input text.
-   *
-   * @param that a Normalizer object to compare this one to
-   * @return comparison result
-   * @stable ICU 2.0
-   */
-  UBool        operator==(const Normalizer& that) const;
-
-  /**
-   * Returns FALSE when both iterators refer to the same character in the same
-   * input text.
-   *
-   * @param that a Normalizer object to compare this one to
-   * @return comparison result
-   * @stable ICU 2.0
-   */
-  inline UBool        operator!=(const Normalizer& that) const;
-
-  /**
-   * Returns a pointer to a new Normalizer that is a clone of this one.
-   * The caller is responsible for deleting the new clone.
-   * @return a pointer to a new Normalizer
-   * @stable ICU 2.0
-   */
-  Normalizer*        clone(void) const;
-
-  /**
-   * Generates a hash code for this iterator.
-   *
-   * @return the hash code
-   * @stable ICU 2.0
-   */
-  int32_t                hashCode(void) const;
-
-  //-------------------------------------------------------------------------
-  // Property access methods
-  //-------------------------------------------------------------------------
-
-  /**
-   * Set the normalization mode for this object.
-   * <p>
-   * <b>Note:</b>If the normalization mode is changed while iterating
-   * over a string, calls to {@link #next() } and {@link #previous() } may
-   * return previously buffers characters in the old normalization mode
-   * until the iteration is able to re-sync at the next base character.
-   * It is safest to call {@link #setIndexOnly }, {@link #reset() },
-   * {@link #setText }, {@link #first() },
-   * {@link #last() }, etc. after calling <code>setMode</code>.
-   * <p>
-   * @param newMode the new mode for this <code>Normalizer</code>.
-   * @see #getUMode
-   * @stable ICU 2.0
-   */
-  void setMode(UNormalizationMode newMode);
-
-  /**
-   * Return the normalization mode for this object.
-   *
-   * This is an unusual name because there used to be a getMode() that
-   * returned a different type.
-   *
-   * @return the mode for this <code>Normalizer</code>
-   * @see #setMode
-   * @stable ICU 2.0
-   */
-  UNormalizationMode getUMode(void) const;
-
-  /**
-   * Set options that affect this <code>Normalizer</code>'s operation.
-   * Options do not change the basic composition or decomposition operation
-   * that is being performed, but they control whether
-   * certain optional portions of the operation are done.
-   * Currently the only available option is obsolete.
-   *
-   * It is possible to specify multiple options that are all turned on or off.
-   *
-   * @param   option  the option(s) whose value is/are to be set.
-   * @param   value   the new setting for the option.  Use <code>TRUE</code> to
-   *                  turn the option(s) on and <code>FALSE</code> to turn it/them off.
-   *
-   * @see #getOption
-   * @stable ICU 2.0
-   */
-  void setOption(int32_t option,
-         UBool value);
-
-  /**
-   * Determine whether an option is turned on or off.
-   * If multiple options are specified, then the result is TRUE if any
-   * of them are set.
-   * <p>
-   * @param option the option(s) that are to be checked
-   * @return TRUE if any of the option(s) are set
-   * @see #setOption
-   * @stable ICU 2.0
-   */
-  UBool getOption(int32_t option) const;
-
-  /**
-   * Set the input text over which this <code>Normalizer</code> will iterate.
-   * The iteration position is set to the beginning.
-   *
-   * @param newText a string that replaces the current input text
-   * @param status a UErrorCode
-   * @stable ICU 2.0
-   */
-  void setText(const UnicodeString& newText,
-           UErrorCode &status);
-
-  /**
-   * Set the input text over which this <code>Normalizer</code> will iterate.
-   * The iteration position is set to the beginning.
-   *
-   * @param newText a CharacterIterator object that replaces the current input text
-   * @param status a UErrorCode
-   * @stable ICU 2.0
-   */
-  void setText(const CharacterIterator& newText,
-           UErrorCode &status);
-
-  /**
-   * Set the input text over which this <code>Normalizer</code> will iterate.
-   * The iteration position is set to the beginning.
-   *
-   * @param newText a string that replaces the current input text
-   * @param length the length of the string, or -1 if NUL-terminated
-   * @param status a UErrorCode
-   * @stable ICU 2.0
-   */
-  void setText(const UChar* newText,
-                    int32_t length,
-            UErrorCode &status);
-  /**
-   * Copies the input text into the UnicodeString argument.
-   *
-   * @param result Receives a copy of the text under iteration.
-   * @stable ICU 2.0
-   */
-  void            getText(UnicodeString&  result);
-
-  /**
-   * ICU "poor man's RTTI", returns a UClassID for this class.
-   * @returns a UClassID for this class.
-   * @stable ICU 2.2
-   */
-  static UClassID U_EXPORT2 getStaticClassID();
-
-  /**
-   * ICU "poor man's RTTI", returns a UClassID for the actual class.
-   * @return a UClassID for the actual class.
-   * @stable ICU 2.2
-   */
-  virtual UClassID getDynamicClassID() const;
-
-private:
-  //-------------------------------------------------------------------------
-  // Private functions
-  //-------------------------------------------------------------------------
-
-  Normalizer(); // default constructor not implemented
-  Normalizer &operator=(const Normalizer &that); // assignment operator not implemented
-
-  // Private utility methods for iteration
-  // For documentation, see the source code
-  UBool nextNormalize();
-  UBool previousNormalize();
-
-  void    init(CharacterIterator *iter);
-  void    clearBuffer(void);
-
-  //-------------------------------------------------------------------------
-  // Private data
-  //-------------------------------------------------------------------------
-
-  UNormalizationMode  fUMode;
-  int32_t             fOptions;
-
-  // The input text and our position in it
-  UCharIterator       *text;
-
-  // The normalization buffer is the result of normalization
-  // of the source in [currentIndex..nextIndex[ .
-  int32_t         currentIndex, nextIndex;
-
-  // A buffer for holding intermediate results
-  UnicodeString       buffer;
-  int32_t         bufferPos;
-
-};
-
-//-------------------------------------------------------------------------
-// Inline implementations
-//-------------------------------------------------------------------------
-
-inline UBool
-Normalizer::operator!= (const Normalizer& other) const
-{ return ! operator==(other); }
-
-inline UNormalizationCheckResult
-Normalizer::quickCheck(const UnicodeString& source,
-                       UNormalizationMode mode,
-                       UErrorCode &status) {
-    if(U_FAILURE(status)) {
-        return UNORM_MAYBE;
-    }
-
-    return unorm_quickCheck(source.getBuffer(), source.length(),
-                            mode, &status);
-}
-
-inline UNormalizationCheckResult
-Normalizer::quickCheck(const UnicodeString& source,
-                       UNormalizationMode mode, int32_t options,
-                       UErrorCode &status) {
-    if(U_FAILURE(status)) {
-        return UNORM_MAYBE;
-    }
-
-    return unorm_quickCheckWithOptions(source.getBuffer(), source.length(),
-                                       mode, options, &status);
-}
-
-inline UBool
-Normalizer::isNormalized(const UnicodeString& source,
-                         UNormalizationMode mode,
-                         UErrorCode &status) {
-    if(U_FAILURE(status)) {
-        return FALSE;
-    }
-
-    return unorm_isNormalized(source.getBuffer(), source.length(),
-                              mode, &status);
-}
-
-inline UBool
-Normalizer::isNormalized(const UnicodeString& source,
-                         UNormalizationMode mode, int32_t options,
-                         UErrorCode &status) {
-    if(U_FAILURE(status)) {
-        return FALSE;
-    }
-
-    return unorm_isNormalizedWithOptions(source.getBuffer(), source.length(),
-                                         mode, options, &status);
-}
-
-inline int32_t
-Normalizer::compare(const UnicodeString &s1, const UnicodeString &s2,
-                    uint32_t options,
-                    UErrorCode &errorCode) {
-  // all argument checking is done in unorm_compare
-  return unorm_compare(s1.getBuffer(), s1.length(),
-                       s2.getBuffer(), s2.length(),
-                       options,
-                       &errorCode);
-}
-
-U_NAMESPACE_END
-
-#endif /* #if !UCONFIG_NO_NORMALIZATION */
-
-#endif // NORMLZR_H


[09/57] [abbrv] remove couch_collate

Posted by be...@apache.org.
http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/uregex.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/uregex.h b/apps/couch_collate/platform/osx/icu/unicode/uregex.h
deleted file mode 100644
index d646047..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/uregex.h
+++ /dev/null
@@ -1,989 +0,0 @@
-/*
-**********************************************************************
-*   Copyright (C) 2004-2008, International Business Machines
-*   Corporation and others.  All Rights Reserved.
-**********************************************************************
-*   file name:  regex.h
-*   encoding:   US-ASCII
-*   indentation:4
-*
-*   created on: 2004mar09
-*   created by: Andy Heninger
-*
-*   ICU Regular Expressions, API for C
-*/
-
-/**
- * \file
- * \brief C API: Regular Expressions
- *
- * <p>This is a C wrapper around the C++ RegexPattern and RegexMatcher classes.</p>
- */
-
-#ifndef UREGEX_H
-#define UREGEX_H
-
-#include "unicode/utypes.h"
-
-#if !UCONFIG_NO_REGULAR_EXPRESSIONS
-
-#include "unicode/parseerr.h"
-
-struct URegularExpression;
-/**
-  * Structure represeting a compiled regular rexpression, plus the results
-  *    of a match operation.
-  * @stable ICU 3.0
-  */
-typedef struct URegularExpression URegularExpression;
-
-
-/**
- * Constants for Regular Expression Match Modes.
- * @stable ICU 2.4
- */
-typedef enum URegexpFlag{
-
-#ifndef U_HIDE_DRAFT_API 
-    /** Forces normalization of pattern and strings. 
-    Not implemented yet, just a placeholder, hence draft. 
-    @draft ICU 2.4 */
-    UREGEX_CANON_EQ         = 128,
-#endif
-    /**  Enable case insensitive matching.  @stable ICU 2.4 */
-    UREGEX_CASE_INSENSITIVE = 2,
-
-    /**  Allow white space and comments within patterns  @stable ICU 2.4 */
-    UREGEX_COMMENTS         = 4,
-
-    /**  If set, '.' matches line terminators,  otherwise '.' matching stops at line end.
-      *  @stable ICU 2.4 */
-    UREGEX_DOTALL           = 32,
-    
-    /**  If set, treat the entire pattern as a literal string.  
-      *  Metacharacters or escape sequences in the input sequence will be given 
-      *  no special meaning.
-      *
-      *  The flags CASE_INSENSITIVE and UNICODE_CASE retain their impact
-      *  on matching when used in conjunction with this flag.
-      *  The other flags become superfluous.
-      *  TODO:  say which escapes are still handled; anything Java does
-      *         early (\u) we should still do.
-      * @draft ICU 4.0
-      */
-    UREGEX_LITERAL = 16,
-
-    /**   Control behavior of "$" and "^"
-      *    If set, recognize line terminators within string,
-      *    otherwise, match only at start and end of input string.
-      *   @stable ICU 2.4 */
-    UREGEX_MULTILINE        = 8,
-    
-    /**   Unix-only line endings.
-      *   When this mode is enabled, only \u000a is recognized as a line ending
-      *    in the behavior of ., ^, and $.
-      *   @draft ICU 4.0
-      */
-    UREGEX_UNIX_LINES = 1,
-
-    /**  Unicode word boundaries.
-      *     If set, \b uses the Unicode TR 29 definition of word boundaries.
-      *     Warning: Unicode word boundaries are quite different from
-      *     traditional regular expression word boundaries.  See
-      *     http://unicode.org/reports/tr29/#Word_Boundaries
-      *     @stable ICU 2.8
-      */
-    UREGEX_UWORD            = 256,
-
-     /**  Error on Unrecognized backslash escapes.
-       *     If set, fail with an error on patterns that contain
-       *     backslash-escaped ASCII letters without a known specail
-       *     meaning.  If this flag is not set, these
-       *     escaped letters represent themselves.
-       *     @draft ICU 4.0
-       */
-     UREGEX_ERROR_ON_UNKNOWN_ESCAPES = 512
-
-}  URegexpFlag;
-
-/**
-  *  Open (compile) an ICU regular expression.  Compiles the regular expression in
-  *  string form into an internal representation using the specified match mode flags.
-  *  The resulting regular expression handle can then be used to perform various
-  *   matching operations.
-  *
-  * @param pattern        The Regular Expression pattern to be compiled. 
-  * @param patternLength  The length of the pattern, or -1 if the pattern is
-  *                       NUL termintated.
-  * @param flags          Flags that alter the default matching behavior for
-  *                       the regular expression, UREGEX_CASE_INSENSITIVE, for
-  *                       example.  For default behavior, set this parameter to zero.
-  *                       See <code>enum URegexpFlag</code>.  All desired flags
-  *                       are bitwise-ORed together.
-  * @param pe             Receives the position (line and column nubers) of any syntax
-  *                       error within the source regular expression string.  If this
-  *                       information is not wanted, pass NULL for this parameter.
-  * @param status         Receives error detected by this function.
-  * @stable ICU 3.0
-  *
-  */
-U_STABLE URegularExpression * U_EXPORT2
-uregex_open( const  UChar          *pattern,
-                    int32_t         patternLength,
-                    uint32_t        flags,
-                    UParseError    *pe,
-                    UErrorCode     *status);
-
-/**
-  *  Open (compile) an ICU regular expression.  The resulting regular expression
-  *   handle can then be used to perform various matching operations.
-  *  <p>
-  *   This function is the same as uregex_open, except that the pattern
-  *   is supplied as an 8 bit char * string in the default code page.
-  *
-  * @param pattern        The Regular Expression pattern to be compiled, 
-  *                       NUL termintated.  
-  * @param flags          Flags that alter the default matching behavior for
-  *                       the regular expression, UREGEX_CASE_INSENSITIVE, for
-  *                       example.  For default behavior, set this parameter to zero.
-  *                       See <code>enum URegexpFlag</code>.  All desired flags
-  *                       are bitwise-ORed together.
-  * @param pe             Receives the position (line and column nubers) of any syntax
-  *                       error within the source regular expression string.  If this
-  *                       information is not wanted, pass NULL for this parameter.
-  * @param status         Receives errors detected by this function.
-  * @return               The URegularExpression object representing the compiled
-  *                       pattern.
-  *
-  * @stable ICU 3.0
-  */
-#if !UCONFIG_NO_CONVERSION
-U_STABLE URegularExpression * U_EXPORT2
-uregex_openC( const char           *pattern,
-                    uint32_t        flags,
-                    UParseError    *pe,
-                    UErrorCode     *status);
-#endif
-
-
-
-/**
-  *  Close the regular expression, recovering all resources (memory) it
-  *   was holding.
-  *
-  * @param regexp   The regular expression to be closed.
-  * @stable ICU 3.0
-  */
-U_STABLE void U_EXPORT2 
-uregex_close(URegularExpression *regexp);
-
-/**
- * Make a copy of a compiled regular expression.  Cloning a regular
- * expression is faster than opening a second instance from the source
- * form of the expression, and requires less memory.
- * <p>
- * Note that the current input string and the position of any matched text
- *  within it are not cloned; only the pattern itself and and the
- *  match mode flags are copied.
- * <p>
- * Cloning can be particularly useful to threaded applications that perform
- * multiple match operations in parallel.  Each concurrent RE
- * operation requires its own instance of a URegularExpression.
- *
- * @param regexp   The compiled regular expression to be cloned.
- * @param status   Receives indication of any errors encountered
- * @return the cloned copy of the compiled regular expression.
- * @stable ICU 3.0
- */
-U_STABLE URegularExpression * U_EXPORT2 
-uregex_clone(const URegularExpression *regexp, UErrorCode *status);
-
-/**
- *  Return a pointer to the source form of the pattern for this regular expression.
- *
- * @param regexp     The compiled regular expression.
- * @param patLength  This output parameter will be set to the length of the
- *                   pattern string.  A NULL pointer may be used here if the
- *                   pattern length is not needed, as would be the case if
- *                   the pattern is known in advance to be a NUL terminated
- *                   string.
- * @param status     Receives errors detected by this function.
- * @return a pointer to the pattern string.  The storage for the string is
- *                   owned by the regular expression object, and must not be
- *                   altered or deleted by the application.  The returned string
- *                   will remain valid until the regular expression is closed.
- * @stable ICU 3.0
- */
-U_STABLE const UChar * U_EXPORT2 
-uregex_pattern(const  URegularExpression   *regexp,
-                         int32_t           *patLength,
-                         UErrorCode        *status);
-
-
-/**
-  * Get the match mode flags that were specified when compiling this regular expression.
-  * @param status   Receives errors detected by this function.
-  * @param regexp   The compiled regular expression.
-  * @return         The match mode flags
-  * @see URegexpFlag
-  * @stable ICU 3.0
-  */
-U_STABLE int32_t U_EXPORT2 
-uregex_flags(const  URegularExpression   *regexp,
-                    UErrorCode           *status);
-
-
-/**
-  *  Set the subject text string upon which the regular expression will look for matches.
-  *  This function may be called any number of times, allowing the regular
-  *  expression pattern to be applied to different strings.
-  *  <p>
-  *  Regular expression matching operations work directly on the application's
-  *  string data.  No copy is made.  The subject string data must not be
-  *  altered after calling this function until after all regular expression
-  *  operations involving this string data are completed.  
-  *  <p>
-  *  Zero length strings are permitted.  In this case, no subsequent match
-  *  operation will dereference the text string pointer.
-  *
-  * @param regexp     The compiled regular expression.
-  * @param text       The subject text string.
-  * @param textLength The length of the subject text, or -1 if the string
-  *                   is NUL terminated.
-  * @param status     Receives errors detected by this function.
-  * @stable ICU 3.0
-  */
-U_STABLE void U_EXPORT2 
-uregex_setText(URegularExpression *regexp,
-               const UChar        *text,
-               int32_t             textLength,
-               UErrorCode         *status);
-
-/**
-  *  Get the subject text that is currently associated with this 
-  *   regular expression object.  This simply returns whatever string
-  *   pointer was previously supplied via uregex_setText().
-  *
-  * @param regexp      The compiled regular expression.
-  * @param textLength  The length of the string is returned in this output parameter. 
-  *                    A NULL pointer may be used here if the
-  *                    text length is not needed, as would be the case if
-  *                    the text is known in advance to be a NUL terminated
-  *                    string.
-  * @param status      Receives errors detected by this function.
-  * @return            Poiner to the subject text string currently associated with
-  *                    this regular expression.
-  * @stable ICU 3.0
-  */
-U_STABLE const UChar * U_EXPORT2 
-uregex_getText(URegularExpression *regexp,
-               int32_t            *textLength,
-               UErrorCode         *status);
-
-/**
-  *   Attempts to match the input string against the pattern.
-  *   To succeed, the match must extend to the end of the string,
-  *   or cover the complete match region.
-  *
-  *   If startIndex >= zero the match operation starts at the specified
-  *   index and must extend to the end of the input string.  Any region
-  *   that has been specified is reset.
-  *
-  *   If startIndex == -1 the match must cover the input region, or the entire
-  *   input string if no region has been set.  This directly corresponds to
-  *   Matcher.matches() in Java
-  *
-  *    @param  regexp      The compiled regular expression.
-  *    @param  startIndex  The input string index at which to begin matching, or -1
-  *                        to match the input Region.
-  *    @param  status      Receives errors detected by this function.
-  *    @return             TRUE if there is a match
-  *    @stable ICU 3.0
-  */
-U_STABLE UBool U_EXPORT2 
-uregex_matches(URegularExpression *regexp,
-                int32_t            startIndex,
-                UErrorCode        *status);
-
-/**
-  *   Attempts to match the input string, starting from the specified index, against the pattern.
-  *   The match may be of any length, and is not required to extend to the end
-  *   of the input string.  Contrast with uregex_matches().
-  *
-  *   <p>If startIndex is >= 0 any input region that was set for this
-  *   URegularExpression is reset before the operation begins.
-  *
-  *   <p>If the specified starting index == -1 the match begins at the start of the input 
-  *   region, or at the start of the full string if no region has been specified.
-  *   This corresponds directly with Matcher.lookingAt() in Java.
-  *
-  *   <p>If the match succeeds then more information can be obtained via the
-  *    <code>uregexp_start()</code>, <code>uregexp_end()</code>,
-  *    and <code>uregexp_group()</code> functions.</p>
-  *
-  *    @param   regexp      The compiled regular expression.
-  *    @param   startIndex  The input string index at which to begin matching, or
-  *                         -1 to match the Input Region
-  *    @param   status      A reference to a UErrorCode to receive any errors.
-  *    @return  TRUE if there is a match.
-  *    @stable ICU 3.0
-  */
-U_STABLE UBool U_EXPORT2 
-uregex_lookingAt(URegularExpression *regexp,
-                 int32_t             startIndex,
-                 UErrorCode         *status);
-
-/**
-  *   Find the first matching substring of the input string that matches the pattern.
-  *   If startIndex is >= zero the search for a match begins at the specified index,
-  *          and any match region is reset.  This corresponds directly with
-  *          Matcher.find(startIndex) in Java.
-  *
-  *   If startIndex == -1 the search begins at the start of the input region,
-  *           or at the start of the full string if no region has been specified.
-  *
-  *   If a match is found, <code>uregex_start(), uregex_end()</code>, and
-  *   <code>uregex_group()</code> will provide more information regarding the match.
-  *
-  *   @param   regexp      The compiled regular expression.
-  *   @param   startIndex  The position in the input string to begin the search, or
-  *                        -1 to search within the Input Region.
-  *   @param   status      A reference to a UErrorCode to receive any errors.
-  *   @return              TRUE if a match is found.
-  *   @stable ICU 3.0
-  */
-U_STABLE UBool U_EXPORT2 
-uregex_find(URegularExpression *regexp,
-            int32_t             startIndex, 
-            UErrorCode         *status);
-
-/**
-  *  Find the next pattern match in the input string.  Begin searching 
-  *  the input at the location following the end of he previous match, 
-  *  or at the start of the string (or region) if there is no 
-  *  previous match.  If a match is found, <code>uregex_start(), uregex_end()</code>, and
-  *  <code>uregex_group()</code> will provide more information regarding the match.
-  *
-  *  @param   regexp      The compiled regular expression.
-  *  @param   status      A reference to a UErrorCode to receive any errors.
-  *  @return              TRUE if a match is found.
-  *  @see uregex_reset
-  *  @stable ICU 3.0
-  */
-U_STABLE UBool U_EXPORT2 
-uregex_findNext(URegularExpression *regexp,
-                UErrorCode         *status);
-
-/**
-  *   Get the number of capturing groups in this regular expression's pattern.
-  *   @param   regexp      The compiled regular expression.
-  *   @param   status      A reference to a UErrorCode to receive any errors.
-  *   @return the number of capture groups
-  *   @stable ICU 3.0
-  */
-U_STABLE int32_t U_EXPORT2 
-uregex_groupCount(URegularExpression *regexp,
-                  UErrorCode         *status);
-
-/** Extract the string for the specified matching expression or subexpression.
-  * Group #0 is the complete string of matched text.
-  * Group #1 is the text matched by the first set of capturing parentheses.
-  *
-  *   @param   regexp       The compiled regular expression.
-  *   @param   groupNum     The capture group to extract.  Group 0 is the complete
-  *                         match.  The value of this parameter must be
-  *                         less than or equal to the number of capture groups in
-  *                         the pattern.
-  *   @param   dest         Buffer to receive the matching string data
-  *   @param   destCapacity Capacity of the dest buffer.
-  *   @param   status       A reference to a UErrorCode to receive any errors.
-  *   @return               Length of matching data,
-  *                         or -1 if no applicable match.
-  *   @stable ICU 3.0
-  */
-U_STABLE int32_t U_EXPORT2 
-uregex_group(URegularExpression *regexp,
-             int32_t             groupNum,
-             UChar              *dest,
-             int32_t             destCapacity,
-             UErrorCode          *status);
-
-
-/**
-  *   Returns the index in the input string of the start of the text matched by the
-  *   specified capture group during the previous match operation.  Return -1 if
-  *   the capture group was not part of the last match.
-  *   Group #0 refers to the complete range of matched text.
-  *   Group #1 refers to the text matched by the first set of capturing parentheses.
-  *
-  *    @param   regexp      The compiled regular expression.
-  *    @param   groupNum    The capture group number
-  *    @param   status      A reference to a UErrorCode to receive any errors.
-  *    @return              the starting position in the input of the text matched 
-  *                         by the specified group.
-  *    @stable ICU 3.0
-  */
-U_STABLE int32_t U_EXPORT2 
-uregex_start(URegularExpression *regexp,
-             int32_t             groupNum,
-             UErrorCode          *status);
-
-/**
-  *   Returns the index in the input string of the position following the end
-  *   of the text matched by the specified capture group.
-  *   Return -1 if the capture group was not part of the last match.
-  *   Group #0 refers to the complete range of matched text.
-  *   Group #1 refers to the text matched by the first set of capturing parentheses.
-  *
-  *    @param   regexp      The compiled regular expression.
-  *    @param   groupNum    The capture group number
-  *    @param   status      A reference to a UErrorCode to receive any errors.
-  *    @return              the index of the position following the last matched character.
-  *    @stable ICU 3.0
-  */
-U_STABLE int32_t U_EXPORT2 
-uregex_end(URegularExpression   *regexp,
-           int32_t               groupNum,
-           UErrorCode           *status);
-
-/**
-  *  Reset any saved state from the previous match.  Has the effect of
-  *  causing uregex_findNext to begin at the specified index, and causing
-  *  uregex_start(), uregex_end() and uregex_group() to return an error 
-  *  indicating that there is no match information available.  Clears any
-  *  match region that may have been set.
-  *
-  *    @param   regexp      The compiled regular expression.
-  *    @param   index       The position in the text at which a
-  *                         uregex_findNext() should begin searching.
-  *    @param   status      A reference to a UErrorCode to receive any errors.
-  *    @stable ICU 3.0
-  */
-U_STABLE void U_EXPORT2 
-uregex_reset(URegularExpression    *regexp,
-             int32_t               index,
-             UErrorCode            *status);
-             
-             
-/** Sets the limits of the matching region for this URegularExpression.
-  * The region is the part of the input string that will be considered when matching.
-  * Invoking this method resets any saved state from the previous match, 
-  * then sets the region to start at the index specified by the start parameter
-  * and end at the index specified by the end parameter.
-  *
-  * Depending on the transparency and anchoring being used (see useTransparentBounds
-  * and useAnchoringBounds), certain constructs such as anchors may behave differently
-  * at or around the boundaries of the region
-  *
-  * The function will fail if start is greater than limit, or if either index
-  *  is less than zero or greater than the length of the string being matched.
-  *
-  * @param regexp The compiled regular expression.
-  * @param regionStart  The index to begin searches at.
-  * @param regionLimit  The index to end searches at (exclusive).
-  * @param status A pointer to a UErrorCode to receive any errors.
-  * @draft ICU 4.0
-  */
-U_DRAFT void U_EXPORT2
-uregex_setRegion(URegularExpression   *regexp,
-                 int32_t               regionStart,
-                 int32_t               regionLimit,
-                 UErrorCode           *status);
-
-/**
-  * Reports the start index of the matching region. Any matches found are limited to
-  * to the region bounded by regionStart (inclusive) and regionEnd (exclusive).
-  *
-  * @param regexp The compiled regular expression.
-  * @param status A pointer to a UErrorCode to receive any errors.
-  * @return The starting index of this matcher's region.
-  * @draft ICU 4.0
-  */
-U_DRAFT int32_t U_EXPORT2
-uregex_regionStart(const  URegularExpression   *regexp,
-                          UErrorCode           *status);
-
-
-
-/**
-  * Reports the end index (exclusive) of the matching region for this URegularExpression.
-  * Any matches found are limited to to the region bounded by regionStart (inclusive)
-  * and regionEnd (exclusive).
-  *
-  * @param regexp The compiled regular expression.
-  * @param status A pointer to a UErrorCode to receive any errors.
-  * @return The ending point of this matcher's region.
-  * @draft ICU 4.0
-  */
-U_DRAFT int32_t U_EXPORT2
-uregex_regionEnd(const  URegularExpression   *regexp,
-                        UErrorCode           *status);
-
-/**
-  * Queries the transparency of region bounds for this URegularExpression.
-  * See useTransparentBounds for a description of transparent and opaque bounds.
-  * By default, matching boundaries are opaque.
-  *
-  * @param regexp The compiled regular expression.
-  * @param status A pointer to a UErrorCode to receive any errors.
-  * @return TRUE if this matcher is using opaque bounds, false if it is not.
-  * @draft ICU 4.0
-  */
-U_DRAFT UBool U_EXPORT2
-uregex_hasTransparentBounds(const  URegularExpression   *regexp,
-                                   UErrorCode           *status);
-
-
-/**
-  * Sets the transparency of region bounds for this URegularExpression.
-  * Invoking this function with an argument of TRUE will set matches to use transparent bounds.
-  * If the boolean argument is FALSE, then opaque bounds will be used.
-  *
-  * Using transparent bounds, the boundaries of the matching region are transparent
-  * to lookahead, lookbehind, and boundary matching constructs. Those constructs can
-  * see text beyond the boundaries of the region while checking for a match.
-  *
-  * With opaque bounds, no text outside of the matching region is visible to lookahead,
-  * lookbehind, and boundary matching constructs.
-  *
-  * By default, opaque bounds are used.
-  *
-  * @param   regexp The compiled regular expression.
-  * @param   b      TRUE for transparent bounds; FALSE for opaque bounds
-  * @param   status A pointer to a UErrorCode to receive any errors.
-  * @draft   ICU 4.0
-  **/
-U_DRAFT void U_EXPORT2  
-uregex_useTransparentBounds(URegularExpression   *regexp, 
-                            UBool                b,
-                            UErrorCode           *status);
-
-
-/**
-  * Return true if this URegularExpression is using anchoring bounds.
-  * By default, anchoring region bounds are used.
-  *
-  * @param  regexp The compiled regular expression.
-  * @param  status A pointer to a UErrorCode to receive any errors.
-  * @return TRUE if this matcher is using anchoring bounds.
-  * @draft  ICU 4.0
-  */
-U_DRAFT UBool U_EXPORT2
-uregex_hasAnchoringBounds(const  URegularExpression   *regexp,
-                                 UErrorCode           *status);
-
-
-/**
-  * Set whether this URegularExpression is using Anchoring Bounds for its region.
-  * With anchoring bounds, pattern anchors such as ^ and $ will match at the start
-  * and end of the region.  Without Anchoring Bounds, anchors will only match at
-  * the positions they would in the complete text.
-  *
-  * Anchoring Bounds are the default for regions.
-  *
-  * @param regexp The compiled regular expression.
-  * @param b      TRUE if to enable anchoring bounds; FALSE to disable them.
-  * @param status A pointer to a UErrorCode to receive any errors.
-  * @draft   ICU 4.0
-  */
-U_DRAFT void U_EXPORT2
-uregex_useAnchoringBounds(URegularExpression   *regexp,
-                          UBool                 b,
-                          UErrorCode           *status);
-
-/**
-  * Return TRUE if the most recent matching operation touched the
-  *  end of the text being processed.  In this case, additional input text could
-  *  change the results of that match.
-  *
-  *  @param regexp The compiled regular expression.
-  *  @param status A pointer to a UErrorCode to receive any errors.
-  *  @return  TRUE if the most recent match hit the end of input
-  *  @draft   ICU 4.0
-  */
-U_DRAFT UBool U_EXPORT2
-uregex_hitEnd(const  URegularExpression   *regexp,
-                     UErrorCode           *status);
-
-/**
-  * Return TRUE the most recent match succeeded and additional input could cause
-  * it to fail. If this function returns false and a match was found, then more input
-  * might change the match but the match won't be lost. If a match was not found,
-  * then requireEnd has no meaning.
-  *
-  * @param regexp The compiled regular expression.
-  * @param status A pointer to a UErrorCode to receive any errors.
-  * @return TRUE  if more input could cause the most recent match to no longer match.
-  * @draft  ICU 4.0
-  */
-U_DRAFT UBool U_EXPORT2   
-uregex_requireEnd(const  URegularExpression   *regexp,
-                         UErrorCode           *status);
-
-
-
-
-
-/**
-  *    Replaces every substring of the input that matches the pattern
-  *    with the given replacement string.  This is a convenience function that
-  *    provides a complete find-and-replace-all operation.
-  *
-  *    This method scans the input string looking for matches of the pattern. 
-  *    Input that is not part of any match is copied unchanged to the
-  *    destination buffer.  Matched regions are replaced in the output
-  *    buffer by the replacement string.   The replacement string may contain
-  *    references to capture groups; these take the form of $1, $2, etc.
-  *
-  *    @param   regexp             The compiled regular expression.
-  *    @param   replacementText    A string containing the replacement text.
-  *    @param   replacementLength  The length of the replacement string, or
-  *                                -1 if it is NUL terminated.
-  *    @param   destBuf            A (UChar *) buffer that will receive the result.
-  *    @param   destCapacity       The capacity of the desitnation buffer.
-  *    @param   status             A reference to a UErrorCode to receive any errors.
-  *    @return                     The length of the string resulting from the find
-  *                                and replace operation.  In the event that the
-  *                                destination capacity is inadequate, the return value
-  *                                is still the full length of the untruncated string.
-  *    @stable ICU 3.0
-  */
-U_STABLE int32_t U_EXPORT2 
-uregex_replaceAll(URegularExpression    *regexp,
-                  const UChar           *replacementText,
-                  int32_t                replacementLength,
-                  UChar                 *destBuf,
-                  int32_t                destCapacity,
-                  UErrorCode            *status);
-
-
-/**
-  *    Replaces the first substring of the input that matches the pattern
-  *    with the given replacement string.  This is a convenience function that
-  *    provides a complete find-and-replace operation.
-  *
-  *    This method scans the input string looking for a match of the pattern. 
-  *    All input that is not part of the match is copied unchanged to the
-  *    destination buffer.  The matched region is replaced in the output
-  *    buffer by the replacement string.   The replacement string may contain
-  *    references to capture groups; these take the form of $1, $2, etc.
-  *
-  *    @param   regexp             The compiled regular expression.
-  *    @param   replacementText    A string containing the replacement text.
-  *    @param   replacementLength  The length of the replacement string, or
-  *                                -1 if it is NUL terminated.
-  *    @param   destBuf            A (UChar *) buffer that will receive the result.
-  *    @param   destCapacity       The capacity of the desitnation buffer.
-  *    @param   status             a reference to a UErrorCode to receive any errors.
-  *    @return                     The length of the string resulting from the find
-  *                                and replace operation.  In the event that the
-  *                                destination capacity is inadequate, the return value
-  *                                is still the full length of the untruncated string.
-  *    @stable ICU 3.0
-  */
-U_STABLE int32_t U_EXPORT2 
-uregex_replaceFirst(URegularExpression  *regexp,
-                    const UChar         *replacementText,
-                    int32_t              replacementLength,
-                    UChar               *destBuf,
-                    int32_t              destCapacity,
-                    UErrorCode          *status);
-
-
-/**
-  *   Implements a replace operation intended to be used as part of an
-  *   incremental find-and-replace.
-  *
-  *   <p>The input string, starting from the end of the previous match and ending at
-  *   the start of the current match, is appended to the destination string.  Then the
-  *   replacement string is appended to the output string,
-  *   including handling any substitutions of captured text.</p>
-  *
-  *   <p>A note on preflight computation of buffersize and error handling:
-  *   Calls to uregex_appendReplacement() and uregex_appendTail() are
-  *   designed to be chained, one after another, with the destination
-  *   buffer pointer and buffer capacity updated after each in preparation
-  *   to for the next.  If the destination buffer is exhausted partway through such a
-  *   sequence, a U_BUFFER_OVERFLOW_ERROR status will be returned.  Normal
-  *   ICU conventions are for a function to perform no action if it is
-  *   called with an error status, but for this one case, uregex_appendRepacement()
-  *   will operate normally so that buffer size computations will complete
-  *   correctly.
-  *
-  *   <p>For simple, prepackaged, non-incremental find-and-replace
-  *      operations, see replaceFirst() or replaceAll().</p>
-  *
-  *   @param   regexp      The regular expression object.  
-  *   @param   replacementText The string that will replace the matched portion of the
-  *                        input string as it is copied to the destination buffer.
-  *                        The replacement text may contain references ($1, for
-  *                        example) to capture groups from the match.
-  *   @param   replacementLength  The length of the replacement text string,
-  *                        or -1 if the string is NUL terminated.
-  *   @param   destBuf     The buffer into which the results of the
-  *                        find-and-replace are placed.  On return, this pointer
-  *                        will be updated to refer to the beginning of the
-  *                        unused portion of buffer, leaving it in position for
-  *                        a subsequent call to this function.
-  *   @param   destCapacity The size of the output buffer,  On return, this
-  *                        parameter will be updated to reflect the space remaining
-  *                        unused in the output buffer.
-  *   @param   status      A reference to a UErrorCode to receive any errors. 
-  *   @return              The length of the result string.  In the event that
-  *                        destCapacity is inadequate, the full length of the
-  *                        untruncated output string is returned.
-  *
-  *   @stable ICU 3.0
-  *
-  */
-U_STABLE int32_t U_EXPORT2 
-uregex_appendReplacement(URegularExpression    *regexp,
-                  const UChar           *replacementText,
-                  int32_t                replacementLength,
-                  UChar                **destBuf,
-                  int32_t               *destCapacity,
-                  UErrorCode            *status);
-
-
-/**
-  * As the final step in a find-and-replace operation, append the remainder
-  * of the input string, starting at the position following the last match,
-  * to the destination string. <code>uregex_appendTail()</code> is intended 
-  *  to be invoked after one or more invocations of the
-  *  <code>uregex_appendReplacement()</code> function.
-  *
-  *   @param   regexp      The regular expression object.  This is needed to 
-  *                        obtain the input string and with the position
-  *                        of the last match within it.
-  *   @param   destBuf     The buffer in which the results of the
-  *                        find-and-replace are placed.  On return, the pointer
-  *                        will be updated to refer to the beginning of the
-  *                        unused portion of buffer.
-  *   @param   destCapacity The size of the output buffer,  On return, this
-  *                        value will be updated to reflect the space remaining
-  *                        unused in the output buffer.
-  *   @param   status      A reference to a UErrorCode to receive any errors. 
-  *   @return              The length of the result string.  In the event that
-  *                        destCapacity is inadequate, the full length of the
-  *                        untruncated output string is returned.
-  *
-  *   @stable ICU 3.0
-  */
-U_STABLE int32_t U_EXPORT2 
-uregex_appendTail(URegularExpression    *regexp,
-                  UChar                **destBuf,
-                  int32_t               *destCapacity,
-                  UErrorCode            *status);
-
-
-
-
- /**
-   * Split a string into fields.  Somewhat like split() from Perl.
-   *  The pattern matches identify delimiters that separate the input
-   *  into fields.  The input data between the matches becomes the
-   *  fields themselves.
-   * <p>
-   *  Each of the fields is copied from the input string to the destination
-   *  buffer, and the NUL terminated.  The position of each field within
-   *  the destination buffer is returned in the destFields array.
-   *
-   *  Note:  another choice for the design of this function would be to not
-   *         copy the resulting fields at all, but to return indexes and
-   *         lengths within the source text.  
-   *           Advantages would be
-   *             o  Faster.  No Copying.
-   *             o  Nothing extra needed when field data may contain embedded NUL chars.
-   *             o  Less memory needed if working on large data.
-   *           Disadvantages
-   *             o  Less consistent with C++ split, which copies into an
-   *                array of UnicodeStrings.
-   *             o  No NUL termination, extracted fields would be less convenient
-   *                to use in most cases.
-   *             o  Possible problems in the future, when support Unicode Normalization
-   *                could cause the fields to not correspond exactly to
-   *                a range of the source text.
-   * 
-   *    @param   regexp      The compiled regular expression.
-   *    @param   destBuf     A (UChar *) buffer to receive the fields that
-   *                         are extracted from the input string. These
-   *                         field pointers will refer to positions within the
-   *                         destination buffer supplied by the caller.  Any
-   *                         extra positions within the destFields array will be
-   *                         set to NULL.
-   *    @param   destCapacity The capacity of the destBuf.
-   *    @param   requiredCapacity  The actual capacity required of the destBuf.
-   *                         If destCapacity is too small, requiredCapacity will return 
-   *                         the total capacity required to hold all of the output, and
-   *                         a U_BUFFER_OVERFLOW_ERROR will be returned.
-   *    @param   destFields  An array to be filled with the position of each
-   *                         of the extracted fields within destBuf.
-   *    @param   destFieldsCapacity  The number of elements in the destFields array.
-   *                If the number of fields found is less than destFieldsCapacity,
-   *                the extra destFields elements are set to zero.
-   *                If destFieldsCapacity is too small, the trailing part of the
-   *                input, including any field delimiters, is treated as if it
-   *                were the last field - it is copied to the destBuf, and
-   *                its position is in the destBuf is stored in the last element
-   *                of destFields.  This behavior mimics that of Perl.  It is not
-   *                an error condition, and no error status is returned when all destField
-   *                positions are used.
-   * @param status  A reference to a UErrorCode to receive any errors.
-   * @return        The number of fields into which the input string was split.
-   * @stable ICU 3.0
-   */
-U_STABLE int32_t U_EXPORT2 
-uregex_split(   URegularExpression      *regexp,
-                  UChar                 *destBuf,
-                  int32_t                destCapacity,
-                  int32_t               *requiredCapacity,
-                  UChar                 *destFields[],
-                  int32_t                destFieldsCapacity,
-                  UErrorCode            *status);
-
-
-
-
-/**
- * Set a processing time limit for match operations with this URegularExpression.
- *
- * Some patterns, when matching certain strings, can run in exponential time.
- * For practical purposes, the match operation may appear to be in an
- * infinite loop.
- * When a limit is set a match operation will fail with an error if the
- * limit is exceeded.
- * <p>
- * The units of the limit are steps of the match engine.
- * Correspondence with actual processor time will depend on the speed
- * of the processor and the details of the specific pattern, but will
- * typically be on the order of milliseconds.
- * <p>
- * By default, the matching time is not limited.
- * <p>
- *
- * @param   regexp      The compiled regular expression.
- * @param   limit       The limit value, or 0 for no limit.
- * @param   status      A reference to a UErrorCode to receive any errors.
- * @draft ICU 4.0
- */
-U_DRAFT void U_EXPORT2
-uregex_setTimeLimit(URegularExpression      *regexp,
-                    int32_t                  limit,
-                    UErrorCode              *status);
-
-/**
- * Get the time limit for for matches with this URegularExpression.
- * A return value of zero indicates that there is no limit.
- *
- * @param   regexp      The compiled regular expression.
- * @param   status      A reference to a UErrorCode to receive any errors.
- * @return the maximum allowed time for a match, in units of processing steps.
- * @draft ICU 4.0
- */
-U_DRAFT int32_t U_EXPORT2
-uregex_getTimeLimit(const URegularExpression      *regexp,
-                          UErrorCode              *status);
-
-/**
- * Set the amount of heap storage avaliable for use by the match backtracking stack.
- * <p>
- * ICU uses a backtracking regular expression engine, with the backtrack stack
- * maintained on the heap.  This function sets the limit to the amount of memory
- * that can be used  for this purpose.  A backtracking stack overflow will
- * result in an error from the match operation that caused it.
- * <p>
- * A limit is desirable because a malicious or poorly designed pattern can use
- * excessive memory, potentially crashing the process.  A limit is enabled
- * by default.
- * <p>
- * @param   regexp      The compiled regular expression.
- * @param   limit       The maximum size, in bytes, of the matching backtrack stack.
- *                      A value of -1 means no limit.
- *                      The limit must be greater than zero, or -1.
- * @param   status      A reference to a UErrorCode to receive any errors.
- *
- * @draft ICU 4.0
- */
-U_DRAFT void U_EXPORT2
-uregex_setStackLimit(URegularExpression      *regexp,
-                     int32_t                  limit,
-                     UErrorCode              *status);
-
-/**
- * Get the size of the heap storage available for use by the back tracking stack.
- *
- * @return  the maximum backtracking stack size, in bytes, or zero if the
- *          stack size is unlimited.
- * @draft ICU 4.0
- */
-U_DRAFT int32_t U_EXPORT2
-uregex_getStackLimit(const URegularExpression      *regexp,
-                           UErrorCode              *status);
-
-
-/**
- * Function pointer for a regular expression matching callback function.
- * When set, a callback function will be called periodically during matching
- * operations.  If the call back function returns FALSE, the matching
- * operation will be terminated early.
- *
- * Note:  the callback function must not call other functions on this
- *        URegularExpression.
- *
- * @param context  context pointer.  The callback function will be invoked
- *                 with the context specified at the time that
- *                 uregex_setMatchCallback() is called.
- * @param steps    the accumulated processing time, in match steps, 
- *                 for this matching operation.
- * @return         TRUE to continue the matching operation.
- *                 FALSE to terminate the matching operation.
- * @draft ICU 4.0
- */
-U_CDECL_BEGIN
-typedef UBool U_CALLCONV URegexMatchCallback (
-                   const void *context,
-                   int32_t     steps);
-U_CDECL_END
-
-/**
- * Set a callback function for this URegularExpression.
- * During matching operations the function will be called periodically,
- * giving the application the opportunity to terminate a long-running
- * match.
- *
- * @param   regexp      The compiled regular expression.
- * @param   callback    A pointer to the user-supplied callback function.
- * @param   context     User context pointer.  The value supplied at the
- *                      time the callback function is set will be saved
- *                      and passed to the callback each time that it is called.
- * @param   status      A reference to a UErrorCode to receive any errors.
- * @draft ICU 4.0
- */
-U_DRAFT void U_EXPORT2
-uregex_setMatchCallback(URegularExpression      *regexp,
-                        URegexMatchCallback     *callback,
-                        const void              *context,
-                        UErrorCode              *status);
-
-
-/**
- *  Get the callback function for this URegularExpression.
- *
- * @param   regexp      The compiled regular expression.
- * @param   callback    Out paramater, receives a pointer to the user-supplied 
- *                      callback function.
- * @param   context     Out parameter, receives the user context pointer that
- *                      was set when uregex_setMatchCallback() was called.
- * @param   status      A reference to a UErrorCode to receive any errors.
- * @draft ICU 4.0
- */
-U_DRAFT void U_EXPORT2
-uregex_getMatchCallback(const URegularExpression    *regexp,
-                        URegexMatchCallback        **callback,
-                        const void                 **context,
-                        UErrorCode                  *status);
-
-
-
-#endif   /*  !UCONFIG_NO_REGULAR_EXPRESSIONS  */
-#endif   /*  UREGEX_H  */


[06/57] [abbrv] remove couch_collate

Posted by be...@apache.org.
http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/usearch.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/usearch.h b/apps/couch_collate/platform/osx/icu/unicode/usearch.h
deleted file mode 100644
index deaa78f..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/usearch.h
+++ /dev/null
@@ -1,766 +0,0 @@
-/*
-**********************************************************************
-*   Copyright (C) 2001-2008 IBM and others. All rights reserved.
-**********************************************************************
-*   Date        Name        Description
-*  06/28/2001   synwee      Creation.
-**********************************************************************
-*/
-#ifndef USEARCH_H
-#define USEARCH_H
-
-#include "unicode/utypes.h"
-
-#if !UCONFIG_NO_COLLATION && !UCONFIG_NO_BREAK_ITERATION
-
-#include "unicode/ucol.h"
-#include "unicode/ucoleitr.h"
-#include "unicode/ubrk.h"
-
-/**
- * \file
- * \brief C API: StringSearch
- *
- * C Apis for an engine that provides language-sensitive text searching based 
- * on the comparison rules defined in a <tt>UCollator</tt> data struct,
- * see <tt>ucol.h</tt>. This ensures that language eccentricity can be 
- * handled, e.g. for the German collator, characters &szlig; and SS will be matched 
- * if case is chosen to be ignored. 
- * See the <a href="http://source.icu-project.org/repos/icu/icuhtml/trunk/design/collation/ICU_collation_design.htm">
- * "ICU Collation Design Document"</a> for more information.
- * <p> 
- * The algorithm implemented is a modified form of the Boyer Moore's search.
- * For more information  see 
- * <a href="http://icu-project.org/docs/papers/efficient_text_searching_in_java.html">
- * "Efficient Text Searching in Java"</a>, published in <i>Java Report</i> 
- * in February, 1999, for further information on the algorithm.
- * <p>
- * There are 2 match options for selection:<br>
- * Let S' be the sub-string of a text string S between the offsets start and 
- * end <start, end>.
- * <br>
- * A pattern string P matches a text string S at the offsets <start, end> 
- * if
- * <pre> 
- * option 1. Some canonical equivalent of P matches some canonical equivalent 
- *           of S'
- * option 2. P matches S' and if P starts or ends with a combining mark, 
- *           there exists no non-ignorable combining mark before or after S' 
- *           in S respectively. 
- * </pre>
- * Option 2. will be the default.
- * <p>
- * This search has APIs similar to that of other text iteration mechanisms 
- * such as the break iterators in <tt>ubrk.h</tt>. Using these 
- * APIs, it is easy to scan through text looking for all occurances of 
- * a given pattern. This search iterator allows changing of direction by 
- * calling a <tt>reset</tt> followed by a <tt>next</tt> or <tt>previous</tt>. 
- * Though a direction change can occur without calling <tt>reset</tt> first,  
- * this operation comes with some speed penalty.
- * Generally, match results in the forward direction will match the result 
- * matches in the backwards direction in the reverse order
- * <p>
- * <tt>usearch.h</tt> provides APIs to specify the starting position 
- * within the text string to be searched, e.g. <tt>usearch_setOffset</tt>,
- * <tt>usearch_preceding</tt> and <tt>usearch_following</tt>. Since the 
- * starting position will be set as it is specified, please take note that 
- * there are some dangerous positions which the search may render incorrect 
- * results:
- * <ul>
- * <li> The midst of a substring that requires normalization.
- * <li> If the following match is to be found, the position should not be the
- *      second character which requires to be swapped with the preceding 
- *      character. Vice versa, if the preceding match is to be found, 
- *      position to search from should not be the first character which 
- *      requires to be swapped with the next character. E.g certain Thai and
- *      Lao characters require swapping.
- * <li> If a following pattern match is to be found, any position within a 
- *      contracting sequence except the first will fail. Vice versa if a 
- *      preceding pattern match is to be found, a invalid starting point 
- *      would be any character within a contracting sequence except the last.
- * </ul>
- * <p>
- * A breakiterator can be used if only matches at logical breaks are desired.
- * Using a breakiterator will only give you results that exactly matches the
- * boundaries given by the breakiterator. For instance the pattern "e" will
- * not be found in the string "\u00e9" if a character break iterator is used.
- * <p>
- * Options are provided to handle overlapping matches. 
- * E.g. In English, overlapping matches produces the result 0 and 2 
- * for the pattern "abab" in the text "ababab", where else mutually 
- * exclusive matches only produce the result of 0.
- * <p>
- * Though collator attributes will be taken into consideration while 
- * performing matches, there are no APIs here for setting and getting the 
- * attributes. These attributes can be set by getting the collator
- * from <tt>usearch_getCollator</tt> and using the APIs in <tt>ucol.h</tt>.
- * Lastly to update String Search to the new collator attributes, 
- * usearch_reset() has to be called.
- * <p> 
- * Restriction: <br>
- * Currently there are no composite characters that consists of a
- * character with combining class > 0 before a character with combining 
- * class == 0. However, if such a character exists in the future, the 
- * search mechanism does not guarantee the results for option 1.
- * 
- * <p>
- * Example of use:<br>
- * <pre><code>
- * char *tgtstr = "The quick brown fox jumped over the lazy fox";
- * char *patstr = "fox";
- * UChar target[64];
- * UChar pattern[16];
- * UErrorCode status = U_ZERO_ERROR;
- * u_uastrcpy(target, tgtstr);
- * u_uastrcpy(pattern, patstr);
- *
- * UStringSearch *search = usearch_open(pattern, -1, target, -1, "en_US", 
- *                                  NULL, &status);
- * if (U_SUCCESS(status)) {
- *     for (int pos = usearch_first(search, &status); 
- *          pos != USEARCH_DONE; 
- *          pos = usearch_next(search, &status))
- *     {
- *         printf("Found match at %d pos, length is %d\n", pos, 
- *                                        usearch_getMatchLength(search));
- *     }
- * }
- *
- * usearch_close(search);
- * </code></pre>
- * @stable ICU 2.4
- */
-
-/**
-* DONE is returned by previous() and next() after all valid matches have 
-* been returned, and by first() and last() if there are no matches at all.
-* @stable ICU 2.4
-*/
-#define USEARCH_DONE -1
-
-/**
-* Data structure for searching
-* @stable ICU 2.4
-*/
-struct UStringSearch;
-/**
-* Data structure for searching
-* @stable ICU 2.4
-*/
-typedef struct UStringSearch UStringSearch;
-
-/**
-* @stable ICU 2.4
-*/
-typedef enum {
-    /** Option for overlapping matches */
-    USEARCH_OVERLAP,
-    /** 
-    Option for canonical matches. option 1 in header documentation.
-    The default value will be USEARCH_OFF
-    */
-    USEARCH_CANONICAL_MATCH,
-    USEARCH_ATTRIBUTE_COUNT
-} USearchAttribute;
-
-/**
-* @stable ICU 2.4
-*/
-typedef enum {
-    /** default value for any USearchAttribute */
-    USEARCH_DEFAULT = -1,
-    /** value for USEARCH_OVERLAP and USEARCH_CANONICAL_MATCH */
-    USEARCH_OFF, 
-    /** value for USEARCH_OVERLAP and USEARCH_CANONICAL_MATCH */
-    USEARCH_ON,
-    USEARCH_ATTRIBUTE_VALUE_COUNT
-} USearchAttributeValue;
-
-/* open and close ------------------------------------------------------ */
-
-/**
-* Creating a search iterator data struct using the argument locale language
-* rule set. A collator will be created in the process, which will be owned by
-* this search and will be deleted in <tt>usearch_close</tt>.
-* @param pattern for matching
-* @param patternlength length of the pattern, -1 for null-termination
-* @param text text string
-* @param textlength length of the text string, -1 for null-termination
-* @param locale name of locale for the rules to be used
-* @param breakiter A BreakIterator that will be used to restrict the points
-*                  at which matches are detected. If a match is found, but 
-*                  the match's start or end index is not a boundary as 
-*                  determined by the <tt>BreakIterator</tt>, the match will 
-*                  be rejected and another will be searched for. 
-*                  If this parameter is <tt>NULL</tt>, no break detection is 
-*                  attempted.
-* @param status for errors if it occurs. If pattern or text is NULL, or if
-*               patternlength or textlength is 0 then an 
-*               U_ILLEGAL_ARGUMENT_ERROR is returned.
-* @return search iterator data structure, or NULL if there is an error.
-* @stable ICU 2.4
-*/
-U_STABLE UStringSearch * U_EXPORT2 usearch_open(const UChar          *pattern, 
-                                              int32_t         patternlength, 
-                                        const UChar          *text, 
-                                              int32_t         textlength,
-                                        const char           *locale,
-                                              UBreakIterator *breakiter,
-                                              UErrorCode     *status);
-
-/**
-* Creating a search iterator data struct using the argument collator language
-* rule set. Note, user retains the ownership of this collator, thus the 
-* responsibility of deletion lies with the user.
-* NOTE: string search cannot be instantiated from a collator that has 
-* collate digits as numbers (CODAN) turned on.
-* @param pattern for matching
-* @param patternlength length of the pattern, -1 for null-termination
-* @param text text string
-* @param textlength length of the text string, -1 for null-termination
-* @param collator used for the language rules
-* @param breakiter A BreakIterator that will be used to restrict the points
-*                  at which matches are detected. If a match is found, but 
-*                  the match's start or end index is not a boundary as 
-*                  determined by the <tt>BreakIterator</tt>, the match will 
-*                  be rejected and another will be searched for. 
-*                  If this parameter is <tt>NULL</tt>, no break detection is 
-*                  attempted.
-* @param status for errors if it occurs. If collator, pattern or text is NULL, 
-*               or if patternlength or textlength is 0 then an 
-*               U_ILLEGAL_ARGUMENT_ERROR is returned.
-* @return search iterator data structure, or NULL if there is an error.
-* @stable ICU 2.4
-*/
-U_STABLE UStringSearch * U_EXPORT2 usearch_openFromCollator(
-                                         const UChar *pattern, 
-                                               int32_t         patternlength,
-                                         const UChar          *text, 
-                                               int32_t         textlength,
-                                         const UCollator      *collator,
-                                               UBreakIterator *breakiter,
-                                               UErrorCode     *status);
-
-/**
-* Destroying and cleaning up the search iterator data struct.
-* If a collator is created in <tt>usearch_open</tt>, it will be destroyed here.
-* @param searchiter data struct to clean up
-* @stable ICU 2.4
-*/
-U_STABLE void U_EXPORT2 usearch_close(UStringSearch *searchiter);
-
-/* get and set methods -------------------------------------------------- */
-
-/**
-* Sets the current position in the text string which the next search will 
-* start from. Clears previous states. 
-* This method takes the argument index and sets the position in the text 
-* string accordingly without checking if the index is pointing to a 
-* valid starting point to begin searching. 
-* Search positions that may render incorrect results are highlighted in the
-* header comments
-* @param strsrch search iterator data struct
-* @param position position to start next search from. If position is less
-*          than or greater than the text range for searching, 
-*          an U_INDEX_OUTOFBOUNDS_ERROR will be returned
-* @param status error status if any.
-* @stable ICU 2.4
-*/
-U_STABLE void U_EXPORT2 usearch_setOffset(UStringSearch *strsrch, 
-                                        int32_t    position,
-                                        UErrorCode    *status);
-
-/**
-* Return the current index in the string text being searched.
-* If the iteration has gone past the end of the text (or past the beginning 
-* for a backwards search), <tt>USEARCH_DONE</tt> is returned.
-* @param strsrch search iterator data struct
-* @see #USEARCH_DONE
-* @stable ICU 2.4
-*/
-U_STABLE int32_t U_EXPORT2 usearch_getOffset(const UStringSearch *strsrch);
-    
-/**
-* Sets the text searching attributes located in the enum USearchAttribute
-* with values from the enum USearchAttributeValue.
-* <tt>USEARCH_DEFAULT</tt> can be used for all attributes for resetting.
-* @param strsrch search iterator data struct
-* @param attribute text attribute to be set
-* @param value text attribute value
-* @param status for errors if it occurs
-* @see #usearch_getAttribute
-* @stable ICU 2.4
-*/
-U_STABLE void U_EXPORT2 usearch_setAttribute(UStringSearch         *strsrch, 
-                                           USearchAttribute       attribute,
-                                           USearchAttributeValue  value,
-                                           UErrorCode            *status);
-
-/**    
-* Gets the text searching attributes.
-* @param strsrch search iterator data struct
-* @param attribute text attribute to be retrieve
-* @return text attribute value
-* @see #usearch_setAttribute
-* @stable ICU 2.4
-*/
-U_STABLE USearchAttributeValue U_EXPORT2 usearch_getAttribute(
-                                         const UStringSearch    *strsrch,
-                                               USearchAttribute  attribute);
-
-/**
-* Returns the index to the match in the text string that was searched.
-* This call returns a valid result only after a successful call to 
-* <tt>usearch_first</tt>, <tt>usearch_next</tt>, <tt>usearch_previous</tt>, 
-* or <tt>usearch_last</tt>.
-* Just after construction, or after a searching method returns 
-* <tt>USEARCH_DONE</tt>, this method will return <tt>USEARCH_DONE</tt>.
-* <p>
-* Use <tt>usearch_getMatchedLength</tt> to get the matched string length.
-* @param strsrch search iterator data struct
-* @return index to a substring within the text string that is being 
-*         searched.
-* @see #usearch_first
-* @see #usearch_next
-* @see #usearch_previous
-* @see #usearch_last
-* @see #USEARCH_DONE
-* @stable ICU 2.4
-*/
-U_STABLE int32_t U_EXPORT2 usearch_getMatchedStart(
-                                               const UStringSearch *strsrch);
-    
-/**
-* Returns the length of text in the string which matches the search pattern. 
-* This call returns a valid result only after a successful call to 
-* <tt>usearch_first</tt>, <tt>usearch_next</tt>, <tt>usearch_previous</tt>, 
-* or <tt>usearch_last</tt>.
-* Just after construction, or after a searching method returns 
-* <tt>USEARCH_DONE</tt>, this method will return 0.
-* @param strsrch search iterator data struct
-* @return The length of the match in the string text, or 0 if there is no 
-*         match currently.
-* @see #usearch_first
-* @see #usearch_next
-* @see #usearch_previous
-* @see #usearch_last
-* @see #USEARCH_DONE
-* @stable ICU 2.4
-*/
-U_STABLE int32_t U_EXPORT2 usearch_getMatchedLength(
-                                               const UStringSearch *strsrch);
-
-/**
-* Returns the text that was matched by the most recent call to 
-* <tt>usearch_first</tt>, <tt>usearch_next</tt>, <tt>usearch_previous</tt>, 
-* or <tt>usearch_last</tt>.
-* If the iterator is not pointing at a valid match (e.g. just after 
-* construction or after <tt>USEARCH_DONE</tt> has been returned, returns
-* an empty string. If result is not large enough to store the matched text,
-* result will be filled with the partial text and an U_BUFFER_OVERFLOW_ERROR 
-* will be returned in status. result will be null-terminated whenever 
-* possible. If the buffer fits the matched text exactly, a null-termination 
-* is not possible, then a U_STRING_NOT_TERMINATED_ERROR set in status.
-* Pre-flighting can be either done with length = 0 or the API 
-* <tt>usearch_getMatchLength</tt>.
-* @param strsrch search iterator data struct
-* @param result UChar buffer to store the matched string
-* @param resultCapacity length of the result buffer
-* @param status error returned if result is not large enough
-* @return exact length of the matched text, not counting the null-termination
-* @see #usearch_first
-* @see #usearch_next
-* @see #usearch_previous
-* @see #usearch_last
-* @see #USEARCH_DONE
-* @stable ICU 2.4
-*/
-U_STABLE int32_t U_EXPORT2 usearch_getMatchedText(const UStringSearch *strsrch, 
-                                            UChar         *result, 
-                                            int32_t        resultCapacity, 
-                                            UErrorCode    *status);
-
-#if !UCONFIG_NO_BREAK_ITERATION
-
-/**
-* Set the BreakIterator that will be used to restrict the points at which 
-* matches are detected.
-* @param strsrch search iterator data struct
-* @param breakiter A BreakIterator that will be used to restrict the points
-*                  at which matches are detected. If a match is found, but 
-*                  the match's start or end index is not a boundary as 
-*                  determined by the <tt>BreakIterator</tt>, the match will 
-*                  be rejected and another will be searched for. 
-*                  If this parameter is <tt>NULL</tt>, no break detection is 
-*                  attempted.
-* @param status for errors if it occurs
-* @see #usearch_getBreakIterator
-* @stable ICU 2.4
-*/
-U_STABLE void U_EXPORT2 usearch_setBreakIterator(UStringSearch  *strsrch, 
-                                               UBreakIterator *breakiter,
-                                               UErrorCode     *status);
-
-/**
-* Returns the BreakIterator that is used to restrict the points at which 
-* matches are detected. This will be the same object that was passed to the 
-* constructor or to <tt>usearch_setBreakIterator</tt>. Note that 
-* <tt>NULL</tt> 
-* is a legal value; it means that break detection should not be attempted.
-* @param strsrch search iterator data struct
-* @return break iterator used
-* @see #usearch_setBreakIterator
-* @stable ICU 2.4
-*/
-U_STABLE const UBreakIterator * U_EXPORT2 usearch_getBreakIterator(
-                                              const UStringSearch *strsrch);
-    
-#endif
-    
-/**
-* Set the string text to be searched. Text iteration will hence begin at the 
-* start of the text string. This method is useful if you want to re-use an 
-* iterator to search for the same pattern within a different body of text.
-* @param strsrch search iterator data struct
-* @param text new string to look for match
-* @param textlength length of the new string, -1 for null-termination
-* @param status for errors if it occurs. If text is NULL, or textlength is 0 
-*               then an U_ILLEGAL_ARGUMENT_ERROR is returned with no change
-*               done to strsrch.
-* @see #usearch_getText
-* @stable ICU 2.4
-*/
-U_STABLE void U_EXPORT2 usearch_setText(      UStringSearch *strsrch, 
-                                      const UChar         *text,
-                                            int32_t        textlength,
-                                            UErrorCode    *status);
-
-/**
-* Return the string text to be searched.
-* @param strsrch search iterator data struct
-* @param length returned string text length
-* @return string text 
-* @see #usearch_setText
-* @stable ICU 2.4
-*/
-U_STABLE const UChar * U_EXPORT2 usearch_getText(const UStringSearch *strsrch, 
-                                               int32_t       *length);
-
-/**
-* Gets the collator used for the language rules. 
-* <p>
-* Deleting the returned <tt>UCollator</tt> before calling 
-* <tt>usearch_close</tt> would cause the string search to fail.
-* <tt>usearch_close</tt> will delete the collator if this search owns it.
-* @param strsrch search iterator data struct
-* @return collator
-* @stable ICU 2.4
-*/
-U_STABLE UCollator * U_EXPORT2 usearch_getCollator(
-                                               const UStringSearch *strsrch);
-
-/**
-* Sets the collator used for the language rules. User retains the ownership 
-* of this collator, thus the responsibility of deletion lies with the user.
-* This method causes internal data such as Boyer-Moore shift tables to  
-* be recalculated, but the iterator's position is unchanged.
-* @param strsrch search iterator data struct
-* @param collator to be used
-* @param status for errors if it occurs
-* @stable ICU 2.4
-*/
-U_STABLE void U_EXPORT2 usearch_setCollator(      UStringSearch *strsrch, 
-                                          const UCollator     *collator,
-                                                UErrorCode    *status);
-
-/**
-* Sets the pattern used for matching.
-* Internal data like the Boyer Moore table will be recalculated, but the 
-* iterator's position is unchanged.
-* @param strsrch search iterator data struct
-* @param pattern string
-* @param patternlength pattern length, -1 for null-terminated string
-* @param status for errors if it occurs. If text is NULL, or textlength is 0 
-*               then an U_ILLEGAL_ARGUMENT_ERROR is returned with no change
-*               done to strsrch.
-* @stable ICU 2.4
-*/
-U_STABLE void U_EXPORT2 usearch_setPattern(      UStringSearch *strsrch, 
-                                         const UChar         *pattern,
-                                               int32_t        patternlength,
-                                               UErrorCode    *status);
-
-/**
-* Gets the search pattern
-* @param strsrch search iterator data struct
-* @param length return length of the pattern, -1 indicates that the pattern 
-*               is null-terminated
-* @return pattern string
-* @stable ICU 2.4
-*/
-U_STABLE const UChar * U_EXPORT2 usearch_getPattern(
-                                               const UStringSearch *strsrch, 
-                                                     int32_t       *length);
-
-/* methods ------------------------------------------------------------- */
-
-/**
-* Returns the first index at which the string text matches the search 
-* pattern.  
-* The iterator is adjusted so that its current index (as returned by 
-* <tt>usearch_getOffset</tt>) is the match position if one was found.
-* If a match is not found, <tt>USEARCH_DONE</tt> will be returned and
-* the iterator will be adjusted to the index <tt>USEARCH_DONE</tt>.
-* @param strsrch search iterator data struct
-* @param status for errors if it occurs
-* @return The character index of the first match, or 
-* <tt>USEARCH_DONE</tt> if there are no matches.
-* @see #usearch_getOffset
-* @see #USEARCH_DONE
-* @stable ICU 2.4
-*/
-U_STABLE int32_t U_EXPORT2 usearch_first(UStringSearch *strsrch, 
-                                           UErrorCode    *status);
-
-/**
-* Returns the first index greater than <tt>position</tt> at which the string 
-* text 
-* matches the search pattern. The iterator is adjusted so that its current 
-* index (as returned by <tt>usearch_getOffset</tt>) is the match position if 
-* one was found.
-* If a match is not found, <tt>USEARCH_DONE</tt> will be returned and
-* the iterator will be adjusted to the index <tt>USEARCH_DONE</tt>
-* <p>
-* Search positions that may render incorrect results are highlighted in the
-* header comments. If position is less than or greater than the text range 
-* for searching, an U_INDEX_OUTOFBOUNDS_ERROR will be returned
-* @param strsrch search iterator data struct
-* @param position to start the search at
-* @param status for errors if it occurs
-* @return The character index of the first match following <tt>pos</tt>,
-*         or <tt>USEARCH_DONE</tt> if there are no matches.
-* @see #usearch_getOffset
-* @see #USEARCH_DONE
-* @stable ICU 2.4
-*/
-U_STABLE int32_t U_EXPORT2 usearch_following(UStringSearch *strsrch, 
-                                               int32_t    position, 
-                                               UErrorCode    *status);
-    
-/**
-* Returns the last index in the target text at which it matches the search 
-* pattern. The iterator is adjusted so that its current 
-* index (as returned by <tt>usearch_getOffset</tt>) is the match position if 
-* one was found.
-* If a match is not found, <tt>USEARCH_DONE</tt> will be returned and
-* the iterator will be adjusted to the index <tt>USEARCH_DONE</tt>.
-* @param strsrch search iterator data struct
-* @param status for errors if it occurs
-* @return The index of the first match, or <tt>USEARCH_DONE</tt> if there 
-*         are no matches.
-* @see #usearch_getOffset
-* @see #USEARCH_DONE
-* @stable ICU 2.4
-*/
-U_STABLE int32_t U_EXPORT2 usearch_last(UStringSearch *strsrch, 
-                                          UErrorCode    *status);
-
-/**
-* Returns the first index less than <tt>position</tt> at which the string text 
-* matches the search pattern. The iterator is adjusted so that its current 
-* index (as returned by <tt>usearch_getOffset</tt>) is the match position if 
-* one was found.
-* If a match is not found, <tt>USEARCH_DONE</tt> will be returned and
-* the iterator will be adjusted to the index <tt>USEARCH_DONE</tt>
-* <p>
-* Search positions that may render incorrect results are highlighted in the
-* header comments. If position is less than or greater than the text range 
-* for searching, an U_INDEX_OUTOFBOUNDS_ERROR will be returned
-* @param strsrch search iterator data struct
-* @param position index position the search is to begin at
-* @param status for errors if it occurs
-* @return The character index of the first match preceding <tt>pos</tt>,
-*         or <tt>USEARCH_DONE</tt> if there are no matches.
-* @see #usearch_getOffset
-* @see #USEARCH_DONE
-* @stable ICU 2.4
-*/
-U_STABLE int32_t U_EXPORT2 usearch_preceding(UStringSearch *strsrch, 
-                                               int32_t    position, 
-                                               UErrorCode    *status);
-    
-/**
-* Returns the index of the next point at which the string text matches the
-* search pattern, starting from the current position.
-* The iterator is adjusted so that its current 
-* index (as returned by <tt>usearch_getOffset</tt>) is the match position if 
-* one was found.
-* If a match is not found, <tt>USEARCH_DONE</tt> will be returned and
-* the iterator will be adjusted to the index <tt>USEARCH_DONE</tt>
-* @param strsrch search iterator data struct
-* @param status for errors if it occurs
-* @return The index of the next match after the current position, or 
-*         <tt>USEARCH_DONE</tt> if there are no more matches.
-* @see #usearch_first
-* @see #usearch_getOffset
-* @see #USEARCH_DONE
-* @stable ICU 2.4
-*/
-U_STABLE int32_t U_EXPORT2 usearch_next(UStringSearch *strsrch, 
-                                          UErrorCode    *status);
-
-/**
-* Returns the index of the previous point at which the string text matches
-* the search pattern, starting at the current position.
-* The iterator is adjusted so that its current 
-* index (as returned by <tt>usearch_getOffset</tt>) is the match position if 
-* one was found.
-* If a match is not found, <tt>USEARCH_DONE</tt> will be returned and
-* the iterator will be adjusted to the index <tt>USEARCH_DONE</tt>
-* @param strsrch search iterator data struct
-* @param status for errors if it occurs
-* @return The index of the previous match before the current position,
-*         or <tt>USEARCH_DONE</tt> if there are no more matches.
-* @see #usearch_last
-* @see #usearch_getOffset
-* @see #USEARCH_DONE
-* @stable ICU 2.4
-*/
-U_STABLE int32_t U_EXPORT2 usearch_previous(UStringSearch *strsrch, 
-                                              UErrorCode    *status);
-    
-/** 
-* Reset the iteration.
-* Search will begin at the start of the text string if a forward iteration 
-* is initiated before a backwards iteration. Otherwise if a backwards 
-* iteration is initiated before a forwards iteration, the search will begin
-* at the end of the text string.
-* @param strsrch search iterator data struct
-* @see #usearch_first
-* @stable ICU 2.4
-*/
-U_STABLE void U_EXPORT2 usearch_reset(UStringSearch *strsrch);
-
-/**
-  *  Simple forward search for the pattern, starting at a specified index,
-  *     and using using a default set search options.
-  *
-  *  This is an experimental function, and is not an official part of the
-  *      ICU API.
-  *
-  *  The collator options, such as UCOL_STRENGTH and UCOL_NORMALIZTION, are honored.
-  *
-  *  The UStringSearch options USEARCH_CANONICAL_MATCH, USEARCH_OVERLAP and
-  *  any Break Iterator are ignored.
-  *
-  *  Matches obey the following constraints:
-  *
-  *      Characters at the start or end positions of a match that are ignorable
-  *      for collation are not included as part of the match, unless they
-  *      are part of a combining sequence, as described below.
-  *
-  *      A match will not include a partial combining sequence.  Combining
-  *      character sequences  are considered to be  inseperable units,
-  *      and either match the pattern completely, or are considered to not match
-  *      at all.  Thus, for example, an A followed a combining accent mark will 
-  *      not be found when searching for a plain (unaccented) A.   (unless
-  *      the collation strength has been set to ignore all accents).
-  *
-  *      When beginning a search, the initial starting position, startIdx,
-  *      is assumed to be an acceptable match boundary with respect to
-  *      combining characters.  A combining sequence that spans across the
-  *      starting point will not supress a match beginning at startIdx.
-  *
-  *      Characters that expand to multiple collation elements
-  *      (German sharp-S becoming 'ss', or the composed forms of accented
-  *      characters, for example) also must match completely.
-  *      Searching for a single 's' in a string containing only a sharp-s will 
-  *      find no match.
-  *
-  *
-  *  @param strsrch    the UStringSearch struct, which references both
-  *                    the text to be searched  and the pattern being sought.
-  *  @param startIdx   The index into the text to begin the search.
-  *  @param matchStart An out parameter, the starting index of the matched text.
-  *                    This parameter may be NULL.
-  *                    A value of -1 will be returned if no match was found.
-  *  @param matchLimit Out parameter, the index of the first position following the matched text.
-  *                    The matchLimit will be at a suitable position for beginning a subsequent search
-  *                    in the input text.
-  *                    This parameter may be NULL.
-  *                    A value of -1 will be returned if no match was found.
-  *          
-  *  @param status     Report any errors.  Note that no match found is not an error.
-  *  @return           TRUE if a match was found, FALSE otherwise.
-  *
-  *  @internal
-  */
-U_INTERNAL UBool U_EXPORT2 usearch_search(UStringSearch *strsrch,
-                                          int32_t        startIdx,
-                                          int32_t        *matchStart,
-                                          int32_t        *matchLimit,
-                                          UErrorCode     *status);
-
-/**
-  *  Simple backwards search for the pattern, starting at a specified index,
-  *     and using using a default set search options.
-  *
-  *  This is an experimental function, and is not an official part of the
-  *      ICU API.
-  *
-  *  The collator options, such as UCOL_STRENGTH and UCOL_NORMALIZTION, are honored.
-  *
-  *  The UStringSearch options USEARCH_CANONICAL_MATCH, USEARCH_OVERLAP and
-  *  any Break Iterator are ignored.
-  *
-  *  Matches obey the following constraints:
-  *
-  *      Characters at the start or end positions of a match that are ignorable
-  *      for collation are not included as part of the match, unless they
-  *      are part of a combining sequence, as described below.
-  *
-  *      A match will not include a partial combining sequence.  Combining
-  *      character sequences  are considered to be  inseperable units,
-  *      and either match the pattern completely, or are considered to not match
-  *      at all.  Thus, for example, an A followed a combining accent mark will 
-  *      not be found when searching for a plain (unaccented) A.   (unless
-  *      the collation strength has been set to ignore all accents).
-  *
-  *      When beginning a search, the initial starting position, startIdx,
-  *      is assumed to be an acceptable match boundary with respect to
-  *      combining characters.  A combining sequence that spans across the
-  *      starting point will not supress a match beginning at startIdx.
-  *
-  *      Characters that expand to multiple collation elements
-  *      (German sharp-S becoming 'ss', or the composed forms of accented
-  *      characters, for example) also must match completely.
-  *      Searching for a single 's' in a string containing only a sharp-s will 
-  *      find no match.
-  *
-  *
-  *  @param strsrch    the UStringSearch struct, which references both
-  *                    the text to be searched  and the pattern being sought.
-  *  @param startIdx   The index into the text to begin the search.
-  *  @param matchStart An out parameter, the starting index of the matched text.
-  *                    This parameter may be NULL.
-  *                    A value of -1 will be returned if no match was found.
-  *  @param matchLimit Out parameter, the index of the first position following the matched text.
-  *                    The matchLimit will be at a suitable position for beginning a subsequent search
-  *                    in the input text.
-  *                    This parameter may be NULL.
-  *                    A value of -1 will be returned if no match was found.
-  *          
-  *  @param status     Report any errors.  Note that no match found is not an error.
-  *  @return           TRUE if a match was found, FALSE otherwise.
-  *
-  *  @internal
-  */
-U_INTERNAL UBool U_EXPORT2 usearch_searchBackwards(UStringSearch *strsrch,
-                                                   int32_t        startIdx,
-                                                   int32_t        *matchStart,
-                                                   int32_t        *matchLimit,
-                                                   UErrorCode     *status);
-
-#endif /* #if !UCONFIG_NO_COLLATION  && !UCONFIG_NO_BREAK_ITERATION */
-
-#endif

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/uset.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/uset.h b/apps/couch_collate/platform/osx/icu/unicode/uset.h
deleted file mode 100644
index 2bbfd7a..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/uset.h
+++ /dev/null
@@ -1,1052 +0,0 @@
-/*
-*******************************************************************************
-*
-*   Copyright (C) 2002-2008, International Business Machines
-*   Corporation and others.  All Rights Reserved.
-*
-*******************************************************************************
-*   file name:  uset.h
-*   encoding:   US-ASCII
-*   tab size:   8 (not used)
-*   indentation:4
-*
-*   created on: 2002mar07
-*   created by: Markus W. Scherer
-*
-*   C version of UnicodeSet.
-*/
-
-
-/**
- * \file
- * \brief C API: Unicode Set
- *
- * <p>This is a C wrapper around the C++ UnicodeSet class.</p>
- */
-
-#ifndef __USET_H__
-#define __USET_H__
-
-#include "unicode/utypes.h"
-#include "unicode/uchar.h"
-
-#ifndef UCNV_H
-struct USet;
-/**
- * A UnicodeSet.  Use the uset_* API to manipulate.  Create with
- * uset_open*, and destroy with uset_close.
- * @stable ICU 2.4
- */
-typedef struct USet USet;
-#endif
-
-/**
- * Bitmask values to be passed to uset_openPatternOptions() or
- * uset_applyPattern() taking an option parameter.
- * @stable ICU 2.4
- */
-enum {
-    /**
-     * Ignore white space within patterns unless quoted or escaped.
-     * @stable ICU 2.4
-     */
-    USET_IGNORE_SPACE = 1,  
-
-    /**
-     * Enable case insensitive matching.  E.g., "[ab]" with this flag
-     * will match 'a', 'A', 'b', and 'B'.  "[^ab]" with this flag will
-     * match all except 'a', 'A', 'b', and 'B'. This performs a full
-     * closure over case mappings, e.g. U+017F for s.
-     *
-     * The resulting set is a superset of the input for the code points but
-     * not for the strings.
-     * It performs a case mapping closure of the code points and adds
-     * full case folding strings for the code points, and reduces strings of
-     * the original set to their full case folding equivalents.
-     *
-     * This is designed for case-insensitive matches, for example
-     * in regular expressions. The full code point case closure allows checking of
-     * an input character directly against the closure set.
-     * Strings are matched by comparing the case-folded form from the closure
-     * set with an incremental case folding of the string in question.
-     *
-     * The closure set will also contain single code points if the original
-     * set contained case-equivalent strings (like U+00DF for "ss" or "Ss" etc.).
-     * This is not necessary (that is, redundant) for the above matching method
-     * but results in the same closure sets regardless of whether the original
-     * set contained the code point or a string.
-     *
-     * @stable ICU 2.4
-     */
-    USET_CASE_INSENSITIVE = 2,  
-
-    /**
-     * Enable case insensitive matching.  E.g., "[ab]" with this flag
-     * will match 'a', 'A', 'b', and 'B'.  "[^ab]" with this flag will
-     * match all except 'a', 'A', 'b', and 'B'. This adds the lower-,
-     * title-, and uppercase mappings as well as the case folding
-     * of each existing element in the set.
-     * @stable ICU 3.2
-     */
-    USET_ADD_CASE_MAPPINGS = 4,
-    
-    /**
-     * Enough for any single-code point set
-     * @internal
-     */
-    USET_SERIALIZED_STATIC_ARRAY_CAPACITY=8
-};
-
-/**
- * Argument values for whether span() and similar functions continue while
- * the current character is contained vs. not contained in the set.
- *
- * The functionality is straightforward for sets with only single code points,
- * without strings (which is the common case):
- * - USET_SPAN_CONTAINED and USET_SPAN_SIMPLE
- *   work the same.
- * - span() and spanBack() partition any string the same way when
- *   alternating between span(USET_SPAN_NOT_CONTAINED) and
- *   span(either "contained" condition).
- * - Using a complemented (inverted) set and the opposite span conditions
- *   yields the same results.
- *
- * When a set contains multi-code point strings, then these statements may not
- * be true, depending on the strings in the set (for example, whether they
- * overlap with each other) and the string that is processed.
- * For a set with strings:
- * - The complement of the set contains the opposite set of code points,
- *   but the same set of strings.
- *   Therefore, complementing both the set and the span conditions
- *   may yield different results.
- * - When starting spans at different positions in a string
- *   (span(s, ...) vs. span(s+1, ...)) the ends of the spans may be different
- *   because a set string may start before the later position.
- * - span(USET_SPAN_SIMPLE) may be shorter than
- *   span(USET_SPAN_CONTAINED) because it will not recursively try
- *   all possible paths.
- *   For example, with a set which contains the three strings "xy", "xya" and "ax",
- *   span("xyax", USET_SPAN_CONTAINED) will return 4 but
- *   span("xyax", USET_SPAN_SIMPLE) will return 3.
- *   span(USET_SPAN_SIMPLE) will never be longer than
- *   span(USET_SPAN_CONTAINED).
- * - With either "contained" condition, span() and spanBack() may partition
- *   a string in different ways.
- *   For example, with a set which contains the two strings "ab" and "ba",
- *   and when processing the string "aba",
- *   span() will yield contained/not-contained boundaries of { 0, 2, 3 }
- *   while spanBack() will yield boundaries of { 0, 1, 3 }.
- *
- * Note: If it is important to get the same boundaries whether iterating forward
- * or backward through a string, then either only span() should be used and
- * the boundaries cached for backward operation, or an ICU BreakIterator
- * could be used.
- *
- * Note: Unpaired surrogates are treated like surrogate code points.
- * Similarly, set strings match only on code point boundaries,
- * never in the middle of a surrogate pair.
- * Illegal UTF-8 sequences are treated like U+FFFD.
- * When processing UTF-8 strings, malformed set strings
- * (strings with unpaired surrogates which cannot be converted to UTF-8)
- * are ignored.
- *
- * @stable ICU 4.0
- */
-typedef enum USetSpanCondition {
-    /**
-     * Continue a span() while there is no set element at the current position.
-     * Stops before the first set element (character or string).
-     * (For code points only, this is like while contains(current)==FALSE).
-     *
-     * When span() returns, the substring between where it started and the position
-     * it returned consists only of characters that are not in the set,
-     * and none of its strings overlap with the span.
-     *
-     * @stable ICU 4.0
-     */
-    USET_SPAN_NOT_CONTAINED = 0,
-    /**
-     * Continue a span() while there is a set element at the current position.
-     * (For characters only, this is like while contains(current)==TRUE).
-     *
-     * When span() returns, the substring between where it started and the position
-     * it returned consists only of set elements (characters or strings) that are in the set.
-     *
-     * If a set contains strings, then the span will be the longest substring
-     * matching any of the possible concatenations of set elements (characters or strings).
-     * (There must be a single, non-overlapping concatenation of characters or strings.)
-     * This is equivalent to a POSIX regular expression for (OR of each set element)*.
-     *
-     * @stable ICU 4.0
-     */
-    USET_SPAN_CONTAINED = 1,
-    /**
-     * Continue a span() while there is a set element at the current position.
-     * (For characters only, this is like while contains(current)==TRUE).
-     *
-     * When span() returns, the substring between where it started and the position
-     * it returned consists only of set elements (characters or strings) that are in the set.
-     *
-     * If a set only contains single characters, then this is the same
-     * as USET_SPAN_CONTAINED.
-     *
-     * If a set contains strings, then the span will be the longest substring
-     * with a match at each position with the longest single set element (character or string).
-     *
-     * Use this span condition together with other longest-match algorithms,
-     * such as ICU converters (ucnv_getUnicodeSet()).
-     *
-     * @stable ICU 4.0
-     */
-    USET_SPAN_SIMPLE = 2,
-    /**
-     * One more than the last span condition.
-     * @stable ICU 4.0
-     */
-    USET_SPAN_CONDITION_COUNT
-} USetSpanCondition;
-
-/**
- * A serialized form of a Unicode set.  Limited manipulations are
- * possible directly on a serialized set.  See below.
- * @stable ICU 2.4
- */
-typedef struct USerializedSet {
-    /**
-     * The serialized Unicode Set.
-     * @stable ICU 2.4
-     */
-    const uint16_t *array;
-    /**
-     * The length of the array that contains BMP characters.
-     * @stable ICU 2.4
-     */
-    int32_t bmpLength;
-    /**
-     * The total length of the array.
-     * @stable ICU 2.4
-     */
-    int32_t length;
-    /**
-     * A small buffer for the array to reduce memory allocations.
-     * @stable ICU 2.4
-     */
-    uint16_t staticArray[USET_SERIALIZED_STATIC_ARRAY_CAPACITY];
-} USerializedSet;
-
-/*********************************************************************
- * USet API
- *********************************************************************/
-
-/**
- * Creates a USet object that contains the range of characters
- * start..end, inclusive.  If <code>start > end</code> 
- * then an empty set is created.
- * @param start first character of the range, inclusive
- * @param end last character of the range, inclusive
- * @return a newly created USet.  The caller must call uset_close() on
- * it when done.
- * @stable ICU 2.4
- */
-U_STABLE USet* U_EXPORT2
-uset_open(UChar32 start, UChar32 end);
-
-/**
- * Creates a set from the given pattern.  See the UnicodeSet class
- * description for the syntax of the pattern language.
- * @param pattern a string specifying what characters are in the set
- * @param patternLength the length of the pattern, or -1 if null
- * terminated
- * @param ec the error code
- * @stable ICU 2.4
- */
-U_STABLE USet* U_EXPORT2
-uset_openPattern(const UChar* pattern, int32_t patternLength,
-                 UErrorCode* ec);
-
-/**
- * Creates a set from the given pattern.  See the UnicodeSet class
- * description for the syntax of the pattern language.
- * @param pattern a string specifying what characters are in the set
- * @param patternLength the length of the pattern, or -1 if null
- * terminated
- * @param options bitmask for options to apply to the pattern.
- * Valid options are USET_IGNORE_SPACE and USET_CASE_INSENSITIVE.
- * @param ec the error code
- * @stable ICU 2.4
- */
-U_STABLE USet* U_EXPORT2
-uset_openPatternOptions(const UChar* pattern, int32_t patternLength,
-                 uint32_t options,
-                 UErrorCode* ec);
-
-/**
- * Disposes of the storage used by a USet object.  This function should
- * be called exactly once for objects returned by uset_open().
- * @param set the object to dispose of
- * @stable ICU 2.4
- */
-U_STABLE void U_EXPORT2
-uset_close(USet* set);
-
-/**
- * Returns a copy of this object.
- * If this set is frozen, then the clone will be frozen as well.
- * Use uset_cloneAsThawed() for a mutable clone of a frozen set.
- * @param set the original set
- * @return the newly allocated copy of the set
- * @see uset_cloneAsThawed
- * @stable ICU 4.0
- */
-U_DRAFT USet * U_EXPORT2
-uset_clone(const USet *set);
-
-/**
- * Determines whether the set has been frozen (made immutable) or not.
- * See the ICU4J Freezable interface for details.
- * @param set the set
- * @return TRUE/FALSE for whether the set has been frozen
- * @see uset_freeze
- * @see uset_cloneAsThawed
- * @stable ICU 4.0
- */
-U_DRAFT UBool U_EXPORT2
-uset_isFrozen(const USet *set);
-
-/**
- * Freeze the set (make it immutable).
- * Once frozen, it cannot be unfrozen and is therefore thread-safe
- * until it is deleted.
- * See the ICU4J Freezable interface for details.
- * Freezing the set may also make some operations faster, for example
- * uset_contains() and uset_span().
- * A frozen set will not be modified. (It remains frozen.)
- * @param set the set
- * @return the same set, now frozen
- * @see uset_isFrozen
- * @see uset_cloneAsThawed
- * @stable ICU 4.0
- */
-U_DRAFT void U_EXPORT2
-uset_freeze(USet *set);
-
-/**
- * Clone the set and make the clone mutable.
- * See the ICU4J Freezable interface for details.
- * @param set the set
- * @return the mutable clone
- * @see uset_freeze
- * @see uset_isFrozen
- * @see uset_clone
- * @stable ICU 4.0
- */
-U_DRAFT USet * U_EXPORT2
-uset_cloneAsThawed(const USet *set);
-
-/**
- * Causes the USet object to represent the range <code>start - end</code>.
- * If <code>start > end</code> then this USet is set to an empty range.
- * A frozen set will not be modified.
- * @param set the object to set to the given range
- * @param start first character in the set, inclusive
- * @param end last character in the set, inclusive
- * @stable ICU 3.2
- */
-U_STABLE void U_EXPORT2
-uset_set(USet* set,
-         UChar32 start, UChar32 end);
-
-/**
- * Modifies the set to represent the set specified by the given
- * pattern. See the UnicodeSet class description for the syntax of 
- * the pattern language. See also the User Guide chapter about UnicodeSet.
- * <em>Empties the set passed before applying the pattern.</em>
- * A frozen set will not be modified.
- * @param set               The set to which the pattern is to be applied. 
- * @param pattern           A pointer to UChar string specifying what characters are in the set.
- *                          The character at pattern[0] must be a '['.
- * @param patternLength     The length of the UChar string. -1 if NUL terminated.
- * @param options           A bitmask for options to apply to the pattern.
- *                          Valid options are USET_IGNORE_SPACE and USET_CASE_INSENSITIVE.
- * @param status            Returns an error if the pattern cannot be parsed.
- * @return                  Upon successful parse, the value is either
- *                          the index of the character after the closing ']' 
- *                          of the parsed pattern.
- *                          If the status code indicates failure, then the return value 
- *                          is the index of the error in the source.
- *
- * @stable ICU 2.8
- */
-U_STABLE int32_t U_EXPORT2 
-uset_applyPattern(USet *set,
-                  const UChar *pattern, int32_t patternLength,
-                  uint32_t options,
-                  UErrorCode *status);
-
-/**
- * Modifies the set to contain those code points which have the given value
- * for the given binary or enumerated property, as returned by
- * u_getIntPropertyValue.  Prior contents of this set are lost.
- * A frozen set will not be modified.
- *
- * @param set the object to contain the code points defined by the property
- *
- * @param prop a property in the range UCHAR_BIN_START..UCHAR_BIN_LIMIT-1
- * or UCHAR_INT_START..UCHAR_INT_LIMIT-1
- * or UCHAR_MASK_START..UCHAR_MASK_LIMIT-1.
- *
- * @param value a value in the range u_getIntPropertyMinValue(prop)..
- * u_getIntPropertyMaxValue(prop), with one exception.  If prop is
- * UCHAR_GENERAL_CATEGORY_MASK, then value should not be a UCharCategory, but
- * rather a mask value produced by U_GET_GC_MASK().  This allows grouped
- * categories such as [:L:] to be represented.
- *
- * @param ec error code input/output parameter
- *
- * @stable ICU 3.2
- */
-U_STABLE void U_EXPORT2
-uset_applyIntPropertyValue(USet* set,
-                           UProperty prop, int32_t value, UErrorCode* ec);
-
-/**
- * Modifies the set to contain those code points which have the
- * given value for the given property.  Prior contents of this
- * set are lost.
- * A frozen set will not be modified.
- *
- * @param set the object to contain the code points defined by the given
- * property and value alias
- *
- * @param prop a string specifying a property alias, either short or long.
- * The name is matched loosely.  See PropertyAliases.txt for names and a
- * description of loose matching.  If the value string is empty, then this
- * string is interpreted as either a General_Category value alias, a Script
- * value alias, a binary property alias, or a special ID.  Special IDs are
- * matched loosely and correspond to the following sets:
- *
- * "ANY" = [\\u0000-\\U0010FFFF],
- * "ASCII" = [\\u0000-\\u007F],
- * "Assigned" = [:^Cn:].
- *
- * @param propLength the length of the prop, or -1 if NULL
- *
- * @param value a string specifying a value alias, either short or long.
- * The name is matched loosely.  See PropertyValueAliases.txt for names
- * and a description of loose matching.  In addition to aliases listed,
- * numeric values and canonical combining classes may be expressed
- * numerically, e.g., ("nv", "0.5") or ("ccc", "220").  The value string
- * may also be empty.
- *
- * @param valueLength the length of the value, or -1 if NULL
- *
- * @param ec error code input/output parameter
- *
- * @stable ICU 3.2
- */
-U_STABLE void U_EXPORT2
-uset_applyPropertyAlias(USet* set,
-                        const UChar *prop, int32_t propLength,
-                        const UChar *value, int32_t valueLength,
-                        UErrorCode* ec);
-
-/**
- * Return true if the given position, in the given pattern, appears
- * to be the start of a UnicodeSet pattern.
- *
- * @param pattern a string specifying the pattern
- * @param patternLength the length of the pattern, or -1 if NULL
- * @param pos the given position
- * @stable ICU 3.2
- */
-U_STABLE UBool U_EXPORT2
-uset_resemblesPattern(const UChar *pattern, int32_t patternLength,
-                      int32_t pos);
-
-/**
- * Returns a string representation of this set.  If the result of
- * calling this function is passed to a uset_openPattern(), it
- * will produce another set that is equal to this one.
- * @param set the set
- * @param result the string to receive the rules, may be NULL
- * @param resultCapacity the capacity of result, may be 0 if result is NULL
- * @param escapeUnprintable if TRUE then convert unprintable
- * character to their hex escape representations, \\uxxxx or
- * \\Uxxxxxxxx.  Unprintable characters are those other than
- * U+000A, U+0020..U+007E.
- * @param ec error code.
- * @return length of string, possibly larger than resultCapacity
- * @stable ICU 2.4
- */
-U_STABLE int32_t U_EXPORT2
-uset_toPattern(const USet* set,
-               UChar* result, int32_t resultCapacity,
-               UBool escapeUnprintable,
-               UErrorCode* ec);
-
-/**
- * Adds the given character to the given USet.  After this call,
- * uset_contains(set, c) will return TRUE.
- * A frozen set will not be modified.
- * @param set the object to which to add the character
- * @param c the character to add
- * @stable ICU 2.4
- */
-U_STABLE void U_EXPORT2
-uset_add(USet* set, UChar32 c);
-
-/**
- * Adds all of the elements in the specified set to this set if
- * they're not already present.  This operation effectively
- * modifies this set so that its value is the <i>union</i> of the two
- * sets.  The behavior of this operation is unspecified if the specified
- * collection is modified while the operation is in progress.
- * A frozen set will not be modified.
- *
- * @param set the object to which to add the set
- * @param additionalSet the source set whose elements are to be added to this set.
- * @stable ICU 2.6
- */
-U_STABLE void U_EXPORT2
-uset_addAll(USet* set, const USet *additionalSet);
-
-/**
- * Adds the given range of characters to the given USet.  After this call,
- * uset_contains(set, start, end) will return TRUE.
- * A frozen set will not be modified.
- * @param set the object to which to add the character
- * @param start the first character of the range to add, inclusive
- * @param end the last character of the range to add, inclusive
- * @stable ICU 2.2
- */
-U_STABLE void U_EXPORT2
-uset_addRange(USet* set, UChar32 start, UChar32 end);
-
-/**
- * Adds the given string to the given USet.  After this call,
- * uset_containsString(set, str, strLen) will return TRUE.
- * A frozen set will not be modified.
- * @param set the object to which to add the character
- * @param str the string to add
- * @param strLen the length of the string or -1 if null terminated.
- * @stable ICU 2.4
- */
-U_STABLE void U_EXPORT2
-uset_addString(USet* set, const UChar* str, int32_t strLen);
-
-/**
- * Adds each of the characters in this string to the set. Thus "ch" => {"c", "h"}
- * If this set already any particular character, it has no effect on that character.
- * A frozen set will not be modified.
- * @param set the object to which to add the character
- * @param str the source string
- * @param strLen the length of the string or -1 if null terminated.
- * @stable ICU 3.4
- */
-U_STABLE void U_EXPORT2
-uset_addAllCodePoints(USet* set, const UChar *str, int32_t strLen);
-
-/**
- * Removes the given character from the given USet.  After this call,
- * uset_contains(set, c) will return FALSE.
- * A frozen set will not be modified.
- * @param set the object from which to remove the character
- * @param c the character to remove
- * @stable ICU 2.4
- */
-U_STABLE void U_EXPORT2
-uset_remove(USet* set, UChar32 c);
-
-/**
- * Removes the given range of characters from the given USet.  After this call,
- * uset_contains(set, start, end) will return FALSE.
- * A frozen set will not be modified.
- * @param set the object to which to add the character
- * @param start the first character of the range to remove, inclusive
- * @param end the last character of the range to remove, inclusive
- * @stable ICU 2.2
- */
-U_STABLE void U_EXPORT2
-uset_removeRange(USet* set, UChar32 start, UChar32 end);
-
-/**
- * Removes the given string to the given USet.  After this call,
- * uset_containsString(set, str, strLen) will return FALSE.
- * A frozen set will not be modified.
- * @param set the object to which to add the character
- * @param str the string to remove
- * @param strLen the length of the string or -1 if null terminated.
- * @stable ICU 2.4
- */
-U_STABLE void U_EXPORT2
-uset_removeString(USet* set, const UChar* str, int32_t strLen);
-
-/**
- * Removes from this set all of its elements that are contained in the
- * specified set.  This operation effectively modifies this
- * set so that its value is the <i>asymmetric set difference</i> of
- * the two sets.
- * A frozen set will not be modified.
- * @param set the object from which the elements are to be removed
- * @param removeSet the object that defines which elements will be
- * removed from this set
- * @stable ICU 3.2
- */
-U_STABLE void U_EXPORT2
-uset_removeAll(USet* set, const USet* removeSet);
-
-/**
- * Retain only the elements in this set that are contained in the
- * specified range.  If <code>start > end</code> then an empty range is
- * retained, leaving the set empty.  This is equivalent to
- * a boolean logic AND, or a set INTERSECTION.
- * A frozen set will not be modified.
- *
- * @param set the object for which to retain only the specified range
- * @param start first character, inclusive, of range to be retained
- * to this set.
- * @param end last character, inclusive, of range to be retained
- * to this set.
- * @stable ICU 3.2
- */
-U_STABLE void U_EXPORT2
-uset_retain(USet* set, UChar32 start, UChar32 end);
-
-/**
- * Retains only the elements in this set that are contained in the
- * specified set.  In other words, removes from this set all of
- * its elements that are not contained in the specified set.  This
- * operation effectively modifies this set so that its value is
- * the <i>intersection</i> of the two sets.
- * A frozen set will not be modified.
- *
- * @param set the object on which to perform the retain
- * @param retain set that defines which elements this set will retain
- * @stable ICU 3.2
- */
-U_STABLE void U_EXPORT2
-uset_retainAll(USet* set, const USet* retain);
-
-/**
- * Reallocate this objects internal structures to take up the least
- * possible space, without changing this object's value.
- * A frozen set will not be modified.
- *
- * @param set the object on which to perfrom the compact
- * @stable ICU 3.2
- */
-U_STABLE void U_EXPORT2
-uset_compact(USet* set);
-
-/**
- * Inverts this set.  This operation modifies this set so that
- * its value is its complement.  This operation does not affect
- * the multicharacter strings, if any.
- * A frozen set will not be modified.
- * @param set the set
- * @stable ICU 2.4
- */
-U_STABLE void U_EXPORT2
-uset_complement(USet* set);
-
-/**
- * Complements in this set all elements contained in the specified
- * set.  Any character in the other set will be removed if it is
- * in this set, or will be added if it is not in this set.
- * A frozen set will not be modified.
- *
- * @param set the set with which to complement
- * @param complement set that defines which elements will be xor'ed
- * from this set.
- * @stable ICU 3.2
- */
-U_STABLE void U_EXPORT2
-uset_complementAll(USet* set, const USet* complement);
-
-/**
- * Removes all of the elements from this set.  This set will be
- * empty after this call returns.
- * A frozen set will not be modified.
- * @param set the set
- * @stable ICU 2.4
- */
-U_STABLE void U_EXPORT2
-uset_clear(USet* set);
-
-/**
- * Returns TRUE if the given USet contains no characters and no
- * strings.
- * @param set the set
- * @return true if set is empty
- * @stable ICU 2.4
- */
-U_STABLE UBool U_EXPORT2
-uset_isEmpty(const USet* set);
-
-/**
- * Returns TRUE if the given USet contains the given character.
- * This function works faster with a frozen set.
- * @param set the set
- * @param c The codepoint to check for within the set
- * @return true if set contains c
- * @stable ICU 2.4
- */
-U_STABLE UBool U_EXPORT2
-uset_contains(const USet* set, UChar32 c);
-
-/**
- * Returns TRUE if the given USet contains all characters c
- * where start <= c && c <= end.
- * @param set the set
- * @param start the first character of the range to test, inclusive
- * @param end the last character of the range to test, inclusive
- * @return TRUE if set contains the range
- * @stable ICU 2.2
- */
-U_STABLE UBool U_EXPORT2
-uset_containsRange(const USet* set, UChar32 start, UChar32 end);
-
-/**
- * Returns TRUE if the given USet contains the given string.
- * @param set the set
- * @param str the string
- * @param strLen the length of the string or -1 if null terminated.
- * @return true if set contains str
- * @stable ICU 2.4
- */
-U_STABLE UBool U_EXPORT2
-uset_containsString(const USet* set, const UChar* str, int32_t strLen);
-
-/**
- * Returns the index of the given character within this set, where
- * the set is ordered by ascending code point.  If the character
- * is not in this set, return -1.  The inverse of this method is
- * <code>charAt()</code>.
- * @param set the set
- * @param c the character to obtain the index for
- * @return an index from 0..size()-1, or -1
- * @stable ICU 3.2
- */
-U_STABLE int32_t U_EXPORT2
-uset_indexOf(const USet* set, UChar32 c);
-
-/**
- * Returns the character at the given index within this set, where
- * the set is ordered by ascending code point.  If the index is
- * out of range, return (UChar32)-1.  The inverse of this method is
- * <code>indexOf()</code>.
- * @param set the set
- * @param index an index from 0..size()-1 to obtain the char for
- * @return the character at the given index, or (UChar32)-1.
- * @stable ICU 3.2
- */
-U_STABLE UChar32 U_EXPORT2
-uset_charAt(const USet* set, int32_t index);
-
-/**
- * Returns the number of characters and strings contained in the given
- * USet.
- * @param set the set
- * @return a non-negative integer counting the characters and strings
- * contained in set
- * @stable ICU 2.4
- */
-U_STABLE int32_t U_EXPORT2
-uset_size(const USet* set);
-
-/**
- * Returns the number of items in this set.  An item is either a range
- * of characters or a single multicharacter string.
- * @param set the set
- * @return a non-negative integer counting the character ranges
- * and/or strings contained in set
- * @stable ICU 2.4
- */
-U_STABLE int32_t U_EXPORT2
-uset_getItemCount(const USet* set);
-
-/**
- * Returns an item of this set.  An item is either a range of
- * characters or a single multicharacter string.
- * @param set the set
- * @param itemIndex a non-negative integer in the range 0..
- * uset_getItemCount(set)-1
- * @param start pointer to variable to receive first character
- * in range, inclusive
- * @param end pointer to variable to receive last character in range,
- * inclusive
- * @param str buffer to receive the string, may be NULL
- * @param strCapacity capacity of str, or 0 if str is NULL
- * @param ec error code
- * @return the length of the string (>= 2), or 0 if the item is a
- * range, in which case it is the range *start..*end, or -1 if
- * itemIndex is out of range
- * @stable ICU 2.4
- */
-U_STABLE int32_t U_EXPORT2
-uset_getItem(const USet* set, int32_t itemIndex,
-             UChar32* start, UChar32* end,
-             UChar* str, int32_t strCapacity,
-             UErrorCode* ec);
-
-/**
- * Returns true if set1 contains all the characters and strings
- * of set2. It answers the question, 'Is set1 a superset of set2?'
- * @param set1 set to be checked for containment
- * @param set2 set to be checked for containment
- * @return true if the test condition is met
- * @stable ICU 3.2
- */
-U_STABLE UBool U_EXPORT2
-uset_containsAll(const USet* set1, const USet* set2);
-
-/**
- * Returns true if this set contains all the characters
- * of the given string. This is does not check containment of grapheme
- * clusters, like uset_containsString.
- * @param set set of characters to be checked for containment
- * @param str string containing codepoints to be checked for containment
- * @param strLen the length of the string or -1 if null terminated.
- * @return true if the test condition is met
- * @stable ICU 3.4
- */
-U_STABLE UBool U_EXPORT2
-uset_containsAllCodePoints(const USet* set, const UChar *str, int32_t strLen);
-
-/**
- * Returns true if set1 contains none of the characters and strings
- * of set2. It answers the question, 'Is set1 a disjoint set of set2?'
- * @param set1 set to be checked for containment
- * @param set2 set to be checked for containment
- * @return true if the test condition is met
- * @stable ICU 3.2
- */
-U_STABLE UBool U_EXPORT2
-uset_containsNone(const USet* set1, const USet* set2);
-
-/**
- * Returns true if set1 contains some of the characters and strings
- * of set2. It answers the question, 'Does set1 and set2 have an intersection?'
- * @param set1 set to be checked for containment
- * @param set2 set to be checked for containment
- * @return true if the test condition is met
- * @stable ICU 3.2
- */
-U_STABLE UBool U_EXPORT2
-uset_containsSome(const USet* set1, const USet* set2);
-
-/**
- * Returns the length of the initial substring of the input string which
- * consists only of characters and strings that are contained in this set
- * (USET_SPAN_CONTAINED, USET_SPAN_SIMPLE),
- * or only of characters and strings that are not contained
- * in this set (USET_SPAN_NOT_CONTAINED).
- * See USetSpanCondition for details.
- * Similar to the strspn() C library function.
- * Unpaired surrogates are treated according to contains() of their surrogate code points.
- * This function works faster with a frozen set and with a non-negative string length argument.
- * @param set the set
- * @param s start of the string
- * @param length of the string; can be -1 for NUL-terminated
- * @param spanCondition specifies the containment condition
- * @return the length of the initial substring according to the spanCondition;
- *         0 if the start of the string does not fit the spanCondition
- * @stable ICU 4.0
- * @see USetSpanCondition
- */
-U_DRAFT int32_t U_EXPORT2
-uset_span(const USet *set, const UChar *s, int32_t length, USetSpanCondition spanCondition);
-
-/**
- * Returns the start of the trailing substring of the input string which
- * consists only of characters and strings that are contained in this set
- * (USET_SPAN_CONTAINED, USET_SPAN_SIMPLE),
- * or only of characters and strings that are not contained
- * in this set (USET_SPAN_NOT_CONTAINED).
- * See USetSpanCondition for details.
- * Unpaired surrogates are treated according to contains() of their surrogate code points.
- * This function works faster with a frozen set and with a non-negative string length argument.
- * @param set the set
- * @param s start of the string
- * @param length of the string; can be -1 for NUL-terminated
- * @param spanCondition specifies the containment condition
- * @return the start of the trailing substring according to the spanCondition;
- *         the string length if the end of the string does not fit the spanCondition
- * @stable ICU 4.0
- * @see USetSpanCondition
- */
-U_DRAFT int32_t U_EXPORT2
-uset_spanBack(const USet *set, const UChar *s, int32_t length, USetSpanCondition spanCondition);
-
-/**
- * Returns the length of the initial substring of the input string which
- * consists only of characters and strings that are contained in this set
- * (USET_SPAN_CONTAINED, USET_SPAN_SIMPLE),
- * or only of characters and strings that are not contained
- * in this set (USET_SPAN_NOT_CONTAINED).
- * See USetSpanCondition for details.
- * Similar to the strspn() C library function.
- * Malformed byte sequences are treated according to contains(0xfffd).
- * This function works faster with a frozen set and with a non-negative string length argument.
- * @param set the set
- * @param s start of the string (UTF-8)
- * @param length of the string; can be -1 for NUL-terminated
- * @param spanCondition specifies the containment condition
- * @return the length of the initial substring according to the spanCondition;
- *         0 if the start of the string does not fit the spanCondition
- * @stable ICU 4.0
- * @see USetSpanCondition
- */
-U_DRAFT int32_t U_EXPORT2
-uset_spanUTF8(const USet *set, const char *s, int32_t length, USetSpanCondition spanCondition);
-
-/**
- * Returns the start of the trailing substring of the input string which
- * consists only of characters and strings that are contained in this set
- * (USET_SPAN_CONTAINED, USET_SPAN_SIMPLE),
- * or only of characters and strings that are not contained
- * in this set (USET_SPAN_NOT_CONTAINED).
- * See USetSpanCondition for details.
- * Malformed byte sequences are treated according to contains(0xfffd).
- * This function works faster with a frozen set and with a non-negative string length argument.
- * @param set the set
- * @param s start of the string (UTF-8)
- * @param length of the string; can be -1 for NUL-terminated
- * @param spanCondition specifies the containment condition
- * @return the start of the trailing substring according to the spanCondition;
- *         the string length if the end of the string does not fit the spanCondition
- * @stable ICU 4.0
- * @see USetSpanCondition
- */
-U_DRAFT int32_t U_EXPORT2
-uset_spanBackUTF8(const USet *set, const char *s, int32_t length, USetSpanCondition spanCondition);
-
-/**
- * Returns true if set1 contains all of the characters and strings
- * of set2, and vis versa. It answers the question, 'Is set1 equal to set2?'
- * @param set1 set to be checked for containment
- * @param set2 set to be checked for containment
- * @return true if the test condition is met
- * @stable ICU 3.2
- */
-U_STABLE UBool U_EXPORT2
-uset_equals(const USet* set1, const USet* set2);
-
-/*********************************************************************
- * Serialized set API
- *********************************************************************/
-
-/**
- * Serializes this set into an array of 16-bit integers.  Serialization
- * (currently) only records the characters in the set; multicharacter
- * strings are ignored.
- *
- * The array
- * has following format (each line is one 16-bit integer):
- *
- *  length     = (n+2*m) | (m!=0?0x8000:0)
- *  bmpLength  = n; present if m!=0
- *  bmp[0]
- *  bmp[1]
- *  ...
- *  bmp[n-1]
- *  supp-high[0]
- *  supp-low[0]
- *  supp-high[1]
- *  supp-low[1]
- *  ...
- *  supp-high[m-1]
- *  supp-low[m-1]
- *
- * The array starts with a header.  After the header are n bmp
- * code points, then m supplementary code points.  Either n or m
- * or both may be zero.  n+2*m is always <= 0x7FFF.
- *
- * If there are no supplementary characters (if m==0) then the
- * header is one 16-bit integer, 'length', with value n.
- *
- * If there are supplementary characters (if m!=0) then the header
- * is two 16-bit integers.  The first, 'length', has value
- * (n+2*m)|0x8000.  The second, 'bmpLength', has value n.
- *
- * After the header the code points are stored in ascending order.
- * Supplementary code points are stored as most significant 16
- * bits followed by least significant 16 bits.
- *
- * @param set the set
- * @param dest pointer to buffer of destCapacity 16-bit integers.
- * May be NULL only if destCapacity is zero.
- * @param destCapacity size of dest, or zero.  Must not be negative.
- * @param pErrorCode pointer to the error code.  Will be set to
- * U_INDEX_OUTOFBOUNDS_ERROR if n+2*m > 0x7FFF.  Will be set to
- * U_BUFFER_OVERFLOW_ERROR if n+2*m+(m!=0?2:1) > destCapacity.
- * @return the total length of the serialized format, including
- * the header, that is, n+2*m+(m!=0?2:1), or 0 on error other
- * than U_BUFFER_OVERFLOW_ERROR.
- * @stable ICU 2.4
- */
-U_STABLE int32_t U_EXPORT2
-uset_serialize(const USet* set, uint16_t* dest, int32_t destCapacity, UErrorCode* pErrorCode);
-
-/**
- * Given a serialized array, fill in the given serialized set object.
- * @param fillSet pointer to result
- * @param src pointer to start of array
- * @param srcLength length of array
- * @return true if the given array is valid, otherwise false
- * @stable ICU 2.4
- */
-U_STABLE UBool U_EXPORT2
-uset_getSerializedSet(USerializedSet* fillSet, const uint16_t* src, int32_t srcLength);
-
-/**
- * Set the USerializedSet to contain the given character (and nothing
- * else).
- * @param fillSet pointer to result
- * @param c The codepoint to set
- * @stable ICU 2.4
- */
-U_STABLE void U_EXPORT2
-uset_setSerializedToOne(USerializedSet* fillSet, UChar32 c);
-
-/**
- * Returns TRUE if the given USerializedSet contains the given
- * character.
- * @param set the serialized set
- * @param c The codepoint to check for within the set
- * @return true if set contains c
- * @stable ICU 2.4
- */
-U_STABLE UBool U_EXPORT2
-uset_serializedContains(const USerializedSet* set, UChar32 c);
-
-/**
- * Returns the number of disjoint ranges of characters contained in
- * the given serialized set.  Ignores any strings contained in the
- * set.
- * @param set the serialized set
- * @return a non-negative integer counting the character ranges
- * contained in set
- * @stable ICU 2.4
- */
-U_STABLE int32_t U_EXPORT2
-uset_getSerializedRangeCount(const USerializedSet* set);
-
-/**
- * Returns a range of characters contained in the given serialized
- * set.
- * @param set the serialized set
- * @param rangeIndex a non-negative integer in the range 0..
- * uset_getSerializedRangeCount(set)-1
- * @param pStart pointer to variable to receive first character
- * in range, inclusive
- * @param pEnd pointer to variable to receive last character in range,
- * inclusive
- * @return true if rangeIndex is valid, otherwise false
- * @stable ICU 2.4
- */
-U_STABLE UBool U_EXPORT2
-uset_getSerializedRange(const USerializedSet* set, int32_t rangeIndex,
-                        UChar32* pStart, UChar32* pEnd);
-
-#endif

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/usetiter.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/usetiter.h b/apps/couch_collate/platform/osx/icu/unicode/usetiter.h
deleted file mode 100644
index defa75c..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/usetiter.h
+++ /dev/null
@@ -1,318 +0,0 @@
-/*
-**********************************************************************
-* Copyright (c) 2002-2006, International Business Machines
-* Corporation and others.  All Rights Reserved.
-**********************************************************************
-*/
-#ifndef USETITER_H
-#define USETITER_H
-
-#include "unicode/utypes.h"
-#include "unicode/uobject.h"
-#include "unicode/unistr.h"
-
-/**
- * \file 
- * \brief C++ API: UnicodeSetIterator iterates over the contents of a UnicodeSet.
- */
-
-U_NAMESPACE_BEGIN
-
-class UnicodeSet;
-class UnicodeString;
-
-/**
- *
- * UnicodeSetIterator iterates over the contents of a UnicodeSet.  It
- * iterates over either code points or code point ranges.  After all
- * code points or ranges have been returned, it returns the
- * multicharacter strings of the UnicodSet, if any.
- *
- * This class is not intended to be subclassed.  Consider any fields
- *  or methods declared as "protected" to be private.  The use of
- *  protected in this class is an artifact of history.
- *
- * <p>To iterate over code points and strings, use a loop like this:
- * <pre>
- * UnicodeSetIterator it(set);
- * while (set.next()) {
- *     processItem(set.getString());
- * }
- * </pre>
- * <p>Each item in the set is accessed as a string.  Set elements
- *    consisting of single code points are returned as strings containing
- *    just the one code point.
- *
- * <p>To iterate over code point ranges, instead of individual code points,
- *    use a loop like this:
- * <pre>
- * UnicodeSetIterator it(set);
- * while (it.nextRange()) {
- *   if (it.isString()) {
- *     processString(it.getString());
- *   } else {
- *     processCodepointRange(it.getCodepoint(), it.getCodepointEnd());
- *   }
- * }
- * </pre>
- * @author M. Davis
- * @stable ICU 2.4
- */
-class U_COMMON_API UnicodeSetIterator : public UObject {
-
- protected:
-
-    /**
-     * Value of <tt>codepoint</tt> if the iterator points to a string.
-     * If <tt>codepoint == IS_STRING</tt>, then examine
-     * <tt>string</tt> for the current iteration result.
-     * @stable ICU 2.4
-     */
-    enum { IS_STRING = -1 };
-
-    /**
-     * Current code point, or the special value <tt>IS_STRING</tt>, if
-     * the iterator points to a string.
-     * @stable ICU 2.4
-     */
-    UChar32 codepoint;
-
-    /**
-     * When iterating over ranges using <tt>nextRange()</tt>,
-     * <tt>codepointEnd</tt> contains the inclusive end of the
-     * iteration range, if <tt>codepoint != IS_STRING</tt>.  If
-     * iterating over code points using <tt>next()</tt>, or if
-     * <tt>codepoint == IS_STRING</tt>, then the value of
-     * <tt>codepointEnd</tt> is undefined.
-     * @stable ICU 2.4
-     */
-    UChar32 codepointEnd;
-
-    /**
-     * If <tt>codepoint == IS_STRING</tt>, then <tt>string</tt> points
-     * to the current string.  If <tt>codepoint != IS_STRING</tt>, the
-     * value of <tt>string</tt> is undefined.
-     * @stable ICU 2.4
-     */
-    const UnicodeString* string;
-
- public:
-
-    /**
-     * Create an iterator over the given set.  The iterator is valid
-     * only so long as <tt>set</tt> is valid.
-     * @param set set to iterate over
-     * @stable ICU 2.4
-     */
-    UnicodeSetIterator(const UnicodeSet& set);
-
-    /**
-     * Create an iterator over nothing.  <tt>next()</tt> and
-     * <tt>nextRange()</tt> return false. This is a convenience
-     * constructor allowing the target to be set later.
-     * @stable ICU 2.4
-     */
-    UnicodeSetIterator();
-
-    /**
-     * Destructor.
-     * @stable ICU 2.4
-     */
-    virtual ~UnicodeSetIterator();
-
-    /**
-     * Returns true if the current element is a string.  If so, the
-     * caller can retrieve it with <tt>getString()</tt>.  If this
-     * method returns false, the current element is a code point or
-     * code point range, depending on whether <tt>next()</tt> or
-     * <tt>nextRange()</tt> was called.
-     * Elements of types string and codepoint can both be retrieved
-     * with the function <tt>getString()</tt>.
-     * Elements of type codepoint can also be retrieved with
-     * <tt>getCodepoint()</tt>.
-     * For ranges, <tt>getCodepoint()</tt> returns the starting codepoint
-     * of the range, and <tt>getCodepointEnd()</tt> returns the end
-     * of the range.
-     * @stable ICU 2.4
-     */
-    inline UBool isString() const;
-
-    /**
-     * Returns the current code point, if <tt>isString()</tt> returned
-     * false.  Otherwise returns an undefined result.
-     * @stable ICU 2.4
-     */
-    inline UChar32 getCodepoint() const;
-
-    /**
-     * Returns the end of the current code point range, if
-     * <tt>isString()</tt> returned false and <tt>nextRange()</tt> was
-     * called.  Otherwise returns an undefined result.
-     * @stable ICU 2.4
-     */
-    inline UChar32 getCodepointEnd() const;
-
-    /**
-     * Returns the current string, if <tt>isString()</tt> returned
-     * true.  If the current iteration item is a code point, a UnicodeString
-     * containing that single code point is returned.
-     *
-     * Ownership of the returned string remains with the iterator.
-     * The string is guaranteed to remain valid only until the iterator is
-     *   advanced to the next item, or until the iterator is deleted.
-     * 
-     * @stable ICU 2.4
-     */
-    const UnicodeString& getString();
-
-    /**
-     * Advances the iteration position to the next element in the set, 
-     * which can be either a single code point or a string.  
-     * If there are no more elements in the set, return false.
-     *
-     * <p>
-     * If <tt>isString() == TRUE</tt>, the value is a
-     * string, otherwise the value is a
-     * single code point.  Elements of either type can be retrieved
-     * with the function <tt>getString()</tt>, while elements of
-     * consisting of a single code point can be retrieved with
-     * <tt>getCodepoint()</tt>
-     *
-     * <p>The order of iteration is all code points in sorted order,
-     * followed by all strings sorted order.    Do not mix
-     * calls to <tt>next()</tt> and <tt>nextRange()</tt> without
-     * calling <tt>reset()</tt> between them.  The results of doing so
-     * are undefined.
-     *
-     * @return true if there was another element in the set.
-     * @stable ICU 2.4
-     */
-    UBool next();
-
-    /**
-     * Returns the next element in the set, either a code point range
-     * or a string.  If there are no more elements in the set, return
-     * false.  If <tt>isString() == TRUE</tt>, the value is a
-     * string and can be accessed with <tt>getString()</tt>.  Otherwise the value is a
-     * range of one or more code points from <tt>getCodepoint()</tt> to
-     * <tt>getCodepointeEnd()</tt> inclusive.
-     *
-     * <p>The order of iteration is all code points ranges in sorted
-     * order, followed by all strings sorted order.  Ranges are
-     * disjoint and non-contiguous.  The value returned from <tt>getString()</tt>
-     * is undefined unless <tt>isString() == TRUE</tt>.  Do not mix calls to
-     * <tt>next()</tt> and <tt>nextRange()</tt> without calling
-     * <tt>reset()</tt> between them.  The results of doing so are
-     * undefined.
-     *
-     * @return true if there was another element in the set.
-     * @stable ICU 2.4
-     */
-    UBool nextRange();
-
-    /**
-     * Sets this iterator to visit the elements of the given set and
-     * resets it to the start of that set.  The iterator is valid only
-     * so long as <tt>set</tt> is valid.
-     * @param set the set to iterate over.
-     * @stable ICU 2.4
-     */
-    void reset(const UnicodeSet& set);
-
-    /**
-     * Resets this iterator to the start of the set.
-     * @stable ICU 2.4
-     */
-    void reset();
-
-    /**
-     * ICU "poor man's RTTI", returns a UClassID for this class.
-     *
-     * @stable ICU 2.4
-     */
-    static UClassID U_EXPORT2 getStaticClassID();
-
-    /**
-     * ICU "poor man's RTTI", returns a UClassID for the actual class.
-     *
-     * @stable ICU 2.4
-     */
-    virtual UClassID getDynamicClassID() const;
-
-    // ======================= PRIVATES ===========================
-
- protected:
-
-    // endElement and nextElements are really UChar32's, but we keep
-    // them as signed int32_t's so we can do comparisons with
-    // endElement set to -1.  Leave them as int32_t's.
-    /** The set
-     * @stable ICU 2.4
-     */
-    const UnicodeSet* set;
-    /** End range
-     * @stable ICU 2.4
-     */
-    int32_t endRange;
-    /** Range
-     * @stable ICU 2.4
-     */
-    int32_t range;
-    /** End element
-     * @stable ICU 2.4
-     */
-    int32_t endElement;
-    /** Next element
-     * @stable ICU 2.4
-     */
-    int32_t nextElement;
-    //UBool abbreviated;
-    /** Next string
-     * @stable ICU 2.4
-     */
-    int32_t nextString;
-    /** String count
-     * @stable ICU 2.4
-     */
-    int32_t stringCount;
-
-    /**
-     *  Points to the string to use when the caller asks for a
-     *  string and the current iteration item is a code point, not a string.
-     *  @internal
-     */
-    UnicodeString *cpString;
-
-    /** Copy constructor. Disallowed.
-     * @stable ICU 2.4
-     */
-    UnicodeSetIterator(const UnicodeSetIterator&); // disallow
-
-    /** Assignment operator. Disallowed.
-     * @stable ICU 2.4
-     */
-    UnicodeSetIterator& operator=(const UnicodeSetIterator&); // disallow
-
-    /** Load range
-     * @stable ICU 2.4
-     */
-    virtual void loadRange(int32_t range);
-
-};
-
-inline UBool UnicodeSetIterator::isString() const {
-    return codepoint == (UChar32)IS_STRING;
-}
-
-inline UChar32 UnicodeSetIterator::getCodepoint() const {
-    return codepoint;
-}
-
-inline UChar32 UnicodeSetIterator::getCodepointEnd() const {
-    return codepointEnd;
-}
-
-
-U_NAMESPACE_END
-
-#endif


[45/57] [abbrv] remove couch_replicator

Posted by be...@apache.org.
http://git-wip-us.apache.org/repos/asf/couchdb/blob/4c39d7a5/apps/couch_replicator/src/couch_replicator_worker.erl
----------------------------------------------------------------------
diff --git a/apps/couch_replicator/src/couch_replicator_worker.erl b/apps/couch_replicator/src/couch_replicator_worker.erl
deleted file mode 100644
index 0f65900..0000000
--- a/apps/couch_replicator/src/couch_replicator_worker.erl
+++ /dev/null
@@ -1,515 +0,0 @@
-% Licensed 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.
-
--module(couch_replicator_worker).
--behaviour(gen_server).
-
-% public API
--export([start_link/5]).
-
-% gen_server callbacks
--export([init/1, terminate/2, code_change/3]).
--export([handle_call/3, handle_cast/2, handle_info/2]).
-
--include_lib("couch/include/couch_db.hrl").
--include("couch_replicator_api_wrap.hrl").
--include("couch_replicator.hrl").
-
-% TODO: maybe make both buffer max sizes configurable
--define(DOC_BUFFER_BYTE_SIZE, 512 * 1024).   % for remote targets
--define(DOC_BUFFER_LEN, 10).                 % for local targets, # of documents
--define(MAX_BULK_ATT_SIZE, 64 * 1024).
--define(MAX_BULK_ATTS_PER_DOC, 8).
--define(STATS_DELAY, 10000000).              % 10 seconds (in microseconds)
-
--define(inc_stat(StatPos, Stats, Inc),
-    setelement(StatPos, Stats, element(StatPos, Stats) + Inc)).
-
--import(couch_replicator_utils, [
-    open_db/1,
-    close_db/1,
-    start_db_compaction_notifier/2,
-    stop_db_compaction_notifier/1
-]).
--import(couch_util, [
-    to_binary/1,
-    get_value/2,
-    get_value/3
-]).
-
-
--record(batch, {
-    docs = [],
-    size = 0
-}).
-
--record(state, {
-    cp,
-    loop,
-    max_parallel_conns,
-    source,
-    target,
-    readers = [],
-    writer = nil,
-    pending_fetch = nil,
-    flush_waiter = nil,
-    stats = #rep_stats{},
-    source_db_compaction_notifier = nil,
-    target_db_compaction_notifier = nil,
-    batch = #batch{}
-}).
-
-
-
-start_link(Cp, #db{} = Source, Target, ChangesManager, _MaxConns) ->
-    Pid = spawn_link(fun() ->
-        erlang:put(last_stats_report, now()),
-        queue_fetch_loop(Source, Target, Cp, Cp, ChangesManager)
-    end),
-    {ok, Pid};
-
-start_link(Cp, Source, Target, ChangesManager, MaxConns) ->
-    gen_server:start_link(
-        ?MODULE, {Cp, Source, Target, ChangesManager, MaxConns}, []).
-
-
-init({Cp, Source, Target, ChangesManager, MaxConns}) ->
-    process_flag(trap_exit, true),
-    Parent = self(),
-    LoopPid = spawn_link(fun() ->
-        queue_fetch_loop(Source, Target, Parent, Cp, ChangesManager)
-    end),
-    erlang:put(last_stats_report, now()),
-    State = #state{
-        cp = Cp,
-        max_parallel_conns = MaxConns,
-        loop = LoopPid,
-        source = open_db(Source),
-        target = open_db(Target),
-        source_db_compaction_notifier =
-            start_db_compaction_notifier(Source, self()),
-        target_db_compaction_notifier =
-            start_db_compaction_notifier(Target, self())
-    },
-    {ok, State}.
-
-
-handle_call({fetch_doc, {_Id, _Revs, _PAs} = Params}, {Pid, _} = From,
-    #state{loop = Pid, readers = Readers, pending_fetch = nil,
-        source = Src, target = Tgt, max_parallel_conns = MaxConns} = State) ->
-    case length(Readers) of
-    Size when Size < MaxConns ->
-        Reader = spawn_doc_reader(Src, Tgt, Params),
-        NewState = State#state{
-            readers = [Reader | Readers]
-        },
-        {reply, ok, NewState};
-    _ ->
-        NewState = State#state{
-            pending_fetch = {From, Params}
-        },
-        {noreply, NewState}
-    end;
-
-handle_call({batch_doc, Doc}, From, State) ->
-    gen_server:reply(From, ok),
-    {noreply, maybe_flush_docs(Doc, State)};
-
-handle_call({add_stats, IncStats}, From, #state{stats = Stats} = State) ->
-    gen_server:reply(From, ok),
-    NewStats = couch_replicator_utils:sum_stats(Stats, IncStats),
-    NewStats2 = maybe_report_stats(State#state.cp, NewStats),
-    {noreply, State#state{stats = NewStats2}};
-
-handle_call(flush, {Pid, _} = From,
-    #state{loop = Pid, writer = nil, flush_waiter = nil,
-        target = Target, batch = Batch} = State) ->
-    State2 = case State#state.readers of
-    [] ->
-        State#state{writer = spawn_writer(Target, Batch)};
-    _ ->
-        State
-    end,
-    {noreply, State2#state{flush_waiter = From}}.
-
-
-handle_cast({db_compacted, DbName},
-    #state{source = #db{name = DbName} = Source} = State) ->
-    {ok, NewSource} = couch_db:reopen(Source),
-    {noreply, State#state{source = NewSource}};
-
-handle_cast({db_compacted, DbName},
-    #state{target = #db{name = DbName} = Target} = State) ->
-    {ok, NewTarget} = couch_db:reopen(Target),
-    {noreply, State#state{target = NewTarget}};
-
-handle_cast(Msg, State) ->
-    {stop, {unexpected_async_call, Msg}, State}.
-
-
-handle_info({'EXIT', Pid, normal}, #state{loop = Pid} = State) ->
-    #state{
-        batch = #batch{docs = []}, readers = [], writer = nil,
-        pending_fetch = nil, flush_waiter = nil
-    } = State,
-    {stop, normal, State};
-
-handle_info({'EXIT', Pid, normal}, #state{writer = Pid} = State) ->
-    {noreply, after_full_flush(State)};
-
-handle_info({'EXIT', Pid, normal}, #state{writer = nil} = State) ->
-    #state{
-        readers = Readers, writer = Writer, batch = Batch,
-        source = Source, target = Target,
-        pending_fetch = Fetch, flush_waiter = FlushWaiter
-    } = State,
-    case Readers -- [Pid] of
-    Readers ->
-        {noreply, State};
-    Readers2 ->
-        State2 = case Fetch of
-        nil ->
-            case (FlushWaiter =/= nil) andalso (Writer =:= nil) andalso
-                (Readers2 =:= [])  of
-            true ->
-                State#state{
-                    readers = Readers2,
-                    writer = spawn_writer(Target, Batch)
-                };
-            false ->
-                State#state{readers = Readers2}
-            end;
-        {From, FetchParams} ->
-            Reader = spawn_doc_reader(Source, Target, FetchParams),
-            gen_server:reply(From, ok),
-            State#state{
-                readers = [Reader | Readers2],
-                pending_fetch = nil
-            }
-        end,
-        {noreply, State2}
-    end;
-
-handle_info({'EXIT', Pid, Reason}, State) ->
-   {stop, {process_died, Pid, Reason}, State}.
-
-
-terminate(_Reason, State) ->
-    close_db(State#state.source),
-    close_db(State#state.target),
-    stop_db_compaction_notifier(State#state.source_db_compaction_notifier),
-    stop_db_compaction_notifier(State#state.target_db_compaction_notifier).
-
-
-code_change(_OldVsn, State, _Extra) ->
-    {ok, State}.
-
-
-queue_fetch_loop(Source, Target, Parent, Cp, ChangesManager) ->
-    ChangesManager ! {get_changes, self()},
-    receive
-    {closed, ChangesManager} ->
-        ok;
-    {changes, ChangesManager, Changes, ReportSeq} ->
-        Target2 = open_db(Target),
-        {IdRevs, Stats0} = find_missing(Changes, Target2),
-        case Source of
-        #db{} ->
-            Source2 = open_db(Source),
-            Stats = local_process_batch(
-                IdRevs, Cp, Source2, Target2, #batch{}, Stats0),
-            close_db(Source2);
-        #httpdb{} ->
-            ok = gen_server:call(Parent, {add_stats, Stats0}, infinity),
-            remote_process_batch(IdRevs, Parent),
-            {ok, Stats} = gen_server:call(Parent, flush, infinity)
-        end,
-        close_db(Target2),
-        ok = gen_server:call(Cp, {report_seq_done, ReportSeq, Stats}, infinity),
-        erlang:put(last_stats_report, now()),
-        ?LOG_DEBUG("Worker reported completion of seq ~p", [ReportSeq]),
-        queue_fetch_loop(Source, Target, Parent, Cp, ChangesManager)
-    end.
-
-
-local_process_batch([], _Cp, _Src, _Tgt, #batch{docs = []}, Stats) ->
-    Stats;
-
-local_process_batch([], Cp, Source, Target, #batch{docs = Docs, size = Size}, Stats) ->
-    case Target of
-    #httpdb{} ->
-        ?LOG_DEBUG("Worker flushing doc batch of size ~p bytes", [Size]);
-    #db{} ->
-        ?LOG_DEBUG("Worker flushing doc batch of ~p docs", [Size])
-    end,
-    Stats2 = flush_docs(Target, Docs),
-    Stats3 = couch_replicator_utils:sum_stats(Stats, Stats2),
-    local_process_batch([], Cp, Source, Target, #batch{}, Stats3);
-
-local_process_batch([IdRevs | Rest], Cp, Source, Target, Batch, Stats) ->
-    {ok, {_, DocList, Stats2, _}} = fetch_doc(
-        Source, IdRevs, fun local_doc_handler/2, {Target, [], Stats, Cp}),
-    {Batch2, Stats3} = lists:foldl(
-        fun(Doc, {Batch0, Stats0}) ->
-            {Batch1, S} = maybe_flush_docs(Target, Batch0, Doc),
-            {Batch1, couch_replicator_utils:sum_stats(Stats0, S)}
-        end,
-        {Batch, Stats2}, DocList),
-    local_process_batch(Rest, Cp, Source, Target, Batch2, Stats3).
-
-
-remote_process_batch([], _Parent) ->
-    ok;
-
-remote_process_batch([{Id, Revs, PAs} | Rest], Parent) ->
-    % When the source is a remote database, we fetch a single document revision
-    % per HTTP request. This is mostly to facilitate retrying of HTTP requests
-    % due to network transient failures. It also helps not exceeding the maximum
-    % URL length allowed by proxies and Mochiweb.
-    lists:foreach(
-        fun(Rev) ->
-            ok = gen_server:call(Parent, {fetch_doc, {Id, [Rev], PAs}}, infinity)
-        end,
-        Revs),
-    remote_process_batch(Rest, Parent).
-
-
-spawn_doc_reader(Source, Target, FetchParams) ->
-    Parent = self(),
-    spawn_link(fun() ->
-        Source2 = open_db(Source),
-        fetch_doc(
-            Source2, FetchParams, fun remote_doc_handler/2, {Parent, Target}),
-        close_db(Source2)
-    end).
-
-
-fetch_doc(Source, {Id, Revs, PAs}, DocHandler, Acc) ->
-    try
-        couch_replicator_api_wrap:open_doc_revs(
-            Source, Id, Revs, [{atts_since, PAs}, latest], DocHandler, Acc)
-    catch
-    throw:{missing_stub, _} ->
-        ?LOG_ERROR("Retrying fetch and update of document `~s` due to out of "
-            "sync attachment stubs. Missing revisions are: ~s",
-            [Id, couch_doc:revs_to_strs(Revs)]),
-        couch_replicator_api_wrap:open_doc_revs(Source, Id, Revs, [latest], DocHandler, Acc)
-    end.
-
-
-local_doc_handler({ok, Doc}, {Target, DocList, Stats, Cp}) ->
-    Stats2 = ?inc_stat(#rep_stats.docs_read, Stats, 1),
-    case batch_doc(Doc) of
-    true ->
-        {ok, {Target, [Doc | DocList], Stats2, Cp}};
-    false ->
-        ?LOG_DEBUG("Worker flushing doc with attachments", []),
-        Target2 = open_db(Target),
-        Success = (flush_doc(Target2, Doc) =:= ok),
-        close_db(Target2),
-        Stats3 = case Success of
-        true ->
-            ?inc_stat(#rep_stats.docs_written, Stats2, 1);
-        false ->
-            ?inc_stat(#rep_stats.doc_write_failures, Stats2, 1)
-        end,
-        Stats4 = maybe_report_stats(Cp, Stats3),
-        {ok, {Target, DocList, Stats4, Cp}}
-    end;
-local_doc_handler(_, Acc) ->
-    {ok, Acc}.
-
-
-remote_doc_handler({ok, #doc{atts = []} = Doc}, {Parent, _} = Acc) ->
-    ok = gen_server:call(Parent, {batch_doc, Doc}, infinity),
-    {ok, Acc};
-remote_doc_handler({ok, Doc}, {Parent, Target} = Acc) ->
-    % Immediately flush documents with attachments received from a remote
-    % source. The data property of each attachment is a function that starts
-    % streaming the attachment data from the remote source, therefore it's
-    % convenient to call it ASAP to avoid ibrowse inactivity timeouts.
-    Stats = #rep_stats{docs_read = 1},
-    ?LOG_DEBUG("Worker flushing doc with attachments", []),
-    Target2 = open_db(Target),
-    Success = (flush_doc(Target2, Doc) =:= ok),
-    close_db(Target2),
-    {Result, Stats2} = case Success of
-    true ->
-        {{ok, Acc}, ?inc_stat(#rep_stats.docs_written, Stats, 1)};
-    false ->
-        {{skip, Acc}, ?inc_stat(#rep_stats.doc_write_failures, Stats, 1)}
-    end,
-    ok = gen_server:call(Parent, {add_stats, Stats2}, infinity),
-    Result;
-remote_doc_handler(_, Acc) ->
-    {ok, Acc}.
-
-
-spawn_writer(Target, #batch{docs = DocList, size = Size}) ->
-    case {Target, Size > 0} of
-    {#httpdb{}, true} ->
-        ?LOG_DEBUG("Worker flushing doc batch of size ~p bytes", [Size]);
-    {#db{}, true} ->
-        ?LOG_DEBUG("Worker flushing doc batch of ~p docs", [Size]);
-    _ ->
-        ok
-    end,
-    Parent = self(),
-    spawn_link(
-        fun() ->
-            Target2 = open_db(Target),
-            Stats = flush_docs(Target2, DocList),
-            close_db(Target2),
-            ok = gen_server:call(Parent, {add_stats, Stats}, infinity)
-        end).
-
-
-after_full_flush(#state{stats = Stats, flush_waiter = Waiter} = State) ->
-    gen_server:reply(Waiter, {ok, Stats}),
-    erlang:put(last_stats_report, now()),
-    State#state{
-        stats = #rep_stats{},
-        flush_waiter = nil,
-        writer = nil,
-        batch = #batch{}
-    }.
-
-
-maybe_flush_docs(Doc,State) ->
-    #state{
-        target = Target, batch = Batch,
-        stats = Stats, cp = Cp
-    } = State,
-    {Batch2, WStats} = maybe_flush_docs(Target, Batch, Doc),
-    Stats2 = couch_replicator_utils:sum_stats(Stats, WStats),
-    Stats3 = ?inc_stat(#rep_stats.docs_read, Stats2, 1),
-    Stats4 = maybe_report_stats(Cp, Stats3),
-    State#state{stats = Stats4, batch = Batch2}.
-
-
-maybe_flush_docs(#httpdb{} = Target, Batch, Doc) ->
-    #batch{docs = DocAcc, size = SizeAcc} = Batch,
-    case batch_doc(Doc) of
-    false ->
-        ?LOG_DEBUG("Worker flushing doc with attachments", []),
-        case flush_doc(Target, Doc) of
-        ok ->
-            {Batch, #rep_stats{docs_written = 1}};
-        _ ->
-            {Batch, #rep_stats{doc_write_failures = 1}}
-        end;
-    true ->
-        JsonDoc = ?JSON_ENCODE(couch_doc:to_json_obj(Doc, [revs, attachments])),
-        case SizeAcc + iolist_size(JsonDoc) of
-        SizeAcc2 when SizeAcc2 > ?DOC_BUFFER_BYTE_SIZE ->
-            ?LOG_DEBUG("Worker flushing doc batch of size ~p bytes", [SizeAcc2]),
-            Stats = flush_docs(Target, [JsonDoc | DocAcc]),
-            {#batch{}, Stats};
-        SizeAcc2 ->
-            {#batch{docs = [JsonDoc | DocAcc], size = SizeAcc2}, #rep_stats{}}
-        end
-    end;
-
-maybe_flush_docs(#db{} = Target, #batch{docs = DocAcc, size = SizeAcc}, Doc) ->
-    case SizeAcc + 1 of
-    SizeAcc2 when SizeAcc2 >= ?DOC_BUFFER_LEN ->
-        ?LOG_DEBUG("Worker flushing doc batch of ~p docs", [SizeAcc2]),
-        Stats = flush_docs(Target, [Doc | DocAcc]),
-        {#batch{}, Stats};
-    SizeAcc2 ->
-        {#batch{docs = [Doc | DocAcc], size = SizeAcc2}, #rep_stats{}}
-    end.
-
-
-batch_doc(#doc{atts = []}) ->
-    true;
-batch_doc(#doc{atts = Atts}) ->
-    (length(Atts) =< ?MAX_BULK_ATTS_PER_DOC) andalso
-        lists:all(
-            fun(#att{disk_len = L, data = Data}) ->
-                (L =< ?MAX_BULK_ATT_SIZE) andalso (Data =/= stub)
-            end, Atts).
-
-
-flush_docs(_Target, []) ->
-    #rep_stats{};
-
-flush_docs(Target, DocList) ->
-    {ok, Errors} = couch_replicator_api_wrap:update_docs(
-        Target, DocList, [delay_commit], replicated_changes),
-    DbUri = couch_replicator_api_wrap:db_uri(Target),
-    lists:foreach(
-        fun({Props}) ->
-            ?LOG_ERROR("Replicator: couldn't write document `~s`, revision `~s`,"
-                " to target database `~s`. Error: `~s`, reason: `~s`.",
-                [get_value(id, Props, ""), get_value(rev, Props, ""), DbUri,
-                    get_value(error, Props, ""), get_value(reason, Props, "")])
-        end, Errors),
-    #rep_stats{
-        docs_written = length(DocList) - length(Errors),
-        doc_write_failures = length(Errors)
-    }.
-
-flush_doc(Target, #doc{id = Id, revs = {Pos, [RevId | _]}} = Doc) ->
-    try couch_replicator_api_wrap:update_doc(Target, Doc, [], replicated_changes) of
-    {ok, _} ->
-        ok;
-    Error ->
-        ?LOG_ERROR("Replicator: error writing document `~s` to `~s`: ~s",
-            [Id, couch_replicator_api_wrap:db_uri(Target), couch_util:to_binary(Error)]),
-        Error
-    catch
-    throw:{missing_stub, _} = MissingStub ->
-        throw(MissingStub);
-    throw:{Error, Reason} ->
-        ?LOG_ERROR("Replicator: couldn't write document `~s`, revision `~s`,"
-            " to target database `~s`. Error: `~s`, reason: `~s`.",
-            [Id, couch_doc:rev_to_str({Pos, RevId}),
-                couch_replicator_api_wrap:db_uri(Target), to_binary(Error), to_binary(Reason)]),
-        {error, Error};
-    throw:Err ->
-        ?LOG_ERROR("Replicator: couldn't write document `~s`, revision `~s`,"
-            " to target database `~s`. Error: `~s`.",
-            [Id, couch_doc:rev_to_str({Pos, RevId}),
-                couch_replicator_api_wrap:db_uri(Target), to_binary(Err)]),
-        {error, Err}
-    end.
-
-
-find_missing(DocInfos, Target) ->
-    {IdRevs, AllRevsCount} = lists:foldr(
-        fun(#doc_info{id = Id, revs = RevsInfo}, {IdRevAcc, CountAcc}) ->
-            Revs = [Rev || #rev_info{rev = Rev} <- RevsInfo],
-            {[{Id, Revs} | IdRevAcc], CountAcc + length(Revs)}
-        end,
-        {[], 0}, DocInfos),
-    {ok, Missing} = couch_replicator_api_wrap:get_missing_revs(Target, IdRevs),
-    MissingRevsCount = lists:foldl(
-        fun({_Id, MissingRevs, _PAs}, Acc) -> Acc + length(MissingRevs) end,
-        0, Missing),
-    Stats = #rep_stats{
-        missing_checked = AllRevsCount,
-        missing_found = MissingRevsCount
-    },
-    {Missing, Stats}.
-
-
-maybe_report_stats(Cp, Stats) ->
-    Now = now(),
-    case timer:now_diff(erlang:get(last_stats_report), Now) >= ?STATS_DELAY of
-    true ->
-        ok = gen_server:call(Cp, {add_stats, Stats}, infinity),
-        erlang:put(last_stats_report, Now),
-        #rep_stats{};
-    false ->
-        Stats
-    end.

http://git-wip-us.apache.org/repos/asf/couchdb/blob/4c39d7a5/apps/couch_replicator/test/01-load.t
----------------------------------------------------------------------
diff --git a/apps/couch_replicator/test/01-load.t b/apps/couch_replicator/test/01-load.t
deleted file mode 100644
index b900297..0000000
--- a/apps/couch_replicator/test/01-load.t
+++ /dev/null
@@ -1,38 +0,0 @@
-#!/usr/bin/env escript
-%% -*- erlang -*-
-%%! -pa ./deps/*/ebin -pa ./apps/*/ebin -pa ./test/etap
-
-% Licensed 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.
-
-% Test that we can load each module.
-
-main(_) ->
-    test_util:init_code_path(),
-    Modules = [
-        couch_replicator_api_wrap,
-        couch_replicator_httpc,
-        couch_replicator_httpd,
-        couch_replicator_manager,
-        couch_replicator_notifier,
-        couch_replicator,
-        couch_replicator_worker,
-        couch_replicator_utils,
-        couch_replicator_job_sup
-    ],
-
-    etap:plan(length(Modules)),
-    lists:foreach(
-        fun(Module) ->
-            etap:loaded_ok(Module, lists:concat(["Loaded: ", Module]))
-        end, Modules),
-    etap:end_tests().

http://git-wip-us.apache.org/repos/asf/couchdb/blob/4c39d7a5/apps/couch_replicator/test/02-httpc-pool.t
----------------------------------------------------------------------
diff --git a/apps/couch_replicator/test/02-httpc-pool.t b/apps/couch_replicator/test/02-httpc-pool.t
deleted file mode 100755
index 560b6a1..0000000
--- a/apps/couch_replicator/test/02-httpc-pool.t
+++ /dev/null
@@ -1,249 +0,0 @@
-#!/usr/bin/env escript
-%% -*- erlang -*-
-%%! -pa ./deps/*/ebin -pa ./apps/*/ebin -pa ./test/etap
-
-% Licensed 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.
-
-main(_) ->
-    etap:plan(55),
-    case (catch test()) of
-        ok ->
-            etap:end_tests();
-        Other ->
-            etap:diag(io_lib:format("Test died abnormally: ~p", [Other])),
-            etap:bail(Other)
-    end,
-    ok.
-
-
-test() ->
-    test_util:start_couch(),
-
-    test_pool_full(),
-    test_worker_dead_pool_non_full(),
-    test_worker_dead_pool_full(),
-
-    test_util:stop_couch(),
-    ok.
-
-
-test_pool_full() ->
-    Pool = spawn_pool(),
-    Client1 = spawn_client(Pool),
-    Client2 = spawn_client(Pool),
-    Client3 = spawn_client(Pool),
-
-    etap:diag("Check that we can spawn the max number of connections."),
-    etap:is(ping_client(Client1), ok, "Client 1 started ok."),
-    etap:is(ping_client(Client2), ok, "Client 2 started ok."),
-    etap:is(ping_client(Client3), ok, "Client 3 started ok."),
-
-    Worker1 = get_client_worker(Client1, "1"),
-    Worker2 = get_client_worker(Client2, "2"),
-    Worker3 = get_client_worker(Client3, "3"),
-    etap:is(is_process_alive(Worker1), true, "Client's 1 worker is alive."),
-    etap:is(is_process_alive(Worker2), true, "Client's 2 worker is alive."),
-    etap:is(is_process_alive(Worker3), true, "Client's 3 worker is alive."),
-
-    etap:isnt(Worker1, Worker2, "Clients 1 and 2 got different workers."),
-    etap:isnt(Worker2, Worker3, "Clients 2 and 3 got different workers."),
-    etap:isnt(Worker1, Worker3, "Clients 1 and 3 got different workers."),
-
-    etap:diag("Check that client 4 blocks waiting for a worker."),
-    Client4 = spawn_client(Pool),
-    etap:is(ping_client(Client4), timeout, "Client 4 blocked while waiting."),
-
-    etap:diag("Check that stopping a client gives up its worker."),
-    etap:is(stop_client(Client1), ok, "First client stopped."),
-
-    etap:diag("And check that our blocked client has been unblocked."),
-    etap:is(ping_client(Client4), ok, "Client 4 was unblocked."),
-
-    Worker4 = get_client_worker(Client4, "4"),
-    etap:is(is_process_alive(Worker4), true, "Client's 4 worker is alive."),
-    etap:is(Worker4, Worker1, "Client 4 got worker that client 1 got before."),
-
-    lists:foreach(fun(C) -> ok = stop_client(C) end, [Client2, Client3, Client4]),
-    stop_pool(Pool).
-
-
-test_worker_dead_pool_non_full() ->
-    Pool = spawn_pool(),
-    Client1 = spawn_client(Pool),
-
-    etap:is(ping_client(Client1), ok, "Client 1 started ok."),
-    Worker1 = get_client_worker(Client1, "1"),
-    etap:is(is_process_alive(Worker1), true, "Client's 1 worker is alive."),
-
-    etap:diag("Kill client's 1 worker."),
-    etap:is(kill_client_worker(Client1), ok, "Killed client's 1 worker."),
-    etap:is(is_process_alive(Worker1), false, "Client's 1 worker process is dead."),
-
-    etap:is(stop_client(Client1), ok, "First client stopped and released its worker."),
-
-    Client2 = spawn_client(Pool),
-    etap:is(ping_client(Client2), ok, "Client 2 started ok."),
-    Worker2 = get_client_worker(Client2, "2"),
-    etap:isnt(Worker2, Worker1, "Client 2 got a different worker from client 1"),
-    etap:is(is_process_alive(Worker2), true, "Client's 2 worker is alive."),
-
-    etap:is(stop_client(Client2), ok, "Second client stopped."),
-    stop_pool(Pool).
-
-
-test_worker_dead_pool_full() ->
-    Pool = spawn_pool(),
-    Client1 = spawn_client(Pool),
-    Client2 = spawn_client(Pool),
-    Client3 = spawn_client(Pool),
-
-    etap:diag("Check that we can spawn the max number of connections."),
-    etap:is(ping_client(Client1), ok, "Client 1 started ok."),
-    etap:is(ping_client(Client2), ok, "Client 2 started ok."),
-    etap:is(ping_client(Client3), ok, "Client 3 started ok."),
-
-    Worker1 = get_client_worker(Client1, "1"),
-    Worker2 = get_client_worker(Client2, "2"),
-    Worker3 = get_client_worker(Client3, "3"),
-    etap:is(is_process_alive(Worker1), true, "Client's 1 worker is alive."),
-    etap:is(is_process_alive(Worker2), true, "Client's 2 worker is alive."),
-    etap:is(is_process_alive(Worker3), true, "Client's 3 worker is alive."),
-
-    etap:isnt(Worker1, Worker2, "Clients 1 and 2 got different workers."),
-    etap:isnt(Worker2, Worker3, "Clients 2 and 3 got different workers."),
-    etap:isnt(Worker1, Worker3, "Clients 1 and 3 got different workers."),
-
-    etap:diag("Check that client 4 blocks waiting for a worker."),
-    Client4 = spawn_client(Pool),
-    etap:is(ping_client(Client4), timeout, "Client 4 blocked while waiting."),
-
-    etap:diag("Kill client's 1 worker."),
-    etap:is(kill_client_worker(Client1), ok, "Killed client's 1 worker."),
-    etap:is(is_process_alive(Worker1), false, "Client's 1 worker process is dead."),
-
-    etap:diag("Check client 4 got unblocked after first worker's death"),
-    etap:is(ping_client(Client4), ok, "Client 4 not blocked anymore."),
-
-    Worker4 = get_client_worker(Client4, "4"),
-    etap:is(is_process_alive(Worker4), true, "Client's 4 worker is alive."),
-    etap:isnt(Worker4, Worker1, "Client 4 got a worker different from client 1."),
-    etap:isnt(Worker4, Worker2, "Client 4 got a worker different from client 2."),
-    etap:isnt(Worker4, Worker3, "Client 4 got a worker different from client 3."),
-
-    etap:diag("Check that stopping client 1 is a noop."),
-    etap:is(stop_client(Client1), ok, "First client stopped."),
-
-    etap:is(is_process_alive(Worker2), true, "Client's 2 worker still alive."),
-    etap:is(is_process_alive(Worker3), true, "Client's 3 worker still alive."),
-    etap:is(is_process_alive(Worker4), true, "Client's 4 worker still alive."),
-
-    etap:diag("Check that client 5 blocks waiting for a worker."),
-    Client5 = spawn_client(Pool),
-    etap:is(ping_client(Client5), timeout, "Client 5 blocked while waiting."),
-
-    etap:diag("Check that stopping client 2 gives up its worker."),
-    etap:is(stop_client(Client2), ok, "Second client stopped."),
-
-    etap:diag("Now check that client 5 has been unblocked."),
-    etap:is(ping_client(Client5), ok, "Client 5 was unblocked."),
-
-    Worker5 = get_client_worker(Client5, "5"),
-    etap:is(is_process_alive(Worker5), true, "Client's 5 worker is alive."),
-    etap:isnt(Worker5, Worker1, "Client 5 got a worker different from client 1."),
-    etap:is(Worker5, Worker2, "Client 5 got same worker as client 2."),
-    etap:isnt(Worker5, Worker3, "Client 5 got a worker different from client 3."),
-    etap:isnt(Worker5, Worker4, "Client 5 got a worker different from client 4."),
-
-    etap:is(is_process_alive(Worker3), true, "Client's 3 worker still alive."),
-    etap:is(is_process_alive(Worker4), true, "Client's 4 worker still alive."),
-    etap:is(is_process_alive(Worker5), true, "Client's 5 worker still alive."),
-
-    lists:foreach(fun(C) -> ok = stop_client(C) end, [Client3, Client4, Client5]),
-    stop_pool(Pool).
-
-
-spawn_client(Pool) ->
-    Parent = self(),
-    Ref = make_ref(),
-    Pid = spawn(fun() ->
-        {ok, Worker} = couch_replicator_httpc_pool:get_worker(Pool),
-        loop(Parent, Ref, Worker, Pool)
-    end),
-    {Pid, Ref}.
-
-
-ping_client({Pid, Ref}) ->
-    Pid ! ping,
-    receive
-        {pong, Ref} ->
-            ok
-    after 3000 ->
-        timeout
-    end.
-
-
-get_client_worker({Pid, Ref}, ClientName) ->
-    Pid ! get_worker,
-    receive
-        {worker, Ref, Worker} ->
-            Worker
-    after 3000 ->
-        etap:bail("Timeout getting client " ++ ClientName ++ " worker.")
-    end.
-
-
-stop_client({Pid, Ref}) ->
-    Pid ! stop,
-    receive
-        {stop, Ref} ->
-            ok
-    after 3000 ->
-        timeout
-    end.
-
-
-kill_client_worker({Pid, Ref}) ->
-    Pid ! get_worker,
-    receive
-        {worker, Ref, Worker} ->
-            exit(Worker, kill),
-            ok
-    after 3000 ->
-        timeout
-    end.
-
-
-loop(Parent, Ref, Worker, Pool) ->
-    receive
-        ping ->
-            Parent ! {pong, Ref},
-            loop(Parent, Ref, Worker, Pool);
-        get_worker  ->
-            Parent ! {worker, Ref, Worker},
-            loop(Parent, Ref, Worker, Pool);
-        stop ->
-            couch_replicator_httpc_pool:release_worker(Pool, Worker),
-            Parent ! {stop, Ref}
-    end.
-
-
-spawn_pool() ->
-    Host = couch_config:get("httpd", "bind_address", "127.0.0.1"),
-    Port = couch_config:get("httpd", "port", "5984"),
-    {ok, Pool} = couch_replicator_httpc_pool:start_link(
-        "http://" ++ Host ++ ":5984", [{max_connections, 3}]),
-    Pool.
-
-
-stop_pool(Pool) ->
-    ok = couch_replicator_httpc_pool:stop(Pool).

http://git-wip-us.apache.org/repos/asf/couchdb/blob/4c39d7a5/apps/couch_replicator/test/03-replication-compact.t
----------------------------------------------------------------------
diff --git a/apps/couch_replicator/test/03-replication-compact.t b/apps/couch_replicator/test/03-replication-compact.t
deleted file mode 100755
index 2deb9dd..0000000
--- a/apps/couch_replicator/test/03-replication-compact.t
+++ /dev/null
@@ -1,489 +0,0 @@
-#!/usr/bin/env escript
-%% -*- erlang -*-
-%%! -pa ./deps/*/ebin -pa ./apps/*/ebin -pa ./test/etap
-
-% Licensed 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.
-
-% Verify that compacting databases that are being used as the source or
-% target of a replication doesn't affect the replication and that the
-% replication doesn't hold their reference counters forever.
-
--define(b2l(B), binary_to_list(B)).
-
--record(user_ctx, {
-    name = null,
-    roles = [],
-    handler
-}).
-
--record(db, {
-    main_pid = nil,
-    update_pid = nil,
-    compactor_pid = nil,
-    instance_start_time, % number of microsecs since jan 1 1970 as a binary string
-    fd,
-    updater_fd,
-    fd_ref_counter,
-    header = nil,
-    committed_update_seq,
-    fulldocinfo_by_id_btree,
-    docinfo_by_seq_btree,
-    local_docs_btree,
-    update_seq,
-    name,
-    filepath,
-    validate_doc_funs = [],
-    security = [],
-    security_ptr = nil,
-    user_ctx = #user_ctx{},
-    waiting_delayed_commit = nil,
-    revs_limit = 1000,
-    fsync_options = [],
-    options = [],
-    compression,
-    before_doc_update,
-    after_doc_read
-}).
-
--record(rep, {
-    id,
-    source,
-    target,
-    options,
-    user_ctx,
-    type = db,
-    view = nil,
-    doc_id
-}).
-
-
-source_db_name() -> <<"couch_test_rep_db_a">>.
-target_db_name() -> <<"couch_test_rep_db_b">>.
-
-
-main(_) ->
-etap:plan(376),
-    case (catch test()) of
-        ok ->
-            etap:end_tests();
-        Other ->
-            etap:diag(io_lib:format("Test died abnormally: ~p", [Other])),
-            etap:bail(Other)
-    end,
-    ok.
-
-
-test() ->
-    test_util:start_couch(),
-
-    Pairs = [
-        {source_db_name(), target_db_name()},
-        {{remote, source_db_name()}, target_db_name()},
-        {source_db_name(), {remote, target_db_name()}},
-        {{remote, source_db_name()}, {remote, (target_db_name())}}
-    ],
-
-    lists:foreach(
-        fun({Source, Target}) ->
-            {ok, SourceDb} = create_db(source_db_name()),
-            etap:is(couch_db:is_idle(SourceDb), true,
-                "Source database is idle before starting replication"),
-
-            {ok, TargetDb} = create_db(target_db_name()),
-            etap:is(couch_db:is_idle(TargetDb), true,
-                "Target database is idle before starting replication"),
-
-            {ok, RepPid, RepId} = replicate(Source, Target),
-            check_active_tasks(RepPid, RepId, Source, Target),
-            {ok, DocsWritten} = populate_and_compact_test(
-                RepPid, SourceDb, TargetDb),
-
-            wait_target_in_sync(DocsWritten, TargetDb),
-            check_active_tasks(RepPid, RepId, Source, Target),
-            cancel_replication(RepId, RepPid),
-            compare_dbs(SourceDb, TargetDb),
-
-            delete_db(SourceDb),
-            delete_db(TargetDb),
-            test_util:stop_couch(),
-            ok = timer:sleep(1000),
-            test_util:start_couch()
-        end,
-        Pairs),
-
-    test_util:stop_couch(),
-    ok.
-
-
-populate_and_compact_test(RepPid, SourceDb0, TargetDb0) ->
-    etap:is(is_process_alive(RepPid), true, "Replication process is alive"),
-    check_db_alive("source", SourceDb0),
-    check_db_alive("target", TargetDb0),
-
-    Writer = spawn_writer(SourceDb0),
-
-    lists:foldl(
-        fun(_, {SourceDb, TargetDb, DocCount}) ->
-            pause_writer(Writer),
-
-            compact_db("source", SourceDb),
-            etap:is(is_process_alive(RepPid), true,
-                "Replication process is alive after source database compaction"),
-            check_db_alive("source", SourceDb),
-            check_ref_counter("source", SourceDb),
-
-            compact_db("target", TargetDb),
-            etap:is(is_process_alive(RepPid), true,
-                "Replication process is alive after target database compaction"),
-            check_db_alive("target", TargetDb),
-            check_ref_counter("target", TargetDb),
-
-            {ok, SourceDb2} = reopen_db(SourceDb),
-            {ok, TargetDb2} = reopen_db(TargetDb),
-
-            resume_writer(Writer),
-            wait_writer(Writer, DocCount),
-
-            compact_db("source", SourceDb2),
-            etap:is(is_process_alive(RepPid), true,
-                "Replication process is alive after source database compaction"),
-            check_db_alive("source", SourceDb2),
-            pause_writer(Writer),
-            check_ref_counter("source", SourceDb2),
-            resume_writer(Writer),
-
-            compact_db("target", TargetDb2),
-            etap:is(is_process_alive(RepPid), true,
-                "Replication process is alive after target database compaction"),
-            check_db_alive("target", TargetDb2),
-            pause_writer(Writer),
-            check_ref_counter("target", TargetDb2),
-            resume_writer(Writer),
-
-            {ok, SourceDb3} = reopen_db(SourceDb2),
-            {ok, TargetDb3} = reopen_db(TargetDb2),
-            {SourceDb3, TargetDb3, DocCount + 50}
-        end,
-        {SourceDb0, TargetDb0, 50}, lists:seq(1, 5)),
-
-    DocsWritten = stop_writer(Writer),
-    {ok, DocsWritten}.
-
-
-check_db_alive(Type, #db{main_pid = Pid}) ->
-    etap:is(is_process_alive(Pid), true,
-        "Local " ++ Type ++ " database main pid is alive").
-
-
-compact_db(Type, #db{name = Name}) ->
-    {ok, Db} = couch_db:open_int(Name, []),
-    {ok, CompactPid} = couch_db:start_compact(Db),
-    MonRef = erlang:monitor(process, CompactPid),
-    receive
-    {'DOWN', MonRef, process, CompactPid, normal} ->
-        ok;
-    {'DOWN', MonRef, process, CompactPid, Reason} ->
-        etap:bail("Error compacting " ++ Type ++ " database " ++ ?b2l(Name) ++
-            ": " ++ couch_util:to_list(Reason))
-    after 30000 ->
-        etap:bail("Compaction for " ++ Type ++ " database " ++ ?b2l(Name) ++
-            " didn't finish")
-    end,
-    ok = couch_db:close(Db).
-
-
-check_ref_counter(Type, #db{name = Name, fd_ref_counter = OldRefCounter}) ->
-    MonRef = erlang:monitor(process, OldRefCounter),
-    receive
-    {'DOWN', MonRef, process, OldRefCounter, _} ->
-        etap:diag("Old " ++ Type ++ " database ref counter terminated")
-    after 30000 ->
-        etap:bail("Old " ++ Type ++ " database ref counter didn't terminate")
-    end,
-    {ok, #db{fd_ref_counter = NewRefCounter} = Db} = couch_db:open_int(Name, []),
-    ok = couch_db:close(Db),
-    etap:isnt(
-        NewRefCounter, OldRefCounter, Type ++ " database has new ref counter").
-
-
-reopen_db(#db{name = Name}) ->
-    {ok, Db} = couch_db:open_int(Name, []),
-    ok = couch_db:close(Db),
-    {ok, Db}.
-
-
-wait_target_in_sync(DocCount, #db{name = TargetName}) ->
-    wait_target_in_sync_loop(DocCount, TargetName, 300).
-
-
-wait_target_in_sync_loop(_DocCount, _TargetName, 0) ->
-    etap:bail("Could not get source and target databases in sync");
-wait_target_in_sync_loop(DocCount, TargetName, RetriesLeft) ->
-    {ok, Target} = couch_db:open_int(TargetName, []),
-    {ok, TargetInfo} = couch_db:get_db_info(Target),
-    ok = couch_db:close(Target),
-    TargetDocCount = couch_util:get_value(doc_count, TargetInfo),
-    case TargetDocCount == DocCount of
-    true ->
-        etap:diag("Source and target databases are in sync");
-    false ->
-        ok = timer:sleep(100),
-        wait_target_in_sync_loop(DocCount, TargetName, RetriesLeft - 1)
-    end.
-
-
-compare_dbs(#db{name = SourceName}, #db{name = TargetName}) ->
-    {ok, SourceDb} = couch_db:open_int(SourceName, []),
-    {ok, TargetDb} = couch_db:open_int(TargetName, []),
-    Fun = fun(FullDocInfo, _, Acc) ->
-        {ok, Doc} = couch_db:open_doc(SourceDb, FullDocInfo),
-        {Props} = DocJson = couch_doc:to_json_obj(Doc, [attachments]),
-        DocId = couch_util:get_value(<<"_id">>, Props),
-        DocTarget = case couch_db:open_doc(TargetDb, DocId) of
-        {ok, DocT} ->
-            DocT;
-        Error ->
-            etap:bail("Error opening document '" ++ ?b2l(DocId) ++
-                "' from target: " ++ couch_util:to_list(Error))
-        end,
-        DocTargetJson = couch_doc:to_json_obj(DocTarget, [attachments]),
-        case DocTargetJson of
-        DocJson ->
-            ok;
-        _ ->
-            etap:bail("Content from document '" ++ ?b2l(DocId) ++
-                "' differs in target database")
-        end,
-        {ok, Acc}
-    end,
-    {ok, _, _} = couch_db:enum_docs(SourceDb, Fun, [], []),
-    etap:diag("Target database has the same documents as the source database"),
-    ok = couch_db:close(SourceDb),
-    ok = couch_db:close(TargetDb).
-
-
-check_active_tasks(RepPid, {BaseId, Ext} = _RepId, Src, Tgt) ->
-    Source = case Src of
-    {remote, NameSrc} ->
-        <<(db_url(NameSrc))/binary, $/>>;
-    _ ->
-        Src
-    end,
-    Target = case Tgt of
-    {remote, NameTgt} ->
-        <<(db_url(NameTgt))/binary, $/>>;
-    _ ->
-        Tgt
-    end,
-    FullRepId = list_to_binary(BaseId ++ Ext),
-    Pid = list_to_binary(pid_to_list(RepPid)),
-    [RepTask] = couch_task_status:all(),
-    etap:is(couch_util:get_value(pid, RepTask), Pid,
-        "_active_tasks entry has correct pid property"),
-    etap:is(couch_util:get_value(replication_id, RepTask), FullRepId,
-        "_active_tasks entry has right replication id"),
-    etap:is(couch_util:get_value(continuous, RepTask), true,
-        "_active_tasks entry has continuous property set to true"),
-    etap:is(couch_util:get_value(source, RepTask), Source,
-        "_active_tasks entry has correct source property"),
-    etap:is(couch_util:get_value(target, RepTask), Target,
-        "_active_tasks entry has correct target property"),
-    etap:is(is_integer(couch_util:get_value(docs_read, RepTask)), true,
-        "_active_tasks entry has integer docs_read property"),
-    etap:is(is_integer(couch_util:get_value(docs_written, RepTask)), true,
-        "_active_tasks entry has integer docs_written property"),
-    etap:is(is_integer(couch_util:get_value(doc_write_failures, RepTask)), true,
-        "_active_tasks entry has integer doc_write_failures property"),
-    etap:is(is_integer(couch_util:get_value(revisions_checked, RepTask)), true,
-        "_active_tasks entry has integer revisions_checked property"),
-    etap:is(is_integer(couch_util:get_value(missing_revisions_found, RepTask)), true,
-        "_active_tasks entry has integer missing_revisions_found property"),
-    etap:is(is_integer(couch_util:get_value(checkpointed_source_seq, RepTask)), true,
-        "_active_tasks entry has integer checkpointed_source_seq property"),
-    etap:is(is_integer(couch_util:get_value(source_seq, RepTask)), true,
-        "_active_tasks entry has integer source_seq property"),
-    Progress = couch_util:get_value(progress, RepTask),
-    etap:is(is_integer(Progress), true,
-        "_active_tasks entry has an integer progress property"),
-    etap:is(Progress =< 100, true, "Progress is not greater than 100%").
-
-
-wait_writer(Pid, NumDocs) ->
-    case get_writer_num_docs_written(Pid) of
-    N when N >= NumDocs ->
-        ok;
-    _ ->
-        wait_writer(Pid, NumDocs)
-    end.
-
-
-spawn_writer(Db) ->
-    Parent = self(),
-    Pid = spawn(fun() -> writer_loop(Db, Parent, 0) end),
-    etap:diag("Started source database writer"),
-    Pid.
-
-
-pause_writer(Pid) ->
-    Ref = make_ref(),
-    Pid ! {pause, Ref},
-    receive
-    {paused, Ref} ->
-        ok
-    after 30000 ->
-        etap:bail("Failed to pause source database writer")
-    end.
-
-
-resume_writer(Pid) ->
-    Ref = make_ref(),
-    Pid ! {continue, Ref},
-    receive
-    {ok, Ref} ->
-        ok
-    after 30000 ->
-        etap:bail("Failed to unpause source database writer")
-    end.
-
-
-get_writer_num_docs_written(Pid) ->
-    Ref = make_ref(),
-    Pid ! {get_count, Ref},
-    receive
-    {count, Ref, Count} ->
-        Count
-    after 30000 ->
-        etap:bail("Timeout getting number of documents written from "
-            "source database writer")
-    end.
-
-
-stop_writer(Pid) ->
-    Ref = make_ref(),
-    Pid ! {stop, Ref},
-    receive
-    {stopped, Ref, DocsWritten} ->
-        MonRef = erlang:monitor(process, Pid),
-        receive
-        {'DOWN', MonRef, process, Pid, _Reason} ->
-            etap:diag("Stopped source database writer"),
-            DocsWritten
-        after 30000 ->
-            etap:bail("Timeout stopping source database writer")
-        end
-    after 30000 ->
-        etap:bail("Timeout stopping source database writer")
-    end.
-
-
-writer_loop(#db{name = DbName}, Parent, Counter) ->
-    maybe_pause(Parent, Counter),
-    Doc = couch_doc:from_json_obj({[
-        {<<"_id">>, list_to_binary(integer_to_list(Counter + 1))},
-        {<<"value">>, Counter + 1},
-        {<<"_attachments">>, {[
-            {<<"icon1.png">>, {[
-                {<<"data">>, base64:encode(att_data())},
-                {<<"content_type">>, <<"image/png">>}
-            ]}},
-            {<<"icon2.png">>, {[
-                {<<"data">>, base64:encode(iolist_to_binary(
-                    [att_data(), att_data()]))},
-                {<<"content_type">>, <<"image/png">>}
-            ]}}
-        ]}}
-    ]}),
-    maybe_pause(Parent, Counter),
-    {ok, Db} = couch_db:open_int(DbName, []),
-    {ok, _} = couch_db:update_doc(Db, Doc, []),
-    ok = couch_db:close(Db),
-    receive
-    {get_count, Ref} ->
-        Parent ! {count, Ref, Counter + 1},
-        writer_loop(Db, Parent, Counter + 1);
-    {stop, Ref} ->
-        Parent ! {stopped, Ref, Counter + 1}
-    after 0 ->
-        ok = timer:sleep(500),
-        writer_loop(Db, Parent, Counter + 1)
-    end.
-
-
-maybe_pause(Parent, Counter) ->
-    receive
-    {get_count, Ref} ->
-        Parent ! {count, Ref, Counter};
-    {pause, Ref} ->
-        Parent ! {paused, Ref},
-        receive {continue, Ref2} -> Parent ! {ok, Ref2} end
-    after 0 ->
-        ok
-    end.
-
-
-db_url(DbName) ->
-    iolist_to_binary([
-        "http://", couch_config:get("httpd", "bind_address", "127.0.0.1"),
-        ":", integer_to_list(mochiweb_socket_server:get(couch_http, port)),
-        "/", DbName
-    ]).
-
-
-create_db(DbName) ->
-    {ok, Db} = couch_db:create(
-        DbName,
-        [{user_ctx, #user_ctx{roles = [<<"_admin">>]}}, overwrite]),
-    couch_db:close(Db),
-    {ok, Db}.
-
-
-delete_db(#db{name = DbName, main_pid = Pid}) ->
-    ok = couch_server:delete(
-        DbName, [{user_ctx, #user_ctx{roles = [<<"_admin">>]}}]),
-    MonRef = erlang:monitor(process, Pid),
-    receive
-    {'DOWN', MonRef, process, Pid, _Reason} ->
-        ok
-    after 30000 ->
-        etap:bail("Timeout deleting database")
-    end.
-
-
-replicate({remote, Db}, Target) ->
-    replicate(db_url(Db), Target);
-
-replicate(Source, {remote, Db}) ->
-    replicate(Source, db_url(Db));
-
-replicate(Source, Target) ->
-    RepObject = {[
-        {<<"source">>, Source},
-        {<<"target">>, Target},
-        {<<"continuous">>, true}
-    ]},
-    {ok, Rep} = couch_replicator_utils:parse_rep_doc(
-        RepObject, #user_ctx{roles = [<<"_admin">>]}),
-    {ok, Pid} = couch_replicator:async_replicate(Rep),
-    {ok, Pid, Rep#rep.id}.
-
-
-cancel_replication(RepId, RepPid) ->
-    {ok, _} = couch_replicator:cancel_replication(RepId),
-    etap:is(is_process_alive(RepPid), false,
-        "Replication process is no longer alive after cancel").
-
-
-att_data() ->
-    {ok, Data} = file:read_file(
-        test_util:build_file("share/www/image/logo.png")),
-    Data.

http://git-wip-us.apache.org/repos/asf/couchdb/blob/4c39d7a5/apps/couch_replicator/test/04-replication-large-atts.t
----------------------------------------------------------------------
diff --git a/apps/couch_replicator/test/04-replication-large-atts.t b/apps/couch_replicator/test/04-replication-large-atts.t
deleted file mode 100755
index c001f3e..0000000
--- a/apps/couch_replicator/test/04-replication-large-atts.t
+++ /dev/null
@@ -1,266 +0,0 @@
-#!/usr/bin/env escript
-%% -*- erlang -*-
-%%! -pa ./deps/*/ebin -pa ./apps/*/ebin -pa ./test/etap
-
-% Licensed 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.
-
-% Test replication of large attachments. Verify that both source and
-% target have the same attachment data and metadata.
-
--define(b2l(Bin), binary_to_list(Bin)).
-
--record(user_ctx, {
-    name = null,
-    roles = [],
-    handler
-}).
-
--record(doc, {
-    id = <<"">>,
-    revs = {0, []},
-    body = {[]},
-    atts = [],
-    deleted = false,
-    meta = []
-}).
-
--record(att, {
-    name,
-    type,
-    att_len,
-    disk_len,
-    md5= <<>>,
-    revpos=0,
-    data,
-    encoding=identity
-}).
-
-
-source_db_name() -> <<"couch_test_rep_db_a">>.
-target_db_name() -> <<"couch_test_rep_db_b">>.
-
-
-main(_) ->
-    etap:plan(1192),
-    case (catch test()) of
-        ok ->
-            etap:end_tests();
-        Other ->
-            etap:diag(io_lib:format("Test died abnormally: ~p", [Other])),
-            etap:bail(Other)
-    end,
-    ok.
-
-
-test() ->
-    test_util:start_couch(),
-
-    couch_config:set("attachments", "compressible_types", "text/*", false),
-
-    Pairs = [
-        {source_db_name(), target_db_name()},
-        {{remote, source_db_name()}, target_db_name()},
-        {source_db_name(), {remote, target_db_name()}},
-        {{remote, source_db_name()}, {remote, (target_db_name())}}
-    ],
-
-    {ok, SourceDb} = create_db(source_db_name()),
-    etap:diag("Populating source database"),
-    populate_db(SourceDb, 11),
-    ok = couch_db:close(SourceDb),
-
-    lists:foreach(
-        fun({Source, Target}) ->
-            etap:diag("Creating target database"),
-            {ok, TargetDb} = create_db(target_db_name()),
-
-            ok = couch_db:close(TargetDb),
-            etap:diag("Triggering replication"),
-            replicate(Source, Target),
-            etap:diag("Replication finished, comparing source and target databases"),
-            compare_dbs(SourceDb, TargetDb),
-
-            etap:diag("Deleting target database"),
-            delete_db(TargetDb),
-            ok = timer:sleep(1000)
-        end,
-        Pairs),
-
-    delete_db(SourceDb),
-    test_util:stop_couch(),
-    ok.
-
-
-populate_db(Db, DocCount) ->
-    Docs = lists:foldl(
-        fun(DocIdCounter, Acc) ->
-            Doc = #doc{
-                id = iolist_to_binary(["doc", integer_to_list(DocIdCounter)]),
-                body = {[]},
-                atts = [
-                    att(<<"att1">>, 2 * 1024 * 1024, <<"text/plain">>),
-                    att(<<"att2">>, round(6.6 * 1024 * 1024), <<"app/binary">>)
-                ]
-            },
-            [Doc | Acc]
-        end,
-        [], lists:seq(1, DocCount)),
-    {ok, _} = couch_db:update_docs(Db, Docs, []).
-
-
-att(Name, Size, Type) ->
-    #att{
-        name = Name,
-        type = Type,
-        att_len = Size,
-        data = fun(Count) -> crypto:rand_bytes(Count) end
-    }.
-
-
-compare_dbs(Source, Target) ->
-    {ok, SourceDb} = couch_db:open_int(couch_db:name(Source), []),
-    {ok, TargetDb} = couch_db:open_int(couch_db:name(Target), []),
-
-    Fun = fun(FullDocInfo, _, Acc) ->
-        {ok, DocSource} = couch_db:open_doc(SourceDb, FullDocInfo),
-        Id = DocSource#doc.id,
-
-        etap:diag("Verifying document " ++ ?b2l(Id)),
-
-        {ok, DocTarget} = couch_db:open_doc(TargetDb, Id),
-        etap:is(DocTarget#doc.body, DocSource#doc.body,
-            "Same body in source and target databases"),
-
-        #doc{atts = SourceAtts} = DocSource,
-        #doc{atts = TargetAtts} = DocTarget,
-        etap:is(
-            lists:sort([N || #att{name = N} <- SourceAtts]),
-            lists:sort([N || #att{name = N} <- TargetAtts]),
-            "Document has same number (and names) of attachments in "
-            "source and target databases"),
-
-        lists:foreach(
-            fun(#att{name = AttName} = Att) ->
-                etap:diag("Verifying attachment " ++ ?b2l(AttName)),
-
-                {ok, AttTarget} = find_att(TargetAtts, AttName),
-                SourceMd5 = att_md5(Att),
-                TargetMd5 = att_md5(AttTarget),
-                case AttName of
-                <<"att1">> ->
-                    etap:is(Att#att.encoding, gzip,
-                        "Attachment is gzip encoded in source database"),
-                    etap:is(AttTarget#att.encoding, gzip,
-                        "Attachment is gzip encoded in target database"),
-                    DecSourceMd5 = att_decoded_md5(Att),
-                    DecTargetMd5 = att_decoded_md5(AttTarget),
-                    etap:is(DecTargetMd5, DecSourceMd5,
-                        "Same identity content in source and target databases");
-                _ ->
-                    etap:is(Att#att.encoding, identity,
-                        "Attachment is not encoded in source database"),
-                    etap:is(AttTarget#att.encoding, identity,
-                        "Attachment is not encoded in target database")
-                end,
-                etap:is(TargetMd5, SourceMd5,
-                    "Same content in source and target databases"),
-                etap:is(is_integer(Att#att.disk_len), true,
-                    "#att.disk_len is an integer in source database"),
-                etap:is(is_integer(Att#att.att_len), true,
-                    "#att.att_len is an integer in source database"),
-                etap:is(is_integer(AttTarget#att.disk_len), true,
-                    "#att.disk_len is an integer in target database"),
-                etap:is(is_integer(AttTarget#att.att_len), true,
-                    "#att.att_len is an integer in target database"),
-                etap:is(Att#att.disk_len, AttTarget#att.disk_len,
-                    "Same identity length in source and target databases"),
-                etap:is(Att#att.att_len, AttTarget#att.att_len,
-                    "Same encoded length in source and target databases"),
-                etap:is(Att#att.type, AttTarget#att.type,
-                    "Same type in source and target databases"),
-                etap:is(Att#att.md5, SourceMd5, "Correct MD5 in source database"),
-                etap:is(AttTarget#att.md5, SourceMd5, "Correct MD5 in target database")
-            end,
-            SourceAtts),
-
-        {ok, Acc}
-    end,
-
-    {ok, _, _} = couch_db:enum_docs(SourceDb, Fun, [], []),
-    ok = couch_db:close(SourceDb),
-    ok = couch_db:close(TargetDb).
-
-
-find_att([], _Name) ->
-    nil;
-find_att([#att{name = Name} = Att | _], Name) ->
-    {ok, Att};
-find_att([_ | Rest], Name) ->
-    find_att(Rest, Name).
-
-
-att_md5(Att) ->
-    Md50 = couch_doc:att_foldl(
-        Att,
-        fun(Chunk, Acc) -> couch_util:md5_update(Acc, Chunk) end,
-        couch_util:md5_init()),
-    couch_util:md5_final(Md50).
-
-att_decoded_md5(Att) ->
-    Md50 = couch_doc:att_foldl_decode(
-        Att,
-        fun(Chunk, Acc) -> couch_util:md5_update(Acc, Chunk) end,
-        couch_util:md5_init()),
-    couch_util:md5_final(Md50).
-
-
-db_url(DbName) ->
-    iolist_to_binary([
-        "http://", couch_config:get("httpd", "bind_address", "127.0.0.1"),
-        ":", integer_to_list(mochiweb_socket_server:get(couch_http, port)),
-        "/", DbName
-    ]).
-
-
-create_db(DbName) ->
-    couch_db:create(
-        DbName,
-        [{user_ctx, #user_ctx{roles = [<<"_admin">>]}}, overwrite]).
-
-
-delete_db(Db) ->
-    ok = couch_server:delete(
-        couch_db:name(Db), [{user_ctx, #user_ctx{roles = [<<"_admin">>]}}]).
-
-
-replicate({remote, Db}, Target) ->
-    replicate(db_url(Db), Target);
-
-replicate(Source, {remote, Db}) ->
-    replicate(Source, db_url(Db));
-
-replicate(Source, Target) ->
-    RepObject = {[
-        {<<"source">>, Source},
-        {<<"target">>, Target}
-    ]},
-    {ok, Rep} = couch_replicator_utils:parse_rep_doc(
-        RepObject, #user_ctx{roles = [<<"_admin">>]}),
-    {ok, Pid} = couch_replicator:async_replicate(Rep),
-    MonRef = erlang:monitor(process, Pid),
-    receive
-    {'DOWN', MonRef, process, Pid, Reason} ->
-        etap:is(Reason, normal, "Replication finished successfully")
-    after 300000 ->
-        etap:bail("Timeout waiting for replication to finish")
-    end.

http://git-wip-us.apache.org/repos/asf/couchdb/blob/4c39d7a5/apps/couch_replicator/test/05-replication-many-leaves.t
----------------------------------------------------------------------
diff --git a/apps/couch_replicator/test/05-replication-many-leaves.t b/apps/couch_replicator/test/05-replication-many-leaves.t
deleted file mode 100755
index c4c0007..0000000
--- a/apps/couch_replicator/test/05-replication-many-leaves.t
+++ /dev/null
@@ -1,295 +0,0 @@
-#!/usr/bin/env escript
-%% -*- erlang -*-
-%%! -pa ./deps/*/ebin -pa ./apps/*/ebin -pa ./test/etap
-
-% Licensed 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.
-
-% Test replication of documents with many leaf revisions.
-% Motivated by COUCHDB-1340 and other similar issues where a document
-% GET with a too long ?open_revs revision list doesn't work due to
-% maximum web server limits for the HTTP request path.
-
--record(user_ctx, {
-    name = null,
-    roles = [],
-    handler
-}).
-
--record(doc, {
-    id = <<"">>,
-    revs = {0, []},
-    body = {[]},
-    atts = [],
-    deleted = false,
-    meta = []
-}).
-
--record(att, {
-    name,
-    type,
-    att_len,
-    disk_len,
-    md5= <<>>,
-    revpos=0,
-    data,
-    encoding=identity
-}).
-
--define(b2l(B), binary_to_list(B)).
--define(l2b(L), list_to_binary(L)).
--define(i2l(I), integer_to_list(I)).
-
-
-source_db_name() -> <<"couch_test_rep_db_a">>.
-target_db_name() -> <<"couch_test_rep_db_b">>.
-
-doc_ids() ->
-    [<<"doc1">>, <<"doc2">>, <<"doc3">>].
-
-doc_num_conflicts(<<"doc1">>) -> 10;
-doc_num_conflicts(<<"doc2">>) -> 100;
-% a number > MaxURLlength (7000) / length(DocRevisionString)
-doc_num_conflicts(<<"doc3">>) -> 210.
-
-
-main(_) ->
-    test_util:init_code_path(),
-
-    etap:plan(56),
-    case (catch test()) of
-        ok ->
-            etap:end_tests();
-        Other ->
-            etap:diag(io_lib:format("Test died abnormally: ~p", [Other])),
-            etap:bail(Other)
-    end,
-    ok.
-
-
-test() ->
-    test_util:start_couch(),
- 
-    couch_config:set("replicator", "connection_timeout", "90000", false),
-
-    Pairs = [
-        {source_db_name(), target_db_name()},
-        {{remote, source_db_name()}, target_db_name()},
-        {source_db_name(), {remote, target_db_name()}},
-        {{remote, source_db_name()}, {remote, (target_db_name())}}
-    ],
-
-    lists:foreach(
-        fun({Source, Target}) ->
-            {ok, SourceDb} = create_db(source_db_name()),
-            etap:diag("Populating source database"),
-            {ok, DocRevs} = populate_db(SourceDb),
-            ok = couch_db:close(SourceDb),
-            etap:diag("Creating target database"),
-            {ok, TargetDb} = create_db(target_db_name()),
-
-            ok = couch_db:close(TargetDb),
-            etap:diag("Triggering replication"),
-            replicate(Source, Target),
-            etap:diag("Replication finished, comparing source and target databases"),
-            {ok, SourceDb2} = couch_db:open_int(source_db_name(), []),
-            {ok, TargetDb2} = couch_db:open_int(target_db_name(), []),
-            verify_target(SourceDb2, TargetDb2, DocRevs),
-            ok = couch_db:close(SourceDb2),
-            ok = couch_db:close(TargetDb2),
-
-            {ok, SourceDb3} = couch_db:open_int(source_db_name(), []),
-            {ok, DocRevs2} = add_attachments(SourceDb3, DocRevs, 2),
-            ok = couch_db:close(SourceDb3),
-            etap:diag("Triggering replication again"),
-            replicate(Source, Target),
-            etap:diag("Replication finished, comparing source and target databases"),
-            {ok, SourceDb4} = couch_db:open_int(source_db_name(), []),
-            {ok, TargetDb4} = couch_db:open_int(target_db_name(), []),
-            verify_target(SourceDb4, TargetDb4, DocRevs2),
-            ok = couch_db:close(SourceDb4),
-            ok = couch_db:close(TargetDb4),
-
-            etap:diag("Deleting source and target databases"),
-            delete_db(TargetDb),
-            delete_db(SourceDb),
-            ok = timer:sleep(1000)
-        end,
-        Pairs),
-
-    test_util:stop_couch(),
-    ok.
-
-
-populate_db(Db) ->
-    DocRevsDict = lists:foldl(
-        fun(DocId, Acc) ->
-            Value = <<"0">>,
-            Doc = #doc{
-                id = DocId,
-                body = {[ {<<"value">>, Value} ]}
-            },
-            {ok, Rev} = couch_db:update_doc(Db, Doc, []),
-            {ok, DocRevs} = add_doc_siblings(Db, DocId, doc_num_conflicts(DocId)),
-            dict:store(DocId, [Rev | DocRevs], Acc)
-        end,
-        dict:new(), doc_ids()),
-    {ok, dict:to_list(DocRevsDict)}.
-
-
-add_doc_siblings(Db, DocId, NumLeaves) when NumLeaves > 0 ->
-    add_doc_siblings(Db, DocId, NumLeaves, [], []).
-
-
-add_doc_siblings(Db, _DocId, 0, AccDocs, AccRevs) ->
-    {ok, []} = couch_db:update_docs(Db, AccDocs, [], replicated_changes),
-    {ok, AccRevs};
-
-add_doc_siblings(Db, DocId, NumLeaves, AccDocs, AccRevs) ->
-    Value = list_to_binary(integer_to_list(NumLeaves)),
-    Rev = couch_util:md5(Value),
-    Doc = #doc{
-        id = DocId,
-        revs = {1, [Rev]},
-        body = {[ {<<"value">>, Value} ]}
-    },
-    add_doc_siblings(Db, DocId, NumLeaves - 1, [Doc | AccDocs], [{1, Rev} | AccRevs]).
-
-
-verify_target(_SourceDb, _TargetDb, []) ->
-    ok;
-
-verify_target(SourceDb, TargetDb, [{DocId, RevList} | Rest]) ->
-    {ok, Lookups} = couch_db:open_doc_revs(
-        TargetDb,
-        DocId,
-        RevList,
-        [conflicts, deleted_conflicts]),
-    Docs = [Doc || {ok, Doc} <- Lookups],
-    {ok, SourceLookups} = couch_db:open_doc_revs(
-        SourceDb,
-        DocId,
-        RevList,
-        [conflicts, deleted_conflicts]),
-    SourceDocs = [Doc || {ok, Doc} <- SourceLookups],
-    Total = doc_num_conflicts(DocId) + 1,
-    etap:is(
-        length(Docs),
-        Total,
-        "Target has " ++ ?i2l(Total) ++ " leaf revisions of document " ++ ?b2l(DocId)),
-    etap:diag("Verifying all revisions of document " ++ ?b2l(DocId)),
-    lists:foreach(
-        fun({#doc{id = Id, revs = Revs} = TgtDoc, #doc{id = Id, revs = Revs} = SrcDoc}) ->
-            SourceJson = couch_doc:to_json_obj(SrcDoc, [attachments]),
-            TargetJson = couch_doc:to_json_obj(TgtDoc, [attachments]),
-            case TargetJson of
-            SourceJson ->
-                ok;
-            _ ->
-                {Pos, [Rev | _]} = Revs,
-                etap:bail("Wrong value for revision " ++
-                    ?b2l(couch_doc:rev_to_str({Pos, Rev})) ++
-                    " of document " ++ ?b2l(DocId))
-            end
-        end,
-        lists:zip(Docs, SourceDocs)),
-    verify_target(SourceDb, TargetDb, Rest).
-
-
-add_attachments(Source, DocIdRevs, NumAtts) ->
-    add_attachments(Source, DocIdRevs, NumAtts, []).
-
-add_attachments(_SourceDb, [], _NumAtts, Acc) ->
-    {ok, Acc};
-
-add_attachments(SourceDb, [{DocId, RevList} | Rest], NumAtts, IdRevsAcc) ->
-    {ok, SourceLookups} = couch_db:open_doc_revs(
-        SourceDb,
-        DocId,
-        RevList,
-        []),
-    SourceDocs = [Doc || {ok, Doc} <- SourceLookups],
-    Total = doc_num_conflicts(DocId) + 1,
-    etap:is(
-        length(SourceDocs),
-        Total,
-        "Source still has " ++ ?i2l(Total) ++
-            " leaf revisions of document " ++ ?b2l(DocId)),
-    etap:diag("Adding " ++ ?i2l(NumAtts) ++
-        " attachments to each revision of the document " ++ ?b2l(DocId)),
-    NewDocs = lists:foldl(
-        fun(#doc{atts = Atts, revs = {Pos, [Rev | _]}} = Doc, Acc) ->
-            NewAtts = lists:foldl(
-                fun(I, AttAcc) ->
-                    AttData = crypto:rand_bytes(100),
-                    NewAtt = #att{
-                        name = iolist_to_binary(
-                            ["att_", ?i2l(I), "_", couch_doc:rev_to_str({Pos, Rev})]),
-                        type = <<"application/foobar">>,
-                        att_len = byte_size(AttData),
-                        data = AttData
-                    },
-                    [NewAtt | AttAcc]
-                end,
-                [], lists:seq(1, NumAtts)),
-            [Doc#doc{atts = Atts ++ NewAtts} | Acc]
-        end,
-        [], SourceDocs),
-    {ok, UpdateResults} = couch_db:update_docs(SourceDb, NewDocs, []),
-    NewRevs = [R || {ok, R} <- UpdateResults],
-    etap:is(
-        length(NewRevs),
-        length(NewDocs),
-        "Document revisions updated with " ++ ?i2l(NumAtts) ++ " attachments"),
-    add_attachments(SourceDb, Rest, NumAtts, [{DocId, NewRevs} | IdRevsAcc]).
-
-
-db_url(DbName) ->
-    iolist_to_binary([
-        "http://", couch_config:get("httpd", "bind_address", "127.0.0.1"),
-        ":", integer_to_list(mochiweb_socket_server:get(couch_http, port)),
-        "/", DbName
-    ]).
-
-
-create_db(DbName) ->
-    couch_db:create(
-        DbName,
-        [{user_ctx, #user_ctx{roles = [<<"_admin">>]}}, overwrite]).
-
-
-delete_db(Db) ->
-    ok = couch_server:delete(
-        couch_db:name(Db), [{user_ctx, #user_ctx{roles = [<<"_admin">>]}}]).
-
-
-replicate({remote, Db}, Target) ->
-    replicate(db_url(Db), Target);
-
-replicate(Source, {remote, Db}) ->
-    replicate(Source, db_url(Db));
-
-replicate(Source, Target) ->
-    RepObject = {[
-        {<<"source">>, Source},
-        {<<"target">>, Target}
-    ]},
-    {ok, Rep} = couch_replicator_utils:parse_rep_doc(
-        RepObject, #user_ctx{roles = [<<"_admin">>]}),
-    {ok, Pid} = couch_replicator:async_replicate(Rep),
-    MonRef = erlang:monitor(process, Pid),
-    receive
-    {'DOWN', MonRef, process, Pid, Reason} ->
-        etap:is(Reason, normal, "Replication finished successfully")
-    after 900000 ->
-        etap:bail("Timeout waiting for replication to finish")
-    end.

http://git-wip-us.apache.org/repos/asf/couchdb/blob/4c39d7a5/apps/couch_replicator/test/06-doc-missing-stubs.t
----------------------------------------------------------------------
diff --git a/apps/couch_replicator/test/06-doc-missing-stubs.t b/apps/couch_replicator/test/06-doc-missing-stubs.t
deleted file mode 100755
index 5db5830..0000000
--- a/apps/couch_replicator/test/06-doc-missing-stubs.t
+++ /dev/null
@@ -1,303 +0,0 @@
-#!/usr/bin/env escript
-%% -*- erlang -*-
-%%! -pa ./deps/*/ebin -pa ./apps/*/ebin -pa ./test/etap
-
-% Licensed 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.
-
-% Test replication of documents with many leaf revisions.
-% Motivated by COUCHDB-1340 and other similar issues where a document
-% GET with a too long ?open_revs revision list doesn't work due to
-% maximum web server limits for the HTTP request path.
-
--record(user_ctx, {
-    name = null,
-    roles = [],
-    handler
-}).
-
--record(doc, {
-    id = <<"">>,
-    revs = {0, []},
-    body = {[]},
-    atts = [],
-    deleted = false,
-    meta = []
-}).
-
--record(att, {
-    name,
-    type,
-    att_len,
-    disk_len,
-    md5= <<>>,
-    revpos=0,
-    data,
-    encoding=identity
-}).
-
--define(b2l(B), binary_to_list(B)).
-
-source_db_name() -> <<"couch_test_rep_db_a">>.
-target_db_name() -> <<"couch_test_rep_db_b">>.
-
-target_revs_limit() -> 3.
-
-
-main(_) ->
-    etap:plan(128),
-    case (catch test()) of
-        ok ->
-            etap:end_tests();
-        Other ->
-            etap:diag(io_lib:format("Test died abnormally: ~p", [Other])),
-            etap:bail(Other)
-    end,
-    ok.
-
-
-% Test motivated by COUCHDB-1365.
-test() ->
-    test_util:start_couch(),
-
-    Pairs = [
-        {source_db_name(), target_db_name()},
-        {{remote, source_db_name()}, target_db_name()},
-        {source_db_name(), {remote, target_db_name()}},
-        {{remote, source_db_name()}, {remote, (target_db_name())}}
-    ],
-
-    lists:foreach(
-        fun({Source, Target}) ->
-            {ok, SourceDb} = create_db(source_db_name()),
-            etap:diag("Populating source database"),
-            populate_db(SourceDb),
-            ok = couch_db:close(SourceDb),
-
-            etap:diag("Creating target database"),
-            {ok, TargetDb} = create_db(target_db_name()),
-            ok = couch_db:set_revs_limit(TargetDb, target_revs_limit()),
-            ok = couch_db:close(TargetDb),
-
-            etap:diag("Triggering replication"),
-            replicate(Source, Target),
-            etap:diag("Replication finished, comparing source and target databases"),
-            compare_dbs(SourceDb, TargetDb),
-
-            etap:diag("Updating source database docs"),
-            update_db_docs(couch_db:name(SourceDb), target_revs_limit() + 2),
-
-            etap:diag("Triggering replication again"),
-            replicate(Source, Target),
-            etap:diag("Replication finished, comparing source and target databases"),
-            compare_dbs(SourceDb, TargetDb),
-
-            etap:diag("Deleting databases"),
-            delete_db(TargetDb),
-            delete_db(SourceDb),
-            ok = timer:sleep(1000)
-        end,
-        Pairs),
-
-    test_util:stop_couch(),
-    ok.
-
-
-populate_db(Db) ->
-    AttData = crypto:rand_bytes(6000),
-    Doc1 = #doc{
-        id = <<"doc1">>,
-        atts = [
-            #att{
-                name = <<"doc1_att1">>,
-                type = <<"application/foobar">>,
-                att_len = byte_size(AttData),
-                data = AttData
-            }
-        ]
-    },
-    {ok, _} = couch_db:update_doc(Db, Doc1, []).
-
-
-update_db_docs(DbName, Times) ->
-    {ok, Db} = couch_db:open_int(DbName, []),
-    {ok, _, _} = couch_db:enum_docs(
-        Db,
-        fun(FDI, _, Acc) -> db_fold_fun(FDI, Acc) end,
-        {DbName, Times},
-        []),
-    ok = couch_db:close(Db).
-
-
-db_fold_fun(FullDocInfo, {DbName, Times}) ->
-    {ok, Db} = couch_db:open_int(DbName, []),
-    {ok, Doc} = couch_db:open_doc(Db, FullDocInfo),
-    lists:foldl(
-        fun(_, {Pos, RevId}) ->
-            {ok, Db2} = couch_db:reopen(Db),
-            NewDocVersion = Doc#doc{
-                revs = {Pos, [RevId]},
-                body = {[{<<"value">>, base64:encode(crypto:rand_bytes(100))}]}
-            },
-            {ok, NewRev} = couch_db:update_doc(Db2, NewDocVersion, []),
-            NewRev
-        end,
-        {element(1, Doc#doc.revs), hd(element(2, Doc#doc.revs))},
-        lists:seq(1, Times)),
-    ok = couch_db:close(Db),
-    {ok, {DbName, Times}}.
-
-
-compare_dbs(Source, Target) ->
-    {ok, SourceDb} = couch_db:open_int(couch_db:name(Source), []),
-    {ok, TargetDb} = couch_db:open_int(couch_db:name(Target), []),
-
-    Fun = fun(FullDocInfo, _, Acc) ->
-        {ok, DocSource} = couch_db:open_doc(
-            SourceDb, FullDocInfo, [conflicts, deleted_conflicts]),
-        Id = DocSource#doc.id,
-
-        etap:diag("Verifying document " ++ ?b2l(Id)),
-
-        {ok, DocTarget} = couch_db:open_doc(
-            TargetDb, Id, [conflicts, deleted_conflicts]),
-        etap:is(DocTarget#doc.body, DocSource#doc.body,
-            "Same body in source and target databases"),
-
-        etap:is(
-            couch_doc:to_json_obj(DocTarget, []),
-            couch_doc:to_json_obj(DocSource, []),
-            "Same doc body in source and target databases"),
-
-        #doc{atts = SourceAtts} = DocSource,
-        #doc{atts = TargetAtts} = DocTarget,
-        etap:is(
-            lists:sort([N || #att{name = N} <- SourceAtts]),
-            lists:sort([N || #att{name = N} <- TargetAtts]),
-            "Document has same number (and names) of attachments in "
-            "source and target databases"),
-
-        lists:foreach(
-            fun(#att{name = AttName} = Att) ->
-                etap:diag("Verifying attachment " ++ ?b2l(AttName)),
-
-                {ok, AttTarget} = find_att(TargetAtts, AttName),
-                SourceMd5 = att_md5(Att),
-                TargetMd5 = att_md5(AttTarget),
-                case AttName of
-                <<"att1">> ->
-                    etap:is(Att#att.encoding, gzip,
-                        "Attachment is gzip encoded in source database"),
-                    etap:is(AttTarget#att.encoding, gzip,
-                        "Attachment is gzip encoded in target database"),
-                    DecSourceMd5 = att_decoded_md5(Att),
-                    DecTargetMd5 = att_decoded_md5(AttTarget),
-                    etap:is(DecTargetMd5, DecSourceMd5,
-                        "Same identity content in source and target databases");
-                _ ->
-                    etap:is(Att#att.encoding, identity,
-                        "Attachment is not encoded in source database"),
-                    etap:is(AttTarget#att.encoding, identity,
-                        "Attachment is not encoded in target database")
-                end,
-                etap:is(TargetMd5, SourceMd5,
-                    "Same content in source and target databases"),
-                etap:is(is_integer(Att#att.disk_len), true,
-                    "#att.disk_len is an integer in source database"),
-                etap:is(is_integer(Att#att.att_len), true,
-                    "#att.att_len is an integer in source database"),
-                etap:is(is_integer(AttTarget#att.disk_len), true,
-                    "#att.disk_len is an integer in target database"),
-                etap:is(is_integer(AttTarget#att.att_len), true,
-                    "#att.att_len is an integer in target database"),
-                etap:is(Att#att.disk_len, AttTarget#att.disk_len,
-                    "Same identity length in source and target databases"),
-                etap:is(Att#att.att_len, AttTarget#att.att_len,
-                    "Same encoded length in source and target databases"),
-                etap:is(Att#att.type, AttTarget#att.type,
-                    "Same type in source and target databases"),
-                etap:is(Att#att.md5, SourceMd5, "Correct MD5 in source database"),
-                etap:is(AttTarget#att.md5, SourceMd5, "Correct MD5 in target database")
-            end,
-            SourceAtts),
-
-        {ok, Acc}
-    end,
-
-    {ok, _, _} = couch_db:enum_docs(SourceDb, Fun, [], []),
-    ok = couch_db:close(SourceDb),
-    ok = couch_db:close(TargetDb).
-
-
-find_att([], _Name) ->
-    nil;
-find_att([#att{name = Name} = Att | _], Name) ->
-    {ok, Att};
-find_att([_ | Rest], Name) ->
-    find_att(Rest, Name).
-
-
-att_md5(Att) ->
-    Md50 = couch_doc:att_foldl(
-        Att,
-        fun(Chunk, Acc) -> couch_util:md5_update(Acc, Chunk) end,
-        couch_util:md5_init()),
-    couch_util:md5_final(Md50).
-
-att_decoded_md5(Att) ->
-    Md50 = couch_doc:att_foldl_decode(
-        Att,
-        fun(Chunk, Acc) -> couch_util:md5_update(Acc, Chunk) end,
-        couch_util:md5_init()),
-    couch_util:md5_final(Md50).
-
-
-db_url(DbName) ->
-    iolist_to_binary([
-        "http://", couch_config:get("httpd", "bind_address", "127.0.0.1"),
-        ":", integer_to_list(mochiweb_socket_server:get(couch_http, port)),
-        "/", DbName
-    ]).
-
-
-create_db(DbName) ->
-    couch_db:create(
-        DbName,
-        [{user_ctx, #user_ctx{roles = [<<"_admin">>]}}, overwrite]).
-
-
-delete_db(Db) ->
-    ok = couch_server:delete(
-        couch_db:name(Db), [{user_ctx, #user_ctx{roles = [<<"_admin">>]}}]).
-
-
-replicate({remote, Db}, Target) ->
-    replicate(db_url(Db), Target);
-
-replicate(Source, {remote, Db}) ->
-    replicate(Source, db_url(Db));
-
-replicate(Source, Target) ->
-    RepObject = {[
-        {<<"source">>, Source},
-        {<<"target">>, Target}
-    ]},
-    {ok, Rep} = couch_replicator_utils:parse_rep_doc(
-        RepObject, #user_ctx{roles = [<<"_admin">>]}),
-    {ok, Pid} = couch_replicator:async_replicate(Rep),
-    MonRef = erlang:monitor(process, Pid),
-    receive
-    {'DOWN', MonRef, process, Pid, Reason} ->
-        etap:is(Reason, normal, "Replication finished successfully")
-    after 300000 ->
-        etap:bail("Timeout waiting for replication to finish")
-    end.

http://git-wip-us.apache.org/repos/asf/couchdb/blob/4c39d7a5/apps/couch_replicator/test/07-use-checkpoints.t
----------------------------------------------------------------------
diff --git a/apps/couch_replicator/test/07-use-checkpoints.t b/apps/couch_replicator/test/07-use-checkpoints.t
deleted file mode 100755
index 9f975e2..0000000
--- a/apps/couch_replicator/test/07-use-checkpoints.t
+++ /dev/null
@@ -1,255 +0,0 @@
-#!/usr/bin/env escript
-%%! -pa ./deps/*/ebin -pa ./apps/*/ebin -pa ./test/etap
-
-%% -*- erlang -*-
-% Licensed 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.
-
-% Verify that compacting databases that are being used as the source or
-% target of a replication doesn't affect the replication and that the
-% replication doesn't hold their reference counters forever.
-
--define(b2l(B), binary_to_list(B)).
-
--record(user_ctx, {
-    name = null,
-    roles = [],
-    handler
-}).
-
--record(doc, {
-    id = <<"">>,
-    revs = {0, []},
-    body = {[]},
-    atts = [],
-    deleted = false,
-    meta = []
-}).
-
--record(db, {
-    main_pid = nil,
-    update_pid = nil,
-    compactor_pid = nil,
-    instance_start_time, % number of microsecs since jan 1 1970 as a binary string
-    fd,
-    updater_fd,
-    fd_ref_counter,
-    header = nil,
-    committed_update_seq,
-    fulldocinfo_by_id_btree,
-    docinfo_by_seq_btree,
-    local_docs_btree,
-    update_seq,
-    name,
-    filepath,
-    validate_doc_funs = [],
-    security = [],
-    security_ptr = nil,
-    user_ctx = #user_ctx{},
-    waiting_delayed_commit = nil,
-    revs_limit = 1000,
-    fsync_options = [],
-    options = [],
-    compression,
-    before_doc_update,
-    after_doc_read
-}).
-
--record(rep, {
-    id,
-    source,
-    target,
-    options,
-    user_ctx,
-    doc_id
-}).
-
-
-source_db_name() -> <<"couch_test_rep_db_a">>.
-target_db_name() -> <<"couch_test_rep_db_b">>.
-
-
-main(_) ->
-    etap:plan(16),
-    case (catch test()) of
-        ok ->
-            etap:end_tests();
-        Other ->
-            etap:diag(io_lib:format("Test died abnormally: ~p", [Other])),
-            etap:bail(Other)
-    end,
-    ok.
-
-
-test() ->
-    test_util:start_couch(),
-
-    test_use_checkpoints(false),
-    test_use_checkpoints(true),
-
-    test_util:stop_couch(),
-    ok.
-
-
-test_use_checkpoints(UseCheckpoints) ->
-    Pairs = [
-        {source_db_name(), target_db_name()},
-        {{remote, source_db_name()}, target_db_name()},
-        {source_db_name(), {remote, target_db_name()}},
-        {{remote, source_db_name()}, {remote, (target_db_name())}}
-    ],
-
-    ListenerFun = case UseCheckpoints of
-    false ->
-        fun({finished, _, {CheckpointHistory}}) ->
-            etap:is(CheckpointHistory,
-            [{<<"use_checkpoints">>,false}],
-            "No checkpoints found");
-        (_) ->
-            ok
-        end;
-    true ->
-        fun({finished, _, {CheckpointHistory}}) ->
-            SessionId = lists:keyfind(
-                <<"session_id">>, 1, CheckpointHistory),
-            etap:isnt(SessionId, false, "There's a checkpoint");
-        (_) ->
-            ok
-        end
-    end,
-    {ok, Listener} = couch_replicator_notifier:start_link(ListenerFun),
-
-    lists:foreach(
-        fun({Source, Target}) ->
-            {ok, SourceDb} = create_db(source_db_name()),
-            etap:diag("Populating source database"),
-            populate_db(SourceDb, 100),
-            ok = couch_db:close(SourceDb),
-
-            etap:diag("Creating target database"),
-            {ok, TargetDb} = create_db(target_db_name()),
-            ok = couch_db:close(TargetDb),
-
-            etap:diag("Setup replicator notifier listener"),
-
-            etap:diag("Triggering replication"),
-            replicate(Source, Target, UseCheckpoints),
-
-            etap:diag("Replication finished, comparing source and target databases"),
-            compare_dbs(SourceDb, TargetDb),
-
-            etap:diag("Deleting databases"),
-            delete_db(TargetDb),
-            delete_db(SourceDb),
-
-            ok = timer:sleep(1000)
-        end,
-        Pairs),
-
-    couch_replicator_notifier:stop(Listener).
-
-
-populate_db(Db, DocCount) ->
-    Docs = lists:foldl(
-        fun(DocIdCounter, Acc) ->
-            Id = iolist_to_binary(["doc", integer_to_list(DocIdCounter)]),
-            Value = iolist_to_binary(["val", integer_to_list(DocIdCounter)]),
-            Doc = #doc{
-                id = Id,
-                body = {[ {<<"value">>, Value} ]}
-            },
-            [Doc | Acc]
-        end,
-        [], lists:seq(1, DocCount)),
-    {ok, _} = couch_db:update_docs(Db, Docs, []).
-
-
-compare_dbs(#db{name = SourceName}, #db{name = TargetName}) ->
-    {ok, SourceDb} = couch_db:open_int(SourceName, []),
-    {ok, TargetDb} = couch_db:open_int(TargetName, []),
-    Fun = fun(FullDocInfo, _, Acc) ->
-        {ok, Doc} = couch_db:open_doc(SourceDb, FullDocInfo),
-        {Props} = DocJson = couch_doc:to_json_obj(Doc, [attachments]),
-        DocId = couch_util:get_value(<<"_id">>, Props),
-        DocTarget = case couch_db:open_doc(TargetDb, DocId) of
-        {ok, DocT} ->
-            DocT;
-        Error ->
-            etap:bail("Error opening document '" ++ ?b2l(DocId) ++
-                "' from target: " ++ couch_util:to_list(Error))
-        end,
-        DocTargetJson = couch_doc:to_json_obj(DocTarget, [attachments]),
-        case DocTargetJson of
-        DocJson ->
-            ok;
-        _ ->
-            etap:bail("Content from document '" ++ ?b2l(DocId) ++
-                "' differs in target database")
-        end,
-        {ok, Acc}
-    end,
-    {ok, _, _} = couch_db:enum_docs(SourceDb, Fun, [], []),
-    etap:diag("Target database has the same documents as the source database"),
-    ok = couch_db:close(SourceDb),
-    ok = couch_db:close(TargetDb).
-
-
-db_url(DbName) ->
-    iolist_to_binary([
-        "http://", couch_config:get("httpd", "bind_address", "127.0.0.1"),
-        ":", integer_to_list(mochiweb_socket_server:get(couch_http, port)),
-        "/", DbName
-    ]).
-
-
-create_db(DbName) ->
-    {ok, Db} = couch_db:create(
-        DbName,
-        [{user_ctx, #user_ctx{roles = [<<"_admin">>]}}, overwrite]),
-    couch_db:close(Db),
-    {ok, Db}.
-
-
-delete_db(#db{name = DbName, main_pid = Pid}) ->
-    ok = couch_server:delete(
-        DbName, [{user_ctx, #user_ctx{roles = [<<"_admin">>]}}]),
-    MonRef = erlang:monitor(process, Pid),
-    receive
-    {'DOWN', MonRef, process, Pid, _Reason} ->
-        ok
-    after 30000 ->
-        etap:bail("Timeout deleting database")
-    end.
-
-
-replicate({remote, Db}, Target, UseCheckpoints) ->
-    replicate(db_url(Db), Target, UseCheckpoints);
-
-replicate(Source, {remote, Db}, UseCheckpoints) ->
-    replicate(Source, db_url(Db), UseCheckpoints);
-
-replicate(Source, Target, UseCheckpoints) ->
-    RepObject = {[
-        {<<"source">>, Source},
-        {<<"target">>, Target},
-        {<<"use_checkpoints">>, UseCheckpoints}
-    ]},
-    {ok, Rep} = couch_replicator_utils:parse_rep_doc(
-        RepObject, #user_ctx{roles = [<<"_admin">>]}),
-    {ok, Pid} = couch_replicator:async_replicate(Rep),
-    MonRef = erlang:monitor(process, Pid),
-    receive
-    {'DOWN', MonRef, process, Pid, Reason} ->
-        etap:is(Reason, normal, "Replication finished successfully")
-    after 300000 ->
-        etap:bail("Timeout waiting for replication to finish")
-    end.


[35/57] [abbrv] remove couch_collate

Posted by be...@apache.org.
http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/dtitvinf.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/dtitvinf.h b/apps/couch_collate/platform/osx/icu/unicode/dtitvinf.h
deleted file mode 100644
index 07a8dbd..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/dtitvinf.h
+++ /dev/null
@@ -1,528 +0,0 @@
-/*
- *******************************************************************************
- * Copyright (C) 2008, International Business Machines Corporation and
- * others. All Rights Reserved.
- *******************************************************************************
- *
- * File DTITVINF.H
- *
- *******************************************************************************
- */
-
-#ifndef __DTITVINF_H__
-#define __DTITVINF_H__
-
-#include "unicode/utypes.h"
-
-/**
- * \file
- * \brief C++ API: Date/Time interval patterns for formatting date/time interval
- */
-
-#if !UCONFIG_NO_FORMATTING
-
-#include "unicode/udat.h"
-#include "unicode/locid.h"
-#include "unicode/ucal.h"
-#include "unicode/dtptngen.h"
-//#include "dtitv_impl.h"
-
-/**
- * @internal ICU 4.0
- */
- 
-union UHashTok;
-
-
-U_NAMESPACE_BEGIN
-
-U_CDECL_BEGIN 
-
-/**
- * @internal ICU 4.0
- */
-static UBool U_CALLCONV hashTableValueComparator(UHashTok val1, UHashTok val2) ;
-
-U_CDECL_END 
-
-
-/**
- * DateIntervalInfo is a public class for encapsulating localizable
- * date time interval patterns. It is used by DateIntervalFormat.
- *
- * <P>
- * For most users, ordinary use of DateIntervalFormat does not need to create
- * DateIntervalInfo object directly.
- * DateIntervalFormat will take care of it when creating a date interval
- * formatter when user pass in skeleton and locale.
- *
- * <P>
- * For power users, who want to create their own date interval patterns,
- * or want to re-set date interval patterns, they could do so by
- * directly creating DateIntervalInfo and manupulating it.
- *
- * <P>
- * Logically, the interval patterns are mappings
- * from (skeleton, the_largest_different_calendar_field)
- * to (date_interval_pattern).
- *
- * <P>
- * A skeleton 
- * <ol>
- * <li>
- * only keeps the field pattern letter and ignores all other parts 
- * in a pattern, such as space, punctuations, and string literals.
- * <li>
- * hides the order of fields. 
- * <li>
- * might hide a field's pattern letter length.
- *
- * For those non-digit calendar fields, the pattern letter length is 
- * important, such as MMM, MMMM, and MMMMM; EEE and EEEE, 
- * and the field's pattern letter length is honored.
- *    
- * For the digit calendar fields,  such as M or MM, d or dd, yy or yyyy, 
- * the field pattern length is ignored and the best match, which is defined 
- * in date time patterns, will be returned without honor the field pattern
- * letter length in skeleton.
- * </ol>
- *
- * <P>
- * The calendar fields we support for interval formatting are:
- * year, month, date, day-of-week, am-pm, hour, hour-of-day, and minute.
- * Those calendar fields can be defined in the following order:
- * year >  month > date > am-pm > hour >  minute 
- *  
- * The largest different calendar fields between 2 calendars is the
- * first different calendar field in above order.
- *
- * For example: the largest different calendar fields between "Jan 10, 2007" 
- * and "Feb 20, 2008" is year.
- *   
- * <P>
- * There is a set of pre-defined static skeleton strings.
- * There are pre-defined interval patterns for those pre-defined skeletons
- * in locales' resource files.
- * For example, for a skeleton UDAT_YEAR_ABBR_MONTH_DAY, which is  "yMMMd",
- * in  en_US, if the largest different calendar field between date1 and date2 
- * is "year", the date interval pattern  is "MMM d, yyyy - MMM d, yyyy", 
- * such as "Jan 10, 2007 - Jan 10, 2008".
- * If the largest different calendar field between date1 and date2 is "month",
- * the date interval pattern is "MMM d - MMM d, yyyy",
- * such as "Jan 10 - Feb 10, 2007".
- * If the largest different calendar field between date1 and date2 is "day",
- * the date interval pattern is ""MMM d-d, yyyy", such as "Jan 10-20, 2007".
- *
- * For date skeleton, the interval patterns when year, or month, or date is 
- * different are defined in resource files.
- * For time skeleton, the interval patterns when am/pm, or hour, or minute is
- * different are defined in resource files.
- *
- *
- * <P>
- * There are 2 dates in interval pattern. For most locales, the first date
- * in an interval pattern is the earlier date. There might be a locale in which
- * the first date in an interval pattern is the later date.
- * We use fallback format for the default order for the locale.
- * For example, if the fallback format is "{0} - {1}", it means
- * the first date in the interval pattern for this locale is earlier date.
- * If the fallback format is "{1} - {0}", it means the first date is the 
- * later date.
- * For a particular interval pattern, the default order can be overriden
- * by prefixing "latestFirst:" or "earliestFirst:" to the interval pattern.
- * For example, if the fallback format is "{0}-{1}",
- * but for skeleton "yMMMd", the interval pattern when day is different is 
- * "latestFirst:d-d MMM yy", it means by default, the first date in interval
- * pattern is the earlier date. But for skeleton "yMMMd", when day is different,
- * the first date in "d-d MMM yy" is the later date.
- * 
- * <P>
- * The recommended way to create a DateIntervalFormat object is to pass in 
- * the locale. 
- * By using a Locale parameter, the DateIntervalFormat object is 
- * initialized with the pre-defined interval patterns for a given or 
- * default locale.
- * <P>
- * Users can also create DateIntervalFormat object 
- * by supplying their own interval patterns.
- * It provides flexibility for power users.
- *
- * <P>
- * After a DateIntervalInfo object is created, clients may modify
- * the interval patterns using setIntervalPattern function as so desired.
- * Currently, users can only set interval patterns when the following 
- * calendar fields are different: ERA, YEAR, MONTH, DATE,  DAY_OF_MONTH, 
- * DAY_OF_WEEK, AM_PM,  HOUR, HOUR_OF_DAY, and MINUTE.
- * Interval patterns when other calendar fields are different is not supported.
- * <P>
- * DateIntervalInfo objects are cloneable. 
- * When clients obtain a DateIntervalInfo object, 
- * they can feel free to modify it as necessary.
- * <P>
- * DateIntervalInfo are not expected to be subclassed. 
- * Data for a calendar is loaded out of resource bundles. 
- * To ICU 4.0, date interval patterns are only supported in Gregorian calendar. 
- * @draft ICU 4.0
-**/
-
-class U_I18N_API DateIntervalInfo : public UObject {
-public:
-    /**
-     * Default constructor.
-     * It does not initialize any interval patterns except
-     * that it initialize default fall-back pattern as "{0} - {1}",
-     * which can be reset by setFallbackIntervalPattern().
-     * It should be followed by setFallbackIntervalPattern() and 
-     * setIntervalPattern(), 
-     * and is recommended to be used only for power users who
-     * wants to create their own interval patterns and use them to create
-     * date interval formatter.
-     * @param status   output param set to success/failure code on exit
-     * @internal ICU 4.0
-     */
-    DateIntervalInfo(UErrorCode& status);
-
-
-    /** 
-     * Construct DateIntervalInfo for the given locale,
-     * @param locale  the interval patterns are loaded from the Gregorian 
-     *                calendar data in this locale.
-     * @param status  output param set to success/failure code on exit
-     * @draft ICU 4.0
-     */
-    DateIntervalInfo(const Locale& locale, UErrorCode& status);
-
-
-    /**
-     * Copy constructor.
-     * @draft ICU 4.0
-     */
-    DateIntervalInfo(const DateIntervalInfo&);
-
-    /**
-     * Assignment operator
-     * @draft ICU 4.0
-     */
-    DateIntervalInfo& operator=(const DateIntervalInfo&);
-
-    /**
-     * Clone this object polymorphically.
-     * The caller owns the result and should delete it when done.
-     * @return   a copy of the object
-     * @draft    ICU4.0
-     */
-    virtual DateIntervalInfo* clone(void) const;
-
-    /**
-     * Destructor.
-     * It is virtual to be safe, but it is not designed to be subclassed.
-     * @draft ICU 4.0
-     */
-    virtual ~DateIntervalInfo();
-
-
-    /**
-     * Return true if another object is semantically equal to this one.
-     *
-     * @param other    the DateIntervalInfo object to be compared with.
-     * @return         true if other is semantically equal to this.
-     * @stable ICU 4.0
-     */
-    virtual UBool operator==(const DateIntervalInfo& other) const;
-
-    /**
-     * Return true if another object is semantically unequal to this one.
-     *
-     * @param other    the DateIntervalInfo object to be compared with.
-     * @return         true if other is semantically unequal to this.
-     * @stable ICU 4.0
-     */
-    UBool operator!=(const DateIntervalInfo& other) const;
-
-
-
-    /** 
-     * Provides a way for client to build interval patterns.
-     * User could construct DateIntervalInfo by providing a list of skeletons
-     * and their patterns.
-     * <P>
-     * For example:
-     * <pre>
-     * UErrorCode status = U_ZERO_ERROR;
-     * DateIntervalInfo dIntervalInfo = new DateIntervalInfo();
-     * dIntervalInfo->setFallbackIntervalPattern("{0} ~ {1}");
-     * dIntervalInfo->setIntervalPattern("yMd", UCAL_YEAR, "'from' yyyy-M-d 'to' yyyy-M-d", status); 
-     * dIntervalInfo->setIntervalPattern("yMMMd", UCAL_MONTH, "'from' yyyy MMM d 'to' MMM d", status);
-     * dIntervalInfo->setIntervalPattern("yMMMd", UCAL_DAY, "yyyy MMM d-d", status, status);
-     * </pre>
-     *
-     * Restriction: 
-     * Currently, users can only set interval patterns when the following 
-     * calendar fields are different: ERA, YEAR, MONTH, DATE,  DAY_OF_MONTH, 
-     * DAY_OF_WEEK, AM_PM,  HOUR, HOUR_OF_DAY, and MINUTE.
-     * Interval patterns when other calendar fields are different are 
-     * not supported.
-     *
-     * @param skeleton         the skeleton on which interval pattern based
-     * @param lrgDiffCalUnit   the largest different calendar unit.
-     * @param intervalPattern  the interval pattern on the largest different
-     *                         calendar unit.
-     *                         For example, if lrgDiffCalUnit is 
-     *                         "year", the interval pattern for en_US when year
-     *                         is different could be "'from' yyyy 'to' yyyy".
-     * @param status           output param set to success/failure code on exit
-     * @draft ICU 4.0
-     */
-    void setIntervalPattern(const UnicodeString& skeleton, 
-                            UCalendarDateFields lrgDiffCalUnit, 
-                            const UnicodeString& intervalPattern,
-                            UErrorCode& status);
-
-    /**
-     * Get the interval pattern given skeleton and 
-     * the largest different calendar field.
-     * @param skeleton   the skeleton
-     * @param field      the largest different calendar field
-     * @param result     output param to receive the pattern
-     * @param status     output param set to success/failure code on exit
-     * @return a reference to 'result'
-     * @draft ICU 4.0 
-     */
-    UnicodeString& getIntervalPattern(const UnicodeString& skeleton,
-                                      UCalendarDateFields field,
-                                      UnicodeString& result,
-                                      UErrorCode& status) const; 
-
-    /**
-     * Get the fallback interval pattern.
-     * @param  result   output param to receive the pattern
-     * @return a reference to 'result'
-     * @draft ICU 4.0 
-     */
-    UnicodeString& getFallbackIntervalPattern(UnicodeString& result) const;
-
-
-    /**
-     * Re-set the fallback interval pattern.
-     *
-     * In construction, default fallback pattern is set as "{0} - {1}".
-     * And constructor taking locale as parameter will set the
-     * fallback pattern as what defined in the locale resource file.
-     *
-     * This method provides a way for user to replace the fallback pattern.
-     *
-     * @param fallbackPattern  fall-back interval pattern.
-     * @param status           output param set to success/failure code on exit
-     * @draft ICU 4.0 
-     */
-    void setFallbackIntervalPattern(const UnicodeString& fallbackPattern,
-                                    UErrorCode& status);
-
-
-    /** Get default order -- whether the first date in pattern is later date
-                             or not.
-     * return default date ordering in interval pattern. TRUE if the first date
-     *        in pattern is later date, FALSE otherwise.
-     * @draft ICU 4.0 
-     */
-    UBool getDefaultOrder() const;
-
-
-    /**
-     * ICU "poor man's RTTI", returns a UClassID for the actual class.
-     *
-     * @stable ICU 4.0
-     */
-    virtual UClassID getDynamicClassID() const;
-
-    /**
-     * ICU "poor man's RTTI", returns a UClassID for this class.
-     *
-     * @stable ICU 4.0
-     */
-    static UClassID U_EXPORT2 getStaticClassID();
-
-
-private:
-    /**
-     * DateIntervalFormat will need access to
-     * getBestSkeleton(), parseSkeleton(), enum IntervalPatternIndex,
-     * and calendarFieldToPatternIndex().
-     *
-     * Instead of making above public,
-     * make DateIntervalFormat a friend of DateIntervalInfo.
-     */
-    friend class DateIntervalFormat;
-
-    friend UBool U_CALLCONV hashTableValueComparator(UHashTok val1, UHashTok val2) ;
-
-    /**
-     * Following is for saving the interval patterns.
-     * We only support interval patterns on
-     * ERA, YEAR, MONTH, DAY, AM_PM, HOUR, and MINUTE
-     */
-    enum IntervalPatternIndex
-    {
-        kIPI_ERA,
-        kIPI_YEAR,
-        kIPI_MONTH,
-        kIPI_DATE,
-        kIPI_AM_PM,
-        kIPI_HOUR,
-        kIPI_MINUTE,
-        kIPI_MAX_INDEX
-    };
-
-    /** 
-     * Initialize the DateIntervalInfo from locale
-     * @param locale   the given locale.
-     * @param status   output param set to success/failure code on exit
-     * @internal ICU 4.0 
-     */
-    void initializeData(const Locale& locale, UErrorCode& status);
-
-
-    /* Set Interval pattern.
-     *
-     * It sets interval pattern into the hash map.
-     *
-     * @param skeleton         skeleton on which the interval pattern based
-     * @param lrgDiffCalUnit   the largest different calendar unit.
-     * @param intervalPattern  the interval pattern on the largest different
-     *                         calendar unit.
-     * @param status           output param set to success/failure code on exit
-     * @internal ICU 4.0
-     */
-    void setIntervalPatternInternally(const UnicodeString& skeleton,
-                                      UCalendarDateFields lrgDiffCalUnit,
-                                      const UnicodeString& intervalPattern,
-                                      UErrorCode& status); 
-
-
-    /**given an input skeleton, get the best match skeleton 
-     * which has pre-defined interval pattern in resource file.
-     * Also return the difference between the input skeleton
-     * and the best match skeleton.
-     *
-     * TODO (xji): set field weight or
-     *             isolate the funtionality in DateTimePatternGenerator
-     * @param  skeleton               input skeleton
-     * @param  bestMatchDistanceInfo  the difference between input skeleton
-     *                                and best match skeleton.
-     *         0, if there is exact match for input skeleton
-     *         1, if there is only field width difference between 
-     *            the best match and the input skeleton
-     *         2, the only field difference is 'v' and 'z'
-     *        -1, if there is calendar field difference between
-     *            the best match and the input skeleton
-     * @return                        best match skeleton
-     * @internal ICU 4.0
-     */
-    const UnicodeString* getBestSkeleton(const UnicodeString& skeleton,
-                                         int8_t& bestMatchDistanceInfo) const;
-
-
-    /**
-     * Parse skeleton, save each field's width.
-     * It is used for looking for best match skeleton,
-     * and adjust pattern field width.
-     * @param skeleton            skeleton to be parsed
-     * @param skeletonFieldWidth  parsed skeleton field width
-     * @internal ICU 4.0
-     */
-    static void U_EXPORT2 parseSkeleton(const UnicodeString& skeleton, 
-                                        int32_t* skeletonFieldWidth);
-
-
-    /**
-     * Check whether one field width is numeric while the other is string.
-     *
-     * TODO (xji): make it general
-     *
-     * @param fieldWidth          one field width
-     * @param anotherFieldWidth   another field width
-     * @param patternLetter       pattern letter char
-     * @return true if one field width is numeric and the other is string,
-     *         false otherwise.
-     * @internal ICU 4.0
-     */
-    static UBool U_EXPORT2 stringNumeric(int32_t fieldWidth,
-                                         int32_t anotherFieldWidth,
-                                         char patternLetter);
-
-
-    /** 
-     * Convert calendar field to the interval pattern index in 
-     * hash table.
-     *
-     * Since we only support the following calendar fields: 
-     * ERA, YEAR, MONTH, DATE,  DAY_OF_MONTH, DAY_OF_WEEK, 
-     * AM_PM,  HOUR, HOUR_OF_DAY, and MINUTE,
-     * We reserve only 4 interval patterns for a skeleton.
-     *
-     * @param field    calendar field
-     * @param status   output param set to success/failure code on exit
-     * @return  interval pattern index in hash table
-     * @internal ICU 4.0
-     */
-    static IntervalPatternIndex U_EXPORT2 calendarFieldToIntervalIndex(
-                                                      UCalendarDateFields field,
-                                                      UErrorCode& status);
-
-
-    /**
-     * delete hash table (of type fIntervalPatterns).
-     *
-     * @param hTable  hash table to be deleted
-     * @internal ICU 4.0
-     */
-    void deleteHash(Hashtable* hTable);
-
-
-    /**
-     * initialize hash table (of type fIntervalPatterns).
-     *
-     * @param status   output param set to success/failure code on exit
-     * @return         hash table initialized
-     * @internal ICU 4.0
-     */
-    Hashtable* initHash(UErrorCode& status);
-
-
-
-    /**
-     * copy hash table (of type fIntervalPatterns).
-     *
-     * @param source   the source to copy from
-     * @param target   the target to copy to
-     * @param status   output param set to success/failure code on exit
-     * @internal ICU 4.0
-     */
-    void copyHash(const Hashtable* source, Hashtable* target, UErrorCode& status);
-
-
-    // data members
-    // fallback interval pattern 
-    UnicodeString fFallbackIntervalPattern;
-    // default order
-    UBool fFirstDateInPtnIsLaterDate;
-
-    // HashMap<UnicodeString, UnicodeString[kIPI_MAX_INDEX]>
-    // HashMap( skeleton, pattern[largest_different_field] )
-    Hashtable* fIntervalPatterns;
-
-};// end class DateIntervalInfo
-
-
-inline UBool
-DateIntervalInfo::operator!=(const DateIntervalInfo& other) const {
-    return !operator==(other);
-}
-
-
-U_NAMESPACE_END
-
-#endif
-
-#endif
-

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/dtptngen.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/dtptngen.h b/apps/couch_collate/platform/osx/icu/unicode/dtptngen.h
deleted file mode 100644
index eeea626..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/dtptngen.h
+++ /dev/null
@@ -1,423 +0,0 @@
-/*
-*******************************************************************************
-* Copyright (C) 2007-2009, International Business Machines Corporation and
-* others. All Rights Reserved.
-*******************************************************************************
-*
-* File DTPTNGEN.H
-*
-*******************************************************************************
-*/
-
-#ifndef __DTPTNGEN_H__
-#define __DTPTNGEN_H__
-
-#include "unicode/datefmt.h"
-#include "unicode/locid.h"
-#include "unicode/udat.h"
-#include "unicode/udatpg.h"
-
-U_NAMESPACE_BEGIN
-
-/**
- * \file
- * \brief C++ API: Date/Time Pattern Generator
- */
-
-
-class Hashtable;
-class FormatParser;
-class DateTimeMatcher;
-class DistanceInfo;
-class PatternMap;
-class PtnSkeleton;
-
-/**
- * This class provides flexible generation of date format patterns, like "yy-MM-dd". 
- * The user can build up the generator by adding successive patterns. Once that 
- * is done, a query can be made using a "skeleton", which is a pattern which just
- * includes the desired fields and lengths. The generator will return the "best fit" 
- * pattern corresponding to that skeleton.
- * <p>The main method people will use is getBestPattern(String skeleton),
- * since normally this class is pre-built with data from a particular locale. 
- * However, generators can be built directly from other data as well.
- * <p><i>Issue: may be useful to also have a function that returns the list of 
- * fields in a pattern, in order, since we have that internally.
- * That would be useful for getting the UI order of field elements.</i>
- * @stable ICU 3.8
-**/
-class U_I18N_API DateTimePatternGenerator : public UObject {
-public:
-    /**
-     * Construct a flexible generator according to default locale.
-     * @param status  Output param set to success/failure code on exit,
-     *               which must not indicate a failure before the function call.
-     * @stable ICU 3.8
-     */
-    static DateTimePatternGenerator* U_EXPORT2 createInstance(UErrorCode& status);
-
-    /**
-     * Construct a flexible generator according to data for a given locale.
-     * @param uLocale
-     * @param status  Output param set to success/failure code on exit,
-     *               which must not indicate a failure before the function call.
-     * @stable ICU 3.8
-     */
-    static DateTimePatternGenerator* U_EXPORT2 createInstance(const Locale& uLocale, UErrorCode& status);
-
-    /**
-     * Create an empty generator, to be constructed with addPattern(...) etc.
-     * @param status  Output param set to success/failure code on exit,
-     *               which must not indicate a failure before the function call.
-     * @stable ICU 3.8
-     */
-     static DateTimePatternGenerator* U_EXPORT2 createEmptyInstance(UErrorCode& status);
-     
-    /**
-     * Destructor.
-     * @stable ICU 3.8
-     */
-    virtual ~DateTimePatternGenerator();
-
-    /**
-     * Clone DateTimePatternGenerator object. Clients are responsible for 
-     * deleting the DateTimePatternGenerator object cloned.
-     * @stable ICU 3.8
-     */
-    DateTimePatternGenerator* clone() const;
-
-     /**
-      * Return true if another object is semantically equal to this one.
-      *
-      * @param other    the DateTimePatternGenerator object to be compared with.
-      * @return         true if other is semantically equal to this.
-      * @stable ICU 3.8
-      */
-    UBool operator==(const DateTimePatternGenerator& other) const;
-    
-    /**
-     * Return true if another object is semantically unequal to this one.
-     *
-     * @param other    the DateTimePatternGenerator object to be compared with.
-     * @return         true if other is semantically unequal to this.
-     * @stable ICU 3.8
-     */
-    UBool operator!=(const DateTimePatternGenerator& other) const;
-
-    /**
-     * Utility to return a unique skeleton from a given pattern. For example,
-     * both "MMM-dd" and "dd/MMM" produce the skeleton "MMMdd".
-     *
-     * @param pattern   Input pattern, such as "dd/MMM"
-     * @param status  Output param set to success/failure code on exit,
-     *                  which must not indicate a failure before the function call.
-     * @return skeleton such as "MMMdd"
-     * @stable ICU 3.8
-     */
-    UnicodeString getSkeleton(const UnicodeString& pattern, UErrorCode& status);
-
-    /**
-     * Utility to return a unique base skeleton from a given pattern. This is
-     * the same as the skeleton, except that differences in length are minimized
-     * so as to only preserve the difference between string and numeric form. So
-     * for example, both "MMM-dd" and "d/MMM" produce the skeleton "MMMd"
-     * (notice the single d).
-     *
-     * @param pattern  Input pattern, such as "dd/MMM"
-     * @param status  Output param set to success/failure code on exit,
-     *               which must not indicate a failure before the function call.
-     * @return base skeleton, such as "Md"
-     * @stable ICU 3.8
-     */
-    UnicodeString getBaseSkeleton(const UnicodeString& pattern, UErrorCode& status);
-
-    /**
-     * Adds a pattern to the generator. If the pattern has the same skeleton as
-     * an existing pattern, and the override parameter is set, then the previous
-     * value is overriden. Otherwise, the previous value is retained. In either
-     * case, the conflicting status is set and previous vale is stored in 
-     * conflicting pattern.
-     * <p>
-     * Note that single-field patterns (like "MMM") are automatically added, and
-     * don't need to be added explicitly!
-     *
-     * @param pattern   Input pattern, such as "dd/MMM"
-     * @param override  When existing values are to be overridden use true, 
-     *                   otherwise use false.
-     * @param conflictingPattern  Previous pattern with the same skeleton.
-     * @param status  Output param set to success/failure code on exit,
-     *               which must not indicate a failure before the function call.
-     * @return conflicting status.  The value could be UDATPG_NO_CONFLICT, 
-     *                             UDATPG_BASE_CONFLICT or UDATPG_CONFLICT.
-     * @stable ICU 3.8
-     */
-    UDateTimePatternConflict addPattern(const UnicodeString& pattern, 
-                                        UBool override, 
-                                        UnicodeString& conflictingPattern,
-                                        UErrorCode& status);
-
-    /**
-     * An AppendItem format is a pattern used to append a field if there is no
-     * good match. For example, suppose that the input skeleton is "GyyyyMMMd",
-     * and there is no matching pattern internally, but there is a pattern
-     * matching "yyyyMMMd", say "d-MM-yyyy". Then that pattern is used, plus the
-     * G. The way these two are conjoined is by using the AppendItemFormat for G
-     * (era). So if that value is, say "{0}, {1}" then the final resulting
-     * pattern is "d-MM-yyyy, G".
-     * <p>
-     * There are actually three available variables: {0} is the pattern so far,
-     * {1} is the element we are adding, and {2} is the name of the element.
-     * <p>
-     * This reflects the way that the CLDR data is organized.
-     *
-     * @param field  such as UDATPG_ERA_FIELD.
-     * @param value  pattern, such as "{0}, {1}"
-     * @stable ICU 3.8
-     */
-    void setAppendItemFormat(UDateTimePatternField field, const UnicodeString& value);
-
-    /**
-     * Getter corresponding to setAppendItemFormat. Values below 0 or at or
-     * above UDATPG_FIELD_COUNT are illegal arguments.
-     *
-     * @param  field  such as UDATPG_ERA_FIELD.
-     * @return append pattern for field
-     * @stable ICU 3.8
-     */
-    const UnicodeString& getAppendItemFormat(UDateTimePatternField field) const;
-
-    /**
-     * Sets the names of field, eg "era" in English for ERA. These are only
-     * used if the corresponding AppendItemFormat is used, and if it contains a
-     * {2} variable.
-     * <p>
-     * This reflects the way that the CLDR data is organized.
-     *
-     * @param field   such as UDATPG_ERA_FIELD.
-     * @param value   name of the field
-     * @stable ICU 3.8
-     */
-    void setAppendItemName(UDateTimePatternField field, const UnicodeString& value);
-
-    /**
-     * Getter corresponding to setAppendItemNames. Values below 0 or at or above
-     * UDATPG_FIELD_COUNT are illegal arguments.
-     *
-     * @param field  such as UDATPG_ERA_FIELD.
-     * @return name for field
-     * @stable ICU 3.8
-     */
-    const UnicodeString& getAppendItemName(UDateTimePatternField field) const;
-
-    /**
-     * The date time format is a message format pattern used to compose date and
-     * time patterns. The default value is "{0} {1}", where {0} will be replaced
-     * by the date pattern and {1} will be replaced by the time pattern.
-     * <p>
-     * This is used when the input skeleton contains both date and time fields,
-     * but there is not a close match among the added patterns. For example,
-     * suppose that this object was created by adding "dd-MMM" and "hh:mm", and
-     * its datetimeFormat is the default "{0} {1}". Then if the input skeleton
-     * is "MMMdhmm", there is not an exact match, so the input skeleton is
-     * broken up into two components "MMMd" and "hmm". There are close matches
-     * for those two skeletons, so the result is put together with this pattern,
-     * resulting in "d-MMM h:mm".
-     *
-     * @param dateTimeFormat
-     *            message format pattern, here {0} will be replaced by the date
-     *            pattern and {1} will be replaced by the time pattern.
-     * @stable ICU 3.8
-     */
-    void setDateTimeFormat(const UnicodeString& dateTimeFormat);
-
-    /**
-     * Getter corresponding to setDateTimeFormat.
-     * @return DateTimeFormat.
-     * @stable ICU 3.8
-     */
-    const UnicodeString& getDateTimeFormat() const;
-
-    /**
-     * Return the best pattern matching the input skeleton. It is guaranteed to
-     * have all of the fields in the skeleton.
-     *
-     * @param skeleton
-     *            The skeleton is a pattern containing only the variable fields.
-     *            For example, "MMMdd" and "mmhh" are skeletons.
-     * @param status  Output param set to success/failure code on exit,
-     *               which must not indicate a failure before the function call.
-     * @return bestPattern
-     *            The best pattern found from the given skeleton.
-     * @stable ICU 3.8
-     */
-     UnicodeString getBestPattern(const UnicodeString& skeleton, UErrorCode& status);
-
-
-    /**
-     * Adjusts the field types (width and subtype) of a pattern to match what is
-     * in a skeleton. That is, if you supply a pattern like "d-M H:m", and a
-     * skeleton of "MMMMddhhmm", then the input pattern is adjusted to be
-     * "dd-MMMM hh:mm". This is used internally to get the best match for the
-     * input skeleton, but can also be used externally.
-     *
-     * @param pattern Input pattern
-     * @param skeleton
-     *            The skeleton is a pattern containing only the variable fields.
-     *            For example, "MMMdd" and "mmhh" are skeletons.
-     * @param status  Output param set to success/failure code on exit,
-     *               which must not indicate a failure before the function call.
-     * @return pattern adjusted to match the skeleton fields widths and subtypes.
-     * @stable ICU 3.8
-     */
-     UnicodeString replaceFieldTypes(const UnicodeString& pattern, 
-                                     const UnicodeString& skeleton, 
-                                     UErrorCode& status);
-
-    /**
-     * Return a list of all the skeletons (in canonical form) from this class.
-     *
-     * Call getPatternForSkeleton() to get the corresponding pattern.
-     *
-     * @param status  Output param set to success/failure code on exit,
-     *               which must not indicate a failure before the function call.
-     * @return StringEnumeration with the skeletons.
-     *         The caller must delete the object.
-     * @stable ICU 3.8
-     */
-     StringEnumeration* getSkeletons(UErrorCode& status) const;
-
-     /**
-      * Get the pattern corresponding to a given skeleton.
-      * @param skeleton 
-      * @return pattern corresponding to a given skeleton.
-      * @stable ICU 3.8
-      */
-     const UnicodeString& getPatternForSkeleton(const UnicodeString& skeleton) const;
-     
-    /**
-     * Return a list of all the base skeletons (in canonical form) from this class.
-     *
-     * @param status  Output param set to success/failure code on exit,
-     *               which must not indicate a failure before the function call.
-     * @return a StringEnumeration with the base skeletons.
-     *         The caller must delete the object.
-     * @stable ICU 3.8
-     */
-     StringEnumeration* getBaseSkeletons(UErrorCode& status) const;
-     
-     /**
-      * Return a list of redundant patterns are those which if removed, make no 
-      * difference in the resulting getBestPattern values. This method returns a 
-      * list of them, to help check the consistency of the patterns used to build 
-      * this generator.
-      * 
-      * @param status  Output param set to success/failure code on exit,
-      *               which must not indicate a failure before the function call.
-      * @return a StringEnumeration with the redundant pattern.
-      *         The caller must delete the object.
-      * @internal ICU 3.8
-      */
-     StringEnumeration* getRedundants(UErrorCode& status);
-      
-    /**
-     * The decimal value is used in formatting fractions of seconds. If the
-     * skeleton contains fractional seconds, then this is used with the
-     * fractional seconds. For example, suppose that the input pattern is
-     * "hhmmssSSSS", and the best matching pattern internally is "H:mm:ss", and
-     * the decimal string is ",". Then the resulting pattern is modified to be
-     * "H:mm:ss,SSSS"
-     *
-     * @param decimal 
-     * @stable ICU 3.8
-     */
-    void setDecimal(const UnicodeString& decimal);
-
-    /**
-     * Getter corresponding to setDecimal.
-     * @return UnicodeString corresponding to the decimal point
-     * @stable ICU 3.8
-     */
-    const UnicodeString& getDecimal() const;
-
-    /**
-     * ICU "poor man's RTTI", returns a UClassID for the actual class.
-     *
-     * @stable ICU 3.8
-     */
-    virtual UClassID getDynamicClassID() const;
-
-    /**
-     * ICU "poor man's RTTI", returns a UClassID for this class.
-     *
-     * @stable ICU 3.8
-     */
-    static UClassID U_EXPORT2 getStaticClassID(void);
-
-private:
-    /**
-     * Constructor.
-     * @stable ICU 3.8
-     */
-    DateTimePatternGenerator(UErrorCode & status);
-
-    /**
-     * Constructor.
-     * @stable ICU 3.8
-     */
-    DateTimePatternGenerator(const Locale& locale, UErrorCode & status);
-
-    /**
-     * Copy constructor.
-     * @param other DateTimePatternGenerator to copy
-     * @stable ICU 3.8
-     */
-    DateTimePatternGenerator(const DateTimePatternGenerator& other);
-
-    /**
-     * Default assignment operator.
-     * @param other DateTimePatternGenerator to copy
-     * @stable ICU 3.8
-     */
-    DateTimePatternGenerator& operator=(const DateTimePatternGenerator& other);
-
-    Locale pLocale;  // pattern locale
-    FormatParser *fp;
-    DateTimeMatcher* dtMatcher;
-    DistanceInfo *distanceInfo;
-    PatternMap *patternMap;
-    UnicodeString appendItemFormats[UDATPG_FIELD_COUNT];
-    UnicodeString appendItemNames[UDATPG_FIELD_COUNT];
-    UnicodeString dateTimeFormat;
-    UnicodeString decimal;
-    DateTimeMatcher *skipMatcher;
-    Hashtable *fAvailableFormatKeyHash;
-    UnicodeString hackPattern;
-    UnicodeString emptyString;
-    UChar fDefaultHourFormatChar;
-
-    void initData(const Locale &locale, UErrorCode &status);
-    void addCanonicalItems();
-    void addICUPatterns(const Locale& locale, UErrorCode& status);
-    void hackTimes(const UnicodeString& hackPattern, UErrorCode& status);
-    void addCLDRData(const Locale& locale);
-    UDateTimePatternConflict addPatternWithSkeleton(const UnicodeString& pattern, const UnicodeString * skeletonToUse, UBool override, UnicodeString& conflictingPattern, UErrorCode& status);
-    void initHashtable(UErrorCode& status);
-    void setDateTimeFromCalendar(const Locale& locale, UErrorCode& status);
-    void setDecimalSymbols(const Locale& locale, UErrorCode& status);
-    UDateTimePatternField getAppendFormatNumber(const char* field) const;
-    UDateTimePatternField getAppendNameNumber(const char* field) const;
-    void getAppendName(UDateTimePatternField field, UnicodeString& value);
-    int32_t getCanonicalIndex(const UnicodeString& field);
-    const UnicodeString* getBestRaw(DateTimeMatcher& source, int32_t includeMask, DistanceInfo* missingFields, const PtnSkeleton** specifiedSkeletonPtr = 0);
-    UnicodeString adjustFieldTypes(const UnicodeString& pattern, const PtnSkeleton* specifiedSkeleton, UBool fixFractionalSeconds);
-    UnicodeString getBestAppending(int32_t missingFields);
-    int32_t getTopBitNumber(int32_t foundMask);
-    void setAvailableFormat(const UnicodeString &key, UErrorCode& status);
-    UBool isAvailableFormatSet(const UnicodeString &key) const;
-    void copyHashtable(Hashtable *other, UErrorCode &status);
-    UBool isCanonicalItem(const UnicodeString& item) const;
-} ;// end class DateTimePatternGenerator
-
-U_NAMESPACE_END
-
-#endif

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/dtrule.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/dtrule.h b/apps/couch_collate/platform/osx/icu/unicode/dtrule.h
deleted file mode 100644
index c46e618..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/dtrule.h
+++ /dev/null
@@ -1,250 +0,0 @@
-/*
-*******************************************************************************
-* Copyright (C) 2007-2008, International Business Machines Corporation and         *
-* others. All Rights Reserved.                                                *
-*******************************************************************************
-*/
-#ifndef DTRULE_H
-#define DTRULE_H
-
-#include "unicode/utypes.h"
-
-/**
- * \file 
- * \brief C++ API: Rule for specifying date and time in an year
- */
-
-#if !UCONFIG_NO_FORMATTING
-
-#include "unicode/uobject.h"
-
-U_NAMESPACE_BEGIN
-/**
- * <code>DateTimeRule</code> is a class representing a time in a year by
- * a rule specified by month, day of month, day of week and
- * time in the day.
- * 
- * @stable ICU 4.0
- */
-class U_I18N_API DateTimeRule : public UObject {
-public:
-
-    /**
-     * Date rule type constants.
-     * @stable ICU 4.0
-     */
-    enum DateRuleType {
-        DOM = 0,        /**< The exact day of month,
-                             for example, March 11. */
-        DOW,            /**< The Nth occurence of the day of week,
-                             for example, 2nd Sunday in March. */
-        DOW_GEQ_DOM,    /**< The first occurence of the day of week on or after the day of monnth,
-                             for example, first Sunday on or after March 8. */
-        DOW_LEQ_DOM     /**< The last occurence of the day of week on or before the day of month,
-                             for example, first Sunday on or before March 14. */
-    };
-
-    /**
-     * Time rule type constants.
-     * @stable ICU 4.0
-     */
-    enum TimeRuleType {
-        WALL_TIME = 0,  /**< The local wall clock time */
-        STANDARD_TIME,  /**< The local standard time */
-        UTC_TIME        /**< The UTC time */
-    };
-
-    /**
-     * Constructs a <code>DateTimeRule</code> by the day of month and
-     * the time rule.  The date rule type for an instance created by
-     * this constructor is <code>DOM</code>.
-     * 
-     * @param month         The rule month, for example, <code>Calendar::JANUARY</code>
-     * @param dayOfMonth    The day of month, 1-based.
-     * @param millisInDay   The milliseconds in the rule date.
-     * @param timeType      The time type, <code>WALL_TIME</code> or <code>STANDARD_TIME</code>
-     *                      or <code>UTC_TIME</code>.
-     * @stable ICU 4.0
-     */
-    DateTimeRule(int32_t month, int32_t dayOfMonth,
-        int32_t millisInDay, TimeRuleType timeType);
-
-    /**
-     * Constructs a <code>DateTimeRule</code> by the day of week and its oridinal
-     * number and the time rule.  The date rule type for an instance created
-     * by this constructor is <code>DOW</code>.
-     * 
-     * @param month         The rule month, for example, <code>Calendar::JANUARY</code>.
-     * @param weekInMonth   The ordinal number of the day of week.  Negative number
-     *                      may be used for specifying a rule date counted from the
-     *                      end of the rule month.
-     * @param dayOfWeek     The day of week, for example, <code>Calendar::SUNDAY</code>.
-     * @param millisInDay   The milliseconds in the rule date.
-     * @param timeType      The time type, <code>WALL_TIME</code> or <code>STANDARD_TIME</code>
-     *                      or <code>UTC_TIME</code>.
-     * @stable ICU 4.0
-     */
-    DateTimeRule(int32_t month, int32_t weekInMonth, int32_t dayOfWeek,
-        int32_t millisInDay, TimeRuleType timeType);
-
-    /**
-     * Constructs a <code>DateTimeRule</code> by the first/last day of week
-     * on or after/before the day of month and the time rule.  The date rule
-     * type for an instance created by this constructor is either
-     * <code>DOM_GEQ_DOM</code> or <code>DOM_LEQ_DOM</code>.
-     * 
-     * @param month         The rule month, for example, <code>Calendar::JANUARY</code>
-     * @param dayOfMonth    The day of month, 1-based.
-     * @param dayOfWeek     The day of week, for example, <code>Calendar::SUNDAY</code>.
-     * @param after         true if the rule date is on or after the day of month.
-     * @param millisInDay   The milliseconds in the rule date.
-     * @param timeType      The time type, <code>WALL_TIME</code> or <code>STANDARD_TIME</code>
-     *                      or <code>UTC_TIME</code>.
-     * @stable ICU 4.0
-     */
-    DateTimeRule(int32_t month, int32_t dayOfMonth, int32_t dayOfWeek, UBool after,
-        int32_t millisInDay, TimeRuleType timeType);
-
-    /**
-     * Copy constructor.
-     * @param source    The DateTimeRule object to be copied.
-     * @stable ICU 4.0
-     */
-    DateTimeRule(const DateTimeRule& source);
-
-    /**
-     * Destructor.
-     * @stable ICU 4.0
-     */
-    ~DateTimeRule();
-
-    /**
-     * Clone this DateTimeRule object polymorphically. The caller owns the result and
-     * should delete it when done.
-     * @return    A copy of the object.
-     * @stable ICU 4.0
-     */
-    DateTimeRule* clone(void) const;
-
-    /**
-     * Assignment operator.
-     * @param right The object to be copied.
-     * @stable ICU 4.0
-     */
-    DateTimeRule& operator=(const DateTimeRule& right);
-
-    /**
-     * Return true if the given DateTimeRule objects are semantically equal. Objects
-     * of different subclasses are considered unequal.
-     * @param that  The object to be compared with.
-     * @return  true if the given DateTimeRule objects are semantically equal.
-     * @stable ICU 4.0
-     */
-    UBool operator==(const DateTimeRule& that) const;
-
-    /**
-     * Return true if the given DateTimeRule objects are semantically unequal. Objects
-     * of different subclasses are considered unequal.
-     * @param that  The object to be compared with.
-     * @return  true if the given DateTimeRule objects are semantically unequal.
-     * @stable ICU 4.0
-     */
-    UBool operator!=(const DateTimeRule& that) const;
-
-    /**
-     * Gets the date rule type, such as <code>DOM</code>
-     * @return The date rule type.
-     * @stable ICU 4.0
-     */
-    DateRuleType getDateRuleType(void) const;
-
-    /**
-     * Gets the time rule type
-     * @return The time rule type, either <code>WALL_TIME</code> or <code>STANDARD_TIME</code>
-     *         or <code>UTC_TIME</code>.
-     * @stable ICU 4.0
-     */
-    TimeRuleType getTimeRuleType(void) const;
-
-    /**
-     * Gets the rule month.
-     * @return The rule month.
-     * @stable ICU 4.0
-     */
-    int32_t getRuleMonth(void) const;
-
-    /**
-     * Gets the rule day of month.  When the date rule type
-     * is <code>DOW</code>, the value is always 0.
-     * @return The rule day of month
-     * @stable ICU 4.0
-     */
-    int32_t getRuleDayOfMonth(void) const;
-
-    /**
-     * Gets the rule day of week.  When the date rule type
-     * is <code>DOM</code>, the value is always 0.
-     * @return The rule day of week.
-     * @stable ICU 4.0
-     */
-    int32_t getRuleDayOfWeek(void) const;
-
-    /**
-     * Gets the ordinal number of the occurence of the day of week
-     * in the month.  When the date rule type is not <code>DOW</code>,
-     * the value is always 0.
-     * @return The rule day of week ordinal number in the month.
-     * @stable ICU 4.0
-     */
-    int32_t getRuleWeekInMonth(void) const;
-
-    /**
-     * Gets the rule time in the rule day.
-     * @return The time in the rule day in milliseconds.
-     * @stable ICU 4.0
-     */
-    int32_t getRuleMillisInDay(void) const;
-
-private:
-    int32_t fMonth;
-    int32_t fDayOfMonth;
-    int32_t fDayOfWeek;
-    int32_t fWeekInMonth;
-    int32_t fMillisInDay;
-    DateRuleType fDateRuleType;
-    TimeRuleType fTimeRuleType;
-
-public:
-    /**
-     * Return the class ID for this class. This is useful only for comparing to
-     * a return value from getDynamicClassID(). For example:
-     * <pre>
-     * .   Base* polymorphic_pointer = createPolymorphicObject();
-     * .   if (polymorphic_pointer->getDynamicClassID() ==
-     * .       erived::getStaticClassID()) ...
-     * </pre>
-     * @return          The class ID for all objects of this class.
-     * @stable ICU 4.0
-     */
-    static UClassID U_EXPORT2 getStaticClassID(void);
-
-    /**
-     * Returns a unique class ID POLYMORPHICALLY. Pure virtual override. This
-     * method is to implement a simple version of RTTI, since not all C++
-     * compilers support genuine RTTI. Polymorphic operator==() and clone()
-     * methods call this method.
-     *
-     * @return          The class ID for this object. All objects of a
-     *                  given class have the same class ID.  Objects of
-     *                  other classes have different class IDs.
-     * @stable ICU 4.0
-     */
-    virtual UClassID getDynamicClassID(void) const;
-};
-
-U_NAMESPACE_END
-
-#endif /* #if !UCONFIG_NO_FORMATTING */
-
-#endif // DTRULE_H
-//eof

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/fieldpos.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/fieldpos.h b/apps/couch_collate/platform/osx/icu/unicode/fieldpos.h
deleted file mode 100644
index 38a9576..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/fieldpos.h
+++ /dev/null
@@ -1,291 +0,0 @@
-/*
- ********************************************************************************
- *   Copyright (C) 1997-2006, International Business Machines
- *   Corporation and others.  All Rights Reserved.
- ********************************************************************************
- *
- * File FIELDPOS.H
- *
- * Modification History:
- *
- *   Date        Name        Description
- *   02/25/97    aliu        Converted from java.
- *   03/17/97    clhuang     Updated per Format implementation.
- *    07/17/98    stephen        Added default/copy ctors, and operators =, ==, !=
- ********************************************************************************
- */
-
-// *****************************************************************************
-// This file was generated from the java source file FieldPosition.java
-// *****************************************************************************
- 
-#ifndef FIELDPOS_H
-#define FIELDPOS_H
-
-#include "unicode/utypes.h"
-
-/**
- * \file 
- * \brief C++ API: FieldPosition identifies the fields in a formatted output.
- */
-
-#if !UCONFIG_NO_FORMATTING
-
-#include "unicode/uobject.h"
-
-U_NAMESPACE_BEGIN
-
-/**
- * <code>FieldPosition</code> is a simple class used by <code>Format</code>
- * and its subclasses to identify fields in formatted output. Fields are
- * identified by constants, whose names typically end with <code>_FIELD</code>,
- * defined in the various subclasses of <code>Format</code>. See
- * <code>ERA_FIELD</code> and its friends in <code>DateFormat</code> for
- * an example.
- *
- * <p>
- * <code>FieldPosition</code> keeps track of the position of the
- * field within the formatted output with two indices: the index
- * of the first character of the field and the index of the last
- * character of the field.
- *
- * <p>
- * One version of the <code>format</code> method in the various
- * <code>Format</code> classes requires a <code>FieldPosition</code>
- * object as an argument. You use this <code>format</code> method
- * to perform partial formatting or to get information about the
- * formatted output (such as the position of a field).
- *
- * The FieldPosition class is not suitable for subclassing.
- *
- * <p>
- * Below is an example of using <code>FieldPosition</code> to aid
- * alignment of an array of formatted floating-point numbers on
- * their decimal points:
- * <pre>
- * \code
- *       double doubleNum[] = {123456789.0, -12345678.9, 1234567.89, -123456.789,
- *                  12345.6789, -1234.56789, 123.456789, -12.3456789, 1.23456789};
- *       int dNumSize = (int)(sizeof(doubleNum)/sizeof(double));
- *       
- *       UErrorCode status = U_ZERO_ERROR;
- *       DecimalFormat* fmt = (DecimalFormat*) NumberFormat::createInstance(status);
- *       fmt->setDecimalSeparatorAlwaysShown(true);
- *       
- *       const int tempLen = 20;
- *       char temp[tempLen];
- *       
- *       for (int i=0; i<dNumSize; i++) {
- *           FieldPosition pos(NumberFormat::INTEGER_FIELD);
- *           UnicodeString buf;
- *           char fmtText[tempLen];
- *           ToCharString(fmt->format(doubleNum[i], buf, pos), fmtText);
- *           for (int j=0; j<tempLen; j++) temp[j] = ' '; // clear with spaces
- *           temp[__min(tempLen, tempLen-pos.getEndIndex())] = '\0';
- *           cout << temp << fmtText   << endl;
- *       }
- *       delete fmt;
- * \endcode
- * </pre>
- * <p>
- * The code will generate the following output:
- * <pre>
- * \code
- *           123,456,789.000
- *           -12,345,678.900
- *             1,234,567.880
- *              -123,456.789
- *                12,345.678
- *                -1,234.567
- *                   123.456
- *                   -12.345
- *                     1.234
- *  \endcode
- * </pre>
- */
-class U_I18N_API FieldPosition : public UObject {
-public:
-    /**
-     * DONT_CARE may be specified as the field to indicate that the
-     * caller doesn't need to specify a field.  Do not subclass.
-     */
-    enum { DONT_CARE = -1 };
-
-    /**
-     * Creates a FieldPosition object with a non-specified field.
-     * @stable ICU 2.0
-     */
-    FieldPosition() 
-        : UObject(), fField(DONT_CARE), fBeginIndex(0), fEndIndex(0) {}
-
-    /**
-     * Creates a FieldPosition object for the given field.  Fields are
-     * identified by constants, whose names typically end with _FIELD,
-     * in the various subclasses of Format.
-     *
-     * @see NumberFormat#INTEGER_FIELD
-     * @see NumberFormat#FRACTION_FIELD
-     * @see DateFormat#YEAR_FIELD
-     * @see DateFormat#MONTH_FIELD
-     * @stable ICU 2.0
-     */
-    FieldPosition(int32_t field) 
-        : UObject(), fField(field), fBeginIndex(0), fEndIndex(0) {}
-
-    /**
-     * Copy constructor
-     * @param copy the object to be copied from.
-     * @stable ICU 2.0
-     */
-    FieldPosition(const FieldPosition& copy) 
-        : UObject(copy), fField(copy.fField), fBeginIndex(copy.fBeginIndex), fEndIndex(copy.fEndIndex) {}
-
-    /**
-     * Destructor
-     * @stable ICU 2.0
-     */
-    virtual ~FieldPosition();
-
-    /**
-     * Assignment operator
-     * @param copy the object to be copied from.
-     * @stable ICU 2.0
-     */
-    FieldPosition&      operator=(const FieldPosition& copy);
-
-    /** 
-     * Equality operator.
-     * @param that    the object to be compared with.
-     * @return        TRUE if the two field positions are equal, FALSE otherwise.
-     * @stable ICU 2.0
-     */
-    UBool              operator==(const FieldPosition& that) const;
-
-    /** 
-     * Equality operator.
-     * @param that    the object to be compared with.
-     * @return        TRUE if the two field positions are not equal, FALSE otherwise.
-     * @stable ICU 2.0
-     */
-    UBool              operator!=(const FieldPosition& that) const;
-
-    /**
-     * Clone this object.
-     * Clones can be used concurrently in multiple threads.
-     * If an error occurs, then NULL is returned.
-     * The caller must delete the clone.
-     *
-     * @return a clone of this object
-     *
-     * @see getDynamicClassID
-     * @stable ICU 2.8
-     */
-    FieldPosition *clone() const;
-
-    /**
-     * Retrieve the field identifier.
-     * @return    the field identifier.
-     * @stable ICU 2.0
-     */
-    int32_t getField(void) const { return fField; }
-
-    /**
-     * Retrieve the index of the first character in the requested field.
-     * @return    the index of the first character in the requested field.
-     * @stable ICU 2.0
-     */
-    int32_t getBeginIndex(void) const { return fBeginIndex; }
-
-    /**
-     * Retrieve the index of the character following the last character in the
-     * requested field.
-     * @return    the index of the character following the last character in the
-     *            requested field.
-     * @stable ICU 2.0
-     */
-    int32_t getEndIndex(void) const { return fEndIndex; }
- 
-    /**
-     * Set the field.
-     * @param f    the new value of the field.
-     * @stable ICU 2.0
-     */
-    void setField(int32_t f) { fField = f; }
-
-    /**
-     * Set the begin index.  For use by subclasses of Format.
-     * @param bi    the new value of the begin index
-     * @stable ICU 2.0
-     */
-    void setBeginIndex(int32_t bi) { fBeginIndex = bi; }
-
-    /**
-     * Set the end index.  For use by subclasses of Format.
-     * @param ei    the new value of the end index
-     * @stable ICU 2.0
-     */
-    void setEndIndex(int32_t ei) { fEndIndex = ei; }
-    
-    /**
-     * ICU "poor man's RTTI", returns a UClassID for the actual class.
-     *
-     * @stable ICU 2.2
-     */
-    virtual UClassID getDynamicClassID() const;
-
-    /**
-     * ICU "poor man's RTTI", returns a UClassID for this class.
-     *
-     * @stable ICU 2.2
-     */
-    static UClassID U_EXPORT2 getStaticClassID();
-
-private:
-    /**
-     * Input: Desired field to determine start and end offsets for.
-     * The meaning depends on the subclass of Format.
-     */
-    int32_t fField;
-
-    /**
-     * Output: Start offset of field in text.
-     * If the field does not occur in the text, 0 is returned.
-     */
-    int32_t fBeginIndex;
-
-    /**
-     * Output: End offset of field in text.
-     * If the field does not occur in the text, 0 is returned.
-     */
-    int32_t fEndIndex;
-};
-
-inline FieldPosition&
-FieldPosition::operator=(const FieldPosition& copy)
-{
-    fField         = copy.fField;
-    fEndIndex     = copy.fEndIndex;
-    fBeginIndex = copy.fBeginIndex;
-    return *this;
-}
-
-inline UBool
-FieldPosition::operator==(const FieldPosition& copy) const
-{
-    return (fField == copy.fField &&
-        fEndIndex == copy.fEndIndex &&
-        fBeginIndex == copy.fBeginIndex);
-}
-
-inline UBool
-FieldPosition::operator!=(const FieldPosition& copy) const
-{
-    return !operator==(copy);
-}
-
-U_NAMESPACE_END
-
-#endif /* #if !UCONFIG_NO_FORMATTING */
-
-#endif // _FIELDPOS
-//eof

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/fmtable.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/fmtable.h b/apps/couch_collate/platform/osx/icu/unicode/fmtable.h
deleted file mode 100644
index 94ee328..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/fmtable.h
+++ /dev/null
@@ -1,591 +0,0 @@
-/*
-********************************************************************************
-*   Copyright (C) 1997-2006, International Business Machines
-*   Corporation and others.  All Rights Reserved.
-********************************************************************************
-*
-* File FMTABLE.H
-*
-* Modification History:
-*
-*   Date        Name        Description
-*   02/29/97    aliu        Creation.
-********************************************************************************
-*/
-#ifndef FMTABLE_H
-#define FMTABLE_H
-
-#include "unicode/utypes.h"
-#include "unicode/unistr.h"
-/**
- * \file 
- * \brief C++ API: Formattable is a thin wrapper for primitive numeric types.
- */
-
-#if !UCONFIG_NO_FORMATTING
-
-U_NAMESPACE_BEGIN
-
-/**
- * Formattable objects can be passed to the Format class or
- * its subclasses for formatting.  Formattable is a thin wrapper
- * class which interconverts between the primitive numeric types
- * (double, long, etc.) as well as UDate and UnicodeString.
- *
- * <p>Internally, a Formattable object is a union of primitive types.
- * As such, it can only store one flavor of data at a time.  To
- * determine what flavor of data it contains, use the getType method.
- *
- * <p>As of ICU 3.0, Formattable may also wrap a UObject pointer,
- * which it owns.  This allows an instance of any ICU class to be
- * encapsulated in a Formattable.  For legacy reasons and for
- * efficiency, primitive numeric types are still stored directly
- * within a Formattable.
- *
- * <p>The Formattable class is not suitable for subclassing.
- */
-class U_I18N_API Formattable : public UObject {
-public:
-    /**
-     * This enum is only used to let callers distinguish between
-     * the Formattable(UDate) constructor and the Formattable(double)
-     * constructor; the compiler cannot distinguish the signatures,
-     * since UDate is currently typedefed to be either double or long.
-     * If UDate is changed later to be a bonafide class
-     * or struct, then we no longer need this enum.
-     * @stable ICU 2.4
-     */
-    enum ISDATE { kIsDate };
-
-    /**
-     * Default constructor
-     * @stable ICU 2.4
-     */
-    Formattable(); // Type kLong, value 0
-
-    /**
-     * Creates a Formattable object with a UDate instance.
-     * @param d the UDate instance.
-     * @param flag the flag to indicate this is a date. Always set it to kIsDate
-     * @stable ICU 2.0  
-     */
-    Formattable(UDate d, ISDATE flag);
-
-    /**
-     * Creates a Formattable object with a double number.
-     * @param d the double number.
-     * @stable ICU 2.0
-     */
-    Formattable(double d);
-
-    /**
-     * Creates a Formattable object with a long number.
-     * @param l the long number.
-     * @stable ICU 2.0
-     */
-    Formattable(int32_t l);
-
-    /**
-     * Creates a Formattable object with an int64_t number
-     * @param ll the int64_t number.
-     * @stable ICU 2.8
-     */
-    Formattable(int64_t ll);
-
-#if !UCONFIG_NO_CONVERSION
-    /**
-     * Creates a Formattable object with a char string pointer.
-     * Assumes that the char string is null terminated.
-     * @param strToCopy the char string.
-     * @stable ICU 2.0
-     */
-    Formattable(const char* strToCopy);
-#endif
-
-    /**
-     * Creates a Formattable object with a UnicodeString object to copy from.
-     * @param strToCopy the UnicodeString string.
-     * @stable ICU 2.0
-     */
-    Formattable(const UnicodeString& strToCopy);
-
-    /**
-     * Creates a Formattable object with a UnicodeString object to adopt from.
-     * @param strToAdopt the UnicodeString string.
-     * @stable ICU 2.0
-     */
-    Formattable(UnicodeString* strToAdopt);
-
-    /**
-     * Creates a Formattable object with an array of Formattable objects.
-     * @param arrayToCopy the Formattable object array.
-     * @param count the array count.
-     * @stable ICU 2.0
-     */
-    Formattable(const Formattable* arrayToCopy, int32_t count);
-
-    /**
-     * Creates a Formattable object that adopts the given UObject.
-     * @param objectToAdopt the UObject to set this object to
-     * @stable ICU 3.0
-     */
-    Formattable(UObject* objectToAdopt);
-
-    /**
-     * Copy constructor.
-     * @stable ICU 2.0
-     */
-    Formattable(const Formattable&);
-
-    /**
-     * Assignment operator.
-     * @param rhs   The Formattable object to copy into this object.
-     * @stable ICU 2.0
-     */
-    Formattable&    operator=(const Formattable &rhs);
-
-    /**
-     * Equality comparison.
-     * @param other    the object to be compared with.
-     * @return        TRUE if other are equal to this, FALSE otherwise.
-     * @stable ICU 2.0
-     */
-    UBool          operator==(const Formattable &other) const;
-    
-    /** 
-     * Equality operator.
-     * @param other    the object to be compared with.
-     * @return        TRUE if other are unequal to this, FALSE otherwise.
-     * @stable ICU 2.0
-     */
-    UBool          operator!=(const Formattable& other) const
-      { return !operator==(other); }
-
-    /** 
-     * Destructor.
-     * @stable ICU 2.0
-     */
-    virtual         ~Formattable();
-
-    /**
-     * Clone this object.
-     * Clones can be used concurrently in multiple threads.
-     * If an error occurs, then NULL is returned.
-     * The caller must delete the clone.
-     *
-     * @return a clone of this object
-     *
-     * @see getDynamicClassID
-     * @stable ICU 2.8
-     */
-    Formattable *clone() const;
-
-    /** 
-     * Selector for flavor of data type contained within a
-     * Formattable object.  Formattable is a union of several
-     * different types, and at any time contains exactly one type.
-     * @stable ICU 2.4
-     */
-    enum Type {
-        /**
-         * Selector indicating a UDate value.  Use getDate to retrieve
-         * the value.
-         * @stable ICU 2.4
-         */
-        kDate,
-
-        /**
-         * Selector indicating a double value.  Use getDouble to
-         * retrieve the value.
-         * @stable ICU 2.4
-         */
-        kDouble,
-
-        /**
-         * Selector indicating a 32-bit integer value.  Use getLong to
-         * retrieve the value.
-         * @stable ICU 2.4
-         */
-        kLong,
-
-        /**
-         * Selector indicating a UnicodeString value.  Use getString
-         * to retrieve the value.
-         * @stable ICU 2.4
-         */
-        kString,
-
-        /**
-         * Selector indicating an array of Formattables.  Use getArray
-         * to retrieve the value.
-         * @stable ICU 2.4
-         */
-        kArray,
-
-        /**
-         * Selector indicating a 64-bit integer value.  Use getInt64
-         * to retrieve the value.
-         * @stable ICU 2.8
-         */
-        kInt64,
-
-        /**
-         * Selector indicating a UObject value.  Use getObject to
-         * retrieve the value.
-         * @stable ICU 3.0
-         */
-        kObject
-   };
-
-    /**
-     * Gets the data type of this Formattable object.
-     * @return    the data type of this Formattable object.
-     * @stable ICU 2.0
-     */
-    Type            getType(void) const;
-    
-    /**
-     * Returns TRUE if the data type of this Formattable object
-     * is kDouble, kLong, or kInt64.
-     * @return TRUE if this is a pure numeric object
-     * @stable ICU 3.0
-     */
-    UBool           isNumeric() const;
-    
-    /**
-     * Gets the double value of this object. If this object is not of type
-     * kDouble then the result is undefined.
-     * @return    the double value of this object.
-     * @stable ICU 2.0
-     */ 
-    double          getDouble(void) const { return fValue.fDouble; }
-
-    /**
-     * Gets the double value of this object. If this object is of type
-     * long or int64 then a casting conversion is peformed, with
-     * possible loss of precision.  If the type is kObject and the
-     * object is a Measure, then the result of
-     * getNumber().getDouble(status) is returned.  If this object is
-     * neither a numeric type nor a Measure, then 0 is returned and
-     * the status is set to U_INVALID_FORMAT_ERROR.
-     * @param status the error code
-     * @return the double value of this object.
-     * @stable ICU 3.0
-     */ 
-    double          getDouble(UErrorCode& status) const;
-
-    /**
-     * Gets the long value of this object. If this object is not of type
-     * kLong then the result is undefined.
-     * @return    the long value of this object.
-     * @stable ICU 2.0
-     */ 
-    int32_t         getLong(void) const { return (int32_t)fValue.fInt64; }
-
-    /**
-     * Gets the long value of this object. If the magnitude is too
-     * large to fit in a long, then the maximum or minimum long value,
-     * as appropriate, is returned and the status is set to
-     * U_INVALID_FORMAT_ERROR.  If this object is of type kInt64 and
-     * it fits within a long, then no precision is lost.  If it is of
-     * type kDouble, then a casting conversion is peformed, with
-     * truncation of any fractional part.  If the type is kObject and
-     * the object is a Measure, then the result of
-     * getNumber().getLong(status) is returned.  If this object is
-     * neither a numeric type nor a Measure, then 0 is returned and
-     * the status is set to U_INVALID_FORMAT_ERROR.
-     * @param status the error code
-     * @return    the long value of this object.
-     * @stable ICU 3.0
-     */ 
-    int32_t         getLong(UErrorCode& status) const;
-
-    /**
-     * Gets the int64 value of this object. If this object is not of type
-     * kInt64 then the result is undefined.
-     * @return    the int64 value of this object.
-     * @stable ICU 2.8
-     */ 
-    int64_t         getInt64(void) const { return fValue.fInt64; }
-
-    /**
-     * Gets the int64 value of this object. If this object is of type
-     * kDouble and the magnitude is too large to fit in an int64, then
-     * the maximum or minimum int64 value, as appropriate, is returned
-     * and the status is set to U_INVALID_FORMAT_ERROR.  If the
-     * magnitude fits in an int64, then a casting conversion is
-     * peformed, with truncation of any fractional part.  If the type
-     * is kObject and the object is a Measure, then the result of
-     * getNumber().getDouble(status) is returned.  If this object is
-     * neither a numeric type nor a Measure, then 0 is returned and
-     * the status is set to U_INVALID_FORMAT_ERROR.
-     * @param status the error code
-     * @return    the int64 value of this object.
-     * @stable ICU 3.0
-     */ 
-    int64_t         getInt64(UErrorCode& status) const;
-
-    /**
-     * Gets the Date value of this object. If this object is not of type
-     * kDate then the result is undefined.
-     * @return    the Date value of this object.
-     * @stable ICU 2.0
-     */ 
-    UDate           getDate() const { return fValue.fDate; }
-
-    /**
-     * Gets the Date value of this object.  If the type is not a date,
-     * status is set to U_INVALID_FORMAT_ERROR and the return value is
-     * undefined.
-     * @param status the error code.
-     * @return    the Date value of this object.
-     * @stable ICU 3.0
-     */ 
-     UDate          getDate(UErrorCode& status) const;
-
-    /**
-     * Gets the string value of this object. If this object is not of type
-     * kString then the result is undefined.
-     * @param result    Output param to receive the Date value of this object.
-     * @return          A reference to 'result'.
-     * @stable ICU 2.0
-     */ 
-    UnicodeString&  getString(UnicodeString& result) const
-      { result=*fValue.fString; return result; }
-
-    /**
-     * Gets the string value of this object. If the type is not a
-     * string, status is set to U_INVALID_FORMAT_ERROR and a bogus
-     * string is returned.
-     * @param result    Output param to receive the Date value of this object.
-     * @param status    the error code. 
-     * @return          A reference to 'result'.
-     * @stable ICU 3.0
-     */ 
-    UnicodeString&  getString(UnicodeString& result, UErrorCode& status) const;
-
-    /**
-     * Gets a const reference to the string value of this object. If
-     * this object is not of type kString then the result is
-     * undefined.
-     * @return   a const reference to the string value of this object.
-     * @stable ICU 2.0
-     */
-    inline const UnicodeString& getString(void) const;
-
-    /**
-     * Gets a const reference to the string value of this object.  If
-     * the type is not a string, status is set to
-     * U_INVALID_FORMAT_ERROR and the result is a bogus string.
-     * @param status    the error code.
-     * @return   a const reference to the string value of this object.
-     * @stable ICU 3.0
-     */
-    const UnicodeString& getString(UErrorCode& status) const;
-
-    /**
-     * Gets a reference to the string value of this object. If this
-     * object is not of type kString then the result is undefined.
-     * @return   a reference to the string value of this object.
-     * @stable ICU 2.0
-     */
-    inline UnicodeString& getString(void);
-
-    /**
-     * Gets a reference to the string value of this object. If the
-     * type is not a string, status is set to U_INVALID_FORMAT_ERROR
-     * and the result is a bogus string.
-     * @param status    the error code. 
-     * @return   a reference to the string value of this object.
-     * @stable ICU 3.0
-     */
-    UnicodeString& getString(UErrorCode& status);
-
-    /**
-     * Gets the array value and count of this object. If this object
-     * is not of type kArray then the result is undefined.
-     * @param count    fill-in with the count of this object.
-     * @return         the array value of this object.
-     * @stable ICU 2.0
-     */ 
-    const Formattable* getArray(int32_t& count) const
-      { count=fValue.fArrayAndCount.fCount; return fValue.fArrayAndCount.fArray; }
-
-    /**
-     * Gets the array value and count of this object. If the type is
-     * not an array, status is set to U_INVALID_FORMAT_ERROR, count is
-     * set to 0, and the result is NULL.
-     * @param count    fill-in with the count of this object.
-     * @param status the error code. 
-     * @return         the array value of this object.
-     * @stable ICU 3.0
-     */ 
-    const Formattable* getArray(int32_t& count, UErrorCode& status) const;
-
-    /**
-     * Accesses the specified element in the array value of this
-     * Formattable object. If this object is not of type kArray then
-     * the result is undefined.
-     * @param index the specified index.
-     * @return the accessed element in the array.
-     * @stable ICU 2.0
-     */
-    Formattable&    operator[](int32_t index) { return fValue.fArrayAndCount.fArray[index]; }
-       
-    /**
-     * Returns a pointer to the UObject contained within this
-     * formattable, or NULL if this object does not contain a UObject.
-     * @return a UObject pointer, or NULL
-     * @stable ICU 3.0
-     */
-    const UObject*  getObject() const;
-
-    /**
-     * Sets the double value of this object and changes the type to
-     * kDouble.
-     * @param d    the new double value to be set.
-     * @stable ICU 2.0
-     */ 
-    void            setDouble(double d);
-
-    /**
-     * Sets the long value of this object and changes the type to
-     * kLong.
-     * @param l    the new long value to be set.
-     * @stable ICU 2.0
-     */ 
-    void            setLong(int32_t l);
-
-    /**
-     * Sets the int64 value of this object and changes the type to
-     * kInt64.
-     * @param ll    the new int64 value to be set.
-     * @stable ICU 2.8
-     */ 
-    void            setInt64(int64_t ll);
-
-    /**
-     * Sets the Date value of this object and changes the type to
-     * kDate.
-     * @param d    the new Date value to be set.
-     * @stable ICU 2.0
-     */ 
-    void            setDate(UDate d);
-
-    /**
-     * Sets the string value of this object and changes the type to
-     * kString.
-     * @param stringToCopy    the new string value to be set.
-     * @stable ICU 2.0
-     */ 
-    void            setString(const UnicodeString& stringToCopy);
-
-    /**
-     * Sets the array value and count of this object and changes the
-     * type to kArray.
-     * @param array    the array value.
-     * @param count    the number of array elements to be copied.
-     * @stable ICU 2.0
-     */ 
-    void            setArray(const Formattable* array, int32_t count);
-
-    /**
-     * Sets and adopts the string value and count of this object and
-     * changes the type to kArray.
-     * @param stringToAdopt    the new string value to be adopted.
-     * @stable ICU 2.0
-     */ 
-    void            adoptString(UnicodeString* stringToAdopt);
-
-    /**
-     * Sets and adopts the array value and count of this object and
-     * changes the type to kArray.
-     * @stable ICU 2.0
-     */ 
-    void            adoptArray(Formattable* array, int32_t count);
-       
-    /**
-     * Sets and adopts the UObject value of this object and changes
-     * the type to kObject.  After this call, the caller must not
-     * delete the given object.
-     * @param objectToAdopt the UObject value to be adopted
-     * @stable ICU 3.0
-     */
-    void            adoptObject(UObject* objectToAdopt);
-
-    /**
-     * ICU "poor man's RTTI", returns a UClassID for the actual class.
-     *
-     * @stable ICU 2.2
-     */
-    virtual UClassID getDynamicClassID() const;
-
-    /**
-     * ICU "poor man's RTTI", returns a UClassID for this class.
-     *
-     * @stable ICU 2.2
-     */
-    static UClassID U_EXPORT2 getStaticClassID();
-
-    /**
-     * Deprecated variant of getLong(UErrorCode&).
-     * @param status the error code
-     * @return the long value of this object.
-     * @deprecated ICU 3.0 use getLong(UErrorCode&) instead
-     */ 
-    inline int32_t getLong(UErrorCode* status) const;
-
-private:
-    /**
-     * Cleans up the memory for unwanted values.  For example, the adopted
-     * string or array objects.
-     */
-    void            dispose(void);
-
-    UnicodeString* getBogus() const;
-
-    union {
-        UObject*        fObject;
-        UnicodeString*  fString;
-        double          fDouble;
-        int64_t         fInt64;
-        UDate           fDate;
-        struct {
-          Formattable*  fArray;
-          int32_t       fCount;
-        }               fArrayAndCount;
-    } fValue;
-
-    Type                fType;
-    UnicodeString       fBogus; // Bogus string when it's needed.
-};
-
-inline UDate Formattable::getDate(UErrorCode& status) const {
-    if (fType != kDate) {
-        if (U_SUCCESS(status)) {
-            status = U_INVALID_FORMAT_ERROR;
-        }
-        return 0;
-    }
-    return fValue.fDate;
-}
-
-inline const UnicodeString& Formattable::getString(void) const {
-    return *fValue.fString;
-}
-
-inline UnicodeString& Formattable::getString(void) {
-    return *fValue.fString;
-}
-
-inline int32_t Formattable::getLong(UErrorCode* status) const {
-    return getLong(*status);
-}
-
-U_NAMESPACE_END
-
-#endif /* #if !UCONFIG_NO_FORMATTING */
-
-#endif //_FMTABLE
-//eof
-

http://git-wip-us.apache.org/repos/asf/couchdb/blob/81332b78/apps/couch_collate/platform/osx/icu/unicode/format.h
----------------------------------------------------------------------
diff --git a/apps/couch_collate/platform/osx/icu/unicode/format.h b/apps/couch_collate/platform/osx/icu/unicode/format.h
deleted file mode 100644
index 7f17b52..0000000
--- a/apps/couch_collate/platform/osx/icu/unicode/format.h
+++ /dev/null
@@ -1,296 +0,0 @@
-/*
-********************************************************************************
-* Copyright (C) 1997-2006, International Business Machines Corporation and others.
-* All Rights Reserved.
-********************************************************************************
-*
-* File FORMAT.H
-*
-* Modification History:
-*
-*   Date        Name        Description
-*   02/19/97    aliu        Converted from java.
-*   03/17/97    clhuang     Updated per C++ implementation.
-*   03/27/97    helena      Updated to pass the simple test after code review.
-********************************************************************************
-*/
-// *****************************************************************************
-// This file was generated from the java source file Format.java
-// *****************************************************************************
-
-#ifndef FORMAT_H
-#define FORMAT_H
-
-
-#include "unicode/utypes.h"
-
-/**
- * \file 
- * \brief C++ API: Base class for all formats. 
- */
-
-#if !UCONFIG_NO_FORMATTING
-
-#include "unicode/unistr.h"
-#include "unicode/fmtable.h"
-#include "unicode/fieldpos.h"
-#include "unicode/parsepos.h"
-#include "unicode/parseerr.h" 
-#include "unicode/locid.h"
-
-U_NAMESPACE_BEGIN
-
-/**
- * Base class for all formats.  This is an abstract base class which
- * specifies the protocol for classes which convert other objects or
- * values, such as numeric values and dates, and their string
- * representations.  In some cases these representations may be
- * localized or contain localized characters or strings.  For example,
- * a numeric formatter such as DecimalFormat may convert a numeric
- * value such as 12345 to the string "$12,345".  It may also parse
- * the string back into a numeric value.  A date and time formatter
- * like SimpleDateFormat may represent a specific date, encoded
- * numerically, as a string such as "Wednesday, February 26, 1997 AD".
- * <P>
- * Many of the concrete subclasses of Format employ the notion of
- * a pattern.  A pattern is a string representation of the rules which
- * govern the interconversion between values and strings.  For example,
- * a DecimalFormat object may be associated with the pattern
- * "$#,##0.00;($#,##0.00)", which is a common US English format for
- * currency values, yielding strings such as "$1,234.45" for 1234.45,
- * and "($987.65)" for 987.6543.  The specific syntax of a pattern
- * is defined by each subclass.
- * <P>
- * Even though many subclasses use patterns, the notion of a pattern
- * is not inherent to Format classes in general, and is not part of
- * the explicit base class protocol.
- * <P>
- * Two complex formatting classes bear mentioning.  These are
- * MessageFormat and ChoiceFormat.  ChoiceFormat is a subclass of
- * NumberFormat which allows the user to format different number ranges
- * as strings.  For instance, 0 may be represented as "no files", 1 as
- * "one file", and any number greater than 1 as "many files".
- * MessageFormat is a formatter which utilizes other Format objects to
- * format a string containing with multiple values.  For instance,
- * A MessageFormat object might produce the string "There are no files
- * on the disk MyDisk on February 27, 1997." given the arguments 0,
- * "MyDisk", and the date value of 2/27/97.  See the ChoiceFormat
- * and MessageFormat headers for further information.
- * <P>
- * If formatting is unsuccessful, a failing UErrorCode is returned when
- * the Format cannot format the type of object, otherwise if there is
- * something illformed about the the Unicode replacement character
- * 0xFFFD is returned.
- * <P>
- * If there is no match when parsing, a parse failure UErrorCode is
- * retured for methods which take no ParsePosition.  For the method
- * that takes a ParsePosition, the index parameter is left unchanged.
- * <P>
- * <em>User subclasses are not supported.</em> While clients may write
- * subclasses, such code will not necessarily work and will not be
- * guaranteed to work stably from release to release.
- */
-class U_I18N_API Format : public UObject {
-public:
-
-    /** Destructor
-     * @stable ICU 2.4
-     */
-    virtual ~Format();
-
-    /**
-     * Return true if the given Format objects are semantically equal.
-     * Objects of different subclasses are considered unequal.
-     * @param other    the object to be compared with.
-     * @return         Return true if the given Format objects are semantically equal.
-     *                 Objects of different subclasses are considered unequal.
-     * @stable ICU 2.0
-     */
-    virtual UBool operator==(const Format& other) const = 0;
-
-    /**
-     * Return true if the given Format objects are not semantically
-     * equal.
-     * @param other    the object to be compared with.
-     * @return         Return true if the given Format objects are not semantically.
-     * @stable ICU 2.0
-     */
-    UBool operator!=(const Format& other) const { return !operator==(other); }
-
-    /**
-     * Clone this object polymorphically.  The caller is responsible
-     * for deleting the result when done.
-     * @return    A copy of the object
-     * @stable ICU 2.0
-     */
-    virtual Format* clone() const = 0;
-
-    /**
-     * Formats an object to produce a string.
-     *
-     * @param obj       The object to format.
-     * @param appendTo  Output parameter to receive result.
-     *                  Result is appended to existing contents.
-     * @param status    Output parameter filled in with success or failure status.
-     * @return          Reference to 'appendTo' parameter.
-     * @stable ICU 2.0
-     */
-    UnicodeString& format(const Formattable& obj,
-                          UnicodeString& appendTo,
-                          UErrorCode& status) const;
-
-    /**
-     * Format an object to produce a string.  This is a pure virtual method which
-     * subclasses must implement. This method allows polymorphic formatting
-     * of Formattable objects. If a subclass of Format receives a Formattable
-     * object type it doesn't handle (e.g., if a numeric Formattable is passed
-     * to a DateFormat object) then it returns a failing UErrorCode.
-     *
-     * @param obj       The object to format.
-     * @param appendTo  Output parameter to receive result.
-     *                  Result is appended to existing contents.
-     * @param pos       On input: an alignment field, if desired.
-     *                  On output: the offsets of the alignment field.
-     * @param status    Output param filled with success/failure status.
-     * @return          Reference to 'appendTo' parameter.
-     * @stable ICU 2.0
-     */
-    virtual UnicodeString& format(const Formattable& obj,
-                                  UnicodeString& appendTo,
-                                  FieldPosition& pos,
-                                  UErrorCode& status) const = 0;
-
-    /**
-     * Parse a string to produce an object.  This is a pure virtual
-     * method which subclasses must implement.  This method allows
-     * polymorphic parsing of strings into Formattable objects.
-     * <P>
-     * Before calling, set parse_pos.index to the offset you want to
-     * start parsing at in the source.  After calling, parse_pos.index
-     * is the end of the text you parsed.  If error occurs, index is
-     * unchanged.
-     * <P>
-     * When parsing, leading whitespace is discarded (with successful
-     * parse), while trailing whitespace is left as is.
-     * <P>
-     * Example:
-     * <P>
-     * Parsing "_12_xy" (where _ represents a space) for a number,
-     * with index == 0 will result in the number 12, with
-     * parse_pos.index updated to 3 (just before the second space).
-     * Parsing a second time will result in a failing UErrorCode since
-     * "xy" is not a number, and leave index at 3.
-     * <P>
-     * Subclasses will typically supply specific parse methods that
-     * return different types of values. Since methods can't overload
-     * on return types, these will typically be named "parse", while
-     * this polymorphic method will always be called parseObject.  Any
-     * parse method that does not take a parse_pos should set status
-     * to an error value when no text in the required format is at the
-     * start position.
-     *
-     * @param source    The string to be parsed into an object.
-     * @param result    Formattable to be set to the parse result.
-     *                  If parse fails, return contents are undefined.
-     * @param parse_pos The position to start parsing at. Upon return
-     *                  this param is set to the position after the
-     *                  last character successfully parsed. If the
-     *                  source is not parsed successfully, this param
-     *                  will remain unchanged.
-     * @stable ICU 2.0
-     */
-    virtual void parseObject(const UnicodeString& source,
-                             Formattable& result,
-                             ParsePosition& parse_pos) const = 0;
-
-    /**
-     * Parses a string to produce an object. This is a convenience method
-     * which calls the pure virtual parseObject() method, and returns a
-     * failure UErrorCode if the ParsePosition indicates failure.
-     *
-     * @param source    The string to be parsed into an object.
-     * @param result    Formattable to be set to the parse result.
-     *                  If parse fails, return contents are undefined.
-     * @param status    Output param to be filled with success/failure
-     *                  result code.
-     * @stable ICU 2.0
-     */
-    void parseObject(const UnicodeString& source,
-                     Formattable& result,
-                     UErrorCode& status) const;
-
-    /**
-     * Returns a unique class ID POLYMORPHICALLY.  Pure virtual method.
-     * This method is to implement a simple version of RTTI, since not all
-     * C++ compilers support genuine RTTI.  Polymorphic operator==() and
-     * clone() methods call this method.
-     * Concrete subclasses of Format must implement getDynamicClassID()
-     *
-     * @return          The class ID for this object. All objects of a
-     *                  given class have the same class ID.  Objects of
-     *                  other classes have different class IDs.
-     * @stable ICU 2.0
-     */
-    virtual UClassID getDynamicClassID() const = 0;
-
-    /** Get the locale for this format object. You can choose between valid and actual locale.
-     *  @param type type of the locale we're looking for (valid or actual) 
-     *  @param status error code for the operation
-     *  @return the locale
-     *  @stable ICU 2.8
-     */
-    Locale getLocale(ULocDataLocaleType type, UErrorCode& status) const;
-
-    /** Get the locale for this format object. You can choose between valid and actual locale.
-     *  @param type type of the locale we're looking for (valid or actual) 
-     *  @param status error code for the operation
-     *  @return the locale
-     *  @internal
-     */
-    const char* getLocaleID(ULocDataLocaleType type, UErrorCode &status) const;
-
- protected:
-    /** @stable ICU 2.8 */
-    void setLocaleIDs(const char* valid, const char* actual);
-
-protected:
-    /**
-     * Default constructor for subclass use only.  Does nothing.
-     * @stable ICU 2.0
-     */
-    Format();
-
-    /**
-     * @stable ICU 2.0
-     */
-    Format(const Format&); // Does nothing; for subclasses only
-
-    /**
-     * @stable ICU 2.0
-     */
-    Format& operator=(const Format&); // Does nothing; for subclasses
-
-       
-    /**
-     * Simple function for initializing a UParseError from a UnicodeString.
-     *
-     * @param pattern The pattern to copy into the parseError
-     * @param pos The position in pattern where the error occured
-     * @param parseError The UParseError object to fill in
-     * @stable ICU 2.4
-     */
-    static void syntaxError(const UnicodeString& pattern,
-                            int32_t pos,
-                            UParseError& parseError);
-
- private:
-    char actualLocale[ULOC_FULLNAME_CAPACITY];
-    char validLocale[ULOC_FULLNAME_CAPACITY];
-};
-
-U_NAMESPACE_END
-
-#endif /* #if !UCONFIG_NO_FORMATTING */
-
-#endif // _FORMAT
-//eof