stream_chat library

Classes

AcceptInviteResponse
Model response for Channel.acceptInvite api call
Action
The class that contains the information about an action
AddMembersResponse
Model response for Channel.addMembers api call
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.
Attachment
The class that contains the information about an attachment
AttachmentFile
The class that contains the information about an attachment file
AttachmentFileUploader
Class responsible for uploading images and files to a given channel
BackOff<T>
Object holding options for retrying a function.
BannedUser
Contains information about a User that was banned from a Channel or App.
BlockedUsersResponse
Model response for StreamChatClient.queryBlockedUsers api call
CallTokenPayload
The response to CallApi.getCallToken
CancelableCompleter<T>
A completer for a CancelableOperation.
CancelableOperation<T>
An asynchronous operation that can be cancelled.
CancelToken
Controls cancellation of Dio's requests.
CastPollVoteResponse
Model response for StreamChatClient.castPollVote api call
Channel
Class that manages a specific channel.
ChannelClientState
The class that handles the state of the channel listening to the events.
ChannelConfig
The class that contains the information about the configuration of a channel
ChannelModel
The class that contains the information about a channel
ChannelMute
The class that contains the information about a muted channel
ChannelPushPreference
The class that contains push preferences for a specific channel
ChannelState
The class that contains the information about a channel
ChannelStateResponse
Model response for Channel.query api call
ChatPersistenceClient
A simple client used for persisting chat data locally.
ChunkedStreamReader<T>
Utility class for reading elements from a chunked stream.
ClientState
The class that handles the state of the channel listening to the events
Command
The class that contains the information about a command
CompletedState
Represents the completed state of a message.
ConnectGuestUserResponse
Model response for StreamChatClient.connectGuestUser api call
CreateCallPayload
The response to CallApi.createCall
CreateDraftResponse
Model response for StreamChatClient.createDraft api call
CreatePollOptionResponse
Model response for StreamChatClient.createPollOption api call
CreatePollResponse
Model response for StreamChatClient.createPoll api call
CreateReminderResponse
Model response for StreamChatClient.createReminder api call
CurrentPlatform
Utility class that provides information on the current platform
Debounce
Creates a debounced function that delays invoking func until after wait milliseconds have elapsed since the last time the debounced function was invoked. The debounced function comes with a Debounce.cancel method to cancel delayed func invocations and a Debounce.flush method to immediately invoke them. Provide leading and/or trailing to indicate whether func should be invoked on the leading and/or trailing edge of the wait interval. The func is invoked with the last arguments provided to the call function. Subsequent calls to the debounced function return the result of the last func invocation.
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.
Device
The class that contains the information about a device
Draft
A model class representing a draft message.
DraftMessage
The class that contains the information about a draft message.
DraftResponse
Base Model response for draft based api calls.
EmptyResponse
Model response for empty responses
ErrorResponse
Model response for StreamChatNetworkError data
ErrorResult
A result representing a thrown error.
Event
The class that contains the information about an event
EventSinkBase<T>
An abstract class that implements EventSink in terms of onAdd, onError, and onClose methods.
EventType
This class defines some basic event types
FailedState
Represents the failed state of a message.
Filter
Stream supports a limited set of filters for querying channels, users and members. The example below shows how to filter for channels of type messaging where the current user is a member
FutureGroup<T>
A collection of futures waits until all added Futures complete.
GetDraftResponse
Model response for StreamChatClient.getDraft api call
GetMessageResponse
Model response for StreamChatClient.getMessage api call
GetMessagesByIdResponse
Model response for Channel.getMessagesById api call
GetPollOptionResponse
Model response for StreamChatClient.getPollOption api call
GetPollResponse
Model response for StreamChatClient.getPoll api call
GetThreadResponse
Model response for StreamChatClient.getThread api call
GetUnreadCountResponse
Model response for StreamChatClient.getUnreadCount api call
GiphyInfo
A class that contains extra information about a Giphy attachment.
Interceptor
Interceptor helps to deal with RequestOptions, Response, and DioException during the lifecycle of a request before it reaches users.
InterceptorsWrapper
A helper class to create interceptors in ease.
InviteMembersResponse
Model response for Channel.inviteMembers api call
IOSinkBase
An abstract class that implements dart:io's IOSink's API in terms of onAdd, onError, onClose, and onFlush methods.
KeyStrokeHandler
A class that manages buffering typing events and call onTypingStarted and onTypingStopped accordingly in a timed manner.
LazyStream<T>
A Stream wrapper that forwards to another Stream that's initialized lazily.
Level
Levels to control logging output. Logging can be enabled to include all levels above certain Level. Levels are ordered using an integer value Level.value. The predefined Level constants below are sorted as follows (in descending order): Level.SHOUT, Level.SEVERE, Level.WARNING, Level.INFO, Level.CONFIG, Level.FINE, Level.FINER, Level.FINEST, and Level.ALL.
ListDevicesResponse
Model response for StreamChatClient.getDevices api call
Logger
Use a Logger to log debug messages.
LoggingInterceptor
Interceptor dedicated to logging
LogRecord
A log entry representation used to propagate information from Logger to individual handlers.
Member
The class that contains the information about the user membership in a channel
MemberUpdatePayload
Payload for updating a member.
Message
The class that contains the information about a message.
MessageReminder
A model class representing a message reminder.
MessageReminderResponse
Base Model response for draft based api calls.
MessageResponse
Base Model response for message based api calls.
MessageState
Represents the various states a message can be in.
Moderation
Model holding data for a message moderated by Moderation V1-V2.
MultipartFile
An upload content that is a part of MultipartRequest. This doesn't need to correspond to a physical file.
Mute
The class that contains the information about a muted user
NullStreamSink<T>
A StreamSink that discards all events.
OGAttachmentResponse
Model response for Client.enrichUrl api call.
Options
The configuration for a single request. BaseOptions and Options will be merged into one RequestOptions before sending the requests. See Options.compose.
OutgoingState
Represents the state of an outgoing message.
OwnUser
The class that defines the own user model.
PaginationParams
Pagination options.
PartialUpdateChannelResponse
Model response for Channel.updatePartial api call
PartialUpdateMemberResponse
Model response for update member API calls, such as StreamChatClient.updateMemberPartial
PartialUpdateUserRequest
Request model for the client.partialUpdateUser api call.
PermissionType
Describes capabilities of a user vis-a-vis a channel
Poll
A model class representing a poll.
PollOption
A model class representing a poll option.
PollVote
A model class representing a poll vote.
PollVotingMode
The Voting mode for a poll.
PushPreference
The class that contains push preferences for a user
PushPreferenceInput
Input for push preferences, used for creating or updating preferences for a user or a specific channel.
QueryBannedUsersResponse
Model response for StreamChatClient.queryBannedUsers api call
QueryChannelsResponse
Model response for StreamChatClient.queryChannels api call
QueryDraftsResponse
Model response for StreamChatClient.queryDrafts api call
QueryMembersResponse
Model response for StreamChatClient.queryChannels api call
QueryPollsResponse
Model response for StreamChatClient.queryPolls api call
QueryPollVotesResponse
Model response for StreamChatClient.queryPollVotes api call
QueryReactionsResponse
Model response for channel.getReactions api call
QueryRemindersResponse
Model response for StreamChatClient.queryReminders api call
QueryRepliesResponse
Model response for Channel.getReplies api call
QueryThreadsResponse
Model response for StreamChatClient.queryThreads api call
QueryUsersResponse
Model response for StreamChatClient.queryUsers api call
Reaction
The class that defines a reaction
ReactionGroup
A model class representing a reaction group.
Read
The class that defines a read event
RejectInviteResponse
Model response for Channel.rejectInvite api call
RemoveMembersResponse
Model response for Channel.removeMembers api call
RemovePollVoteResponse
Model response for StreamChatClient.removePollVote api call
RequestOptions
The internal request option class that is the eventual result after BaseOptions and Options are composed.
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.
RetryPolicy
The retry policy associated to a client.
SearchMessagesResponse
Model response for StreamChatClient.search api call
SendActionResponse
Model response for Channel.sendAction api call
SendAttachmentResponse
Base Model response for Channel.sendImage and Channel.sendFile api call.
SendFileResponse
Model response for Channel.sendFile api call
SendMessageResponse
Model response for Channel.sendMessage api call
SendReactionResponse
Model response for Channel.sendReaction api call
SingleSubscriptionTransformer<S, T>
A transformer that converts a broadcast stream into a single-subscription stream.
SortOption<T extends ComparableFieldProvider>
A sort specification for objects that implement ComparableFieldProvider.
StreamAttachmentFileUploader
Stream's default implementation of AttachmentFileUploader
StreamChatApi
ApiClient that wraps every other specific api
StreamChatClient
The official Dart client for Stream Chat, a service for building chat applications. This library can be used on any Dart project and on both mobile and web apps with Flutter.
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.
StreamGroup<T>
A collection of streams whose events are unified and sent through a central stream.
StreamHttpClient
This is where we configure the base url, headers, query parameters and convenient methods for http verbs with error parsing.
StreamHttpClientOptions
Client options to modify StreamHttpClient
StreamQueue<T>
An asynchronous pull-based interface for accessing stream events.
StreamQueueTransaction<T>
A transaction on a StreamQueue, created by StreamQueue.startTransaction.
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.
StreamZip<T>
A stream that combines the values of other streams.
SubscriptionStream<T>
A Stream adapter for a StreamSubscription.
SyncResponse
Model response for StreamChatClient.sync api call
SystemEnvironment
A class that represents the environment in which the Stream Chat SDK is running.
Thread
A model class representing a thread. Threads are a way to group replies to a message in a channel.
ThreadOptions
Options for querying threads.
ThreadParticipant
A model class representing a user that is participating in a thread.
Throttle
Creates a throttled function that only invokes func at most once per every wait milliseconds. The throttled function comes with a Throttle.cancel method to cancel delayed func invocations and a Throttle.flush method to immediately invoke them. Provide leading and/or trailing to indicate whether func should be invoked on the leading and/or trailing edge of the wait timeout. The func is invoked with the last arguments provided to the throttled function. Subsequent calls to the throttled function return the result of the last func invocation.
TranslateMessageResponse
Model response for StreamChatClient.queryChannels api call
UnreadCountsChannel
A model class representing information for a specific channel.
UnreadCountsChannelType
A model class representing aggregated unread count information for a specific channel type.
UnreadCountsThread
A model class representing unread count information for a specific thread.
UpdateChannelResponse
Model response for Channel.update api call
UpdateMessageResponse
Model response for StreamChatClient.updateMessage api call
UpdatePollOptionResponse
Model response for StreamChatClient.updatePollOption api call
UpdatePollResponse
Model response for StreamChatClient.updatePoll api call
UpdateReminderResponse
Model response for StreamChatClient.updateReminder api call
UpdateThreadResponse
Model response for StreamChatClient.updateThread api call
UpdateUsersResponse
Model response for StreamChatClient.updateUser api call
UploadState
Union class to hold various UploadState of a attachment.
UpsertPushPreferencesResponse
Model response for StreamChatClient.setPushPreferences api call
User
Class that defines a Stream Chat User.
UserBlock
Contains information about a User blocked from a Channel or App.
UserBlockResponse
Contains information about a User that was banned from a Channel or App.
Uuid
uuid for Dart Author: Yulian Kuncheff Released under MIT License.
UuidValue
ValueResult<T>
A result representing a returned value.

