UNPKG

@sm003/autojs6-dts

Version:
547 lines (536 loc) 1.88 MB
declare module io { export module reactivex { export class BackpressureOverflowStrategy { public static class: java.lang.Class<io.reactivex.BackpressureOverflowStrategy>; public static ERROR: io.reactivex.BackpressureOverflowStrategy; public static DROP_OLDEST: io.reactivex.BackpressureOverflowStrategy; public static DROP_LATEST: io.reactivex.BackpressureOverflowStrategy; public static values(): io.reactivex.BackpressureOverflowStrategy[]; public static valueOf(enumType: java.lang.Class<any>, name: string): java.lang.Enum<any>; public static valueOf(name: string): io.reactivex.BackpressureOverflowStrategy; } } } declare module io { export module reactivex { export class BackpressureStrategy { public static class: java.lang.Class<io.reactivex.BackpressureStrategy>; public static MISSING: io.reactivex.BackpressureStrategy; public static ERROR: io.reactivex.BackpressureStrategy; public static BUFFER: io.reactivex.BackpressureStrategy; public static DROP: io.reactivex.BackpressureStrategy; public static LATEST: io.reactivex.BackpressureStrategy; public static values(): io.reactivex.BackpressureStrategy[]; public static valueOf(enumType: java.lang.Class<any>, name: string): java.lang.Enum<any>; public static valueOf(name: string): io.reactivex.BackpressureStrategy; } } } declare module io { export module reactivex { export abstract class Completable extends java.lang.Object implements io.reactivex.CompletableSource { public static class: java.lang.Class<io.reactivex.Completable>; public static complete(): io.reactivex.Completable; public onErrorComplete(predicate: io.reactivex.functions.Predicate<any>): io.reactivex.Completable; public timeout(timeout: number, param1: java.util.concurrent.TimeUnit, unit: io.reactivex.CompletableSource): io.reactivex.Completable; public static merge(sources: org.reactivestreams.Publisher<any>): io.reactivex.Completable; public static error(errorSupplier: java.util.concurrent.Callable<any>): io.reactivex.Completable; public doAfterTerminate(onAfterTerminate: io.reactivex.functions.Action): io.reactivex.Completable; public startWith(other: org.reactivestreams.Publisher): io.reactivex.Flowable<any>; public repeat(times: number): io.reactivex.Completable; public repeat(): io.reactivex.Completable; public blockingAwait(): void; public static using(resourceSupplier: java.util.concurrent.Callable<any>, completableFunction: io.reactivex.functions.Function<any,any>, disposer: io.reactivex.functions.Consumer<any>): io.reactivex.Completable; public static using(resourceSupplier: java.util.concurrent.Callable<any>, completableFunction: io.reactivex.functions.Function<any,any>, disposer: io.reactivex.functions.Consumer<any>, eager: boolean): io.reactivex.Completable; public toFlowable(): io.reactivex.Flowable<any>; public delaySubscription(delay: number, param1: java.util.concurrent.TimeUnit): io.reactivex.Completable; public constructor(); public timeout(timeout: number, param1: java.util.concurrent.TimeUnit, unit: io.reactivex.Scheduler, scheduler: io.reactivex.CompletableSource): io.reactivex.Completable; public delay(delay: number, param1: java.util.concurrent.TimeUnit, unit: io.reactivex.Scheduler): io.reactivex.Completable; public startWith(other: io.reactivex.CompletableSource): io.reactivex.Completable; public repeatWhen(handler: io.reactivex.functions.Function<any,any>): io.reactivex.Completable; public test(cancelled: boolean): io.reactivex.observers.TestObserver<java.lang.Void>; public onTerminateDetach(): io.reactivex.Completable; public static error(error: java.lang.Throwable): io.reactivex.Completable; public static fromCallable(callable: java.util.concurrent.Callable<any>): io.reactivex.Completable; public static fromPublisher(publisher: org.reactivestreams.Publisher): io.reactivex.Completable; public static concat(sources: org.reactivestreams.Publisher<any>, prefetch: number): io.reactivex.Completable; public retry(): io.reactivex.Completable; public subscribe(observer: io.reactivex.CompletableObserver): void; public retry(predicate: io.reactivex.functions.Predicate<any>): io.reactivex.Completable; public blockingAwait(timeout: number, param1: java.util.concurrent.TimeUnit): boolean; public subscribe(param0: io.reactivex.CompletableObserver): void; public doOnEvent(onEvent: io.reactivex.functions.Consumer<any>): io.reactivex.Completable; public ambWith(other: io.reactivex.CompletableSource): io.reactivex.Completable; public retryWhen(handler: io.reactivex.functions.Function<any,any>): io.reactivex.Completable; public static concatArray(...sources: io.reactivex.CompletableSource[]): io.reactivex.Completable; public static concat(sources: java.lang.Iterable<any>): io.reactivex.Completable; public andThen(next: org.reactivestreams.Publisher): io.reactivex.Flowable<any>; public doOnComplete(onComplete: io.reactivex.functions.Action): io.reactivex.Completable; public doOnDispose(onDispose: io.reactivex.functions.Action): io.reactivex.Completable; public retry(times: number): io.reactivex.Completable; public blockingGet(timeout: number, param1: java.util.concurrent.TimeUnit): java.lang.Throwable; public hide(): io.reactivex.Completable; public static mergeArray(...sources: io.reactivex.CompletableSource[]): io.reactivex.Completable; public andThen(next: io.reactivex.CompletableSource): io.reactivex.Completable; public concatWith(other: io.reactivex.CompletableSource): io.reactivex.Completable; public static ambArray(...sources: io.reactivex.CompletableSource[]): io.reactivex.Completable; public retry(times: number, param1: io.reactivex.functions.Predicate<any>): io.reactivex.Completable; public static unsafeCreate(source: io.reactivex.CompletableSource): io.reactivex.Completable; public static fromRunnable(run: java.lang.Runnable): io.reactivex.Completable; public static create(source: io.reactivex.CompletableOnSubscribe): io.reactivex.Completable; public delay(delay: number, param1: java.util.concurrent.TimeUnit, unit: io.reactivex.Scheduler, scheduler: boolean): io.reactivex.Completable; public static mergeDelayError(sources: org.reactivestreams.Publisher<any>): io.reactivex.Completable; public subscribe(): io.reactivex.disposables.Disposable; public static fromMaybe(maybe: io.reactivex.MaybeSource<any>): io.reactivex.Completable; public takeUntil(other: io.reactivex.CompletableSource): io.reactivex.Completable; public subscribeOn(scheduler: io.reactivex.Scheduler): io.reactivex.Completable; public onErrorResumeNext(errorMapper: io.reactivex.functions.Function<any,any>): io.reactivex.Completable; public toMaybe(): io.reactivex.Maybe<any>; public static mergeDelayError(sources: java.lang.Iterable<any>): io.reactivex.Completable; public andThen(next: io.reactivex.MaybeSource<any>): io.reactivex.Maybe<any>; public doFinally(onFinally: io.reactivex.functions.Action): io.reactivex.Completable; public static fromSingle(single: io.reactivex.SingleSource<any>): io.reactivex.Completable; public unsubscribeOn(scheduler: io.reactivex.Scheduler): io.reactivex.Completable; public static timer(delay: number, param1: java.util.concurrent.TimeUnit): io.reactivex.Completable; public subscribeWith(observer: io.reactivex.CompletableObserver): io.reactivex.CompletableObserver; public blockingGet(): java.lang.Throwable; public timeout(timeout: number, param1: java.util.concurrent.TimeUnit): io.reactivex.Completable; public lift(onLift: io.reactivex.CompletableOperator): io.reactivex.Completable; public static fromObservable(observable: io.reactivex.ObservableSource<any>): io.reactivex.Completable; public delay(delay: number, param1: java.util.concurrent.TimeUnit): io.reactivex.Completable; public compose(transformer: io.reactivex.CompletableTransformer): io.reactivex.Completable; public subscribeActual(param0: io.reactivex.CompletableObserver): void; public static merge(sources: org.reactivestreams.Publisher<any>, maxConcurrency: number): io.reactivex.Completable; public startWith(other: io.reactivex.Observable<any>): io.reactivex.Observable<any>; public timeout(timeout: number, param1: java.util.concurrent.TimeUnit, unit: io.reactivex.Scheduler): io.reactivex.Completable; public to(converter: io.reactivex.functions.Function<any,any>): any; public onErrorComplete(): io.reactivex.Completable; public toSingle(completionValueSupplier: java.util.concurrent.Callable<any>): io.reactivex.Single<any>; public materialize(): io.reactivex.Single<any>; public as(converter: io.reactivex.CompletableConverter<any>): any; public static never(): io.reactivex.Completable; public subscribe(onComplete: io.reactivex.functions.Action): io.reactivex.disposables.Disposable; public delaySubscription(delay: number, param1: java.util.concurrent.TimeUnit, unit: io.reactivex.Scheduler): io.reactivex.Completable; public static fromAction(run: io.reactivex.functions.Action): io.reactivex.Completable; public toObservable(): io.reactivex.Observable<any>; public observeOn(scheduler: io.reactivex.Scheduler): io.reactivex.Completable; public andThen(next: io.reactivex.ObservableSource<any>): io.reactivex.Observable<any>; public doOnTerminate(onTerminate: io.reactivex.functions.Action): io.reactivex.Completable; public repeatUntil(stop: io.reactivex.functions.BooleanSupplier): io.reactivex.Completable; public static amb(sources: java.lang.Iterable<any>): io.reactivex.Completable; public static timer(delay: number, param1: java.util.concurrent.TimeUnit, unit: io.reactivex.Scheduler): io.reactivex.Completable; public static mergeArrayDelayError(...sources: io.reactivex.CompletableSource[]): io.reactivex.Completable; public static merge(sources: java.lang.Iterable<any>): io.reactivex.Completable; public andThen(next: io.reactivex.SingleSource<any>): io.reactivex.Single<any>; public static mergeDelayError(sources: org.reactivestreams.Publisher<any>, maxConcurrency: number): io.reactivex.Completable; public static defer(completableSupplier: java.util.concurrent.Callable<any>): io.reactivex.Completable; public retry(predicate: io.reactivex.functions.BiPredicate<any,any>): io.reactivex.Completable; public mergeWith(other: io.reactivex.CompletableSource): io.reactivex.Completable; public toSingleDefault(completionValue: any): io.reactivex.Single<any>; public subscribe(onComplete: io.reactivex.functions.Action, onError: io.reactivex.functions.Consumer<any>): io.reactivex.disposables.Disposable; public static fromFuture(future: java.util.concurrent.Future<any>): io.reactivex.Completable; public cache(): io.reactivex.Completable; public doOnError(onError: io.reactivex.functions.Consumer<any>): io.reactivex.Completable; public static concat(sources: org.reactivestreams.Publisher<any>): io.reactivex.Completable; public doOnSubscribe(onSubscribe: io.reactivex.functions.Consumer<any>): io.reactivex.Completable; public static wrap(source: io.reactivex.CompletableSource): io.reactivex.Completable; public test(): io.reactivex.observers.TestObserver<java.lang.Void>; } } } declare module io { export module reactivex { export class CompletableConverter<R> extends java.lang.Object { public static class: java.lang.Class<io.reactivex.CompletableConverter<any>>; /** * Constructs a new instance of the io.reactivex.CompletableConverter<any> interface with the provided implementation. An empty constructor exists calling super() when extending the interface class. */ public constructor(implementation: { apply(param0: io.reactivex.Completable): R; }); public constructor(); public apply(param0: io.reactivex.Completable): R; } } } declare module io { export module reactivex { export class CompletableEmitter extends java.lang.Object { public static class: java.lang.Class<io.reactivex.CompletableEmitter>; /** * Constructs a new instance of the io.reactivex.CompletableEmitter interface with the provided implementation. An empty constructor exists calling super() when extending the interface class. */ public constructor(implementation: { onComplete(): void; onError(param0: java.lang.Throwable): void; setDisposable(param0: io.reactivex.disposables.Disposable): void; setCancellable(param0: io.reactivex.functions.Cancellable): void; isDisposed(): boolean; tryOnError(param0: java.lang.Throwable): boolean; }); public constructor(); public tryOnError(param0: java.lang.Throwable): boolean; public isDisposed(): boolean; public onComplete(): void; public setCancellable(param0: io.reactivex.functions.Cancellable): void; public setDisposable(param0: io.reactivex.disposables.Disposable): void; public onError(param0: java.lang.Throwable): void; } } } declare module io { export module reactivex { export class CompletableObserver extends java.lang.Object { public static class: java.lang.Class<io.reactivex.CompletableObserver>; /** * Constructs a new instance of the io.reactivex.CompletableObserver interface with the provided implementation. An empty constructor exists calling super() when extending the interface class. */ public constructor(implementation: { onSubscribe(param0: io.reactivex.disposables.Disposable): void; onComplete(): void; onError(param0: java.lang.Throwable): void; }); public constructor(); public onSubscribe(param0: io.reactivex.disposables.Disposable): void; public onComplete(): void; public onError(param0: java.lang.Throwable): void; } } } declare module io { export module reactivex { export class CompletableOnSubscribe extends java.lang.Object { public static class: java.lang.Class<io.reactivex.CompletableOnSubscribe>; /** * Constructs a new instance of the io.reactivex.CompletableOnSubscribe interface with the provided implementation. An empty constructor exists calling super() when extending the interface class. */ public constructor(implementation: { subscribe(param0: io.reactivex.CompletableEmitter): void; }); public constructor(); public subscribe(param0: io.reactivex.CompletableEmitter): void; } } } declare module io { export module reactivex { export class CompletableOperator extends java.lang.Object { public static class: java.lang.Class<io.reactivex.CompletableOperator>; /** * Constructs a new instance of the io.reactivex.CompletableOperator interface with the provided implementation. An empty constructor exists calling super() when extending the interface class. */ public constructor(implementation: { apply(param0: io.reactivex.CompletableObserver): io.reactivex.CompletableObserver; }); public constructor(); public apply(param0: io.reactivex.CompletableObserver): io.reactivex.CompletableObserver; } } } declare module io { export module reactivex { export class CompletableSource extends java.lang.Object { public static class: java.lang.Class<io.reactivex.CompletableSource>; /** * Constructs a new instance of the io.reactivex.CompletableSource interface with the provided implementation. An empty constructor exists calling super() when extending the interface class. */ public constructor(implementation: { subscribe(param0: io.reactivex.CompletableObserver): void; }); public constructor(); public subscribe(param0: io.reactivex.CompletableObserver): void; } } } declare module io { export module reactivex { export class CompletableTransformer extends java.lang.Object { public static class: java.lang.Class<io.reactivex.CompletableTransformer>; /** * Constructs a new instance of the io.reactivex.CompletableTransformer interface with the provided implementation. An empty constructor exists calling super() when extending the interface class. */ public constructor(implementation: { apply(param0: io.reactivex.Completable): io.reactivex.CompletableSource; }); public constructor(); public apply(param0: io.reactivex.Completable): io.reactivex.CompletableSource; } } } declare module io { export module reactivex { export class Emitter<T> extends java.lang.Object { public static class: java.lang.Class<io.reactivex.Emitter<any>>; /** * Constructs a new instance of the io.reactivex.Emitter<any> interface with the provided implementation. An empty constructor exists calling super() when extending the interface class. */ public constructor(implementation: { onNext(param0: T): void; onError(param0: java.lang.Throwable): void; onComplete(): void; }); public constructor(); public onNext(param0: T): void; public onComplete(): void; public onError(param0: java.lang.Throwable): void; } } } declare module io { export module reactivex { export abstract class Flowable<T> extends org.reactivestreams.Publisher<any> { public static class: java.lang.Class<io.reactivex.Flowable<any>>; public switchMap(mapper: io.reactivex.functions.Function<any,any>, bufferSize: number): io.reactivex.Flowable<any>; public takeLast(count: number, param1: number, time: java.util.concurrent.TimeUnit, param3: io.reactivex.Scheduler, unit: boolean, scheduler: number): io.reactivex.Flowable<any>; public static just(item1: any, item2: any, item3: any, item4: any): io.reactivex.Flowable<any>; public static generate(initialState: java.util.concurrent.Callable<any>, generator: io.reactivex.functions.BiConsumer<any,any>, disposeState: io.reactivex.functions.Consumer<any>): io.reactivex.Flowable<any>; public toMap(keySelector: io.reactivex.functions.Function<any,any>, valueSelector: io.reactivex.functions.Function<any,any>, mapSupplier: java.util.concurrent.Callable<any>): io.reactivex.Single<any>; public mergeWith(other: io.reactivex.SingleSource<any>): io.reactivex.Flowable<any>; /** @deprecated */ public dematerialize(): io.reactivex.Flowable<any>; public window(timespan: number, param1: number, timeskip: java.util.concurrent.TimeUnit, param3: io.reactivex.Scheduler): io.reactivex.Flowable<io.reactivex.Flowable<any>>; public observeOn(scheduler: io.reactivex.Scheduler, delayError: boolean, bufferSize: number): io.reactivex.Flowable<any>; public timeout(firstTimeoutIndicator: org.reactivestreams.Publisher, itemTimeoutIndicator: io.reactivex.functions.Function<any,any>): io.reactivex.Flowable<any>; public subscribeActual(param0: org.reactivestreams.Subscriber<any>): void; public static generate(generator: io.reactivex.functions.Consumer<any>): io.reactivex.Flowable<any>; public takeLast(time: number, param1: java.util.concurrent.TimeUnit, unit: io.reactivex.Scheduler, scheduler: boolean): io.reactivex.Flowable<any>; public buffer(count: number, skip: number, bufferSupplier: java.util.concurrent.Callable<any>): io.reactivex.Flowable<any>; public toList(capacityHint: number): io.reactivex.Single<java.util.List<any>>; public static combineLatestDelayError(combiner: io.reactivex.functions.Function<any,any>, ...sources: org.reactivestreams.Publisher[]): io.reactivex.Flowable<any>; public concatMapCompletable(mapper: io.reactivex.functions.Function<any,any>): io.reactivex.Completable; public flatMap(mapper: io.reactivex.functions.Function<any,any>, combiner: io.reactivex.functions.BiFunction<any,any,any>, delayErrors: boolean): io.reactivex.Flowable<any>; public static ambArray(...sources: org.reactivestreams.Publisher[]): io.reactivex.Flowable<any>; public onErrorReturn(valueSupplier: io.reactivex.functions.Function<any,any>): io.reactivex.Flowable<any>; public collect(initialItemSupplier: java.util.concurrent.Callable<any>, collector: io.reactivex.functions.BiConsumer<any,any>): io.reactivex.Single<any>; public static just(item1: any, item2: any, item3: any, item4: any, item5: any, item6: any, item7: any, item8: any): io.reactivex.Flowable<any>; public static intervalRange(start: number, param1: number, count: number, param3: number, initialDelay: java.util.concurrent.TimeUnit): io.reactivex.Flowable<java.lang.Long>; public static concatDelayError(sources: org.reactivestreams.Publisher): io.reactivex.Flowable<any>; public static zip(source1: org.reactivestreams.Publisher, source2: org.reactivestreams.Publisher, source3: org.reactivestreams.Publisher, source4: org.reactivestreams.Publisher, source5: org.reactivestreams.Publisher, source6: org.reactivestreams.Publisher, zipper: io.reactivex.functions.Function6<any,any,any,any,any,any,any>): io.reactivex.Flowable<any>; public mergeWith(other: io.reactivex.CompletableSource): io.reactivex.Flowable<any>; public groupBy(keySelector: io.reactivex.functions.Function<any,any>): io.reactivex.Flowable<any>; public repeatUntil(stop: io.reactivex.functions.BooleanSupplier): io.reactivex.Flowable<any>; public last(defaultItem: any): io.reactivex.Single<any>; public publish(selector: io.reactivex.functions.Function<any,any>, prefetch: number): io.reactivex.Flowable<any>; public throttleLatest(timeout: number, param1: java.util.concurrent.TimeUnit, unit: boolean): io.reactivex.Flowable<any>; public flatMapCompletable(mapper: io.reactivex.functions.Function<any,any>): io.reactivex.Completable; public forEachWhile(onNext: io.reactivex.functions.Predicate<any>, onError: io.reactivex.functions.Consumer<any>): io.reactivex.disposables.Disposable; public timeout(itemTimeoutIndicator: io.reactivex.functions.Function<any,any>, other: io.reactivex.Flowable<any>): io.reactivex.Flowable<any>; public static intervalRange(start: number, param1: number, count: number, param3: number, initialDelay: java.util.concurrent.TimeUnit, param5: io.reactivex.Scheduler): io.reactivex.Flowable<java.lang.Long>; public static combineLatest(sources: org.reactivestreams.Publisher[], combiner: io.reactivex.functions.Function<any,any>, bufferSize: number): io.reactivex.Flowable<any>; public cacheWithInitialCapacity(initialCapacity: number): io.reactivex.Flowable<any>; public zipWith(other: org.reactivestreams.Publisher, zipper: io.reactivex.functions.BiFunction<any,any,any>, delayError: boolean, bufferSize: number): io.reactivex.Flowable<any>; public static merge(source1: org.reactivestreams.Publisher, source2: org.reactivestreams.Publisher, source3: org.reactivestreams.Publisher, source4: org.reactivestreams.Publisher): io.reactivex.Flowable<any>; public static sequenceEqual(source1: org.reactivestreams.Publisher, source2: org.reactivestreams.Publisher): io.reactivex.Single<any>; public buffer(timespan: number, param1: java.util.concurrent.TimeUnit, unit: io.reactivex.Scheduler, scheduler: number, count: java.util.concurrent.Callable<any>, bufferSupplier: boolean): io.reactivex.Flowable<any>; public take(time: number, param1: java.util.concurrent.TimeUnit): io.reactivex.Flowable<any>; public static combineLatest(source1: org.reactivestreams.Publisher, source2: org.reactivestreams.Publisher, source3: org.reactivestreams.Publisher, source4: org.reactivestreams.Publisher, source5: org.reactivestreams.Publisher, source6: org.reactivestreams.Publisher, source7: org.reactivestreams.Publisher, source8: org.reactivestreams.Publisher, source9: org.reactivestreams.Publisher, combiner: io.reactivex.functions.Function9<any,any,any,any,any,any,any,any,any,any>): io.reactivex.Flowable<any>; public static range(start: number, count: number): io.reactivex.Flowable<java.lang.Integer>; public buffer(openingIndicator: io.reactivex.Flowable<any>, closingIndicator: io.reactivex.functions.Function<any,any>, bufferSupplier: java.util.concurrent.Callable<any>): io.reactivex.Flowable<any>; public static just(item1: any, item2: any, item3: any, item4: any, item5: any, item6: any): io.reactivex.Flowable<any>; public static concatDelayError(sources: java.lang.Iterable<any>): io.reactivex.Flowable<any>; public zipWith(other: org.reactivestreams.Publisher, zipper: io.reactivex.functions.BiFunction<any,any,any>): io.reactivex.Flowable<any>; public flatMapCompletable(mapper: io.reactivex.functions.Function<any,any>, delayErrors: boolean, maxConcurrency: number): io.reactivex.Completable; public observeOn(scheduler: io.reactivex.Scheduler): io.reactivex.Flowable<any>; public static fromFuture(future: java.util.concurrent.Future<any>, timeout: number, param2: java.util.concurrent.TimeUnit): io.reactivex.Flowable<any>; public static concatDelayError(sources: org.reactivestreams.Publisher, prefetch: number, tillTheEnd: boolean): io.reactivex.Flowable<any>; public doOnLifecycle(onSubscribe: io.reactivex.functions.Consumer<any>, onRequest: io.reactivex.functions.LongConsumer, onCancel: io.reactivex.functions.Action): io.reactivex.Flowable<any>; public reduce(seed: any, reducer: io.reactivex.functions.BiFunction<any,any,any>): io.reactivex.Single<any>; public static merge(sources: java.lang.Iterable<any>): io.reactivex.Flowable<any>; public concatMapEager(mapper: io.reactivex.functions.Function<any,any>): io.reactivex.Flowable<any>; public concatMapMaybe(mapper: io.reactivex.functions.Function<any,any>): io.reactivex.Flowable<any>; public window(timespan: number, param1: java.util.concurrent.TimeUnit, unit: io.reactivex.Scheduler): io.reactivex.Flowable<io.reactivex.Flowable<any>>; public static fromCallable(supplier: java.util.concurrent.Callable<any>): io.reactivex.Flowable<any>; public static zip(source1: org.reactivestreams.Publisher, source2: org.reactivestreams.Publisher, source3: org.reactivestreams.Publisher, source4: org.reactivestreams.Publisher, source5: org.reactivestreams.Publisher, source6: org.reactivestreams.Publisher, source7: org.reactivestreams.Publisher, source8: org.reactivestreams.Publisher, zipper: io.reactivex.functions.Function8<any,any,any,any,any,any,any,any,any>): io.reactivex.Flowable<any>; public takeLast(count: number, param1: number, time: java.util.concurrent.TimeUnit): io.reactivex.Flowable<any>; public withLatestFrom(source1: org.reactivestreams.Publisher, source2: org.reactivestreams.Publisher, source3: org.reactivestreams.Publisher, combiner: io.reactivex.functions.Function4<any,any,any,any,any>): io.reactivex.Flowable<any>; public window(openingIndicator: org.reactivestreams.Publisher, closingIndicator: io.reactivex.functions.Function<any,any>, bufferSize: number): io.reactivex.Flowable<any>; public static combineLatestDelayError(sources: java.lang.Iterable<any>, combiner: io.reactivex.functions.Function<any,any>, bufferSize: number): io.reactivex.Flowable<any>; public replay(selector: io.reactivex.functions.Function<any,any>, bufferSize: number, scheduler: io.reactivex.Scheduler): io.reactivex.Flowable<any>; public toList(): io.reactivex.Single<java.util.List<any>>; public static zip(sources: org.reactivestreams.Publisher, zipper: io.reactivex.functions.Function<any,any>): io.reactivex.Flowable<any>; public subscribe(): io.reactivex.disposables.Disposable; public switchMapCompletable(mapper: io.reactivex.functions.Function<any,any>): io.reactivex.Completable; public toMap(keySelector: io.reactivex.functions.Function<any,any>, valueSelector: io.reactivex.functions.Function<any,any>): io.reactivex.Single<any>; public concatMapMaybeDelayError(mapper: io.reactivex.functions.Function<any,any>): io.reactivex.Flowable<any>; public static generate(initialState: java.util.concurrent.Callable<any>, generator: io.reactivex.functions.BiFunction<any,any,any>): io.reactivex.Flowable<any>; public distinct(keySelector: io.reactivex.functions.Function<any,any>): io.reactivex.Flowable<any>; public publish(bufferSize: number): io.reactivex.flowables.ConnectableFlowable<any>; public static concatArrayDelayError(...sources: org.reactivestreams.Publisher[]): io.reactivex.Flowable<any>; public blockingSubscribe(onNext: io.reactivex.functions.Consumer<any>): void; public ambWith(other: org.reactivestreams.Publisher<any>): io.reactivex.Flowable<any>; public concatMapMaybeDelayError(mapper: io.reactivex.functions.Function<any,any>, tillTheEnd: boolean, prefetch: number): io.reactivex.Flowable<any>; public lift(lifter: io.reactivex.FlowableOperator<any,any>): io.reactivex.Flowable<any>; public static just(item1: any, item2: any, item3: any, item4: any, item5: any, item6: any, item7: any): io.reactivex.Flowable<any>; public buffer(timespan: number, param1: number, timeskip: java.util.concurrent.TimeUnit, param3: io.reactivex.Scheduler, unit: java.util.concurrent.Callable<any>): io.reactivex.Flowable<any>; public subscribeWith(subscriber: org.reactivestreams.Subscriber): org.reactivestreams.Subscriber; public blockingIterable(): java.lang.Iterable<any>; public static concat(sources: java.lang.Iterable<any>): io.reactivex.Flowable<any>; public toMultimap(keySelector: io.reactivex.functions.Function<any,any>, valueSelector: io.reactivex.functions.Function<any,any>, mapSupplier: java.util.concurrent.Callable<any>): io.reactivex.Single<any>; public sorted(): io.reactivex.Flowable<any>; public static just(item1: any, item2: any, item3: any, item4: any, item5: any, item6: any, item7: any, item8: any, item9: any): io.reactivex.Flowable<any>; public subscribe(onNext: io.reactivex.functions.Consumer<any>, onError: io.reactivex.functions.Consumer<any>, onComplete: io.reactivex.functions.Action): io.reactivex.disposables.Disposable; public static amb(sources: java.lang.Iterable<any>): io.reactivex.Flowable<any>; public flatMapIterable(mapper: io.reactivex.functions.Function<any,any>, bufferSize: number): io.reactivex.Flowable<any>; public subscribe(s: io.reactivex.FlowableSubscriber<any>): void; public take(count: number): io.reactivex.Flowable<any>; public switchMapSingleDelayError(mapper: io.reactivex.functions.Function<any,any>): io.reactivex.Flowable<any>; public throttleWithTimeout(timeout: number, param1: java.util.concurrent.TimeUnit): io.reactivex.Flowable<any>; public static zip(source1: org.reactivestreams.Publisher, source2: org.reactivestreams.Publisher, source3: org.reactivestreams.Publisher, zipper: io.reactivex.functions.Function3<any,any,any,any>): io.reactivex.Flowable<any>; public window(timespan: number, param1: number, timeskip: java.util.concurrent.TimeUnit, param3: io.reactivex.Scheduler, unit: number): io.reactivex.Flowable<io.reactivex.Flowable<any>>; public skipWhile(predicate: io.reactivex.functions.Predicate<any>): io.reactivex.Flowable<any>; public static combineLatest(source1: org.reactivestreams.Publisher, source2: org.reactivestreams.Publisher, source3: org.reactivestreams.Publisher, source4: org.reactivestreams.Publisher, source5: org.reactivestreams.Publisher, source6: org.reactivestreams.Publisher, source7: org.reactivestreams.Publisher, source8: org.reactivestreams.Publisher, combiner: io.reactivex.functions.Function8<any,any,any,any,any,any,any,any,any>): io.reactivex.Flowable<any>; public static zip(source1: org.reactivestreams.Publisher, source2: org.reactivestreams.Publisher, zipper: io.reactivex.functions.BiFunction<any,any,any>, delayError: boolean, bufferSize: number): io.reactivex.Flowable<any>; public withLatestFrom(source1: org.reactivestreams.Publisher, source2: org.reactivestreams.Publisher, source3: org.reactivestreams.Publisher, source4: org.reactivestreams.Publisher, combiner: io.reactivex.functions.Function5<any,any,any,any,any,any>): io.reactivex.Flowable<any>; public elementAt(index: number, param1: any): io.reactivex.Single<any>; public flatMap(mapper: io.reactivex.functions.Function<any,any>, maxConcurrency: number): io.reactivex.Flowable<any>; public toSortedList(comparator: java.util.Comparator<any>, capacityHint: number): io.reactivex.Single<java.util.List<any>>; public subscribe(param0: org.reactivestreams.Subscriber<any>): void; public takeLast(time: number, param1: java.util.concurrent.TimeUnit, unit: io.reactivex.Scheduler, scheduler: boolean, delayError: number): io.reactivex.Flowable<any>; public static interval(period: number, param1: java.util.concurrent.TimeUnit, unit: io.reactivex.Scheduler): io.reactivex.Flowable<java.lang.Long>; public doOnSubscribe(onSubscribe: io.reactivex.functions.Consumer<any>): io.reactivex.Flowable<any>; public subscribe(s: org.reactivestreams.Subscriber<any>): void; public static zip(source1: org.reactivestreams.Publisher, source2: org.reactivestreams.Publisher, source3: org.reactivestreams.Publisher, source4: org.reactivestreams.Publisher, source5: org.reactivestreams.Publisher, source6: org.reactivestreams.Publisher, source7: org.reactivestreams.Publisher, source8: org.reactivestreams.Publisher, source9: org.reactivestreams.Publisher, zipper: io.reactivex.functions.Function9<any,any,any,any,any,any,any,any,any,any>): io.reactivex.Flowable<any>; public static combineLatestDelayError(sources: java.lang.Iterable<any>, combiner: io.reactivex.functions.Function<any,any>): io.reactivex.Flowable<any>; public static concatEager(sources: java.lang.Iterable<any>, maxConcurrency: number, prefetch: number): io.reactivex.Flowable<any>; public collectInto(initialItem: any, collector: io.reactivex.functions.BiConsumer<any,any>): io.reactivex.Single<any>; public static error(throwable: java.lang.Throwable): io.reactivex.Flowable<any>; public static switchOnNextDelayError(sources: org.reactivestreams.Publisher, prefetch: number): io.reactivex.Flowable<any>; public static concatArrayEagerDelayError(...sources: org.reactivestreams.Publisher[]): io.reactivex.Flowable<any>; public onBackpressureBuffer(capacity: number, onOverflow: io.reactivex.functions.Action): io.reactivex.Flowable<any>; public timestamp(unit: java.util.concurrent.TimeUnit): io.reactivex.Flowable<io.reactivex.schedulers.Timed<any>>; public observeOn(scheduler: io.reactivex.Scheduler, delayError: boolean): io.reactivex.Flowable<any>; public replay(selector: io.reactivex.functions.Function<any,any>, time: number, param2: java.util.concurrent.TimeUnit): io.reactivex.Flowable<any>; public throttleLast(intervalDuration: number, param1: java.util.concurrent.TimeUnit): io.reactivex.Flowable<any>; public window(openingIndicator: org.reactivestreams.Publisher, closingIndicator: io.reactivex.functions.Function<any,any>): io.reactivex.Flowable<any>; public groupBy(keySelector: io.reactivex.functions.Function<any,any>, valueSelector: io.reactivex.functions.Function<any,any>): io.reactivex.Flowable<any>; public delay(delay: number, param1: java.util.concurrent.TimeUnit, unit: boolean): io.reactivex.Flowable<any>; public buffer(boundaryIndicator: org.reactivestreams.Publisher, bufferSupplier: java.util.concurrent.Callable<any>): io.reactivex.Flowable<any>; public flatMap(mapper: io.reactivex.functions.Function<any,any>, delayErrors: boolean, maxConcurrency: number): io.reactivex.Flowable<any>; public window(count: number, param1: number): io.reactivex.Flowable<io.reactivex.Flowable<any>>; public test(): io.reactivex.subscribers.TestSubscriber<any>; public replay(selector: io.reactivex.functions.Function<any,any>, time: number, param2: java.util.concurrent.TimeUnit, unit: io.reactivex.Scheduler): io.reactivex.Flowable<any>; public subscribeOn(scheduler: io.reactivex.Scheduler): io.reactivex.Flowable<any>; public static zip(source1: org.reactivestreams.Publisher, source2: org.reactivestreams.Publisher, zipper: io.reactivex.functions.BiFunction<any,any,any>, delayError: boolean): io.reactivex.Flowable<any>; public replay(time: number, param1: java.util.concurrent.TimeUnit, unit: io.reactivex.Scheduler): io.reactivex.flowables.ConnectableFlowable<any>; public blockingSubscribe(onNext: io.reactivex.functions.Consumer<any>, onError: io.reactivex.functions.Consumer<any>): void; public window(boundaryIndicator: org.reactivestreams.Publisher): io.reactivex.Flowable<any>; public static mergeArrayDelayError(maxConcurrency: number, bufferSize: number, ...sources: org.reactivestreams.Publisher[]): io.reactivex.Flowable<any>; public onBackpressureDrop(): io.reactivex.Flowable<any>; public blockingSubscribe(subscriber: org.reactivestreams.Subscriber<any>): void; public static mergeDelayError(source1: org.reactivestreams.Publisher, source2: org.reactivestreams.Publisher): io.reactivex.Flowable<any>; public replay(scheduler: io.reactivex.Scheduler): io.reactivex.flowables.ConnectableFlowable<any>; public repeat(): io.reactivex.Flowable<any>; public safeSubscribe(s: org.reactivestreams.Subscriber<any>): void; public static mergeDelayError(sources: java.lang.Iterable<any>): io.reactivex.Flowable<any>; public flatMapMaybe(mapper: io.reactivex.functions.Function<any,any>, delayErrors: boolean, maxConcurrency: number): io.reactivex.Flowable<any>; public sorted(sortFunction: java.util.Comparator<any>): io.reactivex.Flowable<any>; public static mergeDelayError(source1: org.reactivestreams.Publisher, source2: org.reactivestreams.Publisher, source3: org.reactivestreams.Publisher): io.reactivex.Flowable<any>; public static switchOnNext(sources: org.reactivestreams.Publisher, bufferSize: number): io.reactivex.Flowable<any>; public static merge(sources: java.lang.Iterable<any>, maxConcurrency: number): io.reactivex.Flowable<any>; public blockingLast(): any; public static combineLatest(source1: org.reactivestreams.Publisher, source2: org.reactivestreams.Publisher, source3: org.reactivestreams.Publisher, combiner: io.reactivex.functions.Function3<any,any,any,any>): io.reactivex.Flowable<any>; public static fromPublisher(source: org.reactivestreams.Publisher): io.reactivex.Flowable<any>; public concatMapMaybeDelayError(mapper: io.reactivex.functions.Function<any,any>, tillTheEnd: boolean): io.reactivex.Flowable<any>; public retryUntil(stop: io.reactivex.functions.BooleanSupplier): io.reactivex.Flowable<any>; public takeLast(count: number): io.reactivex.Flowable<any>; public static concatArray(...sources: org.reactivestreams.Publisher[]): io.reactivex.Flowable<any>; public isEmpty(): io.reactivex.Single<java.lang.Boolean>; public onBackpressureBuffer(delayError: boolean): io.reactivex.Flowable<any>; public static zip(source1: org.reactivestreams.Publisher, source2: org.reactivestreams.Publisher, source3: org.reactivestreams.Publisher, source4: org.reactivestreams.Publisher, source5: org.reactivestreams.Publisher, zipper: io.reactivex.functions.Function5<any,any,any,any,any,any>): io.reactivex.Flowable<any>; public delaySubscription(delay: number, param1: java.util.concurrent.TimeUnit, unit: io.reactivex.Scheduler): io.reactivex.Flowable<any>; public debounce(timeout: number, param1: java.util.concurrent.TimeUnit): io.reactivex.Flowable<any>; public sample(period: number, param1: java.util.concurrent.TimeUnit, unit: io.reactivex.Scheduler): io.reactivex.Flowable<any>; public blockingSubscribe(onNext: io.reactivex.functions.Consumer<any>, onError: io.reactivex.functions.Consumer<any>, onComplete: io.reactivex.functions.Action, bufferSize: number): void; public toMap(keySelector: io.reactivex.functions.Function<any,any>): io.reactivex.Single<any>; public flatMapSingle(mapper: io.reactivex.functions.Function<any,any>, delayErrors: boolean, maxConcurrency: number): io.reactivex.Flowable<any>; public singleOrError(): io.reactivex.Single<any>; public takeLast(count: number, param1: number, time: java.util.concurrent.TimeUnit, param3: io.reactivex.Scheduler): io.reactivex.Flowable<any>; public any(predicate: io.reactivex.functions.Predicate<any>): io.reactivex.Single<java.lang.Boolean>; public startWith(other: org.reactivestreams.Publisher<any>): io.reactivex.Flowable<any>; public doOnCancel(onCancel: io.reactivex.functions.Action): io.reactivex.Flowable<any>; public concatMapIterable(mapper: io.reactivex.functions.Function<any,any>, prefetch: number): io.reactivex.Flowable<any>; public blockingMostRecent(initialItem: any): java.lang.Iterable<any>; public debounce(timeout: number, param1: java.util.concurrent.TimeUnit, unit: io.reactivex.Scheduler): io.reactivex.Flowable<any>; public blockingNext(): java.lang.Iterable<any>; public toFuture(): java.util.concurrent.Future<any>; public toSortedList(): io.reactivex.Single<java.util.List<any>>; public delay(itemDelayIndicator: io.reactivex.functions.Function<any,any>): io.reactivex.Flowable<any>; public startWith(value: any): io.reactivex.Flowable<any>; public withLatestFrom(source1: org.reactivestreams.Publisher, source2: org.reactivestreams.Publisher, combiner: io.reactivex.functions.Function3<any,any,any,any>): io.reactivex.Flowable<any>; public zipWith(other: java.lang.Iterable<any>, zipper: io.reactivex.functions.BiFunction<any,any,any>): io.reactivex.Flowable<any>; public buffer(timespan: number, param1: java.util.concurrent.TimeUnit): io.reactivex.Flowable<java.util.List<any>>; public cast(clazz: java.lang.Class<any>): io.reactivex.Flowable<any>; public concatMapEagerDelayError(mapper: io.reactivex.functions.Function<any,any>, tillTheEnd: boolean): io.reactivex.Flowable<any>; public scan(initialValue: any, accumulator: io.reactivex.functions.BiFunction<any,any,any>): io.reactivex.Flowable<any>; public static concat(source1: org.reactivestreams.Publisher, source2: org.reactivestreams.Publisher): io.reactivex.Flowable<any>; public delay(delay: number, param1: java.util.concurrent.TimeUnit, unit: io.reactivex.Scheduler): io.reactivex.Flowable<any>; public subscribe(onNext: io.reactivex.functions.Consumer<any>, onError: io.reactivex.functions.Consumer<any>, onComplete: io.reactivex.functions.Action, onSubscribe: io.reactivex.functions.Consumer<any>): io.reactivex.disposables.Disposable; public skip(time: number, param1: java.util.concurrent.TimeUnit): io.reactivex.Flowable<any>; public static concat(source1: org.reactivestreams.Publisher, source2: org.reactivestreams.Publisher, source3: org.reactivestreams.Publisher, source4: org.reactivestreams.Publisher): io.reactivex.Flowable<any>; public skipLast(time: number, param1: java.util.concurrent.TimeUnit, unit: boolean): io.reactivex.Flowable<any>; public static zip(sources: java.lang.Iterable<any>, zipper: io.reactivex.functions.Function<any,any>): io.reactivex.Flowable<any>; public static zipIterable(sources: java.lang.Iterable<any>, zipper: io.reactivex.functions.Function<any,any>, delayError: boolean, bufferSize: number): io.reactivex.Flowable<any>; public switchMapMaybe(mapper: io.reactivex.functions.Function<any,any>): io.reactivex.Flowable<any>; public toList(collectionSupplier: java.util.concurrent.Callable<any>): io.reactivex.Single<any>; public static fromFuture(future: java.util.concurrent.Future<any>, timeout: number, param2: java.util.concurrent.TimeUnit, unit: io.reactivex.Scheduler): io.reactivex.Flowable<any>; public replay(): io.reactivex.flowables.ConnectableFlowable<any>; public window(timespan: number, param1: number, timeskip: java.util.concurrent.TimeUnit): io.reactivex.Flowable<io.reactivex.Flowable<any>>; public static concat(source1: org.reactivestreams.Publisher, source2: org.reactivestreams.Publisher, source3: org.reactivestreams.Publisher): io.reactivex.Flowable<any>; public retry(): io.reactivex.Flowable<any>; public switchMapDelayError(mapper: io.reactivex.functions.Function<any,any>): io.reactivex.Flowable<any>; public blockingSingle(): any; public concatMapSingleDelayError(mapper: io.reactivex.functions.Function<any,any>): io.reactivex.Flowable<any>; public doAfterTerminate(onAfterTerminate: io.reactivex.functions.Action): io.reactivex.Flowable<any>; public toMultimap(keySelector: io.reactivex.functions.Function<any,any>, valueSelector: io.reactivex.functions.Function<any,any>, mapSupplier: java.util.concurrent.Callable<any>, collectionFactory: io.reactivex.functions.Function<any,any>): io.reactivex.Single<any>; public static combineLatest(sources: org.reactivestreams.Publisher[], combiner: io.reactivex.functions.Function<any,any>): io.reactivex.Flowable<any>; public publish(selector: io.reactivex.functions.Function<any,any>): io.reactivex.Flowable<any>; public static fromFuture(future: java.util.concurrent.Future<any>): io.reactivex.Flowable<any>; public buffer(timespan: number, param1: number, timeskip: java.util.concurrent.TimeUnit): io.reactivex.Flowable<java.util.List<any>>; public static timer(delay: number, param1: java.util.concurrent.TimeUnit): io.reactivex.Flowable<java.lang.Long>; public doOnError(onError: io.reactivex.functions.Consumer<any>): io.reactivex.Flowable<any>; public concatWith(other: io.reactivex.SingleSource<any>): io.reactivex.Flowable<any>; public static sequenceEqual(source1: org.reactivestreams.Publisher, source2: org.reactivestreams.Publisher, bufferSize: number): io.reactivex.Single<any>; public firstElement(): io.reactivex.Maybe<any>; public test(initialRequest: number): io.reactivex.subscribers.TestSubscriber<any>; public static fromArray(...items: any[]): io.reactivex.Flowable<any>; public timeout(firstTimeoutIndicator: org.reactivestreams.Publisher, itemTimeoutIndicator: io.reactivex.functions.Function<any,any>, other: org.reactivestreams.Publisher): io.reactivex.Flowable<any>; public concatMapCompletableDelayError(mapper: io.reactivex.functions.Function<any,any>): io.reactivex.Completable; public concatMapMaybe(mapper: io.reactivex.functions.Function<any,any>, prefetch: number): io.reactivex.Flowable<any>; public concatMapEager(mapper: io.reactivex.functions.Function<any,any>, maxConcurrency: number, prefetch: number): io.reactivex.Flowable<any>; public window(boundaryIndicator: org.reactivestreams.Publisher, bufferSize: number): io.reactivex.Flowable<any>; public flatMapMaybe(mapper: io.reactivex.functions.Function<any,any>): io.reactivex.Flowable<any>; public static just(item: any): io.reactivex.Flowable<any>; public scanWith(seedSupplier: java.util.concurrent.Callable<any>, accumulator: io.reactivex.functions.BiFunction<any,any,any>): io.reactivex.Flowable<any>; public blockingSubscribe(): void; public elementAt(index: number): io.reactivex.Maybe<any>; public flatMap(mapper: io.reactivex.functions.Function<any,any>, combiner: io.reactivex.functions.BiFunction<any,any,any>): io.reactivex.Flowable<any>; public window(timespan: number, param1: java.util.concurrent.TimeUnit, unit: io.reactivex.Scheduler, scheduler: number): io.reactivex.Flowable<io.reactivex.Flowable<any>>; public to(converter: io.reactivex.functions.Function<any,any>): any; public retry(predicate: io.reactivex.functions.Predicate<any>): io.reactivex.Flowable<any>; public window(count: number, param1: number, skip: number): io.reactivex.Flowable<io.reactivex.Flowable<any>>; public parallel(): io.reactivex.parallel.ParallelFlowable<any>; public concatMapDelayError(mapper: io.reactivex.functions.Function<any,any>): io.reactivex.Flowable<any>; public static just(item1: any, item2: any, item3: any, item4: any, item5: any): io.reactivex.Flowable<any>; public replay(bufferSize: number, time: number, param2: java.util.concurrent.TimeUnit, unit: io.reactivex.Scheduler): io.reactivex.flowables.ConnectableFlowable<any>; public flatMapIterable(mapper: io.reactivex.functions.Function<any,any>, resultSelector: io.reactivex.functions.BiFunction<any,any,any>): io.reactivex.Flowable<any>; public onBackpressureBuffer(capacity: number): io.reactivex.Flowable<any>; public static just(item1: any, item2: any): io.reactivex.Flowable<any>; public static mergeArrayDelayError(...sources: org.reactivestreams.Publisher[]): io.reactivex.Flowable<any>; public withLatestFrom(other: org.reactivestreams.Publisher, combiner: io.reactivex.functions.BiFunction<any,any,any>): io.reactivex.Flowable<any>; public takeUntil(stopPredicate: io.reactivex.functions.Predicate<any>): io.reactivex.Flowable<any>; public onBackpressureBuffer(capacity: number, delayError: boolean, unbounded: boolean, onOverflow: io.reactivex.functions.Action): io.reactivex.Flowable<any>; public onErrorResumeNext(resumeFunction: io.reactivex.functions.Function<any,any>): io.reactivex.Flowable<any>; public switchMapSingle(mapper: io.reactivex.functions.Function<any,any>): io.reactivex.Flowable<any>; public static fromIterable(source: java.lang.Iterable<any>): io.reactivex.Flowable<any>; public distinct(keySelector: io.reactivex.functions.Function<any,any>, collectionSupplier: java.util.concurrent.Callable<any>): io.reactivex.Flowable<any>; public timestamp(scheduler: io.reactivex.Scheduler): io.reactivex.Flowable<io.reactivex.schedulers.Timed<any>>; public concatWith(other: io.reactivex.MaybeSource<any>): io.reactivex.Flowable<any>; public skipLast(time: number, param1: java.util.concurrent.TimeUnit, unit: io.reactivex.Scheduler, scheduler: boolean): io.reactivex.Flowable<any>; public blockingFirst(defaultItem: any): any; public repeatWhen(handler: io.reactivex.functions.Function<any,any>): io.reactivex.Flowable<any>; public blockingSingle(defaultItem: any): any; public sample(period: number, param1: java.util.concurrent.TimeUnit, unit: boolean): io.reactivex.Flowable<any>; public distinctUntilChanged(keySelector: io.reactivex.functions.Function<any,any>): io.reactivex.Flowable<any>; public concatMap(mapper: io.reactivex.functions.Function<any,any>, prefetch: number): io.reactivex.Flowable<any>; public static zip(source1: org.reactivestreams.Publisher, source2: org.reactivestreams.Publisher, source3: org.reactivestreams.Publisher, source4