404

[ Avaa Bypassed ]




Upload:

Command:

botdev@3.16.124.181: ~ $
import { Observable } from '../Observable';
import { Operator } from '../Operator';
import { Subscriber } from '../Subscriber';
import { Subscription } from '../Subscription';
import { Notification } from '../Notification';
import { MonoTypeOperatorFunction, PartialObserver, SchedulerAction, SchedulerLike, TeardownLogic } from '../types';

/**
 *
 * Re-emits all notifications from source Observable with specified scheduler.
 *
 * <span class="informal">Ensure a specific scheduler is used, from outside of an Observable.</span>
 *
 * `observeOn` is an operator that accepts a scheduler as a first parameter, which will be used to reschedule
 * notifications emitted by the source Observable. It might be useful, if you do not have control over
 * internal scheduler of a given Observable, but want to control when its values are emitted nevertheless.
 *
 * Returned Observable emits the same notifications (nexted values, complete and error events) as the source Observable,
 * but rescheduled with provided scheduler. Note that this doesn't mean that source Observables internal
 * scheduler will be replaced in any way. Original scheduler still will be used, but when the source Observable emits
 * notification, it will be immediately scheduled again - this time with scheduler passed to `observeOn`.
 * An anti-pattern would be calling `observeOn` on Observable that emits lots of values synchronously, to split
 * that emissions into asynchronous chunks. For this to happen, scheduler would have to be passed into the source
 * Observable directly (usually into the operator that creates it). `observeOn` simply delays notifications a
 * little bit more, to ensure that they are emitted at expected moments.
 *
 * As a matter of fact, `observeOn` accepts second parameter, which specifies in milliseconds with what delay notifications
 * will be emitted. The main difference between {@link delay} operator and `observeOn` is that `observeOn`
 * will delay all notifications - including error notifications - while `delay` will pass through error
 * from source Observable immediately when it is emitted. In general it is highly recommended to use `delay` operator
 * for any kind of delaying of values in the stream, while using `observeOn` to specify which scheduler should be used
 * for notification emissions in general.
 *
 * ## Example
 * Ensure values in subscribe are called just before browser repaint.
 * ```ts
 * import { interval } from 'rxjs';
 * import { observeOn } from 'rxjs/operators';
 *
 * const intervals = interval(10);                // Intervals are scheduled
 *                                                // with async scheduler by default...
 * intervals.pipe(
 *   observeOn(animationFrameScheduler),          // ...but we will observe on animationFrame
 * )                                              // scheduler to ensure smooth animation.
 * .subscribe(val => {
 *   someDiv.style.height = val + 'px';
 * });
 * ```
 *
 * @see {@link delay}
 *
 * @param {SchedulerLike} scheduler Scheduler that will be used to reschedule notifications from source Observable.
 * @param {number} [delay] Number of milliseconds that states with what delay every notification should be rescheduled.
 * @return {Observable<T>} Observable that emits the same notifications as the source Observable,
 * but with provided scheduler.
 *
 * @method observeOn
 * @owner Observable
 */
export function observeOn<T>(scheduler: SchedulerLike, delay: number = 0): MonoTypeOperatorFunction<T> {
  return function observeOnOperatorFunction(source: Observable<T>): Observable<T> {
    return source.lift(new ObserveOnOperator(scheduler, delay));
  };
}

export class ObserveOnOperator<T> implements Operator<T, T> {
  constructor(private scheduler: SchedulerLike, private delay: number = 0) {
  }

  call(subscriber: Subscriber<T>, source: any): TeardownLogic {
    return source.subscribe(new ObserveOnSubscriber(subscriber, this.scheduler, this.delay));
  }
}

/**
 * We need this JSDoc comment for affecting ESDoc.
 * @ignore
 * @extends {Ignored}
 */
export class ObserveOnSubscriber<T> extends Subscriber<T> {
  /** @nocollapse */
  static dispatch(this: SchedulerAction<ObserveOnMessage>, arg: ObserveOnMessage) {
    const { notification, destination } = arg;
    notification.observe(destination);
    this.unsubscribe();
  }

  constructor(destination: Subscriber<T>,
              private scheduler: SchedulerLike,
              private delay: number = 0) {
    super(destination);
  }

  private scheduleMessage(notification: Notification<any>): void {
    const destination = this.destination as Subscription;
    destination.add(this.scheduler.schedule(
      ObserveOnSubscriber.dispatch,
      this.delay,
      new ObserveOnMessage(notification, this.destination)
    ));
  }

  protected _next(value: T): void {
    this.scheduleMessage(Notification.createNext(value));
  }

  protected _error(err: any): void {
    this.scheduleMessage(Notification.createError(err));
    this.unsubscribe();
  }

  protected _complete(): void {
    this.scheduleMessage(Notification.createComplete());
    this.unsubscribe();
  }
}

export class ObserveOnMessage {
  constructor(public notification: Notification<any>,
              public destination: PartialObserver<any>) {
  }
}

Filemanager