Enums

AITypingState
The current typing state of the AI assistant.
ChatErrorCode
Complete list of errors that are returned by the API together with the description and API code.
ConnectionStatus
Used to notify the WS connection status
DioExceptionType
The exception enumeration indicates what type of exception has happened during requests.
GiphyInfoType
The different types of quality for a Giphy attachment.
InterceptStep
Step where we're logging
MemberUpdateType
Type of member update to unset.
Namespace
RFC4122 & RFC9562 provided namespaces for v3, v5, and v8 namespace based UUIDs
NullOrdering
Defines how null values should be ordered in a sort operation.
PlatformType
Possible platforms
PushProvider
Provider used to send push notifications.
ValidationMode
The options for UUID Validation strictness
VotingVisibility
Represents the visibility of the voting process.

Extension Types

AttachmentType
A type of attachment that determines how the attachment is displayed and handled by the system.
BannedUserSortKey
Extension type representing sortable fields for BannedUser.
CallLevel
Call level push preference type
ChannelCapability
Represents various capabilities that a user can have in a channel.
ChannelSortKey
Extension type representing sortable fields for ChannelState.
ChatLevel
Chat level push preference type
DraftSortKey
Extension type representing sortable fields for Draft.
MemberSortKey
Extension type representing sortable fields for Member.
MessageReminderSortKey
Extension type representing sortable fields for MessageReminder.
MessageSortKey
Extension type representing sortable fields for Message.
MessageType
A type of the message that determines how the message is displayed and handled by the system.
ModerationAction
The moderation action performed over the message.
PollSortKey
Extension type representing sortable fields for Poll.
PollVoteSortKey
Extension type representing sortable fields for PollVote.
ThreadSortKey
Extension type representing sortable fields for Thread.
UserSortKey
Extension type representing sortable fields for User.

