kablo
library
Classes
-
Aggragate<K, V>
-
-
AsyncCache<T>
-
Runs asynchronous functions and caches the result for a period of time.
-
AsyncMemoizer<T>
-
A class for running an asynchronous function exactly once and caching its
result.
-
CancelableCompleter<T>
-
A completer for a CancelableOperation.
-
CancelableOperation<T>
-
An asynchronous operation that can be cancelled.
-
ChunkedStreamReader<T>
-
Utility class for reading elements from a chunked stream.
-
Completer<T>
-
A way to produce Future objects and to complete them later
with a value or error.
-
Controller<T, S>
-
-
DelegatingEventSink<T>
-
Simple delegating wrapper around an EventSink.
-
DelegatingFuture<T>
-
A wrapper that forwards calls to a Future.
-
DelegatingSink<T>
-
Simple delegating wrapper around a Sink.
-
DelegatingStream<T>
-
Simple delegating wrapper around a Stream.
-
DelegatingStreamConsumer<T>
-
Simple delegating wrapper around a StreamConsumer.
-
DelegatingStreamSink<T>
-
Simple delegating wrapper around a StreamSink.
-
DelegatingStreamSubscription<T>
-
Simple delegating wrapper around a StreamSubscription.
-
DuplexSubscription<T, Q>
-
-
ErrorResult
-
A result representing a thrown error.
-
EventSink<T>
-
A Sink that supports adding errors.
-
EventSinkBase<T>
-
An abstract class that implements EventSink in terms of onAdd,
onError, and onClose methods.
-
Future<T>
-
The result of an asynchronous computation.
-
FutureGroup<T>
-
A collection of futures waits until all added Futures complete.
-
FutureOr<T>
-
A type representing values that are either
Future<T>
or T
.
-
GroupBy<K, V>
-
-
InspectLog<T>
-
-
IOSinkBase
-
An abstract class that implements
dart:io
's IOSink
's API in terms of
onAdd, onError, onClose, and onFlush methods.
-
LazyStream<T>
-
A Stream wrapper that forwards to another Stream that's initialized
lazily.
-
LogConfig<T>
-
-
Merge<T>
-
-
MultiStreamController<T>
-
An enhanced stream controller provided by Stream.multi.
-
NullStreamSink<T>
-
A StreamSink that discards all events.
-
Pipe<T>
-
-
Point<T>
-
-
PrintLog<T>
-
-
RestartableTimer
-
A non-periodic timer that can be restarted any number of times.
-
Result<T>
-
The result of a computation.
-
ResultFuture<T>
-
A Future wrapper that provides synchronous access to the result of the
wrapped Future once it's completed.
-
SingleSubscriptionTransformer<S, T>
-
A transformer that converts a broadcast stream into a single-subscription
stream.
-
Snapshot<T>
-
-
Stream<T>
-
A source of asynchronous data events.
-
StreamCloser<T>
-
A StreamTransformer that allows the caller to forcibly close the
transformed Stream.
-
StreamCompleter<T>
-
A single-subscription stream where the contents are provided later.
-
StreamConsumer<S>
-
Abstract interface for a "sink" accepting multiple entire streams.
-
StreamController<T>
-
A controller with the stream it controls.
-
StreamGroup<T>
-
A collection of streams whose events are unified and sent through a central
stream.
-
StreamIterator<T>
-
An Iterator-like interface for the values of a Stream.
-
StreamQueue<T>
-
An asynchronous pull-based interface for accessing stream events.
-
StreamQueueTransaction<T>
-
A transaction on a StreamQueue, created by StreamQueue.startTransaction.
-
StreamSink<S>
-
A object that accepts stream events both synchronously and asynchronously.
-
StreamSinkBase<T>
-
An abstract class that implements StreamSink in terms of onAdd,
onError, and onClose methods.
-
StreamSinkCompleter<T>
-
A sink where the destination is provided later.
-
StreamSinkTransformer<S, T>
-
A StreamSinkTransformer transforms the events being passed to a sink.
-
StreamSplitter<T>
-
A class that splits a single source stream into an arbitrary number of
(single-subscription) streams (called "branch") that emit the same events.
-
StreamSubscription<T>
-
A subscription on events from a Stream.
-
StreamTransformer<S, T>
-
Transforms a Stream.
-
StreamTransformerBase<S, T>
-
Base class for implementing StreamTransformer.
-
StreamView<T>
-
Stream wrapper that only exposes the Stream interface.
-
StreamZip<T>
-
A stream that combines the values of other streams.
-
SubscriptionStream<T>
-
A Stream adapter for a StreamSubscription.
-
SynchronousStreamController<T>
-
A stream controller that delivers its events synchronously.
-
Timer
-
A countdown timer that can be configured to fire once or repeatedly.
-
ValueResult<T>
-
A result representing a returned value.
-
Zone
-
A zone represents an environment that remains stable across asynchronous
calls.
-
ZoneDelegate
-
An adapted view of the parent zone.
-
ZoneSpecification
-
A parameter object with custom zone function handlers for Zone.fork.
Extensions
-
AggragateWidget
on Aggragate<K, V>
-
-
AggregateExtension
on Stream<MapEntry<K, V>>
-
-
AggregateListExtension
on List<Stream<V>>
-
-
AsyncExpand
on Stream<T>
-
Alternatives to asyncExpand.
-
AsyncMap
on Stream<T>
-
Alternatives to asyncMap.
-
ChunkedStreamReaderByteStreamExt
on ChunkedStreamReader<int>
-
Extensions for using ChunkedStreamReader with byte-streams.
-
CombineLatest
on Stream<T>
-
Utilities to combine events from multiple streams through a callback or into
a list.
-
Concatenate
on Stream<T>
-
Utilities to append or prepend to a stream.
-
FutureExtensions
on Future<T>
-
Convenience methods on futures.
-
FutureIterable
on Iterable<Future<T>>
-
-
FutureRecord2
on (Future<T1>, Future<T2>)
-
Parallel operations on a record of futures.
-
FutureRecord3
on (Future<T1>, Future<T2>, Future<T3>)
-
Parallel operations on a record of futures.
-
FutureRecord4
on (Future<T1>, Future<T2>, Future<T3>, Future<T4>)
-
Parallel operations on a record of futures.
-
FutureRecord5
on (Future<T1>, Future<T2>, Future<T3>, Future<T4>, Future<T5>)
-
Parallel operations on a record of futures.
-
FutureRecord6
on (Future<T1>, Future<T2>, Future<T3>, Future<T4>, Future<T5>, Future<T6>)
-
Parallel operations on a record of futures.
-
FutureRecord7
on (Future<T1>, Future<T2>, Future<T3>, Future<T4>, Future<T5>, Future<T6>, Future<T7>)
-
Parallel operations on a record of futures.
-
FutureRecord8
on (Future<T1>, Future<T2>, Future<T3>, Future<T4>, Future<T5>, Future<T6>, Future<T7>, Future<T8>)
-
Parallel operations on a record of futures.
-
FutureRecord9
on (Future<T1>, Future<T2>, Future<T3>, Future<T4>, Future<T5>, Future<T6>, Future<T7>, Future<T8>, Future<T9>)
-
Parallel operations on a record of futures.
-
GroupByListExtension
on List<V>
-
-
GroupByListsExtension
on Stream<List<V>>
-
-
MergeExtension
on Stream<T>
-
-
MergeIterableExtension
on Iterable<Stream<T>>
-
-
PipeExtension
on Stream<T>
-
-
RateLimit
on Stream<T>
-
Utilities to rate limit events.
-
Scan
on Stream<T>
-
A utility similar to fold which emits intermediate accumulations.
-
SnapshotExtension
on Stream<T>
-
-
SnapshotWidget
on Snapshot<T>
-
-
StreamExtensions
on Stream<T>
-
Utility extensions on Stream.
-
StreamSinkExtensions
on StreamSink<T>
-
Extensions on StreamSink to make stream transformations more fluent.
-
Switch
on Stream<T>
-
A utility to take events from the most recent sub stream returned by a
callback.
-
SwitchLatest
on Stream<Stream<T>>
-
A utility to take events from the most recent sub stream.
-
TakeUntil
on Stream<T>
-
A utility to end a stream based on an external trigger.
-
Tap
on Stream<T>
-
A utility to chain extra behavior on a stream.
-
Where
on Stream<T>
-
Utilities to filter events.
-
WhereNotNull
on Stream<T?>
-
Functions
-
asyncBuilder<T>({Widget waiting = const CircularProgressIndicator(), ErrorWidgetBuilder error = defaultError, Widget noData = const Text('No Data'), required ValueWidgetBuilder<T> builder, Widget? child})
→ AsyncWidgetBuilder<T>
-
-
collectBytes(Stream<List<int>> source)
→ Future<Uint8List>
-
Collects an asynchronous sequence of byte lists into a single list of bytes.
-
collectBytesCancelable(Stream<List<int>> source)
→ CancelableOperation<Uint8List>
-
Collects an asynchronous sequence of byte lists into a single list of bytes.
-
defaultError(FlutterErrorDetails details)
→ Widget
-
-
noDataDefault(BuildContext ctx, void value, Widget? child)
→ Widget
-
-
runZoned<R>(R body(), {Map<Object?, Object?>? zoneValues, ZoneSpecification? zoneSpecification, Function? onError})
→ R
-
Runs
body
in its own zone.
-
runZonedGuarded<R>(R body(), void onError(Object error, StackTrace stack), {Map<Object?, Object?>? zoneValues, ZoneSpecification? zoneSpecification})
→ R?
-
Runs
body
in its own error zone.
-
scheduleMicrotask(void callback())
→ void
-
Runs a function asynchronously.
-
subscriptionTransformer<T>({Future handleCancel(StreamSubscription<T>)?, void handlePause(StreamSubscription<T>)?, void handleResume(StreamSubscription<T>)?})
→ StreamTransformer<T, T>
-
Creates a StreamTransformer that modifies the behavior of subscriptions to
a stream.
-
typedStreamTransformer<S, T>(StreamTransformer transformer)
→ StreamTransformer<S, T>
-
Creates a wrapper that coerces the type of
transformer
.
-
unawaited(Future<void>? future)
→ void
-
Explicitly ignores a future.
Typedefs
-
Condition<T>
= bool Function(T? obj)
-
-
ControllerCallback
= void Function()
-
Type of a stream controller's
onListen
, onPause
and onResume
callbacks.
-
ControllerCancelCallback
= FutureOr<void> Function()
-
Type of stream controller
onCancel
callbacks.
-
CreatePeriodicTimerHandler
= Timer Function(Zone self, ZoneDelegate parent, Zone zone, Duration period, void f(Timer timer))
-
The type of a custom Zone.createPeriodicTimer implementation function.
-
CreateTimerHandler
= Timer Function(Zone self, ZoneDelegate parent, Zone zone, Duration duration, void f())
-
The type of a custom Zone.createTimer implementation function.
-
ErrorCallbackHandler
= AsyncError? Function(Zone self, ZoneDelegate parent, Zone zone, Object error, StackTrace? stackTrace)
-
The type of a custom Zone.errorCallback implementation function.
-
ForkHandler
= Zone Function(Zone self, ZoneDelegate parent, Zone zone, ZoneSpecification? specification, Map<Object?, Object?>? zoneValues)
-
The type of a custom Zone.fork implementation function.
-
Formatter<T, Q>
= Q Function(T? obj)
-
-
HandleUncaughtErrorHandler
= void Function(Zone self, ZoneDelegate parent, Zone zone, Object error, StackTrace stackTrace)
-
The type of a custom Zone.handleUncaughtError implementation function.
-
PrintHandler
= void Function(Zone self, ZoneDelegate parent, Zone zone, String line)
-
The type of a custom Zone.print implementation function.
-
RegisterBinaryCallbackHandler
= ZoneBinaryCallback<R, T1, T2> Function<R, T1, T2>(Zone self, ZoneDelegate parent, Zone zone, R f(T1 arg1, T2 arg2))
-
The type of a custom Zone.registerBinaryCallback implementation function.
-
RegisterCallbackHandler
= ZoneCallback<R> Function<R>(Zone self, ZoneDelegate parent, Zone zone, R f())
-
The type of a custom Zone.registerCallback implementation function.
-
RegisterUnaryCallbackHandler
= ZoneUnaryCallback<R, T> Function<R, T>(Zone self, ZoneDelegate parent, Zone zone, R f(T arg))
-
The type of a custom Zone.registerUnaryCallback implementation function.
-
RunBinaryHandler
= R Function<R, T1, T2>(Zone self, ZoneDelegate parent, Zone zone, R f(T1 arg1, T2 arg2), T1 arg1, T2 arg2)
-
The type of a custom Zone.runBinary implementation function.
-
RunHandler
= R Function<R>(Zone self, ZoneDelegate parent, Zone zone, R f())
-
The type of a custom Zone.run implementation function.
-
RunUnaryHandler
= R Function<R, T>(Zone self, ZoneDelegate parent, Zone zone, R f(T arg), T arg)
-
The type of a custom Zone.runUnary implementation function.
-
ScheduleMicrotaskHandler
= void Function(Zone self, ZoneDelegate parent, Zone zone, void f())
-
The type of a custom Zone.scheduleMicrotask implementation function.
-
Sequencer<T>
= int? Function(T? obj)
-
-
ZoneBinaryCallback<R, T1, T2>
= R Function(T1, T2)
-
-
ZoneCallback<R>
= R Function()
-
-
ZoneUnaryCallback<R, T>
= R Function(T)
-