rxjs-mp
Version:
rxjs for wechat miniprogram.
266 lines (264 loc) • 13.2 kB
TypeScript
export { Observable } from 'rxjs/internal/Observable';
export { ConnectableObservable } from 'rxjs/internal/observable/ConnectableObservable';
export { GroupedObservable } from 'rxjs/internal/operators/groupBy';
export { Operator } from 'rxjs/internal/Operator';
export { observable } from 'rxjs/internal/symbol/observable';
export { Subject } from 'rxjs/internal/Subject';
export { BehaviorSubject } from 'rxjs/internal/BehaviorSubject';
export { ReplaySubject } from 'rxjs/internal/ReplaySubject';
export { AsyncSubject } from 'rxjs/internal/AsyncSubject';
export { asap, asapScheduler } from 'rxjs/internal/scheduler/asap';
export { async, asyncScheduler } from 'rxjs/internal/scheduler/async';
export { queue, queueScheduler } from 'rxjs/internal/scheduler/queue';
export { animationFrame, animationFrameScheduler } from 'rxjs/internal/scheduler/animationFrame';
export { VirtualTimeScheduler, VirtualAction } from 'rxjs/internal/scheduler/VirtualTimeScheduler';
export { Scheduler } from 'rxjs/internal/Scheduler';
export { Subscription } from 'rxjs/internal/Subscription';
export { Subscriber } from 'rxjs/internal/Subscriber';
export { Notification, NotificationKind } from 'rxjs/internal/Notification';
export { pipe } from 'rxjs/internal/util/pipe';
export { noop } from 'rxjs/internal/util/noop';
export { identity } from 'rxjs/internal/util/identity';
export { isObservable } from 'rxjs/internal/util/isObservable';
export { ArgumentOutOfRangeError } from 'rxjs/internal/util/ArgumentOutOfRangeError';
export { EmptyError } from 'rxjs/internal/util/EmptyError';
export { ObjectUnsubscribedError } from 'rxjs/internal/util/ObjectUnsubscribedError';
export { UnsubscriptionError } from 'rxjs/internal/util/UnsubscriptionError';
export { TimeoutError } from 'rxjs/internal/util/TimeoutError';
export { bindCallback } from 'rxjs/internal/observable/bindCallback';
export { bindNodeCallback } from 'rxjs/internal/observable/bindNodeCallback';
export { combineLatest } from 'rxjs/internal/observable/combineLatest';
export { concat } from 'rxjs/internal/observable/concat';
export { defer } from 'rxjs/internal/observable/defer';
export { empty } from 'rxjs/internal/observable/empty';
export { forkJoin } from 'rxjs/internal/observable/forkJoin';
export { from } from 'rxjs/internal/observable/from';
export { fromEvent } from 'rxjs/internal/observable/fromEvent';
export { fromEventPattern } from 'rxjs/internal/observable/fromEventPattern';
export { generate } from 'rxjs/internal/observable/generate';
export { iif } from 'rxjs/internal/observable/iif';
export { interval } from 'rxjs/internal/observable/interval';
export { merge } from 'rxjs/internal/observable/merge';
export { never } from 'rxjs/internal/observable/never';
export { of } from 'rxjs/internal/observable/of';
export { onErrorResumeNext } from 'rxjs/internal/observable/onErrorResumeNext';
export { pairs } from 'rxjs/internal/observable/pairs';
export { partition } from 'rxjs/internal/observable/partition';
export { race } from 'rxjs/internal/observable/race';
export { range } from 'rxjs/internal/observable/range';
export { throwError } from 'rxjs/internal/observable/throwError';
export { timer } from 'rxjs/internal/observable/timer';
export { using } from 'rxjs/internal/observable/using';
export { zip } from 'rxjs/internal/observable/zip';
export { scheduled } from 'rxjs/internal/scheduled/scheduled';
export { EMPTY } from 'rxjs/internal/observable/empty';
export { NEVER } from 'rxjs/internal/observable/never';
export * from 'rxjs/internal/types';
export { config } from 'rxjs/internal/config';
import { audit } from 'rxjs/internal/operators/audit';
import { auditTime } from 'rxjs/internal/operators/auditTime';
import { buffer } from 'rxjs/internal/operators/buffer';
import { bufferCount } from 'rxjs/internal/operators/bufferCount';
import { bufferTime } from 'rxjs/internal/operators/bufferTime';
import { bufferToggle } from 'rxjs/internal/operators/bufferToggle';
import { bufferWhen } from 'rxjs/internal/operators/bufferWhen';
import { catchError } from 'rxjs/internal/operators/catchError';
import { combineAll } from 'rxjs/internal/operators/combineAll';
import { combineLatest } from 'rxjs/internal/operators/combineLatest';
import { concat } from 'rxjs/internal/operators/concat';
import { concatAll } from 'rxjs/internal/operators/concatAll';
import { concatMap } from 'rxjs/internal/operators/concatMap';
import { concatMapTo } from 'rxjs/internal/operators/concatMapTo';
import { count } from 'rxjs/internal/operators/count';
import { debounce } from 'rxjs/internal/operators/debounce';
import { debounceTime } from 'rxjs/internal/operators/debounceTime';
import { defaultIfEmpty } from 'rxjs/internal/operators/defaultIfEmpty';
import { delay } from 'rxjs/internal/operators/delay';
import { delayWhen } from 'rxjs/internal/operators/delayWhen';
import { dematerialize } from 'rxjs/internal/operators/dematerialize';
import { distinct } from 'rxjs/internal/operators/distinct';
import { distinctUntilChanged } from 'rxjs/internal/operators/distinctUntilChanged';
import { distinctUntilKeyChanged } from 'rxjs/internal/operators/distinctUntilKeyChanged';
import { elementAt } from 'rxjs/internal/operators/elementAt';
import { endWith } from 'rxjs/internal/operators/endWith';
import { every } from 'rxjs/internal/operators/every';
import { exhaust } from 'rxjs/internal/operators/exhaust';
import { exhaustMap } from 'rxjs/internal/operators/exhaustMap';
import { expand } from 'rxjs/internal/operators/expand';
import { filter } from 'rxjs/internal/operators/filter';
import { finalize } from 'rxjs/internal/operators/finalize';
import { find } from 'rxjs/internal/operators/find';
import { findIndex } from 'rxjs/internal/operators/findIndex';
import { first } from 'rxjs/internal/operators/first';
import { groupBy } from 'rxjs/internal/operators/groupBy';
import { ignoreElements } from 'rxjs/internal/operators/ignoreElements';
import { isEmpty } from 'rxjs/internal/operators/isEmpty';
import { last } from 'rxjs/internal/operators/last';
import { map } from 'rxjs/internal/operators/map';
import { mapTo } from 'rxjs/internal/operators/mapTo';
import { materialize } from 'rxjs/internal/operators/materialize';
import { max } from 'rxjs/internal/operators/max';
import { merge } from 'rxjs/internal/operators/merge';
import { mergeAll } from 'rxjs/internal/operators/mergeAll';
import { mergeMap, flatMap } from 'rxjs/internal/operators/mergeMap';
import { mergeMapTo } from 'rxjs/internal/operators/mergeMapTo';
import { mergeScan } from 'rxjs/internal/operators/mergeScan';
import { min } from 'rxjs/internal/operators/min';
import { multicast } from 'rxjs/internal/operators/multicast';
import { observeOn } from 'rxjs/internal/operators/observeOn';
import { onErrorResumeNext } from 'rxjs/internal/operators/onErrorResumeNext';
import { pairwise } from 'rxjs/internal/operators/pairwise';
import { partition } from 'rxjs/internal/operators/partition';
import { pluck } from 'rxjs/internal/operators/pluck';
import { publish } from 'rxjs/internal/operators/publish';
import { publishBehavior } from 'rxjs/internal/operators/publishBehavior';
import { publishLast } from 'rxjs/internal/operators/publishLast';
import { publishReplay } from 'rxjs/internal/operators/publishReplay';
import { race } from 'rxjs/internal/operators/race';
import { reduce } from 'rxjs/internal/operators/reduce';
import { repeat } from 'rxjs/internal/operators/repeat';
import { repeatWhen } from 'rxjs/internal/operators/repeatWhen';
import { retry } from 'rxjs/internal/operators/retry';
import { retryWhen } from 'rxjs/internal/operators/retryWhen';
import { refCount } from 'rxjs/internal/operators/refCount';
import { sample } from 'rxjs/internal/operators/sample';
import { sampleTime } from 'rxjs/internal/operators/sampleTime';
import { scan } from 'rxjs/internal/operators/scan';
import { sequenceEqual } from 'rxjs/internal/operators/sequenceEqual';
import { share } from 'rxjs/internal/operators/share';
import { shareReplay } from 'rxjs/internal/operators/shareReplay';
import { single } from 'rxjs/internal/operators/single';
import { skip } from 'rxjs/internal/operators/skip';
import { skipLast } from 'rxjs/internal/operators/skipLast';
import { skipUntil } from 'rxjs/internal/operators/skipUntil';
import { skipWhile } from 'rxjs/internal/operators/skipWhile';
import { startWith } from 'rxjs/internal/operators/startWith';
import { subscribeOn } from 'rxjs/internal/operators/subscribeOn';
import { switchAll } from 'rxjs/internal/operators/switchAll';
import { switchMap } from 'rxjs/internal/operators/switchMap';
import { switchMapTo } from 'rxjs/internal/operators/switchMapTo';
import { take } from 'rxjs/internal/operators/take';
import { takeLast } from 'rxjs/internal/operators/takeLast';
import { takeUntil } from 'rxjs/internal/operators/takeUntil';
import { takeWhile } from 'rxjs/internal/operators/takeWhile';
import { tap } from 'rxjs/internal/operators/tap';
import { throttle } from 'rxjs/internal/operators/throttle';
import { throttleTime } from 'rxjs/internal/operators/throttleTime';
import { throwIfEmpty } from 'rxjs/internal/operators/throwIfEmpty';
import { timeInterval } from 'rxjs/internal/operators/timeInterval';
import { timeout } from 'rxjs/internal/operators/timeout';
import { timeoutWith } from 'rxjs/internal/operators/timeoutWith';
import { timestamp } from 'rxjs/internal/operators/timestamp';
import { toArray } from 'rxjs/internal/operators/toArray';
import { window } from 'rxjs/internal/operators/window';
import { windowCount } from 'rxjs/internal/operators/windowCount';
import { windowTime } from 'rxjs/internal/operators/windowTime';
import { windowToggle } from 'rxjs/internal/operators/windowToggle';
import { windowWhen } from 'rxjs/internal/operators/windowWhen';
import { withLatestFrom } from 'rxjs/internal/operators/withLatestFrom';
import { zip } from 'rxjs/internal/operators/zip';
import { zipAll } from 'rxjs/internal/operators/zipAll';
export declare const operators: {
audit: typeof audit;
auditTime: typeof auditTime;
buffer: typeof buffer;
bufferCount: typeof bufferCount;
bufferTime: typeof bufferTime;
bufferToggle: typeof bufferToggle;
bufferWhen: typeof bufferWhen;
catchError: typeof catchError;
combineAll: typeof combineAll;
combineLatest: typeof combineLatest;
concat: typeof concat;
concatAll: typeof concatAll;
concatMap: typeof concatMap;
concatMapTo: typeof concatMapTo;
count: typeof count;
debounce: typeof debounce;
debounceTime: typeof debounceTime;
defaultIfEmpty: typeof defaultIfEmpty;
delay: typeof delay;
delayWhen: typeof delayWhen;
dematerialize: typeof dematerialize;
distinct: typeof distinct;
distinctUntilChanged: typeof distinctUntilChanged;
distinctUntilKeyChanged: typeof distinctUntilKeyChanged;
elementAt: typeof elementAt;
endWith: typeof endWith;
every: typeof every;
exhaust: typeof exhaust;
exhaustMap: typeof exhaustMap;
expand: typeof expand;
filter: typeof filter;
finalize: typeof finalize;
find: typeof find;
findIndex: typeof findIndex;
first: typeof first;
groupBy: typeof groupBy;
ignoreElements: typeof ignoreElements;
isEmpty: typeof isEmpty;
last: typeof last;
map: typeof map;
mapTo: typeof mapTo;
materialize: typeof materialize;
max: typeof max;
merge: typeof merge;
mergeAll: typeof mergeAll;
mergeMapTo: typeof mergeMapTo;
mergeScan: typeof mergeScan;
min: typeof min;
multicast: typeof multicast;
observeOn: typeof observeOn;
onErrorResumeNext: typeof onErrorResumeNext;
pairwise: typeof pairwise;
partition: typeof partition;
pluck: typeof pluck;
publish: typeof publish;
publishBehavior: typeof publishBehavior;
publishLast: typeof publishLast;
publishReplay: typeof publishReplay;
race: typeof race;
reduce: typeof reduce;
repeat: typeof repeat;
repeatWhen: typeof repeatWhen;
retry: typeof retry;
retryWhen: typeof retryWhen;
refCount: typeof refCount;
sample: typeof sample;
sampleTime: typeof sampleTime;
scan: typeof scan;
sequenceEqual: typeof sequenceEqual;
share: typeof share;
shareReplay: typeof shareReplay;
single: typeof single;
skip: typeof skip;
skipLast: typeof skipLast;
skipUntil: typeof skipUntil;
skipWhile: typeof skipWhile;
startWith: typeof startWith;
subscribeOn: typeof subscribeOn;
switchAll: typeof switchAll;
switchMap: typeof switchMap;
switchMapTo: typeof switchMapTo;
take: typeof take;
takeLast: typeof takeLast;
takeUntil: typeof takeUntil;
takeWhile: typeof takeWhile;
tap: typeof tap;
throttle: typeof throttle;
throttleTime: typeof throttleTime;
throwIfEmpty: typeof throwIfEmpty;
timeInterval: typeof timeInterval;
timeout: typeof timeout;
timeoutWith: typeof timeoutWith;
timestamp: typeof timestamp;
toArray: typeof toArray;
window: typeof window;
windowCount: typeof windowCount;
windowTime: typeof windowTime;
windowToggle: typeof windowToggle;
windowWhen: typeof windowWhen;
withLatestFrom: typeof withLatestFrom;
zip: typeof zip;
zipAll: typeof zipAll;
}