Extensions

AttachmentTypeHelper on Attachment
BackOffExtension on FutureOr<T> Function()
Useful rate limiter extensions for Function class.
ChannelCapabilityCheck on Channel
Extension methods for checking channel capabilities on a Channel instance.
ChatErrorCodeX on ChatErrorCode
ChunkedStreamReaderByteStreamExt on ChunkedStreamReader<int>
Extensions for using ChunkedStreamReader with byte-streams.
CompositeComparator on SortOrder<T>
Extension that allows a SortOrder to be used as a comparator function.
DraftMessageToMessage on DraftMessage
Extension on DraftMessage to convert it to a Message.
GiphyInfoX on Attachment
GiphyInfo extension on Attachment class.
IterableMergeExtension on Iterable<T>
Extension providing merge functionality for any iterable.
IterableX on Iterable<T?>
Useful extension functions for Iterable
MapX on Map<K?, V?>
Useful extension functions for Map
MessageModerationHelper on Message
Extension that adds moderation functionality to Message objects.
MessageReactionHelper on Message
Extension that adds reaction manipulation functionality to Message objects.
MessageStateX on MessageState
Helper extension for MessageState.
MessageToDraftMessage on Message
Extension on Message to convert it to a DraftMessage.
MessageTypeHelper on Message
Extension that adds message type functionality to Message objects.
MessageVisibility on Message
Extension that adds visibility control functionality to Message objects.
PollVotingModeX on Poll
A mixin on Poll to determine the voting mode.
PollX on Poll
Helper extension for Poll model.
RateLimit on Function
Useful rate limiter extensions for Function class.
SafeCastExtension on Object?
Extension on Object providing safe casting functionality.
StreamControllerX on StreamController<T>
Extension on StreamController to safely add events and errors.
StreamExtensions on Stream<T>
Utility extensions on Stream.
StreamSinkExtensions on StreamSink<T>
Extensions on StreamSink to make stream transformations more fluent.
StringX on String
Useful extension functions for String

