001/*
002 * Copyright (C) 2012 The Guava Authors
003 *
004 * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except
005 * in compliance with the License. You may obtain a copy of the License at
006 *
007 * http://www.apache.org/licenses/LICENSE-2.0
008 *
009 * Unless required by applicable law or agreed to in writing, software distributed under the License
010 * is distributed on an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express
011 * or implied. See the License for the specific language governing permissions and limitations under
012 * the License.
013 */
014
015package com.google.common.util.concurrent;
016
017import static com.google.common.base.Preconditions.checkArgument;
018import static com.google.common.base.Preconditions.checkNotNull;
019import static com.google.common.util.concurrent.Internal.toNanosSaturated;
020import static java.lang.Math.max;
021import static java.util.concurrent.TimeUnit.MICROSECONDS;
022import static java.util.concurrent.TimeUnit.SECONDS;
023
024import com.google.common.annotations.Beta;
025import com.google.common.annotations.GwtIncompatible;
026import com.google.common.annotations.J2ktIncompatible;
027import com.google.common.annotations.VisibleForTesting;
028import com.google.common.base.Stopwatch;
029import com.google.common.util.concurrent.SmoothRateLimiter.SmoothBursty;
030import com.google.common.util.concurrent.SmoothRateLimiter.SmoothWarmingUp;
031import com.google.errorprone.annotations.CanIgnoreReturnValue;
032import java.time.Duration;
033import java.util.Locale;
034import java.util.concurrent.TimeUnit;
035import org.checkerframework.checker.nullness.qual.Nullable;
036
037/**
038 * A rate limiter. Conceptually, a rate limiter distributes permits at a configurable rate. Each
039 * {@link #acquire()} blocks if necessary until a permit is available, and then takes it. Once
040 * acquired, permits need not be released.
041 *
042 * <p>{@code RateLimiter} is safe for concurrent use: It will restrict the total rate of calls from
043 * all threads. Note, however, that it does not guarantee fairness.
044 *
045 * <p>Rate limiters are often used to restrict the rate at which some physical or logical resource
046 * is accessed. This is in contrast to {@link java.util.concurrent.Semaphore} which restricts the
047 * number of concurrent accesses instead of the rate (note though that concurrency and rate are
048 * closely related, e.g. see <a href="http://en.wikipedia.org/wiki/Little%27s_law">Little's
049 * Law</a>).
050 *
051 * <p>A {@code RateLimiter} is defined primarily by the rate at which permits are issued. Absent
052 * additional configuration, permits will be distributed at a fixed rate, defined in terms of
053 * permits per second. Permits will be distributed smoothly, with the delay between individual
054 * permits being adjusted to ensure that the configured rate is maintained.
055 *
056 * <p>It is possible to configure a {@code RateLimiter} to have a warmup period during which time
057 * the permits issued each second steadily increases until it hits the stable rate.
058 *
059 * <p>As an example, imagine that we have a list of tasks to execute, but we don't want to submit
060 * more than 2 per second:
061 *
062 * <pre>{@code
063 * final RateLimiter rateLimiter = RateLimiter.create(2.0); // rate is "2 permits per second"
064 * void submitTasks(List<Runnable> tasks, Executor executor) {
065 *   for (Runnable task : tasks) {
066 *     rateLimiter.acquire(); // may wait
067 *     executor.execute(task);
068 *   }
069 * }
070 * }</pre>
071 *
072 * <p>As another example, imagine that we produce a stream of data, and we want to cap it at 5kb per
073 * second. This could be accomplished by requiring a permit per byte, and specifying a rate of 5000
074 * permits per second:
075 *
076 * <pre>{@code
077 * final RateLimiter rateLimiter = RateLimiter.create(5000.0); // rate = 5000 permits per second
078 * void submitPacket(byte[] packet) {
079 *   rateLimiter.acquire(packet.length);
080 *   networkService.send(packet);
081 * }
082 * }</pre>
083 *
084 * <p>It is important to note that the number of permits requested <i>never</i> affects the
085 * throttling of the request itself (an invocation to {@code acquire(1)} and an invocation to {@code
086 * acquire(1000)} will result in exactly the same throttling, if any), but it affects the throttling
087 * of the <i>next</i> request. I.e., if an expensive task arrives at an idle RateLimiter, it will be
088 * granted immediately, but it is the <i>next</i> request that will experience extra throttling,
089 * thus paying for the cost of the expensive task.
090 *
091 * @author Dimitris Andreou
092 * @since 13.0
093 */
094// TODO(user): switch to nano precision. A natural unit of cost is "bytes", and a micro precision
095// would mean a maximum rate of "1MB/s", which might be small in some cases.
096@Beta
097@J2ktIncompatible
098@GwtIncompatible
099public abstract class RateLimiter {
100  /**
101   * Creates a {@code RateLimiter} with the specified stable throughput, given as "permits per
102   * second" (commonly referred to as <i>QPS</i>, queries per second).
103   *
104   * <p>The returned {@code RateLimiter} ensures that on average no more than {@code
105   * permitsPerSecond} are issued during any given second, with sustained requests being smoothly
106   * spread over each second. When the incoming request rate exceeds {@code permitsPerSecond} the
107   * rate limiter will release one permit every {@code (1.0 / permitsPerSecond)} seconds. When the
108   * rate limiter is unused, bursts of up to {@code permitsPerSecond} permits will be allowed, with
109   * subsequent requests being smoothly limited at the stable rate of {@code permitsPerSecond}.
110   *
111   * @param permitsPerSecond the rate of the returned {@code RateLimiter}, measured in how many
112   *     permits become available per second
113   * @throws IllegalArgumentException if {@code permitsPerSecond} is negative or zero
114   */
115  // TODO(user): "This is equivalent to
116  // {@code createWithCapacity(permitsPerSecond, 1, TimeUnit.SECONDS)}".
117  public static RateLimiter create(double permitsPerSecond) {
118    /*
119     * The default RateLimiter configuration can save the unused permits of up to one second. This
120     * is to avoid unnecessary stalls in situations like this: A RateLimiter of 1qps, and 4 threads,
121     * all calling acquire() at these moments:
122     *
123     * T0 at 0 seconds
124     * T1 at 1.05 seconds
125     * T2 at 2 seconds
126     * T3 at 3 seconds
127     *
128     * Due to the slight delay of T1, T2 would have to sleep till 2.05 seconds, and T3 would also
129     * have to sleep till 3.05 seconds.
130     */
131    return create(permitsPerSecond, SleepingStopwatch.createFromSystemTimer());
132  }
133
134  @VisibleForTesting
135  static RateLimiter create(double permitsPerSecond, SleepingStopwatch stopwatch) {
136    RateLimiter rateLimiter = new SmoothBursty(stopwatch, 1.0 /* maxBurstSeconds */);
137    rateLimiter.setRate(permitsPerSecond);
138    return rateLimiter;
139  }
140
141  /**
142   * Creates a {@code RateLimiter} with the specified stable throughput, given as "permits per
143   * second" (commonly referred to as <i>QPS</i>, queries per second), and a <i>warmup period</i>,
144   * during which the {@code RateLimiter} smoothly ramps up its rate, until it reaches its maximum
145   * rate at the end of the period (as long as there are enough requests to saturate it). Similarly,
146   * if the {@code RateLimiter} is left <i>unused</i> for a duration of {@code warmupPeriod}, it
147   * will gradually return to its "cold" state, i.e. it will go through the same warming up process
148   * as when it was first created.
149   *
150   * <p>The returned {@code RateLimiter} is intended for cases where the resource that actually
151   * fulfills the requests (e.g., a remote server) needs "warmup" time, rather than being
152   * immediately accessed at the stable (maximum) rate.
153   *
154   * <p>The returned {@code RateLimiter} starts in a "cold" state (i.e. the warmup period will
155   * follow), and if it is left unused for long enough, it will return to that state.
156   *
157   * @param permitsPerSecond the rate of the returned {@code RateLimiter}, measured in how many
158   *     permits become available per second
159   * @param warmupPeriod the duration of the period where the {@code RateLimiter} ramps up its rate,
160   *     before reaching its stable (maximum) rate
161   * @throws IllegalArgumentException if {@code permitsPerSecond} is negative or zero or {@code
162   *     warmupPeriod} is negative
163   * @since 33.4.0 (but since 28.0 in the JRE flavor)
164   */
165  @SuppressWarnings("Java7ApiChecker")
166  @IgnoreJRERequirement // Users will use this only if they're already using Duration.
167  public static RateLimiter create(double permitsPerSecond, Duration warmupPeriod) {
168    return create(permitsPerSecond, toNanosSaturated(warmupPeriod), TimeUnit.NANOSECONDS);
169  }
170
171  /**
172   * Creates a {@code RateLimiter} with the specified stable throughput, given as "permits per
173   * second" (commonly referred to as <i>QPS</i>, queries per second), and a <i>warmup period</i>,
174   * during which the {@code RateLimiter} smoothly ramps up its rate, until it reaches its maximum
175   * rate at the end of the period (as long as there are enough requests to saturate it). Similarly,
176   * if the {@code RateLimiter} is left <i>unused</i> for a duration of {@code warmupPeriod}, it
177   * will gradually return to its "cold" state, i.e. it will go through the same warming up process
178   * as when it was first created.
179   *
180   * <p>The returned {@code RateLimiter} is intended for cases where the resource that actually
181   * fulfills the requests (e.g., a remote server) needs "warmup" time, rather than being
182   * immediately accessed at the stable (maximum) rate.
183   *
184   * <p>The returned {@code RateLimiter} starts in a "cold" state (i.e. the warmup period will
185   * follow), and if it is left unused for long enough, it will return to that state.
186   *
187   * @param permitsPerSecond the rate of the returned {@code RateLimiter}, measured in how many
188   *     permits become available per second
189   * @param warmupPeriod the duration of the period where the {@code RateLimiter} ramps up its rate,
190   *     before reaching its stable (maximum) rate
191   * @param unit the time unit of the warmupPeriod argument
192   * @throws IllegalArgumentException if {@code permitsPerSecond} is negative or zero or {@code
193   *     warmupPeriod} is negative
194   */
195  @SuppressWarnings("GoodTime") // should accept a java.time.Duration
196  public static RateLimiter create(double permitsPerSecond, long warmupPeriod, TimeUnit unit) {
197    checkArgument(warmupPeriod >= 0, "warmupPeriod must not be negative: %s", warmupPeriod);
198    return create(
199        permitsPerSecond, warmupPeriod, unit, 3.0, SleepingStopwatch.createFromSystemTimer());
200  }
201
202  @VisibleForTesting
203  static RateLimiter create(
204      double permitsPerSecond,
205      long warmupPeriod,
206      TimeUnit unit,
207      double coldFactor,
208      SleepingStopwatch stopwatch) {
209    RateLimiter rateLimiter = new SmoothWarmingUp(stopwatch, warmupPeriod, unit, coldFactor);
210    rateLimiter.setRate(permitsPerSecond);
211    return rateLimiter;
212  }
213
214  /**
215   * The underlying timer; used both to measure elapsed time and sleep as necessary. A separate
216   * object to facilitate testing.
217   */
218  private final SleepingStopwatch stopwatch;
219
220  // Can't be initialized in the constructor because mocks don't call the constructor.
221  private volatile @Nullable Object mutexDoNotUseDirectly;
222
223  private Object mutex() {
224    Object mutex = mutexDoNotUseDirectly;
225    if (mutex == null) {
226      synchronized (this) {
227        mutex = mutexDoNotUseDirectly;
228        if (mutex == null) {
229          mutexDoNotUseDirectly = mutex = new Object();
230        }
231      }
232    }
233    return mutex;
234  }
235
236  RateLimiter(SleepingStopwatch stopwatch) {
237    this.stopwatch = checkNotNull(stopwatch);
238  }
239
240  /**
241   * Updates the stable rate of this {@code RateLimiter}, that is, the {@code permitsPerSecond}
242   * argument provided in the factory method that constructed the {@code RateLimiter}. Currently
243   * throttled threads will <b>not</b> be awakened as a result of this invocation, thus they do not
244   * observe the new rate; only subsequent requests will.
245   *
246   * <p>Note though that, since each request repays (by waiting, if necessary) the cost of the
247   * <i>previous</i> request, this means that the very next request after an invocation to {@code
248   * setRate} will not be affected by the new rate; it will pay the cost of the previous request,
249   * which is in terms of the previous rate.
250   *
251   * <p>The behavior of the {@code RateLimiter} is not modified in any other way, e.g. if the {@code
252   * RateLimiter} was configured with a warmup period of 20 seconds, it still has a warmup period of
253   * 20 seconds after this method invocation.
254   *
255   * @param permitsPerSecond the new stable rate of this {@code RateLimiter}
256   * @throws IllegalArgumentException if {@code permitsPerSecond} is negative or zero
257   */
258  public final void setRate(double permitsPerSecond) {
259    checkArgument(permitsPerSecond > 0.0, "rate must be positive");
260    synchronized (mutex()) {
261      doSetRate(permitsPerSecond, stopwatch.readMicros());
262    }
263  }
264
265  abstract void doSetRate(double permitsPerSecond, long nowMicros);
266
267  /**
268   * Returns the stable rate (as {@code permits per seconds}) with which this {@code RateLimiter} is
269   * configured with. The initial value of this is the same as the {@code permitsPerSecond} argument
270   * passed in the factory method that produced this {@code RateLimiter}, and it is only updated
271   * after invocations to {@linkplain #setRate}.
272   */
273  public final double getRate() {
274    synchronized (mutex()) {
275      return doGetRate();
276    }
277  }
278
279  abstract double doGetRate();
280
281  /**
282   * Acquires a single permit from this {@code RateLimiter}, blocking until the request can be
283   * granted. Tells the amount of time slept, if any.
284   *
285   * <p>This method is equivalent to {@code acquire(1)}.
286   *
287   * @return time spent sleeping to enforce rate, in seconds; 0.0 if not rate-limited
288   * @since 16.0 (present in 13.0 with {@code void} return type})
289   */
290  @CanIgnoreReturnValue
291  public double acquire() {
292    return acquire(1);
293  }
294
295  /**
296   * Acquires the given number of permits from this {@code RateLimiter}, blocking until the request
297   * can be granted. Tells the amount of time slept, if any.
298   *
299   * @param permits the number of permits to acquire
300   * @return time spent sleeping to enforce rate, in seconds; 0.0 if not rate-limited
301   * @throws IllegalArgumentException if the requested number of permits is negative or zero
302   * @since 16.0 (present in 13.0 with {@code void} return type})
303   */
304  @CanIgnoreReturnValue
305  public double acquire(int permits) {
306    long microsToWait = reserve(permits);
307    stopwatch.sleepMicrosUninterruptibly(microsToWait);
308    return 1.0 * microsToWait / SECONDS.toMicros(1L);
309  }
310
311  /**
312   * Reserves the given number of permits from this {@code RateLimiter} for future use, returning
313   * the number of microseconds until the reservation can be consumed.
314   *
315   * @return time in microseconds to wait until the resource can be acquired, never negative
316   */
317  final long reserve(int permits) {
318    checkPermits(permits);
319    synchronized (mutex()) {
320      return reserveAndGetWaitLength(permits, stopwatch.readMicros());
321    }
322  }
323
324  /**
325   * Acquires a permit from this {@code RateLimiter} if it can be obtained without exceeding the
326   * specified {@code timeout}, or returns {@code false} immediately (without waiting) if the permit
327   * would not have been granted before the timeout expired.
328   *
329   * <p>This method is equivalent to {@code tryAcquire(1, timeout)}.
330   *
331   * @param timeout the maximum time to wait for the permit. Negative values are treated as zero.
332   * @return {@code true} if the permit was acquired, {@code false} otherwise
333   * @throws IllegalArgumentException if the requested number of permits is negative or zero
334   * @since 33.4.0 (but since 28.0 in the JRE flavor)
335   */
336  @SuppressWarnings("Java7ApiChecker")
337  @IgnoreJRERequirement // Users will use this only if they're already using Duration.
338  public boolean tryAcquire(Duration timeout) {
339    return tryAcquire(1, toNanosSaturated(timeout), TimeUnit.NANOSECONDS);
340  }
341
342  /**
343   * Acquires a permit from this {@code RateLimiter} if it can be obtained without exceeding the
344   * specified {@code timeout}, or returns {@code false} immediately (without waiting) if the permit
345   * would not have been granted before the timeout expired.
346   *
347   * <p>This method is equivalent to {@code tryAcquire(1, timeout, unit)}.
348   *
349   * @param timeout the maximum time to wait for the permit. Negative values are treated as zero.
350   * @param unit the time unit of the timeout argument
351   * @return {@code true} if the permit was acquired, {@code false} otherwise
352   * @throws IllegalArgumentException if the requested number of permits is negative or zero
353   */
354  @SuppressWarnings("GoodTime") // should accept a java.time.Duration
355  public boolean tryAcquire(long timeout, TimeUnit unit) {
356    return tryAcquire(1, timeout, unit);
357  }
358
359  /**
360   * Acquires permits from this {@link RateLimiter} if it can be acquired immediately without delay.
361   *
362   * <p>This method is equivalent to {@code tryAcquire(permits, 0, anyUnit)}.
363   *
364   * @param permits the number of permits to acquire
365   * @return {@code true} if the permits were acquired, {@code false} otherwise
366   * @throws IllegalArgumentException if the requested number of permits is negative or zero
367   * @since 14.0
368   */
369  public boolean tryAcquire(int permits) {
370    return tryAcquire(permits, 0, MICROSECONDS);
371  }
372
373  /**
374   * Acquires a permit from this {@link RateLimiter} if it can be acquired immediately without
375   * delay.
376   *
377   * <p>This method is equivalent to {@code tryAcquire(1)}.
378   *
379   * @return {@code true} if the permit was acquired, {@code false} otherwise
380   * @since 14.0
381   */
382  public boolean tryAcquire() {
383    return tryAcquire(1, 0, MICROSECONDS);
384  }
385
386  /**
387   * Acquires the given number of permits from this {@code RateLimiter} if it can be obtained
388   * without exceeding the specified {@code timeout}, or returns {@code false} immediately (without
389   * waiting) if the permits would not have been granted before the timeout expired.
390   *
391   * @param permits the number of permits to acquire
392   * @param timeout the maximum time to wait for the permits. Negative values are treated as zero.
393   * @return {@code true} if the permits were acquired, {@code false} otherwise
394   * @throws IllegalArgumentException if the requested number of permits is negative or zero
395   * @since 33.4.0 (but since 28.0 in the JRE flavor)
396   */
397  @SuppressWarnings("Java7ApiChecker")
398  @IgnoreJRERequirement // Users will use this only if they're already using Duration.
399  public boolean tryAcquire(int permits, Duration timeout) {
400    return tryAcquire(permits, toNanosSaturated(timeout), TimeUnit.NANOSECONDS);
401  }
402
403  /**
404   * Acquires the given number of permits from this {@code RateLimiter} if it can be obtained
405   * without exceeding the specified {@code timeout}, or returns {@code false} immediately (without
406   * waiting) if the permits would not have been granted before the timeout expired.
407   *
408   * @param permits the number of permits to acquire
409   * @param timeout the maximum time to wait for the permits. Negative values are treated as zero.
410   * @param unit the time unit of the timeout argument
411   * @return {@code true} if the permits were acquired, {@code false} otherwise
412   * @throws IllegalArgumentException if the requested number of permits is negative or zero
413   */
414  @SuppressWarnings("GoodTime") // should accept a java.time.Duration
415  public boolean tryAcquire(int permits, long timeout, TimeUnit unit) {
416    long timeoutMicros = max(unit.toMicros(timeout), 0);
417    checkPermits(permits);
418    long microsToWait;
419    synchronized (mutex()) {
420      long nowMicros = stopwatch.readMicros();
421      if (!canAcquire(nowMicros, timeoutMicros)) {
422        return false;
423      } else {
424        microsToWait = reserveAndGetWaitLength(permits, nowMicros);
425      }
426    }
427    stopwatch.sleepMicrosUninterruptibly(microsToWait);
428    return true;
429  }
430
431  private boolean canAcquire(long nowMicros, long timeoutMicros) {
432    return queryEarliestAvailable(nowMicros) - timeoutMicros <= nowMicros;
433  }
434
435  /**
436   * Reserves next ticket and returns the wait time that the caller must wait for.
437   *
438   * @return the required wait time, never negative
439   */
440  final long reserveAndGetWaitLength(int permits, long nowMicros) {
441    long momentAvailable = reserveEarliestAvailable(permits, nowMicros);
442    return max(momentAvailable - nowMicros, 0);
443  }
444
445  /**
446   * Returns the earliest time that permits are available (with one caveat).
447   *
448   * @return the time that permits are available, or, if permits are available immediately, an
449   *     arbitrary past or present time
450   */
451  abstract long queryEarliestAvailable(long nowMicros);
452
453  /**
454   * Reserves the requested number of permits and returns the time that those permits can be used
455   * (with one caveat).
456   *
457   * @return the time that the permits may be used, or, if the permits may be used immediately, an
458   *     arbitrary past or present time
459   */
460  abstract long reserveEarliestAvailable(int permits, long nowMicros);
461
462  @Override
463  public String toString() {
464    return String.format(Locale.ROOT, "RateLimiter[stableRate=%3.1fqps]", getRate());
465  }
466
467  abstract static class SleepingStopwatch {
468    /** Constructor for use by subclasses. */
469    protected SleepingStopwatch() {}
470
471    /*
472     * We always hold the mutex when calling this. TODO(cpovirk): Is that important? Perhaps we need
473     * to guarantee that each call to reserveEarliestAvailable, etc. sees a value >= the previous?
474     * Also, is it OK that we don't hold the mutex when sleeping?
475     */
476    protected abstract long readMicros();
477
478    protected abstract void sleepMicrosUninterruptibly(long micros);
479
480    public static SleepingStopwatch createFromSystemTimer() {
481      return new SleepingStopwatch() {
482        final Stopwatch stopwatch = Stopwatch.createStarted();
483
484        @Override
485        protected long readMicros() {
486          return stopwatch.elapsed(MICROSECONDS);
487        }
488
489        @Override
490        protected void sleepMicrosUninterruptibly(long micros) {
491          if (micros > 0) {
492            Uninterruptibles.sleepUninterruptibly(micros, MICROSECONDS);
493          }
494        }
495      };
496    }
497  }
498
499  private static void checkPermits(int permits) {
500    checkArgument(permits > 0, "Requested permits (%s) must be positive", permits);
501  }
502}