Name Type Size Permission Actions
audit.ts File 4.14 KB 0644
auditTime.ts File 2.38 KB 0644
buffer.ts File 2.54 KB 0644
bufferCount.ts File 4.46 KB 0644
bufferTime.ts File 8.51 KB 0644
bufferToggle.ts File 5.6 KB 0644
bufferWhen.ts File 3.89 KB 0644
catchError.ts File 4.72 KB 0644
combineAll.ts File 2.44 KB 0644
combineLatest.ts File 4.32 KB 0644
concat.ts File 2.18 KB 0644
concatAll.ts File 2.26 KB 0644
concatMap.ts File 3.4 KB 0644
concatMapTo.ts File 3.05 KB 0644
count.ts File 3.78 KB 0644
debounce.ts File 4.88 KB 0644
debounceTime.ts File 4.54 KB 0644
defaultIfEmpty.ts File 2.69 KB 0644
delay.ts File 5.09 KB 0644
delayWhen.ts File 7.7 KB 0644
dematerialize.ts File 2.58 KB 0644
distinct.ts File 4.22 KB 0644
distinctUntilChanged.ts File 3.76 KB 0644
distinctUntilKeyChanged.ts File 2.79 KB 0644
elementAt.ts File 2.56 KB 0644
endWith.ts File 4.06 KB 0644
every.ts File 2.54 KB 0644
exhaust.ts File 3.2 KB 0644
exhaustMap.ts File 5.64 KB 0644
expand.ts File 6.18 KB 0644
filter.ts File 3.69 KB 0644
finalize.ts File 1.3 KB 0644
find.ts File 3.81 KB 0644
findIndex.ts File 1.86 KB 0644
first.ts File 3.36 KB 0644
groupBy.ts File 9.95 KB 0644
ignoreElements.ts File 1.49 KB 0644
index.ts File 4.02 KB 0644
isEmpty.ts File 2.67 KB 0644
last.ts File 2.36 KB 0644
map.ts File 3.04 KB 0644
mapTo.ts File 1.9 KB 0644
materialize.ts File 3.25 KB 0644
max.ts File 1.54 KB 0644
merge.ts File 3.59 KB 0644
mergeAll.ts File 2.43 KB 0644
mergeMap.ts File 6.28 KB 0644
mergeMapTo.ts File 2.56 KB 0644
mergeScan.ts File 4.65 KB 0644
min.ts File 1.54 KB 0644
multicast.ts File 3.46 KB 0644
observeOn.ts File 5.17 KB 0644
onErrorResumeNext.ts File 8.18 KB 0644
pairwise.ts File 2.43 KB 0644
partition.ts File 2.68 KB 0644
pluck.ts File 3.07 KB 0644
publish.ts File 2.51 KB 0644
publishBehavior.ts File 589 B 0644
publishLast.ts File 2.06 KB 0644
publishReplay.ts File 1.47 KB 0644
race.ts File 1.85 KB 0644
reduce.ts File 3.71 KB 0644
refCount.ts File 5 KB 0644
repeat.ts File 3.03 KB 0644
repeatWhen.ts File 4.15 KB 0644
retry.ts File 2.74 KB 0644
retryWhen.ts File 3.45 KB 0644
sample.ts File 2.78 KB 0644
sampleTime.ts File 3.18 KB 0644
scan.ts File 4.13 KB 0644
sequenceEqual.ts File 5.16 KB 0644
share.ts File 1.02 KB 0644
shareReplay.ts File 4.19 KB 0644
single.ts File 3.79 KB 0644
skip.ts File 1.27 KB 0644
skipLast.ts File 2.81 KB 0644
skipUntil.ts File 3.81 KB 0644
skipWhile.ts File 1.95 KB 0644
startWith.ts File 4.35 KB 0644
subscribeOn.ts File 2.56 KB 0644
switchAll.ts File 1.99 KB 0644
switchMap.ts File 6.04 KB 0644
switchMapTo.ts File 2.56 KB 0644
take.ts File 2.74 KB 0644
takeLast.ts File 3.44 KB 0644
takeUntil.ts File 2.79 KB 0644
takeWhile.ts File 3.87 KB 0644
tap.ts File 5.33 KB 0644
throttle.ts File 4.83 KB 0644
throttleTime.ts File 5.83 KB 0644
throwIfEmpty.ts File 2.19 KB 0644
timeInterval.ts File 2.49 KB 0644
timeout.ts File 4.07 KB 0644
timeoutWith.ts File 6.13 KB 0644
timestamp.ts File 1.67 KB 0644
toArray.ts File 1.12 KB 0644
window.ts File 3.72 KB 0644
windowCount.ts File 4.82 KB 0644
windowTime.ts File 9.9 KB 0644
windowToggle.ts File 6.2 KB 0644
windowWhen.ts File 4.57 KB 0644
withLatestFrom.ts File 7.72 KB 0644
zip.ts File 3.35 KB 0644
zipAll.ts File 653 B 0644