Constants

incomingTypingStartEventTimeout → const int
The maximum time the incoming Event.typingStart event is valid before a Event.typingStop event is emitted automatically.

Functions

backOff<T>(FutureOr<T> func(), {Duration delayFactor = const Duration(milliseconds: 200), double randomizationFactor = 0.25, Duration maxDelay = const Duration(seconds: 30), int maxAttempts = 8, FutureOr<bool> retryIf(Object error, int attempt)?}) Future<T>
TopLevel lambda to apply BackOff to functions.
chatErrorCodeFromCode(int code) ChatErrorCode?
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.
debounce(Function func, Duration wait, {bool leading = false, bool trailing = true, Duration? maxWait}) Debounce
TopLevel lambda to create Debounce functions.
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.
throttle(Function func, Duration wait, {bool leading = true, bool trailing = true}) Throttle
TopLevel lambda to create Throttle functions.
typedStreamTransformer<S, T>(StreamTransformer transformer) StreamTransformer<S, T>
Creates a wrapper that coerces the type of transformer.

Typedefs

AttachmentFileUploaderProvider = AttachmentFileUploader Function(StreamHttpClient httpClient)
Signature for a function which provides instance of AttachmentFileUploader
LogHandlerFunction = void Function(LogRecord record)
Handler function used for logging records. Function requires a single LogRecord as the only parameter.
LogPrint = void Function(InterceptStep step, Object object)
Function used to print the log
ProgressCallback = void Function(int count, int total)
The type of a progress listening callback when sending or receiving data.
SendImageResponse = SendAttachmentResponse
Model response for Channel.sendImage api call
SortOrder<T extends ComparableFieldProvider> = List<SortOption<T>>
A list of SortOptions that define a sorting order for elements of type T

Exceptions / Errors

DioException
DioException describes the exception info when a request failed.
StreamChatError
StreamChatNetworkError
StreamWebSocketError