Options
All
  • Public
  • Public/Protected
  • All
Menu

@nestjs/microservices

Index

Enumerations

Classes

Interfaces

Type aliases

Variables

Functions

Object literals

Type aliases

Admin

Admin: { events: AdminEvents; alterConfigs: any; connect: any; createPartitions: any; createTopics: any; deleteGroups: any; deleteTopics: any; describeCluster: any; describeConfigs: any; describeGroups: any; disconnect: any; fetchOffsets: any; fetchTopicMetadata: any; fetchTopicOffsets: any; fetchTopicOffsetsByTimestamp: any; listGroups: any; listTopics: any; logger: any; on: any; resetOffsets: any; setOffsets: any }

Type declaration

events

events: AdminEvents

alterConfigs

  • alterConfigs(configs: { resources: IResourceConfig[]; validateOnly: boolean }): Promise<any>

connect

  • connect(): Promise<void>

createTopics

  • createTopics(options: { timeout?: number; topics: ITopicConfig[]; validateOnly?: boolean; waitForLeaders?: boolean }): Promise<boolean>
  • Parameters

    • options: { timeout?: number; topics: ITopicConfig[]; validateOnly?: boolean; waitForLeaders?: boolean }
      • Optional timeout?: number
      • topics: ITopicConfig[]
      • Optional validateOnly?: boolean
      • Optional waitForLeaders?: boolean

    Returns Promise<boolean>

deleteTopics

  • deleteTopics(options: { timeout?: number; topics: string[] }): Promise<void>

describeConfigs

  • describeConfigs(configs: { includeSynonyms: boolean; resources: ResourceConfigQuery[] }): Promise<DescribeConfigResponse>

disconnect

  • disconnect(): Promise<void>

fetchOffsets

  • fetchOffsets(options: { groupId: string; topic: string }): Promise<Array<{ metadata: string | null; offset: string; partition: number }>>

fetchTopicMetadata

  • fetchTopicMetadata(options: { topics: string[] }): Promise<{ topics: Array<ITopicMetadata> }>

fetchTopicOffsets

  • fetchTopicOffsets(topic: string): Promise<Array<{ high: string; low: string; offset: string; partition: number }>>

logger

on

  • on(eventName: ValueOf<AdminEvents>, listener: (...args: any[]) => void): void

resetOffsets

  • resetOffsets(options: { earliest: boolean; groupId: string; topic: string }): Promise<void>

setOffsets

  • setOffsets(options: { groupId: string; partitions: SeekEntry[]; topic: string }): Promise<void>

AdminEvents

AdminEvents: { CONNECT: "admin.connect"; DISCONNECT: "admin.disconnect"; REQUEST: "admin.network.request"; REQUEST_QUEUE_SIZE: "admin.network.request_queue_size"; REQUEST_TIMEOUT: "admin.network.request_timeout" }

Type declaration

  • CONNECT: "admin.connect"
  • DISCONNECT: "admin.disconnect"
  • REQUEST: "admin.network.request"
  • REQUEST_QUEUE_SIZE: "admin.network.request_queue_size"
  • REQUEST_TIMEOUT: "admin.network.request_timeout"

CONNECT

CONNECT: "admin.connect"

DISCONNECT

DISCONNECT: "admin.disconnect"

REQUEST

REQUEST: "admin.network.request"

REQUEST_QUEUE_SIZE

REQUEST_QUEUE_SIZE: "admin.network.request_queue_size"

REQUEST_TIMEOUT

REQUEST_TIMEOUT: "admin.network.request_timeout"

Assigner

Assigner: { name: string; version: number; assign: any; protocol: any }

Type declaration

name

name: string

version

version: number

assign

  • assign(group: { members: GroupMember[]; topics: string[]; userData: Buffer }): Promise<GroupMemberAssignment[]>

protocol

  • protocol(subscription: { topics: string[]; userData: Buffer }): GroupState

Assignment

Assignment: {}

Type declaration

  • [topic: string]: number[]

Batch

Batch: { highWatermark: string; messages: KafkaMessage[]; partition: number; topic: string; firstOffset: any; isEmpty: any; lastOffset: any; offsetLag: any; offsetLagLow: any }

Type declaration

highWatermark

highWatermark: string

messages

messages: KafkaMessage[]

partition

partition: number

topic

topic: string

firstOffset

  • firstOffset(): string | null

isEmpty

  • isEmpty(): boolean

lastOffset

  • lastOffset(): string

offsetLag

  • offsetLag(): string

offsetLagLow

  • offsetLagLow(): string

Broker

Broker: { apiVersions: any; connect: any; disconnect: any; fetch: any; isConnected: any; metadata: any; offsetCommit: any }

Type declaration

  • apiVersions: function
    • apiVersions(): Promise<{}>
  • connect: function
    • connect(): Promise<void>
  • disconnect: function
    • disconnect(): Promise<void>
  • fetch: function
    • fetch(request: { isolationLevel?: number; maxBytes?: number; maxWaitTime?: number; minBytes?: number; rackId?: string; replicaId?: number; topics: Array<{ partitions: Array<{ fetchOffset: string; maxBytes: number; partition: number }>; topic: string }> }): Promise<any>
    • Parameters

      • request: { isolationLevel?: number; maxBytes?: number; maxWaitTime?: number; minBytes?: number; rackId?: string; replicaId?: number; topics: Array<{ partitions: Array<{ fetchOffset: string; maxBytes: number; partition: number }>; topic: string }> }
        • Optional isolationLevel?: number
        • Optional maxBytes?: number
        • Optional maxWaitTime?: number
        • Optional minBytes?: number
        • Optional rackId?: string
        • Optional replicaId?: number
        • topics: Array<{ partitions: Array<{ fetchOffset: string; maxBytes: number; partition: number }>; topic: string }>

      Returns Promise<any>

  • isConnected: function
    • isConnected(): boolean
  • metadata: function
    • metadata(topics: string[]): Promise<{ brokers: Array<{ host: string; nodeId: number; port: number; rack?: string }>; topicMetadata: Array<{ partitionMetadata: PartitionMetadata[]; topic: number; topicErrorCode: number }> }>
  • offsetCommit: function
    • offsetCommit(request: { groupGenerationId: number; groupId: string; memberId: string; retentionTime?: number; topics: Array<{ partitions: Array<{ offset: string; partition: number }>; topic: string }> }): Promise<any>
    • Parameters

      • request: { groupGenerationId: number; groupId: string; memberId: string; retentionTime?: number; topics: Array<{ partitions: Array<{ offset: string; partition: number }>; topic: string }> }
        • groupGenerationId: number
        • groupId: string
        • memberId: string
        • Optional retentionTime?: number
        • topics: Array<{ partitions: Array<{ offset: string; partition: number }>; topic: string }>

      Returns Promise<any>

apiVersions

  • apiVersions(): Promise<{}>

connect

  • connect(): Promise<void>

disconnect

  • disconnect(): Promise<void>

isConnected

  • isConnected(): boolean

metadata

  • metadata(topics: string[]): Promise<{ brokers: Array<{ host: string; nodeId: number; port: number }>; topicMetadata: Array<{ partitionMetadata: PartitionMetadata[]; topic: number; topicErrorCode: number }> }>
  • Parameters

    • topics: string[]

    Returns Promise<{ brokers: Array<{ host: string; nodeId: number; port: number }>; topicMetadata: Array<{ partitionMetadata: PartitionMetadata[]; topic: number; topicErrorCode: number }> }>

offsetCommit

  • offsetCommit(request: { groupGenerationId: number; groupId: string; memberId: string; retentionTime?: number; topics: Array<{ partitions: Array<{ offset: string; partition: number }>; topic: string }> }): Promise<any>
  • Parameters

    • request: { groupGenerationId: number; groupId: string; memberId: string; retentionTime?: number; topics: Array<{ partitions: Array<{ offset: string; partition: number }>; topic: string }> }
      • groupGenerationId: number
      • groupId: string
      • memberId: string
      • Optional retentionTime?: number
      • topics: Array<{ partitions: Array<{ offset: string; partition: number }>; topic: string }>

    Returns Promise<any>

BrokersFunction

BrokersFunction: () => string[] | Promise<string[]>

Type declaration

    • (): string[] | Promise<string[]>
    • Returns string[] | Promise<string[]>

CacheTTLFactory

CacheTTLFactory: (ctx: ExecutionContext) => Promise<number> | number

Decorator that sets the cache ttl setting the duration for cache expiration.

For example: @CacheTTL(5)

param

number set the cache expiration time

see

Caching

publicapi

Type declaration

ClientOptions

ClientProviderOptions

ClientProviderOptions: ClientOptions & { name: string | symbol }

ClientsModuleAsyncOptions

ClientsModuleAsyncOptions: Array<ClientsProviderAsyncOptions>

ClientsModuleOptions

ClientsModuleOptions: Array<ClientProviderOptions>

CloseableClient

CloseableClient: Closeable & ClientProxy

Cluster

Cluster: { addTargetTopic: any; connect: any; defaultOffset: any; disconnect: any; fetchTopicsOffset: any; findBroker: any; findControllerBroker: any; findGroupCoordinator: any; findGroupCoordinatorMetadata: any; findLeaderForPartitions: any; findTopicPartitionMetadata: any; isConnected: any; refreshMetadata: any; refreshMetadataIfNecessary: any }

Type declaration

addTargetTopic

  • addTargetTopic(topic: string): Promise<void>

connect

  • connect(): Promise<void>

defaultOffset

  • defaultOffset(config: { fromBeginning: boolean }): number

disconnect

  • disconnect(): Promise<void>

fetchTopicsOffset

  • fetchTopicsOffset(topics: Array<{ fromBeginning: boolean; partitions: Array<{ partition: number }>; topic: string }>): Promise<{ partitions: Array<{ offset: string; partition: number }>; topic: string }>
  • Parameters

    • topics: Array<{ fromBeginning: boolean; partitions: Array<{ partition: number }>; topic: string }>

    Returns Promise<{ partitions: Array<{ offset: string; partition: number }>; topic: string }>

findBroker

  • findBroker(node: { nodeId: string }): Promise<Broker>

findControllerBroker

  • findControllerBroker(): Promise<Broker>

findGroupCoordinator

  • findGroupCoordinator(group: { groupId: string }): Promise<Broker>

findGroupCoordinatorMetadata

  • findGroupCoordinatorMetadata(group: { groupId: string }): Promise<CoordinatorMetadata>

findLeaderForPartitions

  • findLeaderForPartitions(topic: string, partitions: number[]): {}

findTopicPartitionMetadata

  • findTopicPartitionMetadata(topic: string): PartitionMetadata[]

isConnected

  • isConnected(): boolean

refreshMetadata

  • refreshMetadata(): Promise<void>

refreshMetadataIfNecessary

  • refreshMetadataIfNecessary(): Promise<void>

ColorTextFn

ColorTextFn: (text: string) => string

Type declaration

    • (text: string): string
    • Parameters

      • text: string

      Returns string

ConnectEvent

ConnectEvent: InstrumentationEvent<null>

Consumer

Consumer: { events: ConsumerEvents; commitOffsets: any; connect: any; describeGroup: any; disconnect: any; logger: any; on: any; pause: any; paused: any; resume: any; run: any; seek: any; stop: any; subscribe: any }

Type declaration

events

events: ConsumerEvents

commitOffsets

  • commitOffsets(topicPartitions: Array<TopicPartitionOffsetAndMedata>): Promise<void>

connect

  • connect(): Promise<void>

describeGroup

  • describeGroup(): Promise<GroupDescription>

disconnect

  • disconnect(): Promise<void>

logger

on

  • on(eventName: ValueOf<ConsumerEvents>, listener: (...args: any[]) => void): void

pause

  • pause(topics: Array<{ partitions?: number[]; topic: string }>): void

resume

  • resume(topics: Array<{ partitions?: number[]; topic: string }>): void

run

  • run(config?: { autoCommit?: boolean; autoCommitInterval?: number | null; autoCommitThreshold?: number | null; eachBatch?: (payload: EachBatchPayload) => Promise<void>; eachBatchAutoResolve?: boolean; eachMessage?: (payload: EachMessagePayload) => Promise<void>; partitionsConsumedConcurrently?: number }): Promise<void>
  • Parameters

    • Optional config: { autoCommit?: boolean; autoCommitInterval?: number | null; autoCommitThreshold?: number | null; eachBatch?: (payload: EachBatchPayload) => Promise<void>; eachBatchAutoResolve?: boolean; eachMessage?: (payload: EachMessagePayload) => Promise<void>; partitionsConsumedConcurrently?: number }
      • Optional autoCommit?: boolean
      • Optional autoCommitInterval?: number | null
      • Optional autoCommitThreshold?: number | null
      • Optional eachBatch?: (payload: EachBatchPayload) => Promise<void>
          • (payload: EachBatchPayload): Promise<void>
          • Parameters

            • payload: EachBatchPayload

            Returns Promise<void>

      • Optional eachBatchAutoResolve?: boolean
      • Optional eachMessage?: (payload: EachMessagePayload) => Promise<void>
          • (payload: EachMessagePayload): Promise<void>
          • Parameters

            • payload: EachMessagePayload

            Returns Promise<void>

      • Optional partitionsConsumedConcurrently?: number

    Returns Promise<void>

seek

  • seek(topicPartition: { offset: string; partition: number; topic: string }): void

stop

  • stop(): Promise<void>

subscribe

  • subscribe(topic: { fromBeginning?: boolean; topic: string | RegExp }): Promise<void>

ConsumerCommitOffsetsEvent

ConsumerCommitOffsetsEvent: InstrumentationEvent<{ groupGenerationId: number; groupId: string; memberId: string; topics: { partitions: { offset: string; partition: string }[]; topic: string }[] }>

ConsumerCrashEvent

ConsumerCrashEvent: InstrumentationEvent<{ error: Error; groupId: string }>

ConsumerDeserializer

ConsumerDeserializer: Deserializer<any, IncomingRequest | IncomingEvent>

ConsumerEachBatchPayload

ConsumerEachBatchPayload: EachBatchPayload

ConsumerEachMessagePayload

ConsumerEachMessagePayload: EachMessagePayload

ConsumerEndBatchProcessEvent

ConsumerEndBatchProcessEvent: InstrumentationEvent<IBatchProcessEvent & { duration: number }>

ConsumerEvents

ConsumerEvents: { COMMIT_OFFSETS: "consumer.commit_offsets"; CONNECT: "consumer.connect"; CRASH: "consumer.crash"; DISCONNECT: "consumer.disconnect"; END_BATCH_PROCESS: "consumer.end_batch_process"; FETCH: "consumer.fetch"; FETCH_START: "consumer.fetch_start"; GROUP_JOIN: "consumer.group_join"; HEARTBEAT: "consumer.heartbeat"; REQUEST: "consumer.network.request"; REQUEST_QUEUE_SIZE: "consumer.network.request_queue_size"; REQUEST_TIMEOUT: "consumer.network.request_timeout"; START_BATCH_PROCESS: "consumer.start_batch_process"; STOP: "consumer.stop" }

Type declaration

  • COMMIT_OFFSETS: "consumer.commit_offsets"
  • CONNECT: "consumer.connect"
  • CRASH: "consumer.crash"
  • DISCONNECT: "consumer.disconnect"
  • END_BATCH_PROCESS: "consumer.end_batch_process"
  • FETCH: "consumer.fetch"
  • FETCH_START: "consumer.fetch_start"
  • GROUP_JOIN: "consumer.group_join"
  • HEARTBEAT: "consumer.heartbeat"
  • REQUEST: "consumer.network.request"
  • REQUEST_QUEUE_SIZE: "consumer.network.request_queue_size"
  • REQUEST_TIMEOUT: "consumer.network.request_timeout"
  • START_BATCH_PROCESS: "consumer.start_batch_process"
  • STOP: "consumer.stop"

COMMIT_OFFSETS

COMMIT_OFFSETS: "consumer.commit_offsets"

CONNECT

CONNECT: "consumer.connect"

CRASH

CRASH: "consumer.crash"

DISCONNECT

DISCONNECT: "consumer.disconnect"

END_BATCH_PROCESS

END_BATCH_PROCESS: "consumer.end_batch_process"

FETCH

FETCH: "consumer.fetch"

GROUP_JOIN

GROUP_JOIN: "consumer.group_join"

HEARTBEAT

HEARTBEAT: "consumer.heartbeat"

REQUEST

REQUEST: "consumer.network.request"

REQUEST_QUEUE_SIZE

REQUEST_QUEUE_SIZE: "consumer.network.request_queue_size"

REQUEST_TIMEOUT

REQUEST_TIMEOUT: "consumer.network.request_timeout"

START_BATCH_PROCESS

START_BATCH_PROCESS: "consumer.start_batch_process"

STOP

STOP: "consumer.stop"

ConsumerFetchEvent

ConsumerFetchEvent: InstrumentationEvent<{ duration: number; numberOfBatches: number }>

ConsumerGroup

ConsumerGroup: { coordinator: Broker; generationId: number; groupId: string; memberId: string }

Type declaration

  • coordinator: Broker
  • generationId: number
  • groupId: string
  • memberId: string

coordinator

coordinator: Broker

generationId

generationId: number

groupId

groupId: string

memberId

memberId: string

ConsumerGroupJoinEvent

ConsumerGroupJoinEvent: InstrumentationEvent<{ duration: number; groupId: string; groupProtocol: string; isLeader: boolean; leaderId: string; memberAssignment: IMemberAssignment; memberId: string }>

ConsumerHeartbeatEvent

ConsumerHeartbeatEvent: InstrumentationEvent<{ groupGenerationId: number; groupId: string; memberId: string }>

ConsumerRunConfig

ConsumerRunConfig: { autoCommit?: boolean; autoCommitInterval?: number | null; autoCommitThreshold?: number | null; eachBatch?: (payload: EachBatchPayload) => Promise<void>; eachBatchAutoResolve?: boolean; eachMessage?: (payload: EachMessagePayload) => Promise<void>; partitionsConsumedConcurrently?: number }

Type declaration

  • Optional autoCommit?: boolean
  • Optional autoCommitInterval?: number | null
  • Optional autoCommitThreshold?: number | null
  • Optional eachBatch?: (payload: EachBatchPayload) => Promise<void>
  • Optional eachBatchAutoResolve?: boolean
  • Optional eachMessage?: (payload: EachMessagePayload) => Promise<void>
  • Optional partitionsConsumedConcurrently?: number

ConsumerSerializer

ConsumerSerializer: Serializer<OutgoingResponse, any>

ConsumerStartBatchProcessEvent

ConsumerStartBatchProcessEvent: InstrumentationEvent<IBatchProcessEvent>

ConsumerSubscribeTopic

ConsumerSubscribeTopic: { fromBeginning?: boolean; topic: string | RegExp }

Type declaration

  • Optional fromBeginning?: boolean
  • topic: string | RegExp

ContextType

ContextType: "http" | "ws" | "rpc"

Controller

Controller: object

CustomDecorator

CustomDecorator<TKey>: MethodDecorator & ClassDecorator & { KEY: TKey }

Type parameters

  • TKey = string

CustomOrigin

CustomOrigin: (requestOrigin: string, callback: (err: Error | null, allow?: boolean) => void) => void

Set origin to a function implementing some custom logic. The function takes the request origin as the first parameter and a callback (which expects the signature err [object], allow [bool]) as the second.

see

https://github.com/expressjs/cors

publicapi

Type declaration

    • (requestOrigin: string, callback: (err: Error | null, allow?: boolean) => void): void
    • Parameters

      • requestOrigin: string
      • callback: (err: Error | null, allow?: boolean) => void
          • (err: Error | null, allow?: boolean): void
          • Parameters

            • err: Error | null
            • Optional allow: boolean

            Returns void

      Returns void

CustomParamFactory

CustomParamFactory<TData, TInput, TOutput>: (data: TData, input: TInput) => TOutput

Type parameters

  • TData = any

  • TInput = any

  • TOutput = any

Type declaration

    • (data: TData, input: TInput): TOutput
    • Parameters

      • data: TData
      • input: TInput

      Returns TOutput

DefaultPartitioner

DefaultPartitioner: (args: PartitionerArgs) => number

Type declaration

    • (args: PartitionerArgs): number
    • Parameters

      • args: PartitionerArgs

      Returns number

DeleteGroupsResult

DeleteGroupsResult: { errorCode?: number; groupId: string }

Type declaration

  • Optional errorCode?: number
  • groupId: string

DisconnectEvent

DisconnectEvent: InstrumentationEvent<null>

ErrorHandler

ErrorHandler<TRequest, TResponse>: (error: any, req: TRequest, res: TResponse, next?: Function) => any

Type parameters

  • TRequest = any

  • TResponse = any

Type declaration

    • (error: any, req: TRequest, res: TResponse, next?: Function): any
    • Parameters

      • error: any
      • req: TRequest
      • res: TResponse
      • Optional next: Function

      Returns any

ErrorHttpStatusCode

GroupDescription

GroupDescription: { groupId: string; members: MemberDescription[]; protocol: string; protocolType: string; state: string }

Type declaration

  • groupId: string
  • members: MemberDescription[]
  • protocol: string
  • protocolType: string
  • state: string

groupId

groupId: string

members

members: MemberDescription[]

protocol

protocol: string

protocolType

protocolType: string

state

state: string

GroupDescriptions

GroupDescriptions: { groups: GroupDescription[] }

Type declaration

GroupMember

GroupMember: { memberId: string; memberMetadata: Buffer }

Type declaration

  • memberId: string
  • memberMetadata: Buffer

memberId

memberId: string

memberMetadata

memberMetadata: MemberMetadata

GroupMemberAssignment

GroupMemberAssignment: { memberAssignment: Buffer; memberId: string }

Type declaration

  • memberAssignment: Buffer
  • memberId: string

memberAssignment

memberAssignment: Buffer

memberId

memberId: string

GroupOverview

GroupOverview: { groupId: string; protocolType: string }

Type declaration

  • groupId: string
  • protocolType: string

GroupState

GroupState: { metadata: Buffer; name: string }

Type declaration

  • metadata: Buffer
  • name: string

metadata

metadata: Buffer

name

name: string

HandleResponseFn

HandleSseResponseFn

HandleSseResponseFn: <TResult, TResponse, TRequest>(result: TResult, res: TResponse, req: TRequest) => any

Type declaration

    • <TResult, TResponse, TRequest>(result: TResult, res: TResponse, req: TRequest): any
    • Type parameters

      • TResult: Observable<unknown> = any

      • TResponse: HeaderStream = any

      • TRequest: IncomingMessage = any

      Parameters

      • result: TResult
      • res: TResponse
      • req: TRequest

      Returns any

HandlerResponseBasicFn

HandlerResponseBasicFn: <TResult, TResponse>(result: TResult, res: TResponse, req?: any) => any

Type declaration

    • <TResult, TResponse>(result: TResult, res: TResponse, req?: any): any
    • Type parameters

      • TResult

      • TResponse

      Parameters

      • result: TResult
      • res: TResponse
      • Optional req: any

      Returns any

HeaderStream

HeaderStream: WritableStream & WriteHeaders

HostCollection

HostCollection: "providers" | "controllers" | "injectables"

HttpModuleOptions

HttpModuleOptions: AxiosRequestConfig

ICustomPartitioner

ICustomPartitioner: () => (args: PartitionerArgs) => number

Type declaration

    • (): (args: PartitionerArgs) => number
    • Returns (args: PartitionerArgs) => number

        • (args: PartitionerArgs): number
        • Parameters

          • args: PartitionerArgs

          Returns number

ISocketFactory

ISocketFactory: (host: string, port: number, ssl: ConnectionOptions, onConnect: () => void) => Socket

Type declaration

    • (host: string, port: number, ssl: ConnectionOptions, onConnect: () => void): Socket
    • Parameters

      • host: string
      • port: number
      • ssl: ConnectionOptions
      • onConnect: () => void
          • (): void
          • Returns void

      Returns Socket

IncomingEvent

IncomingEvent: ReadPacket

IncomingRequest

IncomingRequest: ReadPacket & PacketId

IncomingResponse

IncomingResponse: WritePacket & PacketId

Injectable

Injectable: unknown

InjectableOptions

InjectableOptions: ScopeOptions

Defines the injection scope.

see

Injection Scopes

publicapi

InjectorDependency

InjectorDependency: Type<any> | Function | string | symbol

The type of an injectable dependency

InstanceToken

InstanceToken: string | symbol | Type<any> | Abstract<any> | Function

JavaCompatiblePartitioner

JavaCompatiblePartitioner: (args: PartitionerArgs) => number

Type declaration

    • (args: PartitionerArgs): number
    • Parameters

      • args: PartitionerArgs

      Returns number

KafkaContextArgs

KafkaContextArgs: [KafkaMessage, number, string]

KafkaMessage

KafkaMessage: { attributes: number; headers?: IHeaders; key: Buffer; offset: string; size: number; timestamp: string; value: Buffer | null }

Type declaration

  • attributes: number
  • Optional headers?: IHeaders
  • key: Buffer
  • offset: string
  • size: number
  • timestamp: string
  • value: Buffer | null

attributes

attributes: number

Optional headers

headers: IHeaders

key

key: Buffer

offset

offset: string

size

size: number

timestamp

timestamp: string

value

value: Buffer

LogLevel

LogLevel: "log" | "error" | "warn" | "debug" | "verbose"

Logger

Logger: (entry: LogEntry) => void

Type declaration

    • (entry: LogEntry): void
    • Parameters

      • entry: LogEntry

      Returns void

MemberAssignment

MemberAssignment: { assignment: Assignment; userData: Buffer; version: number }

Type declaration

  • assignment: Assignment
  • userData: Buffer
  • version: number

assignment

assignment: Assignment

userData

userData: Buffer

version

version: number

MemberDescription

MemberDescription: { clientHost: string; clientId: string; memberAssignment: Buffer; memberId: string; memberMetadata: Buffer }

Type declaration

  • clientHost: string
  • clientId: string
  • memberAssignment: Buffer
  • memberId: string
  • memberMetadata: Buffer

clientHost

clientHost: string

clientId

clientId: string

memberAssignment

memberAssignment: Buffer

memberId

memberId: string

memberMetadata

memberMetadata: Buffer

MemberMetadata

MemberMetadata: { topics: string[]; userData: Buffer; version: number }

Type declaration

  • topics: string[]
  • userData: Buffer
  • version: number

topics

topics: string[]

userData

userData: Buffer

version

version: number

MicroserviceOptions

MqttContextArgs

MqttContextArgs: [string, Record<string, any>]

MsFundamentalPattern

MsFundamentalPattern: string | number

MsPattern

NatsContextArgs

NatsContextArgs: [string]

OutgoingEvent

OutgoingEvent: ReadPacket

OutgoingRequest

OutgoingRequest: ReadPacket & PacketId

OutgoingResponse

OutgoingResponse: WritePacket & PacketId

ParamData

ParamData: object | string | number

ParamDecoratorEnhancer

ParamDecoratorEnhancer: ParameterDecorator

ParamPropertiesWithMetatype

ParamPropertiesWithMetatype<T>: ParamProperties & { metatype?: T }

Type parameters

  • T = any

ParamsMetadata

ParamsMetadata: Record<number, ParamMetadata>

Paramtype

Paramtype: "body" | "query" | "param" | "custom"

PartitionAssigner

PartitionAssigner: (config: { cluster: Cluster }) => Assigner

Type declaration

constructor

  • new PartitionAssigner(config: { cluster: Cluster }): Assigner

PartitionMetadata

PartitionMetadata: { isr: number[]; leader: number; offlineReplicas?: number[]; partitionErrorCode: number; partitionId: number; replicas: number[] }

Type declaration

  • isr: number[]
  • leader: number
  • Optional offlineReplicas?: number[]
  • partitionErrorCode: number
  • partitionId: number
  • replicas: number[]

isr

isr: number[]

leader

leader: number

partitionErrorCode

partitionErrorCode: number

partitionId

partitionId: number

replicas

replicas: number[]

Producer

Producer: Sender & { events: ProducerEvents; connect: any; disconnect: any; isIdempotent: any; logger: any; on: any; transaction: any }

ProducerDeserializer

ProducerDeserializer: Deserializer<any, IncomingResponse>

ProducerEvents

ProducerEvents: { CONNECT: "producer.connect"; DISCONNECT: "producer.disconnect"; REQUEST: "producer.network.request"; REQUEST_QUEUE_SIZE: "producer.network.request_queue_size"; REQUEST_TIMEOUT: "producer.network.request_timeout" }

Type declaration

  • CONNECT: "producer.connect"
  • DISCONNECT: "producer.disconnect"
  • REQUEST: "producer.network.request"
  • REQUEST_QUEUE_SIZE: "producer.network.request_queue_size"
  • REQUEST_TIMEOUT: "producer.network.request_timeout"

CONNECT

CONNECT: "producer.connect"

DISCONNECT

DISCONNECT: "producer.disconnect"

REQUEST

REQUEST: "producer.network.request"

REQUEST_QUEUE_SIZE

REQUEST_QUEUE_SIZE: "producer.network.request_queue_size"

REQUEST_TIMEOUT

REQUEST_TIMEOUT: "producer.network.request_timeout"

ProducerSerializer

ProducerSerializer: Serializer<OutgoingEvent | OutgoingRequest, any>

Provider

Provider<T>: Type<any> | ClassProvider<T> | ValueProvider<T> | FactoryProvider<T> | ExistingProvider<T>
publicapi

Type parameters

  • T = any

QoS

QoS: 0 | 1 | 2

RecordMetadata

RecordMetadata: { errorCode: number; offset: string; partition: number; timestamp: string; topicName: string }

Type declaration

  • errorCode: number
  • offset: string
  • partition: number
  • timestamp: string
  • topicName: string

errorCode

errorCode: number

offset

offset: string

partition

partition: number

timestamp

timestamp: string

topicName

topicName: string

RedisContextArgs

RedisContextArgs: [string]

RemoveInstrumentationEventListener

RemoveInstrumentationEventListener<T>: () => void

Type parameters

  • T

Type declaration

    • (): void
    • Returns void

RequestEvent

RequestEvent: InstrumentationEvent<{ apiKey: number; apiName: string; apiVersion: number; broker: string; clientId: string; correlationId: number; createdAt: number; duration: number; pendingDuration: number; sentAt: number; size: number }>

RequestHandler

RequestHandler<TRequest, TResponse>: (req: TRequest, res: TResponse, next?: Function) => any

Type parameters

  • TRequest = any

  • TResponse = any

Type declaration

    • (req: TRequest, res: TResponse, next?: Function): any
    • Parameters

      • req: TRequest
      • res: TResponse
      • Optional next: Function

      Returns any

RequestQueueSizeEvent

RequestQueueSizeEvent: InstrumentationEvent<{ broker: string; clientId: string; queueSize: number }>

RequestTimeoutEvent

RequestTimeoutEvent: InstrumentationEvent<{ apiKey: number; apiName: string; apiVersion: number; broker: string; clientId: string; correlationId: number; createdAt: number; pendingDuration: number; sentAt: number }>

RmqContextArgs

RmqContextArgs: [Record<string, any>, any, string]

RouterProxyCallback

RouterProxyCallback: <TRequest, TResponse>(req?: TRequest, res?: TResponse, next?: () => void) => void

Type declaration

    • <TRequest, TResponse>(req?: TRequest, res?: TResponse, next?: () => void): void
    • Type parameters

      • TRequest

      • TResponse

      Parameters

      • Optional req: TRequest
      • Optional res: TResponse
      • Optional next: () => void
          • (): void
          • Returns void

      Returns void

RpcParamProperties

RpcParamProperties: ParamProperties & { metatype?: any }

SASLMechanism

SASLMechanism: "plain" | "scram-sha-256" | "scram-sha-512" | "aws"

Sender

Sender: { send: any; sendBatch: any }

Type declaration

send

  • send(record: ProducerRecord): Promise<RecordMetadata[]>

sendBatch

  • sendBatch(batch: ProducerBatch): Promise<RecordMetadata[]>

TcpContextArgs

TcpContextArgs: [JsonSocket, string]

TopicPartitionOffsetAndMedata

TopicPartitionOffsetAndMedata: TopicPartitionOffsetAndMetadata

Optional metadata

metadata: string | null

offset

offset: string

partition

partition: number

topic

topic: string

TopicPartitionOffsetAndMetadata

TopicPartitionOffsetAndMetadata: { metadata?: string | null; offset: string; partition: number; topic: string }

Type declaration

  • Optional metadata?: string | null
  • offset: string
  • partition: number
  • topic: string

TopicPartitions

TopicPartitions: { partitions: number[]; topic: string }

Type declaration

  • partitions: number[]
  • topic: string

partitions

partitions: number[]

topic

topic: string

Transaction

Transaction: Sender & { abort: any; commit: any; isActive: any; sendOffsets: any }

Transform

Transform<T>: (value: T, metadata: ArgumentMetadata) => any

Type parameters

  • T = any

Type declaration

ValueOf

ValueOf<T, T>: T[keyof T]

Type parameters

  • T

  • T

Without

Without<T, U>: {}

Type parameters

  • T

  • U

Type declaration

XOR

XOR<T, U>: (T | U) extends object ? (Without<T, U> & U) | (Without<U, T> & T) : T | U

Type parameters

  • T

  • U

logCreator

logCreator: (logLevel: string) => (entry: LogEntry) => void

Type declaration

    • (logLevel: string): (entry: LogEntry) => void
    • Parameters

      • logLevel: string

      Returns (entry: LogEntry) => void

        • (entry: LogEntry): void
        • Parameters

          • entry: LogEntry

          Returns void

Variables

$

$: L = L

Const $u

$u: (Anonymous function) = Ou()

Const APP_FILTER

APP_FILTER: "APP_FILTER" = "APP_FILTER"

Const APP_GUARD

APP_GUARD: "APP_GUARD" = "APP_GUARD"

Const APP_INTERCEPTOR

APP_INTERCEPTOR: "APP_INTERCEPTOR" = "APP_INTERCEPTOR"

Const APP_PIPE

APP_PIPE: "APP_PIPE" = "APP_PIPE"

Const AXIOS_INSTANCE_TOKEN

AXIOS_INSTANCE_TOKEN: "AXIOS_INSTANCE_TOKEN" = "AXIOS_INSTANCE_TOKEN"

Const All

All: (Anonymous function) = createMappingDecorator(RequestMethod.ALL)

Route handler (method) Decorator. Routes all HTTP requests to the specified path.

see

Routing

publicapi

Let AssignerProtocol

AssignerProtocol: { MemberAssignment: ISerializer<MemberAssignment>; MemberMetadata: ISerializer<MemberMetadata> }

Type declaration

  • MemberAssignment: ISerializer<MemberAssignment>
  • MemberMetadata: ISerializer<MemberMetadata>

Axios

  • Axios(instanceConfig: any): void
  • Create a new instance of Axios

    Parameters

    • instanceConfig: any

      The default config for the instance

    Returns void

Let B

B: boolean = !1

Const BUFFER

BUFFER: unique symbol = Symbol('buffer')

Const Benchmark

Benchmark: any = require('benchmark')

Bu

Bu: (Anonymous function)

C

C: boolean = "undefined"!=typeof window

Const CACHE_KEY_METADATA

CACHE_KEY_METADATA: "cache_module:cache_key" = "cache_module:cache_key"

Const CACHE_MANAGER

CACHE_MANAGER: "CACHE_MANAGER" = "CACHE_MANAGER"

Const CACHE_MODULE_OPTIONS

CACHE_MODULE_OPTIONS: "CACHE_MODULE_OPTIONS" = "CACHE_MODULE_OPTIONS"

Const CACHE_TTL_METADATA

CACHE_TTL_METADATA: "cache_module:cache_ttl" = "cache_module:cache_ttl"

Const CANCEL_EVENT

CANCEL_EVENT: "cancelled" = "cancelled"

Const CLASS_SERIALIZER_OPTIONS

CLASS_SERIALIZER_OPTIONS: "class_serializer:options" = "class_serializer:options"

Const CLIENT_CONFIGURATION_METADATA

CLIENT_CONFIGURATION_METADATA: "microservices:client" = "microservices:client"

Const CLIENT_METADATA

CLIENT_METADATA: "microservices:is_client_instance" = "microservices:is_client_instance"

Const CLOSE_EVENT

CLOSE_EVENT: "close" = "close"

Const CONNECT_EVENT

CONNECT_EVENT: "connect" = "connect"

Const CONN_ERR

CONN_ERR: "CONN_ERR" = "CONN_ERR"

Const CONTEXT

CONTEXT: "REQUEST" = REQUEST

Const CONTROLLER_ID_KEY

CONTROLLER_ID_KEY: "CONTROLLER_ID" = "CONTROLLER_ID"

Const CUSTOM_ROUTE_AGRS_METADATA

CUSTOM_ROUTE_AGRS_METADATA: "__customRouteArgs__" = "__customRouteArgs__"

CacheModule_1

CacheModule_1: any

Let CompressionCodecs

CompressionCodecs: { [CompressionTypes.GZIP]: () => any; [CompressionTypes.LZ4]: () => any; [CompressionTypes.Snappy]: () => any; [CompressionTypes.ZSTD]: () => any }

Type declaration

  • [CompressionTypes.GZIP]: () => any
      • (): any
      • Returns any

  • [CompressionTypes.LZ4]: () => any
      • (): any
      • Returns any

  • [CompressionTypes.Snappy]: () => any
      • (): any
      • Returns any

  • [CompressionTypes.ZSTD]: () => any
      • (): any
      • Returns any

Const Ctx

Ctx: () => ParameterDecorator = createRpcParamDecorator(RpcParamtype.CONTEXT,)

Type declaration

    • (): ParameterDecorator
    • Returns ParameterDecorator

Const Cu

Cu: Map<string, string> = new Map([["n","\n"],["r","\r"],["t","\t"],["b","\b"],["f","\f"],["v","\v"],["0","\0"],["\\","\\"],["e",""],["a",""]])

D

D: any = u(require("util"))

Const DATA_EVENT

DATA_EVENT: "data" = "data"

Const DEFAULT_ARRAY_SEPARATOR

DEFAULT_ARRAY_SEPARATOR: "," = ","

DEFAULT_DELIMITER

DEFAULT_DELIMITER: string = "/"

Default configs.

Const DISCONNECTED_RMQ_MESSAGE

DISCONNECTED_RMQ_MESSAGE: "Disconnected from RMQ. Trying to reconnect." = `Disconnected from RMQ. Trying to reconnect.`

Const DISCONNECT_EVENT

DISCONNECT_EVENT: "disconnect" = "disconnect"

Const DNS

DNS: "6ba7b810-9dad-11d1-80b4-00c04fd430c8" = "6ba7b810-9dad-11d1-80b4-00c04fd430c8"

Const Delete

Delete: (Anonymous function) = createMappingDecorator(RequestMethod.DELETE)

Route handler (method) Decorator. Routes HTTP DELETE requests to the specified path.

see

Routing

publicapi

Let DiscoveryModule

DiscoveryModule: DiscoveryModule = class DiscoveryModule {}
publicapi

Let DiscoveryService

DiscoveryService: DiscoveryService = class DiscoveryService {constructor(modulesContainer) {this.modulesContainer = modulesContainer;}getProviders(options = {}, modules = this.getModules(options)) {const providers = modules.map(item => [...item.providers.values()]);return common_1.flatten(providers);}getControllers(options = {}, modules = this.getModules(options)) {const controllers = modules.map(item => [...item.controllers.values()]);return common_1.flatten(controllers);}getModules(options = {}) {if (!options.include) {const moduleRefs = [...this.modulesContainer.values()];return moduleRefs;}const whitelisted = this.includeWhitelisted(options.include);return whitelisted;}includeWhitelisted(include) {const moduleRefs = [...this.modulesContainer.values()];return moduleRefs.filter(({ metatype }) => include.some(item => item === metatype));}}
publicapi

Du

Du: uu = uu

E

E: boolean = !1

Const ECONNREFUSED

ECONNREFUSED: "ECONNREFUSED" = "ECONNREFUSED"

Const ERROR_EVENT

ERROR_EVENT: "error" = "error"

Const ESCAPES

ESCAPES: Map<string, string> = new Map([['n', '\n'],['r', '\r'],['t', '\t'],['b', '\b'],['f', '\f'],['v', '\v'],['0', '\0'],['\\', '\\'],['e', '\u001B'],['a', '\u0007']])

Const ESCAPE_REGEX

ESCAPE_REGEX: RegExp = /\\(u(?:[a-f\d]{4}|{[a-f\d]{1,6}})|x[a-f\d]{2}|.)|([^\\])/gi

Const EXCEPTION_FILTERS_METADATA

EXCEPTION_FILTERS_METADATA: "__exceptionFilters__" = "__exceptionFilters__"

F

F: string = "development"

FETCH_TIMEOUT

FETCH_TIMEOUT: number = 3000

Const FILTER_CATCH_EXCEPTIONS

FILTER_CATCH_EXCEPTIONS: "__filterCatchExceptions__" = "__filterCatchExceptions__"

Const FORBIDDEN_MESSAGE

FORBIDDEN_MESSAGE: "Forbidden resource" = "Forbidden resource"

Const FORMAT_ARGS

FORMAT_ARGS: (string | number)[][] = [['additional', 5],['message', 4],['type', 2],['date', 1],['tag', 3]]

Const Fu

Fu: RegExp = /\\(u(?:[a-f\d]{4}|{[a-f\d]{1,6}})|x[a-f\d]{2}|.)|([^\\])/gi

Const GLOBAL_MODULE_METADATA

GLOBAL_MODULE_METADATA: "__module:global__" = "__module:global__"

Const GRPC_CANCELLED

GRPC_CANCELLED: "Cancelled" = "Cancelled"

Const GRPC_DEFAULT_MAX_RECEIVE_MESSAGE_LENGTH

GRPC_DEFAULT_MAX_RECEIVE_MESSAGE_LENGTH: number = 4 * 1024 * 1024

Const GRPC_DEFAULT_MAX_SEND_MESSAGE_LENGTH

GRPC_DEFAULT_MAX_SEND_MESSAGE_LENGTH: number = 4 * 1024 * 1024

Const GRPC_DEFAULT_PROTO_LOADER

GRPC_DEFAULT_PROTO_LOADER: "@grpc/proto-loader" = "@grpc/proto-loader"

Const GRPC_DEFAULT_URL

GRPC_DEFAULT_URL: "localhost:5000" = "localhost:5000"

Const GUARDS_METADATA

GUARDS_METADATA: "__guards__" = "__guards__"

Const Get

Get: (Anonymous function) = createMappingDecorator(RequestMethod.GET)

Route handler (method) Decorator. Routes HTTP GET requests to the specified path.

see

Routing

publicapi

Const Gu

Gu: any = "undefined"!=typeof __non_webpack_require__?__non_webpack_require__:require

H

H: (Anonymous function) & { arrowDown: string; arrowLeft: string; arrowRight: string; arrowUp: string; bullet: string; checkboxCircleOff: string; checkboxCircleOn: string; checkboxOff: string; checkboxOn: string; circle: string; circleCircle: string; circleCross: string; circleDotted: string; circleDouble: string; circleFilled: string; circlePipe: string; circleQuestionMark: string; cross: string; dot: string; ellipsis: string; fiveEighths: string; fiveSixths: string; fourFifths: string; hamburger: string; heart: string; info: string; line: string; mustache: string; nodejs: string; oneEighth: string; oneFifth: string; oneHalf: string; oneNinth: string; oneQuarter: string; oneSeventh: string; oneSixth: string; oneTenth: string; oneThird: string; play: string; pointer: string; pointerSmall: string; questionMarkPrefix: string; radioOff: string; radioOn: string; sevenEighths: string; smiley: string; square: string; squareSmall: string; squareSmallFilled: string; star: string; threeEighths: string; threeFifths: string; threeQuarters: string; tick: string; twoFifths: string; twoThirds: string; warning: string } = Object.assign(u=>{if(Y===N)return u;for(const[D,e]of Object.entries(N))e!==Y[D]&&(u=u.replace(new RegExp(U(e),"g"),Y[D]));return u},Y)

Const HANDLER_METADATA_SYMBOL

HANDLER_METADATA_SYMBOL: unique symbol = Symbol.for('handler_metadata:cache')

Const HEADERS_METADATA

HEADERS_METADATA: "__headers__" = "__headers__"

Const HOST_METADATA

HOST_METADATA: "host" = "host"

Const HTTP_ADAPTER_HOST

HTTP_ADAPTER_HOST: "HttpAdapterHost" = "HttpAdapterHost"

Const HTTP_CODE_METADATA

HTTP_CODE_METADATA: "__httpCode__" = "__httpCode__"

Const HTTP_MODULE_ID

HTTP_MODULE_ID: "HTTP_MODULE_ID" = "HTTP_MODULE_ID"

Const HTTP_MODULE_OPTIONS

HTTP_MODULE_OPTIONS: "HTTP_MODULE_OPTIONS" = "HTTP_MODULE_OPTIONS"

Const Head

Head: (Anonymous function) = createMappingDecorator(RequestMethod.HEAD)

Route handler (method) Decorator. Routes HTTP HEAD requests to the specified path.

see

Routing

publicapi

Const HeadersIteratorPrototype

HeadersIteratorPrototype: any = Object.setPrototypeOf({next() {// istanbul ignore ifif (!this || Object.getPrototypeOf(this) !== HeadersIteratorPrototype) {throw new TypeError('Value of `this` is not a HeadersIterator');}var _INTERNAL = this[INTERNAL];const target = _INTERNAL.target,kind = _INTERNAL.kind,index = _INTERNAL.index;const values = getHeaders(target, kind);const len = values.length;if (index >= len) {return {value: undefined,done: true};}this[INTERNAL].index = index + 1;return {value: values[index],done: false};}}, Object.getPrototypeOf(Object.getPrototypeOf([][Symbol.iterator]())))

HttpModule_1

HttpModule_1: any

Const INQUIRER

INQUIRER: "INQUIRER" = "INQUIRER"

Const INSTANCE_ID_SYMBOL

INSTANCE_ID_SYMBOL: unique symbol = Symbol.for('instance_metadata:id')

Const INSTANCE_METADATA_SYMBOL

INSTANCE_METADATA_SYMBOL: unique symbol = Symbol.for('instance_metadata:cache')

Const INTERCEPTORS_METADATA

INTERCEPTORS_METADATA: "__interceptors__" = "__interceptors__"

Const INTERNAL

INTERNAL: unique symbol = Symbol('internal')

Const INTERNALS

INTERNALS: unique symbol = Symbol('Body internals')

Const INTERNALS$1

INTERNALS$1: unique symbol = Symbol('Response internals')

Const INTERNALS$2

INTERNALS$2: unique symbol = Symbol('Request internals')

Const INVALID_EXCEPTION_FILTER

INVALID_EXCEPTION_FILTER: "Invalid exception filters (@UseFilters())." = `Invalid exception filters (@UseFilters()).`

Const INVALID_MIDDLEWARE_CONFIGURATION

INVALID_MIDDLEWARE_CONFIGURATION: "An invalid middleware configuration has been passed inside the module 'configure()' method." = `An invalid middleware configuration has been passed inside the module 'configure()' method.`

InterceptorManager

  • InterceptorManager(): void
  • Returns void

InternalCoreModule_1

InternalCoreModule_1: any

Const Ip

Ip: () => ParameterDecorator = createRouteParamDecorator(RouteParamtypes.IP,)

Route handler parameter decorator. Extracts the Ip property from the req object and populates the decorated parameter with the value of ip.

see

Request object

publicapi

Type declaration

    • (): ParameterDecorator
    • Returns ParameterDecorator

J

J: { ansi16: object; ansi256: object; apple: object; cmyk: object; gray: object; hcg: object; hex: object; hsl: object; hsv: object; hwb: object; keyword: object; lab: object; lch: object; rgb: object; xyz: object } = Q

Type declaration

  • ansi16: object
    • channels: number
    • labels: string[]
  • ansi256: object
    • channels: number
    • labels: string[]
  • apple: object
    • channels: number
    • labels: string[]
  • cmyk: object
    • channels: number
    • labels: string
  • gray: object
    • channels: number
    • labels: string[]
  • hcg: object
    • channels: number
    • labels: string[]
  • hex: object
    • channels: number
    • labels: string[]
  • hsl: object
    • channels: number
    • labels: string
  • hsv: object
    • channels: number
    • labels: string
  • hwb: object
    • channels: number
    • labels: string
  • keyword: object
    • channels: number
    • labels: string[]
  • lab: object
    • channels: number
    • labels: string
  • lch: object
    • channels: number
    • labels: string
  • rgb: object
    • channels: number
    • labels: string
  • xyz: object
    • channels: number
    • labels: string

Ju

Ju: any = global.consola

Const KAFKA_DEFAULT_BROKER

KAFKA_DEFAULT_BROKER: "localhost:9092" = "localhost:9092"

Const KAFKA_DEFAULT_CLIENT

KAFKA_DEFAULT_CLIENT: "nestjs-consumer" = "nestjs-consumer"

Const KAFKA_DEFAULT_GROUP

KAFKA_DEFAULT_GROUP: "nestjs-group" = "nestjs-group"

Const LogLevel

LogLevel: LogLevel

Logger_1

Logger_1: any

Const MAP

MAP: unique symbol = Symbol('map')

Const MESSAGE_EVENT

MESSAGE_EVENT: "message" = "message"

Const METHOD_METADATA

METHOD_METADATA: "method" = "method"

Const MICROSERVICES_PACKAGE_NOT_FOUND_EXCEPTION

MICROSERVICES_PACKAGE_NOT_FOUND_EXCEPTION: "Unable to load @nestjs/microservices package. (Please make sure that it's already installed.)" = `Unable to load @nestjs/microservices package. (Please make sure that it's already installed.)`

Const MODULE_PATH

MODULE_PATH: "__module_path__" = "__module_path__"

Const MQTT_DEFAULT_URL

MQTT_DEFAULT_URL: "mqtt://localhost:1883" = "mqtt://localhost:1883"

Const MQTT_SEPARATOR

MQTT_SEPARATOR: "/" = "/"

Const MQTT_WILDCARD_ALL

MQTT_WILDCARD_ALL: "#" = "#"

Const MQTT_WILDCARD_SINGLE

MQTT_WILDCARD_SINGLE: "+" = "+"

MaxBodyLengthExceededError

MaxBodyLengthExceededError: CustomError = createErrorType("ERR_FR_MAX_BODY_LENGTH_EXCEEDED","Request body larger than maxBodyLength limit")

Const Mu

Mu: string[] = ["rgb","hex","keyword","hsl","hsv","hwb","ansi","ansi256"]

Const NATS_DEFAULT_URL

NATS_DEFAULT_URL: "nats://localhost:4222" = "nats://localhost:4222"

Const NO_EVENT_HANDLER

NO_EVENT_HANDLER: "There is no matching event handler defined in the remote service." = `There is no matching event handler defined in the remote service.`

Const NO_MESSAGE_HANDLER

NO_MESSAGE_HANDLER: "There is no matching message handler defined in the remote service." = `There is no matching message handler defined in the remote service.`

Const Next

Next: () => ParameterDecorator = createRouteParamDecorator(RouteParamtypes.NEXT,)

Route handler parameter decorator. Extracts reference to the Next function from the underlying platform and populates the decorated parameter with the value of Next.

publicapi

Type declaration

    • (): ParameterDecorator
    • Returns ParameterDecorator

Const OPTIONAL_DEPS_METADATA

OPTIONAL_DEPS_METADATA: "optional:paramtypes" = "optional:paramtypes"

Const OPTIONAL_PROPERTY_DEPS_METADATA

OPTIONAL_PROPERTY_DEPS_METADATA: "optional:properties_metadata" = "optional:properties_metadata"

Const Options

Options: (Anonymous function) = createMappingDecorator(RequestMethod.OPTIONS)

Route handler (method) Decorator. Routes HTTP OPTIONS requests to the specified path.

see

Routing

publicapi

P

P: Platform

Const PARAMTYPES_METADATA

PARAMTYPES_METADATA: "design:paramtypes" = "design:paramtypes"

Const PARAM_ARGS_METADATA

PARAM_ARGS_METADATA: "__routeArguments__" = ROUTE_ARGS_METADATA

Const PATH_METADATA

PATH_METADATA: "path" = "path"

PATH_REGEXP

PATH_REGEXP: RegExp = new RegExp([// Match escaped characters that would otherwise appear in future matches.// This allows the user to escape special characters that won't transform.'(\\\\.)',// Match Express-style parameters and un-named parameters with a prefix// and optional suffixes. Matches appear as://// ":test(\\d+)?" => ["test", "\d+", undefined, "?"]// "(\\d+)" => [undefined, undefined, "\d+", undefined]'(?:\\:(\\w+)(?:\\(((?:\\\\.|[^\\\\()])+)\\))?|\\(((?:\\\\.|[^\\\\()])+)\\))([+*?])?'].join('|'), 'g')

The main path matching regexp utility.

Const PATTERN_HANDLER_METADATA

PATTERN_HANDLER_METADATA: "microservices:handler_type" = "microservices:handler_type"

Const PATTERN_METADATA

PATTERN_METADATA: "microservices:pattern" = "microservices:pattern"

Const PIPES_METADATA

PIPES_METADATA: "__pipes__" = "__pipes__"

Const PROPERTY_DEPS_METADATA

PROPERTY_DEPS_METADATA: "self:properties_metadata" = "self:properties_metadata"

Let PartitionAssigners

PartitionAssigners: { roundRobin: PartitionAssigner }

Type declaration

  • roundRobin: PartitionAssigner

Let Partitioners

Partitioners: { DefaultPartitioner: DefaultPartitioner; JavaCompatiblePartitioner: JavaCompatiblePartitioner }

Type declaration

Const PassThrough

  • PassThrough(): { buf: string; end: any; read: any; write: any }
  • Returns { buf: string; end: any; read: any; write: any }

    • buf: string
    • end: function
      • end(b: any): void
      • Parameters

        • b: any

        Returns void

    • read: function
      • read(): string
      • Returns string

    • write: function
      • write(b: any): void
      • Parameters

        • b: any

        Returns void

Const PassThrough$1

PassThrough$1: any = Stream.PassThrough

Const Patch

Patch: (Anonymous function) = createMappingDecorator(RequestMethod.PATCH)

Route handler (method) Decorator. Routes HTTP PATCH requests to the specified path.

see

Routing

publicapi

Const Post

Post: (Anonymous function) = createMappingDecorator(RequestMethod.POST)

Route handler (method) Decorator. Routes HTTP POST requests to the specified path.

see

Routing

publicapi

Const Pu

Pu: Pu

Const Put

Put: (Anonymous function) = createMappingDecorator(RequestMethod.PUT)

Route handler (method) Decorator. Routes HTTP PUT requests to the specified path.

see

Routing

publicapi

R

R: k = k

Const RABBITMQ_REPLY_QUEUE

RABBITMQ_REPLY_QUEUE: "amq.rabbitmq.reply-to" = "amq.rabbitmq.reply-to"

Const REDIRECT_METADATA

REDIRECT_METADATA: "__redirect__" = "__redirect__"

Const REDIS_DEFAULT_URL

REDIS_DEFAULT_URL: "redis://localhost:6379" = "redis://localhost:6379"

Const REFLECTOR

REFLECTOR: "Reflector" = "Reflector"

Const RENDER_METADATA

RENDER_METADATA: "__renderTemplate__" = "__renderTemplate__"

Const REPLY_PATTERN_METADATA

REPLY_PATTERN_METADATA: "microservices:reply_pattern" = "microservices:reply_pattern"

Const REPLY_QUEUE

REPLY_QUEUE: "amq.rabbitmq.reply-to" = "amq.rabbitmq.reply-to"

Const REQUEST

REQUEST: "REQUEST" = "REQUEST"

Const REQUEST_CONTEXT_ID

REQUEST_CONTEXT_ID: unique symbol = Symbol('REQUEST_CONTEXT_ID')

Const REQUEST_PATTERN_METADATA

REQUEST_PATTERN_METADATA: "microservices:request_pattern" = "microservices:request_pattern"

Const RESPONSE_PASSTHROUGH_METADATA

RESPONSE_PASSTHROUGH_METADATA: "__responsePassthrough__" = "__responsePassthrough__"

Const ROUTE_ARGS_METADATA

ROUTE_ARGS_METADATA: "__routeArguments__" = "__routeArguments__"

Const RQM_DEFAULT_IS_GLOBAL_PREFETCH_COUNT

RQM_DEFAULT_IS_GLOBAL_PREFETCH_COUNT: false = false

Const RQM_DEFAULT_NOACK

RQM_DEFAULT_NOACK: true = true

Const RQM_DEFAULT_PERSISTENT

RQM_DEFAULT_PERSISTENT: false = false

Const RQM_DEFAULT_PREFETCH_COUNT

RQM_DEFAULT_PREFETCH_COUNT: 0 = 0

Const RQM_DEFAULT_QUEUE

RQM_DEFAULT_QUEUE: "default" = "default"

Const RQM_DEFAULT_QUEUE_OPTIONS

RQM_DEFAULT_QUEUE_OPTIONS: {}

Type declaration

Const RQM_DEFAULT_URL

RQM_DEFAULT_URL: "amqp://localhost" = "amqp://localhost"

Const Readable

Readable: any = Stream.Readable

RedirectionError

RedirectionError: CustomError = createErrorType("ERR_FR_REDIRECTION_FAILURE","")

Const Req

Req: () => ParameterDecorator = Request

Type declaration

    • (): ParameterDecorator
    • Returns ParameterDecorator

Const Res

Res: (options?: ResponseDecoratorOptions) => ParameterDecorator = Response

Type declaration

Const SCOPE_OPTIONS_METADATA

SCOPE_OPTIONS_METADATA: "scope:options" = "scope:options"

Const SELF_DECLARED_DEPS_METADATA

SELF_DECLARED_DEPS_METADATA: "self:paramtypes" = "self:paramtypes"

Const SSE_METADATA

SSE_METADATA: "__sse__" = "__sse__"

Const STATIC_CONTEXT

STATIC_CONTEXT: ContextId = Object.freeze({id: STATIC_CONTEXT_ID,})

Const STATIC_CONTEXT_ID

STATIC_CONTEXT_ID: 1 = 1

Const STATUS_CODES

STATUS_CODES: any = http.STATUS_CODES

Const STRING_REGEX

STRING_REGEX: RegExp = /^(['"])((?:\\.|(?!\1)[^\\])*)\1$/

Const STYLE_REGEX

STYLE_REGEX: RegExp = /(?:^|\.)(\w+)(?:\(([^)]*)\))?/g

Const SUBSCRIBE

SUBSCRIBE: "subscribe" = "subscribe"

Const Session

Session: () => ParameterDecorator = createRouteParamDecorator(RouteParamtypes.SESSION,)

Route handler parameter decorator. Extracts the Session object from the underlying platform and populates the decorated parameter with the value of Session.

see

Request object

publicapi

Type declaration

    • (): ParameterDecorator
    • Returns ParameterDecorator

SocketModule

SocketModule: any

Stream

Stream: any = _interopDefault(require('stream'))

StringDecoder

StringDecoder: StringDecoder = require('string_decoder').StringDecoder

Const Su

Su: any = Object.defineProperties(()=>{},{..._u,level:{enumerable:!0,get(){return this._generator.level},set(u){this._generator.level=u}}})

T

T: k = k

Const TCP_DEFAULT_HOST

TCP_DEFAULT_HOST: "localhost" = "localhost"

Const TCP_DEFAULT_PORT

TCP_DEFAULT_PORT: 3000 = 3000

Const TEMPLATE_REGEX

TEMPLATE_REGEX: RegExp = /(?:\\(u(?:[a-f\d]{4}|\{[a-f\d]{1,6}\})|x[a-f\d]{2}|.))|(?:\{(~)?(\w+(?:\([^)]*\))?(?:\.\w+(?:\([^)]*\))?)*)(?:[ \t]|(?=\r?\n)))|(\})|((?:.|[\r\n\f])+?)/gi

Const TRANSPORT_METADATA

TRANSPORT_METADATA: "microservices:transport" = "microservices:transport"

Const TYPE

TYPE: unique symbol = Symbol('type')

TooManyRedirectsError

TooManyRedirectsError: CustomError = createErrorType("ERR_FR_TOO_MANY_REDIRECTS","Maximum number of redirects exceeded")

Let Tu

Tu: any

Const UNHANDLED_RUNTIME_EXCEPTION

UNHANDLED_RUNTIME_EXCEPTION: "Unhandled Runtime Exception." = `Unhandled Runtime Exception.`

Const UNKNOWN_REQUEST_MAPPING

UNKNOWN_REQUEST_MAPPING: "An invalid controller has been detected. Perhaps, one of your controllers is missing @Controller() decorator." = `An invalid controller has been detected. Perhaps, one of your controllers is missing @Controller() decorator.`

Const URL

URL: "6ba7b811-9dad-11d1-80b4-00c04fd430c8" = "6ba7b811-9dad-11d1-80b4-00c04fd430c8"

Const UploadedFile

UploadedFile: (fileKey?: string) => ParameterDecorator = createRouteParamDecorator(RouteParamtypes.FILE)

Route handler parameter decorator. Extracts the file object and populates the decorated parameter with the value of file. Used in conjunction with multer middleware.

For example:

uploadFile(@UploadedFile() file) {
  console.log(file);
}
see

Request object

publicapi

Type declaration

    • (fileKey?: string): ParameterDecorator
    • Parameters

      • Optional fileKey: string

      Returns ParameterDecorator

Const UploadedFiles

UploadedFiles: () => ParameterDecorator = createRouteParamDecorator(RouteParamtypes.FILES,)

Route handler parameter decorator. Extracts the files object and populates the decorated parameter with the value of files. Used in conjunction with multer middleware.

For example:

uploadFile(@UploadedFiles() files) {
  console.log(files);
}
see

Request object

publicapi

Type declaration

    • (): ParameterDecorator
    • Returns ParameterDecorator

Url

Url: any = _interopDefault(require('url'))

V

V: { arrowDown: string; arrowLeft: string; arrowRight: string; arrowUp: string; bullet: string; checkboxCircleOff: string; checkboxCircleOn: string; checkboxOff: string; checkboxOn: string; circle: string; circleCircle: string; circleCross: string; circleDotted: string; circleDouble: string; circleFilled: string; circlePipe: string; circleQuestionMark: string; cross: string; dot: string; ellipsis: string; fiveEighths: string; fiveSixths: string; fourFifths: string; hamburger: string; heart: string; info: string; line: string; mustache: string; nodejs: string; oneEighth: string; oneFifth: string; oneHalf: string; oneNinth: string; oneQuarter: string; oneSeventh: string; oneSixth: string; oneTenth: string; oneThird: string; play: string; pointer: string; pointerSmall: string; questionMarkPrefix: string; radioOff: string; radioOn: string; sevenEighths: string; smiley: string; square: string; squareSmall: string; squareSmallFilled: string; star: string; threeEighths: string; threeFifths: string; threeQuarters: string; tick: string; twoFifths: string; twoThirds: string; warning: string } = N

Type declaration

  • arrowDown: string
  • arrowLeft: string
  • arrowRight: string
  • arrowUp: string
  • bullet: string
  • checkboxCircleOff: string
  • checkboxCircleOn: string
  • checkboxOff: string
  • checkboxOn: string
  • circle: string
  • circleCircle: string
  • circleCross: string
  • circleDotted: string
  • circleDouble: string
  • circleFilled: string
  • circlePipe: string
  • circleQuestionMark: string
  • cross: string
  • dot: string
  • ellipsis: string
  • fiveEighths: string
  • fiveSixths: string
  • fourFifths: string
  • hamburger: string
  • heart: string
  • info: string
  • line: string
  • mustache: string
  • nodejs: string
  • oneEighth: string
  • oneFifth: string
  • oneHalf: string
  • oneNinth: string
  • oneQuarter: string
  • oneSeventh: string
  • oneSixth: string
  • oneTenth: string
  • oneThird: string
  • play: string
  • pointer: string
  • pointerSmall: string
  • questionMarkPrefix: string
  • radioOff: string
  • radioOn: string
  • sevenEighths: string
  • smiley: string
  • square: string
  • squareSmall: string
  • squareSmallFilled: string
  • star: string
  • threeEighths: string
  • threeFifths: string
  • threeQuarters: string
  • tick: string
  • twoFifths: string
  • twoThirds: string
  • warning: string

Const VALIDATION_ERROR_MESSAGE

VALIDATION_ERROR_MESSAGE: "Validation failed (parsable array expected)" = "Validation failed (parsable array expected)"

W

W: { arrowDown: string; arrowLeft: string; arrowRight: string; arrowUp: string; bullet: string; checkboxCircleOff: string; checkboxCircleOn: string; checkboxOff: string; checkboxOn: string; circle: string; circleCircle: string; circleCross: string; circleDotted: string; circleDouble: string; circleFilled: string; circlePipe: string; circleQuestionMark: string; cross: string; dot: string; ellipsis: string; fiveEighths: string; fiveSixths: string; fourFifths: string; hamburger: string; heart: string; info: string; line: string; mustache: string; nodejs: string; oneEighth: string; oneFifth: string; oneHalf: string; oneNinth: string; oneQuarter: string; oneSeventh: string; oneSixth: string; oneTenth: string; oneThird: string; play: string; pointer: string; pointerSmall: string; questionMarkPrefix: string; radioOff: string; radioOn: string; sevenEighths: string; smiley: string; square: string; squareSmall: string; squareSmallFilled: string; star: string; threeEighths: string; threeFifths: string; threeQuarters: string; tick: string; twoFifths: string; twoThirds: string; warning: string } = q

Type declaration

  • arrowDown: string
  • arrowLeft: string
  • arrowRight: string
  • arrowUp: string
  • bullet: string
  • checkboxCircleOff: string
  • checkboxCircleOn: string
  • checkboxOff: string
  • checkboxOn: string
  • circle: string
  • circleCircle: string
  • circleCross: string
  • circleDotted: string
  • circleDouble: string
  • circleFilled: string
  • circlePipe: string
  • circleQuestionMark: string
  • cross: string
  • dot: string
  • ellipsis: string
  • fiveEighths: string
  • fiveSixths: string
  • fourFifths: string
  • hamburger: string
  • heart: string
  • info: string
  • line: string
  • mustache: string
  • nodejs: string
  • oneEighth: string
  • oneFifth: string
  • oneHalf: string
  • oneNinth: string
  • oneQuarter: string
  • oneSeventh: string
  • oneSixth: string
  • oneTenth: string
  • oneThird: string
  • play: string
  • pointer: string
  • pointerSmall: string
  • questionMarkPrefix: string
  • radioOff: string
  • radioOn: string
  • sevenEighths: string
  • smiley: string
  • square: string
  • squareSmall: string
  • squareSmallFilled: string
  • star: string
  • threeEighths: string
  • threeFifths: string
  • threeQuarters: string
  • tick: string
  • twoFifths: string
  • twoThirds: string
  • warning: string

Writable

Writable: Writable = require("stream").Writable

WriteAfterEndError

WriteAfterEndError: CustomError = createErrorType("ERR_STREAM_WRITE_AFTER_END","write after end")

Const Y

Y: { arrowDown: string; arrowLeft: string; arrowRight: string; arrowUp: string; bullet: string; checkboxCircleOff: string; checkboxCircleOn: string; checkboxOff: string; checkboxOn: string; circle: string; circleCircle: string; circleCross: string; circleDotted: string; circleDouble: string; circleFilled: string; circlePipe: string; circleQuestionMark: string; cross: string; dot: string; ellipsis: string; fiveEighths: string; fiveSixths: string; fourFifths: string; hamburger: string; heart: string; info: string; line: string; mustache: string; nodejs: string; oneEighth: string; oneFifth: string; oneHalf: string; oneNinth: string; oneQuarter: string; oneSeventh: string; oneSixth: string; oneTenth: string; oneThird: string; play: string; pointer: string; pointerSmall: string; questionMarkPrefix: string; radioOff: string; radioOn: string; sevenEighths: string; smiley: string; square: string; squareSmall: string; squareSmallFilled: string; star: string; threeEighths: string; threeFifths: string; threeQuarters: string; tick: string; twoFifths: string; twoThirds: string; warning: string } = "win32"===P?q:N

Type declaration

  • arrowDown: string
  • arrowLeft: string
  • arrowRight: string
  • arrowUp: string
  • bullet: string
  • checkboxCircleOff: string
  • checkboxCircleOn: string
  • checkboxOff: string
  • checkboxOn: string
  • circle: string
  • circleCircle: string
  • circleCross: string
  • circleDotted: string
  • circleDouble: string
  • circleFilled: string
  • circlePipe: string
  • circleQuestionMark: string
  • cross: string
  • dot: string
  • ellipsis: string
  • fiveEighths: string
  • fiveSixths: string
  • fourFifths: string
  • hamburger: string
  • heart: string
  • info: string
  • line: string
  • mustache: string
  • nodejs: string
  • oneEighth: string
  • oneFifth: string
  • oneHalf: string
  • oneNinth: string
  • oneQuarter: string
  • oneSeventh: string
  • oneSixth: string
  • oneTenth: string
  • oneThird: string
  • play: string
  • pointer: string
  • pointerSmall: string
  • questionMarkPrefix: string
  • radioOff: string
  • radioOn: string
  • sevenEighths: string
  • smiley: string
  • square: string
  • squareSmall: string
  • squareSmallFilled: string
  • star: string
  • threeEighths: string
  • threeFifths: string
  • threeQuarters: string
  • tick: string
  • twoFifths: string
  • twoThirds: string
  • warning: string

__asyncDelegator

  • __asyncDelegator(o: any): {}
  • Parameters

    • o: any

    Returns {}

__asyncGenerator

  • __asyncGenerator(thisArg: any, _arguments: any, generator: any): {}
  • Parameters

    • thisArg: any
    • _arguments: any
    • generator: any

    Returns {}

__asyncValues

  • __asyncValues(o: any): any
  • Parameters

    • o: any

    Returns any

__await

  • __await(v: any): any
  • Parameters

    • v: any

    Returns any

__awaiter

  • __awaiter(thisArg: any, _arguments: any, P: any, generator: any): any
  • Parameters

    • thisArg: any
    • _arguments: any
    • P: any
    • generator: any

    Returns any

__classPrivateFieldGet

  • __classPrivateFieldGet(receiver: any, privateMap: any): any
  • Parameters

    • receiver: any
    • privateMap: any

    Returns any

__classPrivateFieldSet

  • __classPrivateFieldSet(receiver: any, privateMap: any, value: any): any
  • Parameters

    • receiver: any
    • privateMap: any
    • value: any

    Returns any

__createBinding

__createBinding: any = Object.create ? (function(o, m, k, k2) {if (k2 === undefined) k2 = k;Object.defineProperty(o, k2, { enumerable: true, get: function() { return m[k]; } });}) : (function(o, m, k, k2) {if (k2 === undefined) k2 = k;o[k2] = m[k];})

__decorate

  • __decorate(decorators: any, target: any, key: any, desc: any): any
  • Parameters

    • decorators: any
    • target: any
    • key: any
    • desc: any

    Returns any

__exportStar

  • __exportStar(m: any, o: any): void
  • Parameters

    • m: any
    • o: any

    Returns void

__extends

  • __extends(d: any, b: any): void
  • Parameters

    • d: any
    • b: any

    Returns void

__generator

  • __generator(thisArg: any, body: any): { next: (Anonymous function); return: (Anonymous function); throw: (Anonymous function) }
  • Parameters

    • thisArg: any
    • body: any

    Returns { next: (Anonymous function); return: (Anonymous function); throw: (Anonymous function) }

    • next: (Anonymous function)
    • return: (Anonymous function)
    • throw: (Anonymous function)

__importDefault

  • __importDefault(mod: any): any
  • Parameters

    • mod: any

    Returns any

__importStar

  • __importStar(mod: any): any
  • Parameters

    • mod: any

    Returns any

__makeTemplateObject

  • __makeTemplateObject(cooked: any, raw: any): any
  • Parameters

    • cooked: any
    • raw: any

    Returns any

__metadata

  • __metadata(metadataKey: any, metadataValue: any): { (target: Function): void; (target: Object, propertyKey: string | symbol): void }
  • Parameters

    • metadataKey: any
    • metadataValue: any

    Returns { (target: Function): void; (target: Object, propertyKey: string | symbol): void }

      • (target: Function): void
      • (target: Object, propertyKey: string | symbol): void
      • Parameters

        Returns void

      • Parameters

        • target: Object
        • propertyKey: string | symbol

        Returns void

__param

  • __param(paramIndex: any, decorator: any): (Anonymous function)
  • Parameters

    • paramIndex: any
    • decorator: any

    Returns (Anonymous function)

__read

  • __read(o: any, n: any): any
  • Parameters

    • o: any
    • n: any

    Returns any

__rest

  • __rest(s: any, e: any): t
  • Parameters

    • s: any
    • e: any

    Returns t

__setModuleDefault

__setModuleDefault: (Anonymous function) = Object.create ? (function(o, v) {Object.defineProperty(o, "default", { enumerable: true, value: v });}) : function(o, v) {o["default"] = v;}

__spread

  • __spread(): any[]
  • Returns any[]

__spreadArrays

  • __spreadArrays(): any[]
  • Returns any[]

__values

  • __values(o: any): any
  • Parameters

    • o: any

    Returns any

_a

_a: any

_assert

_assert: any = _interopRequireDefault(require("assert"))

Const _bgColorCache

_bgColorCache: _bgColorCache

Let _clockseq

_clockseq: any

Const _colorCache

_colorCache: _colorCache

Const _compileCache

_compileCache: _compileCache

_crypto

_crypto: any = _interopRequireDefault(require("crypto"))

_default

  • _default(name: any, version: any, hashfunc: any): generateUUID
  • Parameters

    • name: any
    • version: any
    • hashfunc: any

    Returns generateUUID

Let _lastMSecs

_lastMSecs: number = 0

Let _lastNSecs

_lastNSecs: number = 0

_md

_md: any = _interopRequireDefault(require("./md5.js"))

_nil

_nil: any = _interopRequireDefault(require("./nil.js"))

Let _nodeId

_nodeId: any

_parse

_parse: any = _interopRequireDefault(require("./parse.js"))

_regex

_regex: any = _interopRequireDefault(require("./regex.js"))

Const _require

_require: any = typeof __non_webpack_require__ !== 'undefined' ? __non_webpack_require__ : require

_rng

_rng: any = _interopRequireDefault(require("./rng.js"))

_sha

_sha: any = _interopRequireDefault(require("./sha1.js"))

_stringify

_stringify: any = _interopRequireDefault(require("./stringify.js"))

Const _u

_u: any = Object.create(null)

_v

_v: any = _interopRequireDefault(require("./v35.js"))

_v2

_v2: any = _interopRequireDefault(require("./v3.js"))

_v3

_v3: any = _interopRequireDefault(require("./v4.js"))

_v4

_v4: any = _interopRequireDefault(require("./v5.js"))

_validate

_validate: any = _interopRequireDefault(require("./validate.js"))

_version

_version: any = _interopRequireDefault(require("./version.js"))

a

a: any = s((function(u,D){var e=process.env;function t(u){return"string"==typeof u?!!e[u]:Object.keys(u).every((function(D){return e[D]===u[D]}))}Object.defineProperty(D,"_vendors",{value:i.map((function(u){return u.constant}))}),D.name=null,D.isPR=null,i.forEach((function(u){var r=(Array.isArray(u.env)?u.env:[u.env]).every((function(u){return t(u)}));if(D[u.constant]=r,r)switch(D.name=u.name,typeof u.pr){case"string":D.isPR=!!e[u.pr];break;case"object":"env"in u.pr?D.isPR=u.pr.env in e&&e[u.pr.env]!==u.pr.ne:"any"in u.pr?D.isPR=u.pr.any.some((function(u){return!!e[u]})):D.isPR=t(u.pr);break;default:D.isPR=null}})),D.isCI=!!(e.CI||e.CONTINUOUS_INTEGRATION||e.BUILD_NUMBER||e.RUN_ID||D.name)}))

Const ansiStyles

ansiStyles: { bgColor: BackgroundColor & ColorBase; codes: ReadonlyMap<number, number>; color: ForegroundColor & ColorBase; modifier: Modifier } & BackgroundColor & ForegroundColor & Modifier = require('ansi-styles')

Const application_config_1

application_config_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/application-config" = require("./application-config")

Const args

args: string[] = process.argv.slice(2)

arr

arr: any[] = []

Const array

array: number[] = new Array(10).fill(0).map((_, i) => i)

assert

assert: assert = require("assert")

Const assign_custom_metadata_util_1

assign_custom_metadata_util_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/common/utils/assign-custom-metadata.util" = require("../../utils/assign-custom-metadata.util")

axios

axios: Axios = createInstance(defaults)

Const axios_1

axios_1: "D:/TS-doc/nest/packages/microservices/node_modules/axios/index" = require("axios")

Const base_exception_filter_1

base_exception_filter_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/exceptions/base-exception-filter" = require("./base-exception-filter")

Const base_exception_filter_context_1

base_exception_filter_context_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/exceptions/base-exception-filter-context" = require("../exceptions/base-exception-filter-context")

bind

bind: bind = require('./helpers/bind')

bu

bu: { has16m: boolean; has256: boolean; hasBasic: boolean; level: any }

Type declaration

  • has16m: boolean
  • has256: boolean
  • hasBasic: boolean
  • level: any

buildFullPath

buildFullPath: buildFullPath = require('../core/buildFullPath')

buildURL

buildURL: buildURL = require('../helpers/buildURL')

Const builder_1

builder_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/middleware/builder" = require("./builder")

Const byteToHex

byteToHex: any[] = []

Convert array of 16 byte values to UUID string format of the form: XXXXXXXX-XXXX-XXXX-XXXX-XXXXXXXXXXXX Convert array of 16 byte values to UUID string format of the form: XXXXXXXX-XXXX-XXXX-XXXX-XXXXXXXXXXXX Convert array of 16 byte values to UUID string format of the form: XXXXXXXX-XXXX-XXXX-XXXX-XXXXXXXXXXXX

c

c: boolean = !1

Const cache_constants_1

cache_constants_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/common/cache/cache.constants" = require("../cache.constants")

Const cache_providers_1

cache_providers_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/common/cache/cache.providers" = require("./cache.providers")

Const chalk

chalk: (Anonymous function) = Chalk()

chalk__default

chalk__default: any = _interopDefaultLegacy(chalk)

child_process

child_process: "child_process" = require('child_process')

Const circ

circ: any = JSON.parse(JSON.stringify(obj))

Const circGetters

circGetters: any = JSON.parse(JSON.stringify(obj))

Const circular_dependency_exception_1

circular_dependency_exception_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/errors/exceptions/circular-dependency.exception" = require("./errors/exceptions/circular-dependency.exception")

Let classTransformer

classTransformer: any

Let classValidator

classValidator: any

Const class_serializer_constants_1

class_serializer_constants_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/common/serializer/class-serializer.constants" = require("../class-serializer.constants")

Const cli_colors_util_1

cli_colors_util_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/common/utils/cli-colors.util" = require("../utils/cli-colors.util")

Const clone

  • clone(instance: any): any
  • Clone body given Res/Req instance

    Parameters

    • instance: any

    Returns any

    Mixed

Let colorConvert

colorConvert: convert

combineURLs

combineURLs: combineURLs = require('../helpers/combineURLs')

Const common_1

common_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/common/index" = require("@nestjs/common")

Const compiler_1

compiler_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/injector/compiler" = require("./compiler")

Const concat_1

concat_1: "D:/TS-doc/nest/packages/microservices/node_modules/iterare/lib/concat" = require("./concat")

consola

consola: "D:/TS-doc/nest/packages/microservices/node_modules/consola/types/consola" = require('consola')

consola__default

consola__default: any = _interopDefaultLegacy(consola)

Const constants_1

constants_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/common/constants" = require("@nestjs/common/constants")

Const constants_2

constants_2: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/constants" = require("./constants")

Const constants_3

constants_3: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/injector/constants" = require("../injector/constants")

Const container_1

container_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/injector/container" = require("./injector/container")

Const context_creator_1

context_creator_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/helpers/context-creator" = require("../helpers/context-creator")

Const context_id_factory_1

context_id_factory_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/helpers/context-id-factory" = require("../helpers/context-id-factory")

Const context_utils_1

context_utils_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/helpers/context-utils" = require("../helpers/context-utils")

Const conversions

conversions: { ansi16: object; ansi256: object; apple: object; cmyk: object; gray: object; hcg: object; hex: object; hsl: object; hsv: object; hwb: object; keyword: object; lab: object; lch: object; rgb: object; xyz: object } = require('./conversions')

Type declaration

  • ansi16: object
    • channels: number
    • labels: string[]
  • ansi256: object
    • channels: number
    • labels: string[]
  • apple: object
    • channels: number
    • labels: string[]
  • cmyk: object
    • channels: number
    • labels: string
  • gray: object
    • channels: number
    • labels: string[]
  • hcg: object
    • channels: number
    • labels: string[]
  • hex: object
    • channels: number
    • labels: string[]
  • hsl: object
    • channels: number
    • labels: string
  • hsv: object
    • channels: number
    • labels: string
  • hwb: object
    • channels: number
    • labels: string
  • keyword: object
    • channels: number
    • labels: string[]
  • lab: object
    • channels: number
    • labels: string
  • lch: object
    • channels: number
    • labels: string
  • rgb: object
    • channels: number
    • labels: string
  • xyz: object
    • channels: number
    • labels: string

cookies

cookies: { read: any; remove: any; write: any } | { read: any; remove: any; write: any } = require('./../helpers/cookies')

Const core_1

core_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/common/decorators/core/index" = require("../decorators/core")

createError

createError: createError = require('./createError')

crypto

crypto: "crypto" = require('crypto')

Const cssKeywords

cssKeywords: "D:/TS-doc/nest/node_modules/@types/color-name/index" = require('color-name')

Const cu

cu: RegExp = /(?:^|\.)(\w+)(?:\(([^)]*)\))?/g

debug

debug: any = require("./debug")

decoder

decoder: StringDecoder = new StringDecoder()

Const decorators_1

decorators_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/common/decorators/index" = require("../../decorators")

Const deep

deep: any = require('./package.json')

Const deepCirc

deepCirc: any = JSON.parse(JSON.stringify(deep))

Const deepCircGetters

deepCircGetters: any = JSON.parse(JSON.stringify(deep))

Const deepCircNonCongifurableGetters

deepCircNonCongifurableGetters: any = JSON.parse(JSON.stringify(deep))

Const default_options_1

default_options_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/common/cache/default-options" = require("./default-options")

delegates

delegates: string[] = ['connect','on','end','setTimeout','setKeepAlive']

Const dependencies_decorator_1

dependencies_decorator_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/common/decorators/core/dependencies.decorator" = require("@nestjs/common/decorators/core/dependencies.decorator")

Const discovery_service_1

discovery_service_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/discovery/discovery-service" = require("./discovery-service")

dispatchRequest

dispatchRequest: dispatchRequest = require('./dispatchRequest')

e

e: PlatformPath = require("path")

encodings

encodings: string[] = ['buffer', 'hex', 'binary', 'base64']

enhanceError

enhanceError: enhanceError = require('./enhanceError')

Const enums_1

enums_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/common/enums/index" = require("../enums")

env

env: ProcessEnv

eu

eu: any = s((function(u){const D=(u,D)=>(...e)=>`[${u(...e)+D}m`,e=(u,D)=>(...e)=>{const t=u(...e);return`[${38+D};5;${t}m`},t=(u,D)=>(...e)=>{const t=u(...e);return`[${38+D};2;${t[0]};${t[1]};${t[2]}m`},r=u=>u,n=(u,D,e)=>[u,D,e],s=(u,D,e)=>{Object.defineProperty(u,D,{get:()=>{const t=e();return Object.defineProperty(u,D,{value:t,enumerable:!0,configurable:!0}),t},enumerable:!0,configurable:!0})};let o;const i=(u,D,e,t)=>{void 0===o&&(o=Du);const r=t?10:0,n={};for(const[t,s]of Object.entries(o)){const o="ansi16"===t?"ansi":t;t===D?n[o]=u(e,r):"object"==typeof s&&(n[o]=u(s[D],r))}return n};Object.defineProperty(u,"exports",{enumerable:!0,get:function(){const u=new Map,o={modifier:{reset:[0,0],bold:[1,22],dim:[2,22],italic:[3,23],underline:[4,24],inverse:[7,27],hidden:[8,28],strikethrough:[9,29]},color:{black:[30,39],red:[31,39],green:[32,39],yellow:[33,39],blue:[34,39],magenta:[35,39],cyan:[36,39],white:[37,39],blackBright:[90,39],redBright:[91,39],greenBright:[92,39],yellowBright:[93,39],blueBright:[94,39],magentaBright:[95,39],cyanBright:[96,39],whiteBright:[97,39]},bgColor:{bgBlack:[40,49],bgRed:[41,49],bgGreen:[42,49],bgYellow:[43,49],bgBlue:[44,49],bgMagenta:[45,49],bgCyan:[46,49],bgWhite:[47,49],bgBlackBright:[100,49],bgRedBright:[101,49],bgGreenBright:[102,49],bgYellowBright:[103,49],bgBlueBright:[104,49],bgMagentaBright:[105,49],bgCyanBright:[106,49],bgWhiteBright:[107,49]}};o.color.gray=o.color.blackBright,o.bgColor.bgGray=o.bgColor.bgBlackBright,o.color.grey=o.color.blackBright,o.bgColor.bgGrey=o.bgColor.bgBlackBright;for(const[D,e]of Object.entries(o)){for(const[D,t]of Object.entries(e))o[D]={open:`[${t[0]}m`,close:`[${t[1]}m`},e[D]=o[D],u.set(t[0],t[1]);Object.defineProperty(o,D,{value:e,enumerable:!1})}return Object.defineProperty(o,"codes",{value:u,enumerable:!1}),o.color.close="",o.bgColor.close="",s(o.color,"ansi",()=>i(D,"ansi16",r,!1)),s(o.color,"ansi256",()=>i(e,"ansi256",r,!1)),s(o.color,"ansi16m",()=>i(t,"rgb",n,!1)),s(o.bgColor,"ansi",()=>i(D,"ansi16",r,!0)),s(o.bgColor,"ansi256",()=>i(e,"ansi256",r,!0)),s(o.bgColor,"ansi16m",()=>i(t,"rgb",n,!0)),o}})}))

eventHandlers

eventHandlers: any = Object.create(null)

Const exception_handler_1

exception_handler_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/errors/exception-handler" = require("./exception-handler")

Const exceptions_1

exceptions_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/common/exceptions/index" = require("@nestjs/common/exceptions")

Const exceptions_handler_1

exceptions_handler_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/exceptions/exceptions-handler" = require("../exceptions/exceptions-handler")

Const exceptions_zone_1

exceptions_zone_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/errors/exceptions-zone" = require("./errors/exceptions-zone")

Const execution_context_host_1

execution_context_host_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/helpers/execution-context-host" = require("../helpers/execution-context-host")

Const extend_metadata_util_1

extend_metadata_util_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/common/utils/extend-metadata.util" = require("../../utils/extend-metadata.util")

Const external_context_creator_1

external_context_creator_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/helpers/external-context-creator" = require("../helpers/external-context-creator")

Const external_exception_filter_1

external_exception_filter_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/exceptions/external-exception-filter" = require("./external-exception-filter")

Const external_exception_filter_context_1

external_exception_filter_context_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/exceptions/external-exception-filter-context" = require("../exceptions/external-exception-filter-context")

Const external_exceptions_handler_1

external_exceptions_handler_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/exceptions/external-exceptions-handler" = require("./external-exceptions-handler")

Const external_proxy_1

external_proxy_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/helpers/external-proxy" = require("./external-proxy")

f

  • f(s: any, x: any, y: any, z: any): number
  • Parameters

    • s: any
    • x: any
    • y: any
    • z: any

    Returns number

Const fastSafeStringify

fastSafeStringify: "D:/TS-doc/nest/packages/microservices/node_modules/fast-safe-stringify/index" = require('./')

Const fast_safe_stringify_1

fast_safe_stringify_1: "D:/TS-doc/nest/packages/microservices/node_modules/fast-safe-stringify/index" = require("fast-safe-stringify")

fetch

  • fetch(url: any, opts: any): Promise<any>
  • Fetch function

    Parameters

    • url: any
    • opts: any

    Returns Promise<any>

    Promise

fetchJson

fetchJson: (Anonymous function) = _async(function (url) {return _catch(function () {return _await(global.fetch("".concat(url, ".json"), {timeout: FETCH_TIMEOUT}), function (_global$fetch) {return _global$fetch.json();});}, function (e) {report(e);reportAndThrowError("Could not fetch ".concat(url, ".json"));});})

fetchLogo

fetchLogo: (Anonymous function) = _async(function (logoUrl) {if (!logoUrl) {// Silent return if no logo has been providedreturn;}if (!logoUrl.match(/^https?:\/\//)) {reportAndThrowError("Your logo URL isn't well-formatted - ".concat(logoUrl));}return _catch(function () {return _await(global.fetch(logoUrl, {timeout: FETCH_TIMEOUT}), function (res) {if (isLogoResponseWellFormatted(res)) {return res.text();}report("Error while fetching logo from ".concat(logoUrl, ". The response wasn't well-formatted"));});}, function () {report("Error while fetching logo from ".concat(logoUrl));});})

fetchStats

fetchStats: (Anonymous function) = _async(function (collectiveUrl) {return _catch(function () {return _await(fetchJson(collectiveUrl));}, function (e) {report(e);report("Could not load the stats for ".concat(collectiveSlugFromUrl(collectiveUrl)));});})

fetch__default

fetch__default: any = _interopDefaultLegacy(fetch)

Const filter_1

filter_1: "D:/TS-doc/nest/packages/microservices/node_modules/iterare/lib/filter" = require("./filter")

Const flatten_1

flatten_1: "D:/TS-doc/nest/packages/microservices/node_modules/iterare/lib/flatten" = require("./flatten")

Let forceColor

forceColor: any

Const format_url

format_url: any = Url.format

fs

fs: "fs" = require('fs')

fs__default

fs__default: any = _interopDefaultLegacy(fs)

Const fss

fss: "D:/TS-doc/nest/packages/microservices/node_modules/fast-safe-stringify/index" = require('./')

getCollective

getCollective: (Anonymous function) = _async$1(function (pkgPath) {var pkg = fetchPkg(pkgPath);var url = collectiveUrl(pkg);var baseCollective = {url: url,slug: collectiveSlugFromUrl(url),logoUrl: collectiveLogoUrl(pkg),donationUrl: collectiveDonationUrl(pkg),donationText: collectiveDonationText(pkg)};var logoUrl = baseCollective.logoUrl;var promises = [fetchStats(url)].concat(logoUrl ? fetchLogo(logoUrl) : []);return _await$1(Promise.all(promises), function (_ref) {var _ref2 = _slicedToArray(_ref, 2),stats = _ref2[0],logo = _ref2[1];return Object.assign(baseCollective, {stats: stats,logo: logo});});})

Const getRandomValues

getRandomValues: any = typeof crypto !== 'undefined' && crypto.getRandomValues && crypto.getRandomValues.bind(crypto) || typeof msCrypto !== 'undefined' && typeof msCrypto.getRandomValues === 'function' && msCrypto.getRandomValues.bind(msCrypto)

Const get_class_scope_1

get_class_scope_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/helpers/get-class-scope" = require("./helpers/get-class-scope")

global

global: any = getGlobal()

Let grpcPackage

grpcPackage: any

Let grpcProtoLoaderPackage

grpcProtoLoaderPackage: any

Const guards_consumer_1

guards_consumer_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/guards/guards-consumer" = require("../guards/guards-consumer")

Const guards_context_creator_1

guards_context_creator_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/guards/guards-context-creator" = require("../guards/guards-context-creator")

h

h: boolean = !1

Const handler_metadata_storage_1

handler_metadata_storage_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/helpers/handler-metadata-storage" = require("../helpers/handler-metadata-storage")

Const hasFlag

hasFlag: hasFlag = require('has-flag')

Const hash

  • hash(object: any, options: any): any
  • Parameters

    • object: any
    • options: any

    Returns any

hashes

hashes: string[] = crypto.getHashes ? crypto.getHashes().slice() : ['sha1', 'md5']

Const helpers_1

helpers_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/helpers/index" = require("./helpers")

Const hooks_1

hooks_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/hooks/index" = require("./hooks")

host

host: string = "127.0.0.1"

http

http: any = _interopDefault(require('http'))

httpFollow

httpFollow: any = require('follow-redirects').http

Const http_adapter_host_1

http_adapter_host_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/helpers/http-adapter-host" = require("../helpers/http-adapter-host")

Const http_constants_1

http_constants_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/common/http/http.constants" = require("./http.constants")

Const http_error_by_code_util_1

http_error_by_code_util_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/common/utils/http-error-by-code.util" = require("../utils/http-error-by-code.util")

Const http_exception_1

http_exception_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/common/exceptions/http.exception" = require("./http.exception")

Const http_service_1

http_service_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/common/http/http.service" = require("./http.service")

Const http_status_enum_1

http_status_enum_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/common/enums/http-status.enum" = require("../enums/http-status.enum")

https

https: any = _interopDefault(require('https'))

httpsFollow

httpsFollow: any = require('follow-redirects').https

Const hu

hu: RegExp = /^(['"])((?:\\.|(?!\1)[^\\])*)\1$/

i

i: ({ constant: string; env: string; name: string; pr: string } | { constant: string; env: string; name: string } | { constant: string; env: string; name: string; pr: object } | { constant: string; name: string; env: object } | { constant: string; env: string; name: string; pr: object } | { constant: string; env: string[]; name: string; pr: object } | { constant: string; env: string; name: string; pr: object } | { constant: string; env: string[]; name: string } | { constant: string; deprecated: true; env: string; name: string; pr: string })[] | Readonly<{ __proto__: null; default: ({ constant: string; env: string; name: string; pr: string } | { constant: string; env: string; name: string } | { constant: string; env: string; name: string; pr: object } | { constant: string; name: string; env: object } | { constant: string; env: string; name: string; pr: object } | { constant: string; env: string[]; name: string; pr: object } | { constant: string; env: string; name: string; pr: object } | { constant: string; env: string[]; name: string } | { constant: string; deprecated: true; env: string; name: string; pr: string })[] }> = (o=Object.freeze({__proto__:null,default:[{name:"AppVeyor",constant:"APPVEYOR",env:"APPVEYOR",pr:"APPVEYOR_PULL_REQUEST_NUMBER"},{name:"Bamboo",constant:"BAMBOO",env:"bamboo_planKey"},{name:"Bitbucket Pipelines",constant:"BITBUCKET",env:"BITBUCKET_COMMIT"},{name:"Bitrise",constant:"BITRISE",env:"BITRISE_IO",pr:"BITRISE_PULL_REQUEST"},{name:"Buddy",constant:"BUDDY",env:"BUDDY_WORKSPACE_ID",pr:"BUDDY_EXECUTION_PULL_REQUEST_ID"},{name:"Buildkite",constant:"BUILDKITE",env:"BUILDKITE",pr:{env:"BUILDKITE_PULL_REQUEST",ne:"false"}},{name:"CircleCI",constant:"CIRCLE",env:"CIRCLECI",pr:"CIRCLE_PULL_REQUEST"},{name:"Cirrus CI",constant:"CIRRUS",env:"CIRRUS_CI",pr:"CIRRUS_PR"},{name:"AWS CodeBuild",constant:"CODEBUILD",env:"CODEBUILD_BUILD_ARN"},{name:"Codeship",constant:"CODESHIP",env:{CI_NAME:"codeship"}},{name:"Drone",constant:"DRONE",env:"DRONE",pr:{DRONE_BUILD_EVENT:"pull_request"}},{name:"dsari",constant:"DSARI",env:"DSARI"},{name:"GitLab CI",constant:"GITLAB",env:"GITLAB_CI"},{name:"GoCD",constant:"GOCD",env:"GO_PIPELINE_LABEL"},{name:"Hudson",constant:"HUDSON",env:"HUDSON_URL"},{name:"Jenkins",constant:"JENKINS",env:["JENKINS_URL","BUILD_ID"],pr:{any:["ghprbPullId","CHANGE_ID"]}},{name:"Magnum CI",constant:"MAGNUM",env:"MAGNUM"},{name:"Sail CI",constant:"SAIL",env:"SAILCI",pr:"SAIL_PULL_REQUEST_NUMBER"},{name:"Semaphore",constant:"SEMAPHORE",env:"SEMAPHORE",pr:"PULL_REQUEST_NUMBER"},{name:"Shippable",constant:"SHIPPABLE",env:"SHIPPABLE",pr:{IS_PULL_REQUEST:"true"}},{name:"Solano CI",constant:"SOLANO",env:"TDDIUM",pr:"TDDIUM_PR_ID"},{name:"Strider CD",constant:"STRIDER",env:"STRIDER"},{name:"TaskCluster",constant:"TASKCLUSTER",env:["TASK_ID","RUN_ID"]},{name:"Solano CI",constant:"TDDIUM",env:"TDDIUM",pr:"TDDIUM_PR_ID",deprecated:!0},{name:"TeamCity",constant:"TEAMCITY",env:"TEAMCITY_VERSION"},{name:"Team Foundation Server",constant:"TFS",env:"TF_BUILD"},{name:"Travis CI",constant:"TRAVIS",env:"TRAVIS",pr:{env:"TRAVIS_PULL_REQUEST",ne:"false"}}]}))&&o.default||o

ignoreDuplicateOf

ignoreDuplicateOf: string[] = ['age', 'authorization', 'content-length', 'content-type', 'etag','expires', 'from', 'host', 'if-modified-since', 'if-unmodified-since','last-modified', 'location', 'max-forwards', 'proxy-authorization','referer', 'retry-after', 'user-agent']

Const index_1

index_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/common/index" = require("../index")

init

init: (Anonymous function) = _async$2(function (path, hide) {if (hide === undefined) hide = hideMessage();if (hide) {return;}global.fetch = global.fetch || fetch__default['default'];return _await$2(getCollective(path), function (collective) {printLogo(collective.logo);printFooter(collective);});})

Const injectable_decorator_1

injectable_decorator_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/common/decorators/core/injectable.decorator" = require("../decorators/core/injectable.decorator")

Const injector_1

injector_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/injector/injector" = require("./injector/injector")

Const inquirer_1

inquirer_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/injector/inquirer/index" = require("./inquirer")

Const inquirer_constants_1

inquirer_constants_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/injector/inquirer/inquirer-constants" = require("./inquirer-constants")

Const inquirer_providers_1

inquirer_providers_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/injector/inquirer/inquirer-providers" = require("./inquirer/inquirer-providers")

inspect

inspect: inspect

Const instance_links_host_1

instance_links_host_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/injector/instance-links-host" = require("./injector/instance-links-host")

Const instance_loader_1

instance_loader_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/injector/instance-loader" = require("./injector/instance-loader")

Const instance_wrapper_1

instance_wrapper_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/injector/instance-wrapper" = require("../injector/instance-wrapper")

Const interceptors_consumer_1

interceptors_consumer_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/interceptors/interceptors-consumer" = require("../interceptors/interceptors-consumer")

Const interceptors_context_creator_1

interceptors_context_creator_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/interceptors/interceptors-context-creator" = require("../interceptors/interceptors-context-creator")

Const interfaces_1

interfaces_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/common/interfaces/index" = require("@nestjs/common/interfaces")

Const internal_core_module_1

internal_core_module_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/injector/internal-core-module" = require("./internal-core-module")

Const internal_providers_storage_1

internal_providers_storage_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/injector/internal-providers-storage" = require("./internal-providers-storage")

Const invalidHeaderCharRegex

invalidHeaderCharRegex: RegExp = /[^\t\x20-\x7e\x80-\xff]/

Const invalidTokenRegex

invalidTokenRegex: RegExp = /[^\^_`a-zA-Z\-0-9!#$%&'*+.|~]/

headers.js headers.js

Headers class offers convenient helpers

Headers class offers convenient helpers

Const invalid_class_exception_1

invalid_class_exception_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/errors/exceptions/invalid-class.exception" = require("../errors/exceptions/invalid-class.exception")

Const invalid_class_scope_exception_1

invalid_class_scope_exception_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/errors/exceptions/invalid-class-scope.exception" = require("./errors/exceptions/invalid-class-scope.exception")

Const invalid_exception_filter_exception_1

invalid_exception_filter_exception_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/errors/exceptions/invalid-exception-filter.exception" = require("../errors/exceptions/invalid-exception-filter.exception")

Const invalid_middleware_exception_1

invalid_middleware_exception_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/errors/exceptions/invalid-middleware.exception" = require("../errors/exceptions/invalid-middleware.exception")

Const invalid_module_exception_1

invalid_module_exception_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/errors/exceptions/invalid-module.exception" = require("./errors/exceptions/invalid-module.exception")

Const ip

ip: "127.0.0.1" = "127.0.0.1"

isAbsoluteURL

isAbsoluteURL: isAbsoluteURL = require('../helpers/isAbsoluteURL')

isCancel

isCancel: isCancel = require('../cancel/isCancel')

isHttps

isHttps: RegExp = /https:?/

isURLSameOrigin

isURLSameOrigin: isURLSameOrigin = require('./../helpers/isURLSameOrigin')

isWin32

isWin32: boolean = process.platform === 'win32'

Const is_uuid_1

is_uuid_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/common/utils/is-uuid" = require("../utils/is-uuid")

Const iterare_1

iterare_1: "D:/TS-doc/nest/packages/microservices/node_modules/iterare/lib/index" = require("iterare")

Const iterate_1

iterate_1: "D:/TS-doc/nest/packages/microservices/node_modules/iterare/lib/iterate" = require("./iterate")

j

j: RegExp = /[|\\{}()[\]^$+*?.]/g

Const jsonStringifySafe

jsonStringifySafe: any = require('json-stringify-safe')

Const ju

ju: ju

Let kafkaPackage

kafkaPackage: any

l

l: boolean = (a.name,a.isPR,a.isCI,!1)

Const label

label: "label" = "label"

Const levelMapping

levelMapping: string[] = ['ansi','ansi','ansi256','ansi16m']

Const load_adapter_1

load_adapter_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/helpers/load-adapter" = require("./helpers/load-adapter")

Const load_package_util_1

load_package_util_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/common/utils/load-package.util" = require("@nestjs/common/utils/load-package.util")

Const logger

logger: Logger = new Logger('PackageLoader')

Const logger_service_1

logger_service_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/common/services/logger.service" = require("@nestjs/common/services/logger.service")

Const longPayload

longPayload: { _id: string; about: string; address: string; age: number; balance: string; company: string; email: string; eyeColor: string; favoriteFruit: string; friends: { id: number; name: string }[]; gender: string; greeting: string; guid: string; index: number; isActive: boolean; latitude: number; longitude: number; name: string; phone: string; picture: string; registered: string; tags: string[] }[] = [{_id: '584f17147fce7ca0a8bacfd2',index: 0,guid: '1d127572-0369-45fb-aa2f-e3bb083ac2b2',isActive: true,balance: '$2,926.06',picture: 'http://placehold.it/32x32',age: 26,eyeColor: 'green',name:'Wçêtson Aguilar [special characters in name that used to fail on long payloads]',gender: 'male',company: 'PROWASTE',email: 'watsonaguilar@prowaste.com',phone: '+1 (821) 517-2430',address: '910 Robert Street, Bangor, Delaware, 4159',about:'Aliqua et irure id do id id non dolore ipsum sit in proident ipsum. Id elit incididunt occaecat do laboris sunt officia fugiat aliquip. Incididunt aute ad minim Lorem cupidatat aute labore enim elit nostrud amet. Tempor sint irure incididunt aliquip amet sunt mollit aliqua Lorem officia pariatur.\r\n',registered: '2014-02-11T08:45:28 +05:00',latitude: 73.891198,longitude: 90.23414,tags: ['veniam', 'nulla', 'cillum', 'tempor', 'sint', 'magna', 'nostrud'],friends: [{id: 0,name: 'Cecelia James',},{id: 1,name: 'Hilary Young',},{id: 2,name: 'Sharron Goodwin',},],greeting: 'Hello, Watson Aguilar! You have 3 unread messages.',favoriteFruit: 'banana',},{_id: '584f1714b2e945fb30f73892',index: 1,guid: '3ffce1ee-a442-4dae-804f-40c59f19e7ee',isActive: false,balance: '$2,507.49',picture: 'http://placehold.it/32x32',age: 34,eyeColor: 'brown',name: 'Aguirre Salazar',gender: 'male',company: 'EZENTIA',email: 'aguirresalazar@ezentia.com',phone: '+1 (910) 443-3647',address: '629 Burnett Street, Tyhee, West Virginia, 2905',about:'Labore laboris et deserunt aliquip. Occaecat esse officia est eiusmod. Officia tempor cupidatat commodo minim deserunt mollit qui ut culpa. Est occaecat laborum occaecat non mollit ad reprehenderit magna ad. Consequat culpa excepteur qui aliqua dolore occaecat aliqua sunt elit ea nisi. Officia consectetur dolor labore voluptate. Esse ad esse qui id incididunt.\r\n',registered: '2015-01-28T06:47:34 +05:00',latitude: -64.632254,longitude: -116.659127,tags: ['sit','anim','quis','officia','minim','cupidatat','adipisicing',],friends: [{id: 0,name: 'Olson Mccall',},{id: 1,name: 'Carolina Conway',},{id: 2,name: 'Carlson Pacheco',},],greeting: 'Hello, Aguirre Salazar! You have 9 unread messages.',favoriteFruit: 'apple',},{_id: '584f17148282bb876fc4e9a2',index: 2,guid: '892ba80c-7149-4904-bd36-22f619d4df0a',isActive: true,balance: '$2,132.56',picture: 'http://placehold.it/32x32',age: 26,eyeColor: 'green',name: 'Hardin Grant',gender: 'male',company: 'CINASTER',email: 'hardingrant@cinaster.com',phone: '+1 (900) 437-2390',address: '180 Ide Court, Gibsonia, Washington, 3027',about:'Ut aliquip officia adipisicing voluptate aliquip aute fugiat ad quis ad eu non consectetur. Laboris labore veniam officia qui eiusmod. Duis aliqua est quis do dolor excepteur ea dolore non. Nisi mollit laboris nostrud nostrud pariatur culpa laboris anim est irure id aute.\r\n',registered: '2016-09-13T10:54:27 +04:00',latitude: 8.651031,longitude: -136.777747,tags: ['consequat', 'deserunt', 'magna', 'enim', 'esse', 'minim', 'ipsum'],friends: [{id: 0,name: 'Lesley Velasquez',},{id: 1,name: 'Natasha Simmons',},{id: 2,name: 'Isabel Avery',},],greeting: 'Hello, Hardin Grant! You have 7 unread messages.',favoriteFruit: 'strawberry',},{_id: '584f1714d90ff4b8914a69e7',index: 3,guid: '76f37726-1f73-4cf7-aabe-8dadf37d3ddd',isActive: true,balance: '$2,493.04',picture: 'http://placehold.it/32x32',age: 32,eyeColor: 'blue',name: 'Randall Roy',gender: 'male',company: 'ZAJ',email: 'randallroy@zaj.com',phone: '+1 (938) 562-2214',address: '872 Rugby Road, Hoehne, Indiana, 9792',about:'Non laboris id et cupidatat velit ea ipsum ea mollit quis qui dolore nisi laboris. Enim sit irure enim dolor velit proident sunt pariatur proident consequat mollit enim minim. Laboris deserunt cupidatat nisi enim adipisicing officia dolore ex cupidatat anim. Cupidatat labore voluptate non magna est dolor. Occaecat occaecat magna anim laborum adipisicing esse excepteur cillum aute qui eu do excepteur eu. Nostrud consectetur consectetur aliquip deserunt velit culpa sint excepteur mollit nostrud sit ex. Est ex ut laboris pariatur.\r\n',registered: '2016-05-05T05:24:56 +04:00',latitude: 18.943281,longitude: -110.942673,tags: ['eu','aliqua','reprehenderit','amet','nulla','consequat','nisi',],friends: [{id: 0,name: 'Barron Maynard',},{id: 1,name: 'Lynn Shepard',},{id: 2,name: 'Robin Whitehead',},],greeting: 'Hello, Randall Roy! You have 3 unread messages.',favoriteFruit: 'strawberry',},{_id: '584f17142a8f47cef0f5401a',index: 4,guid: '9b50ec22-3fbe-40ce-a5b8-b956f1340a77',isActive: false,balance: '$3,234.48',picture: 'http://placehold.it/32x32',age: 33,eyeColor: 'green',name: 'Chandler Vasquez',gender: 'male',company: 'ZILLACTIC',email: 'chandlervasquez@zillactic.com',phone: '+1 (830) 550-3428',address: '610 Hunts Lane, Cazadero, Michigan, 3584',about:'Fugiat in anim adipisicing sint aliquip ea velit do proident eu ad amet. Nulla velit duis ullamco labore ea Lorem velit elit Lorem. Id laboris do mollit exercitation veniam do amet culpa est excepteur reprehenderit consectetur laborum.\r\n',registered: '2014-04-20T05:23:32 +04:00',latitude: -88.088841,longitude: -163.602482,tags: ['sunt','excepteur','enim','incididunt','officia','amet','irure',],friends: [{id: 0,name: 'Mckee Norton',},{id: 1,name: 'Durham Parrish',},{id: 2,name: 'Stewart Kramer',},],greeting: 'Hello, Chandler Vasquez! You have 3 unread messages.',favoriteFruit: 'strawberry',},{_id: '584f171450a4e9dda687adc5',index: 5,guid: '68eeea45-ba6e-4740-b89b-10d690c37a02',isActive: false,balance: '$3,771.46',picture: 'http://placehold.it/32x32',age: 25,eyeColor: 'blue',name: 'Fernandez Caldwell',gender: 'male',company: 'SNIPS',email: 'fernandezcaldwell@snips.com',phone: '+1 (911) 544-3684',address: '786 Newel Street, Elliston, Massachusetts, 6683',about:'Voluptate commodo labore aliqua excepteur irure aliquip officia. Incididunt excepteur elit quis reprehenderit voluptate aliqua ad voluptate duis nisi dolor dolor id dolor. Irure sit consequat amet ea magna laborum velit eu in. Sunt occaecat quis consectetur laboris. Duis est do eu consectetur dolore id incididunt incididunt ut esse magna est. Nostrud irure magna nulla fugiat deserunt deserunt enim mollit proident qui sint dolore incididunt. Incididunt incididunt do quis culpa sint ut aliqua id.\r\n',registered: '2015-08-09T09:02:36 +04:00',latitude: -46.941347,longitude: -171.796168,tags: ['sit','irure','reprehenderit','ut','proident','aliquip','labore',],friends: [{id: 0,name: 'Adela Preston',},{id: 1,name: 'Phillips Moses',},{id: 2,name: 'Neva Wise',},],greeting: 'Hello, Fernandez Caldwell! You have 10 unread messages.',favoriteFruit: 'apple',},]

Const lu

lu: RegExp = /(?:\\(u(?:[a-f\d]{4}|\{[a-f\d]{1,6}\})|x[a-f\d]{2}|.))|(?:\{(~)?(\w+(?:\([^)]*\))?(?:\.\w+(?:\([^)]*\))?)*)(?:[ \t]|(?=\r?\n)))|(\})|((?:.|[\r\n\f])+?)/gi

Const m

m: m

Const map_1

map_1: "D:/TS-doc/nest/packages/microservices/node_modules/iterare/lib/map" = require("./map")

mergeConfig

mergeConfig: mergeConfig = require('./mergeConfig')

Const messages_1

messages_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/helpers/messages" = require("../helpers/messages")

Const metadataKeys

metadataKeys: string[] = [metadataConstants.IMPORTS,metadataConstants.EXPORTS,metadataConstants.CONTROLLERS,metadataConstants.PROVIDERS,]

Const metadata_scanner_1

metadata_scanner_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/metadata-scanner" = require("../metadata-scanner")

Const middleware_module_1

middleware_module_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/middleware/middleware-module" = require("./middleware/middleware-module")

Const models

models: string[] = Object.keys(conversions)

Const module_1

module_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/injector/module" = require("./module")

Const module_decorator_1

module_decorator_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/common/decorators/modules/module.decorator" = require("../decorators/modules/module.decorator")

Const module_ref_1

module_ref_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/injector/module-ref" = require("./module-ref")

Const module_token_factory_1

module_token_factory_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/injector/module-token-factory" = require("./module-token-factory")

Const modules_container_1

modules_container_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/injector/modules-container" = require("./modules-container")

Let mqttPackage

mqttPackage: any

mu

mu: { has16m: boolean; has256: boolean; hasBasic: boolean; level: any }

Type declaration

  • has16m: boolean
  • has256: boolean
  • hasBasic: boolean
  • level: any

n

n: any = u(require("tty"))

Const namespace

namespace: "namespace" = "namespace"

Let natsPackage

natsPackage: any

Const nest_application_1

nest_application_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/nest-application" = require("./nest-application")

Const nest_application_context_1

nest_application_context_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/nest-application-context" = require("./nest-application-context")

nest_factory_1

nest_factory_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/nest-factory" = require("./nest-factory")

net

net: "net" = require('net')

normalizeHeaderName

normalizeHeaderName: normalizeHeaderName = require('./helpers/normalizeHeaderName')

Let nu

nu: any

o

o: any

Const operators_1

operators_1: "D:/TS-doc/nest/node_modules/rxjs/operators/index" = require("rxjs/operators")

Const optional_decorator_1

optional_decorator_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/common/decorators/core/optional.decorator" = require("../decorators/core/optional.decorator")

Const optional_require_1

optional_require_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/helpers/optional-require" = require("./helpers/optional-require")

Const os

os: "os" = require('os')

Const os_1

os_1: "os" = require("os")

p

p: Readonly<{ browser: boolean; ci: boolean; darwin: boolean; debug: boolean; dev: boolean; linux: boolean; minimal: undefined; minimalCLI: undefined; production: boolean; test: boolean; tty: boolean; windows: boolean }> = Object.freeze(g)

Const params_token_factory_1

params_token_factory_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/pipes/params-token-factory" = require("./params-token-factory")

parseHeaders

parseHeaders: parseHeaders = require('./../helpers/parseHeaders')

Const parse_url

parse_url: any = Url.parse

path

path: PlatformPath = require('path')

Const pathToRegexp

  • pathToRegexp(path: string | RegExp | any[], keys: any[], options: any): RegExp
  • Normalize the given path string, returning a regular expression.

    An empty array can be passed in for the keys, which will hold the placeholder key descriptions. For example, using /user/:id, keys will contain [{ name: 'id', delimiter: '/', optional: false, repeat: false }].

    Parameters

    • path: string | RegExp | any[]
    • keys: any[]
    • options: any

    Returns RegExp

path__default

path__default: any = _interopDefaultLegacy(path)

Let paused

paused: boolean = false

Const pipes_consumer_1

pipes_consumer_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/pipes/pipes-consumer" = require("../pipes/pipes-consumer")

Const pipes_context_creator_1

pipes_context_creator_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/pipes/pipes-context-creator" = require("../pipes/pipes-context-creator")

pkg

pkg: any = require('./../../package.json')

Let poolPtr

poolPtr: number = rnds8Pool.length

port

port: number = 9838

Const process

process: any

Const proto

proto: any = Object.defineProperties(() => {}, {...styles,level: {enumerable: true,get() {return this._generator.level;},set(level) {this._generator.level = level;}}})

Const queue

queue: any[] = []

r

r: any = u(require("os"))

Const random_string_generator_util_1

random_string_generator_util_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/common/utils/random-string-generator.util" = require("@nestjs/common/utils/random-string-generator.util")

Let redisPackage

redisPackage: any

replacerStack

replacerStack: any[] = []

Const request_constants_1

request_constants_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/router/request/request-constants" = require("./request/request-constants")

Const request_method_enum_1

request_method_enum_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/common/enums/request-method.enum" = require("@nestjs/common/enums/request-method.enum")

Const request_providers_1

request_providers_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/router/request/request-providers" = require("../router/request/request-providers")

Const resolve_url

resolve_url: any = Url.resolve

Const resolver_1

resolver_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/middleware/resolver" = require("./resolver")

Const rethrow_1

rethrow_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/helpers/rethrow" = require("./helpers/rethrow")

retrieveCols

retrieveCols: (Anonymous function) = function () {var result = false;return function () {if (result) {return result;}var defaultCols = 80;try {var terminalCols = child_process.execSync('tput cols', {stdio: ['pipe', 'pipe', 'ignore']});result = parseInt(terminalCols.toString()) || defaultCols;} catch (e) {result = defaultCols;}return result;};}()

Const reverseKeywords

reverseKeywords: reverseKeywords

Const rnds8

rnds8: Uint8Array = new Uint8Array(16)

Const rnds8Pool

rnds8Pool: Uint8Array = new Uint8Array(256)

Const route

route: __type = require('./route')

Const route_params_factory_1

route_params_factory_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/router/route-params-factory" = require("./route-params-factory")

Const route_paramtypes_enum_1

route_paramtypes_enum_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/common/enums/route-paramtypes.enum" = require("@nestjs/common/enums/route-paramtypes.enum")

Const router_exception_filters_1

router_exception_filters_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/router/router-exception-filters" = require("./router-exception-filters")

Const router_execution_context_1

router_execution_context_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/router/router-execution-context" = require("./router-execution-context")

Const router_explorer_1

router_explorer_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/router/router-explorer" = require("./router-explorer")

Const router_method_factory_1

router_method_factory_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/helpers/router-method-factory" = require("../helpers/router-method-factory")

Const router_proxy_1

router_proxy_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/router/router-proxy" = require("./router-proxy")

Const router_response_controller_1

router_response_controller_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/router/router-response-controller" = require("./router-response-controller")

Const routes_mapper_1

routes_mapper_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/middleware/routes-mapper" = require("./routes-mapper")

Const routes_resolver_1

routes_resolver_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/router/routes-resolver" = require("./router/routes-resolver")

Let rqmPackage

rqmPackage: any

ru

ru: ProcessEnv

Const runtime_exception_1

runtime_exception_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/errors/exceptions/runtime.exception" = require("../errors/exceptions/runtime.exception")

Const rxjs_1

rxjs_1: "D:/TS-doc/nest/node_modules/rxjs/index" = require("rxjs")

Const scanner_1

scanner_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/scanner" = require("./scanner")

server

server: Server = net.createServer()

Const services_1

services_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/services/index" = require("../services")

settle

settle: settle = require('./../core/settle')

Const shared_utils_1

shared_utils_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/common/utils/shared.utils" = require("@nestjs/common/utils/shared.utils")

Const slice_1

slice_1: "D:/TS-doc/nest/packages/microservices/node_modules/iterare/lib/slice" = require("./slice")

socket

socket: JsonSocket = new JsonSocket(new net.Socket())

socketName

socketName: string = "/tmp/socket.sock"

Const sse_stream_1

sse_stream_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/router/sse-stream" = require("./sse-stream")

stderrColor

stderrColor: false | true | { has16m: boolean; has256: boolean; hasBasic: boolean; level: any }

stdoutColor

stdoutColor: false | true | { has16m: boolean; has256: boolean; hasBasic: boolean; level: any }

Const streamDestructionSupported

streamDestructionSupported: boolean = 'destroy' in Stream.Readable.prototype

Const stream_1

stream_1: internal = require("stream")

Const styles

styles: any = Object.create(null)

Const suite

suite: any = new Benchmark.Suite()

t

t: "fs" = require("fs")

Let template

template: any

Const test

test: any = require('tap').test

Const time

time: [number, number] = process.hrtime()

toString

toString: toString = Object.prototype.toString

transformData

transformData: transformData = require('./transformData')

Const transient_instances_1

transient_instances_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/injector/helpers/transient-instances" = require("../injector/helpers/transient-instances")

Const tslib_1

tslib_1: "D:/TS-doc/nest/packages/microservices/node_modules/tslib/tslib" = require("tslib")

Const tty

tty: "tty" = require('tty')

Const undefined_dependency_exception_1

undefined_dependency_exception_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/errors/exceptions/undefined-dependency.exception" = require("../errors/exceptions/undefined-dependency.exception")

Const undefined_forwardref_exception_1

undefined_forwardref_exception_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/errors/exceptions/undefined-forwardref.exception" = require("../errors/exceptions/undefined-forwardref.exception")

Const undefined_module_exception_1

undefined_module_exception_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/errors/exceptions/undefined-module.exception" = require("./errors/exceptions/undefined-module.exception")

Const unknown_dependencies_exception_1

unknown_dependencies_exception_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/errors/exceptions/unknown-dependencies.exception" = require("../errors/exceptions/unknown-dependencies.exception")

Const unknown_element_exception_1

unknown_element_exception_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/errors/exceptions/unknown-element.exception" = require("./errors/exceptions/unknown-element.exception")

Const unknown_export_exception_1

unknown_export_exception_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/errors/exceptions/unknown-export.exception" = require("../errors/exceptions/unknown-export.exception")

Const unknown_module_exception_1

unknown_module_exception_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/errors/exceptions/unknown-module.exception" = require("./errors/exceptions/unknown-module.exception")

Const unknown_request_mapping_exception_1

unknown_request_mapping_exception_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/core/errors/exceptions/unknown-request-mapping.exception" = require("../errors/exceptions/unknown-request-mapping.exception")

url

url: "url" = require("url")

Const usedModels

usedModels: string[] = ['rgb', 'hex', 'keyword', 'hsl', 'hsv', 'hwb', 'ansi', 'ansi256']

utils

utils: { extend: extend; forEach: forEach; isArray: isArray; isArrayBuffer: isArrayBuffer; isArrayBufferView: isArrayBufferView; isBlob: isBlob; isBuffer: isBuffer; isDate: isDate; isFile: isFile; isFormData: isFormData; isFunction: isFunction; isNumber: isNumber; isObject: isObject; isPlainObject: isPlainObject; isStandardBrowserEnv: isStandardBrowserEnv; isStream: isStream; isString: isString; isURLSearchParams: isURLSearchParams; isUndefined: isUndefined; merge: merge; stripBOM: stripBOM; trim: trim } = require('./../utils')

Type declaration

Const utils_1

utils_1: "D:/TS-doc/nest/packages/microservices/node_modules/iterare/lib/utils" = require("./utils")

Const uu

uu: uu

Const uuid_1

uuid_1: "D:/TS-doc/nest/packages/microservices/node_modules/uuid/dist/index" = require("uuid")

Const v

v: any[] = []

Const v3

v3: any = (0, _v.default)('v3', 0x30, _md.default)

Const v5

v5: any = (0, _v.default)('v5', 0x50, _sha.default)

Const validate_each_util_1

validate_each_util_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/common/utils/validate-each.util" = require("../../utils/validate-each.util")

Const validate_module_keys_util_1

validate_module_keys_util_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/common/utils/validate-module-keys.util" = require("../../utils/validate-module-keys.util")

Const validation_pipe_1

validation_pipe_1: "D:/TS-doc/nest/packages/microservices/node_modules/@nestjs/common/pipes/validation.pipe" = require("./validation.pipe")

Const vu

vu: string[] = ["ansi","ansi","ansi256","ansi16m"]

w

w: any = s((function(u,D){u.exports=function(){var u="millisecond",D="second",e="minute",t="hour",r="day",n="week",s="month",o="quarter",i="year",a=/^(\d{4})-?(\d{1,2})-?(\d{0,2})[^0-9]*(\d{1,2})?:?(\d{1,2})?:?(\d{1,2})?.?(\d{1,3})?$/,l=/\[([^\]]+)]|Y{2,4}|M{1,4}|D{1,2}|d{1,4}|H{1,2}|h{1,2}|a|A|m{1,2}|s{1,2}|Z{1,2}|SSS/g,c=function(u,D,e){var t=String(u);return!t||t.length>=D?u:""+Array(D+1-t.length).join(e)+u},h={s:c,z:function(u){var D=-u.utcOffset(),e=Math.abs(D),t=Math.floor(e/60),r=e%60;return(D<=0?"+":"-")+c(t,2,"0")+":"+c(r,2,"0")},m:function(u,D){var e=12*(D.year()-u.year())+(D.month()-u.month()),t=u.clone().add(e,s),r=D-t<0,n=u.clone().add(e+(r?-1:1),s);return Number(-(e+(D-t)/(r?t-n:n-t))||0)},a:function(u){return u<0?Math.ceil(u)||0:Math.floor(u)},p:function(a){return{M:s,y:i,w:n,d:r,D:"date",h:t,m:e,s:D,ms:u,Q:o}[a]||String(a||"").toLowerCase().replace(/s$/,"")},u:function(u){return void 0===u}},F={name:"en",weekdays:"Sunday_Monday_Tuesday_Wednesday_Thursday_Friday_Saturday".split("_"),months:"January_February_March_April_May_June_July_August_September_October_November_December".split("_")},C="en",f={};f[C]=F;var E=function(u){return u instanceof m},d=function(u,D,e){var t;if(!u)return C;if("string"==typeof u)f[u]&&(t=u),D&&(f[u]=D,t=u);else{var r=u.name;f[r]=u,t=r}return!e&&t&&(C=t),t||!e&&C},g=function(u,D){if(E(u))return u.clone();var e="object"==typeof D?D:{};return e.date=u,e.args=arguments,new m(e)},p=h;p.l=d,p.i=E,p.w=function(u,D){return g(u,{locale:D.$L,utc:D.$u,$offset:D.$offset})};var m=function(){function c(u){this.$L=this.$L||d(u.locale,null,!0),this.parse(u)}var h=c.prototype;return h.parse=function(u){this.$d=function(u){var D=u.date,e=u.utc;if(null===D)return new Date(NaN);if(p.u(D))return new Date;if(D instanceof Date)return new Date(D);if("string"==typeof D&&!/Z$/i.test(D)){var t=D.match(a);if(t)return e?new Date(Date.UTC(t[1],t[2]-1,t[3]||1,t[4]||0,t[5]||0,t[6]||0,t[7]||0)):new Date(t[1],t[2]-1,t[3]||1,t[4]||0,t[5]||0,t[6]||0,t[7]||0)}return new Date(D)}(u),this.init()},h.init=function(){var u=this.$d;this.$y=u.getFullYear(),this.$M=u.getMonth(),this.$D=u.getDate(),this.$W=u.getDay(),this.$H=u.getHours(),this.$m=u.getMinutes(),this.$s=u.getSeconds(),this.$ms=u.getMilliseconds()},h.$utils=function(){return p},h.isValid=function(){return!("Invalid Date"===this.$d.toString())},h.isSame=function(u,D){var e=g(u);return this.startOf(D)<=e&&e<=this.endOf(D)},h.isAfter=function(u,D){return g(u)<this.startOf(D)},h.isBefore=function(u,D){return this.endOf(D)<g(u)},h.$g=function(u,D,e){return p.u(u)?this[D]:this.set(e,u)},h.year=function(u){return this.$g(u,"$y",i)},h.month=function(u){return this.$g(u,"$M",s)},h.day=function(u){return this.$g(u,"$W",r)},h.date=function(u){return this.$g(u,"$D","date")},h.hour=function(u){return this.$g(u,"$H",t)},h.minute=function(u){return this.$g(u,"$m",e)},h.second=function(u){return this.$g(u,"$s",D)},h.millisecond=function(D){return this.$g(D,"$ms",u)},h.unix=function(){return Math.floor(this.valueOf()/1e3)},h.valueOf=function(){return this.$d.getTime()},h.startOf=function(u,o){var a=this,l=!!p.u(o)||o,c=p.p(u),h=function(u,D){var e=p.w(a.$u?Date.UTC(a.$y,D,u):new Date(a.$y,D,u),a);return l?e:e.endOf(r)},F=function(u,D){return p.w(a.toDate()[u].apply(a.toDate("s"),(l?[0,0,0,0]:[23,59,59,999]).slice(D)),a)},C=this.$W,f=this.$M,E=this.$D,d="set"+(this.$u?"UTC":"");switch(c){case i:return l?h(1,0):h(31,11);case s:return l?h(1,f):h(0,f+1);case n:var g=this.$locale().weekStart||0,m=(C<g?C+7:C)-g;return h(l?E-m:E+(6-m),f);case r:case"date":return F(d+"Hours",0);case t:return F(d+"Minutes",1);case e:return F(d+"Seconds",2);case D:return F(d+"Milliseconds",3);default:return this.clone()}},h.endOf=function(u){return this.startOf(u,!1)},h.$set=function(n,o){var a,l=p.p(n),c="set"+(this.$u?"UTC":""),h=(a={},a.day=c+"Date",a.date=c+"Date",a[s]=c+"Month",a[i]=c+"FullYear",a[t]=c+"Hours",a[e]=c+"Minutes",a[D]=c+"Seconds",a[u]=c+"Milliseconds",a)[l],F=l===r?this.$D+(o-this.$W):o;if(l===s||l===i){var C=this.clone().set("date",1);C.$d[h](F),C.init(),this.$d=C.set("date",Math.min(this.$D,C.daysInMonth())).toDate()}else h&&this.$d[h](F);return this.init(),this},h.set=function(u,D){return this.clone().$set(u,D)},h.get=function(u){return this[p.p(u)]()},h.add=function(u,o){var a,l=this;u=Number(u);var c=p.p(o),h=function(D){var e=g(l);return p.w(e.date(e.date()+Math.round(D*u)),l)};if(c===s)return this.set(s,this.$M+u);if(c===i)return this.set(i,this.$y+u);if(c===r)return h(1);if(c===n)return h(7);var F=(a={},a[e]=6e4,a[t]=36e5,a[D]=1e3,a)[c]||1,C=this.$d.getTime()+u*F;return p.w(C,this)},h.subtract=function(u,D){return this.add(-1*u,D)},h.format=function(u){var D=this;if(!this.isValid())return"Invalid Date";var e=u||"YYYY-MM-DDTHH:mm:ssZ",t=p.z(this),r=this.$locale(),n=this.$H,s=this.$m,o=this.$M,i=r.weekdays,a=r.months,c=function(u,t,r,n){return u&&(u[t]||u(D,e))||r[t].substr(0,n)},h=function(u){return p.s(n%12||12,u,"0")},F=r.meridiem||function(u,D,e){var t=u<12?"AM":"PM";return e?t.toLowerCase():t},C={YY:String(this.$y).slice(-2),YYYY:this.$y,M:o+1,MM:p.s(o+1,2,"0"),MMM:c(r.monthsShort,o,a,3),MMMM:c(a,o),D:this.$D,DD:p.s(this.$D,2,"0"),d:String(this.$W),dd:c(r.weekdaysMin,this.$W,i,2),ddd:c(r.weekdaysShort,this.$W,i,3),dddd:i[this.$W],H:String(n),HH:p.s(n,2,"0"),h:h(1),hh:h(2),a:F(n,s,!0),A:F(n,s,!1),m:String(s),mm:p.s(s,2,"0"),s:String(this.$s),ss:p.s(this.$s,2,"0"),SSS:p.s(this.$ms,3,"0"),Z:t};return e.replace(l,(function(u,D){return D||C[u]||t.replace(":","")}))},h.utcOffset=function(){return 15*-Math.round(this.$d.getTimezoneOffset()/15)},h.diff=function(u,r,a){var l,c=p.p(r),h=g(u),F=6e4*(h.utcOffset()-this.utcOffset()),C=this-h,f=p.m(this,h);return f=(l={},l[i]=f/12,l[s]=f,l[o]=f/3,l[n]=(C-F)/6048e5,l.day=(C-F)/864e5,l[t]=C/36e5,l[e]=C/6e4,l[D]=C/1e3,l)[c]||C,a?f:p.a(f)},h.daysInMonth=function(){return this.endOf(s).$D},h.$locale=function(){return f[this.$L]},h.locale=function(u,D){if(!u)return this.$L;var e=this.clone(),t=d(u,D,!0);return t&&(e.$L=t),e},h.clone=function(){return p.w(this.$d,this)},h.toDate=function(){return new Date(this.valueOf())},h.toJSON=function(){return this.isValid()?this.toISOString():null},h.toISOString=function(){return this.$d.toISOString()},h.toString=function(){return this.$d.toUTCString()},c}();return g.prototype=m.prototype,g.extend=function(u,D){return u(D,m,g),g},g.locale=d,g.isDayjs=E,g.unix=function(u){return g(1e3*u)},g.en=f[C],g.Ls=f,g}()}))

x

x: L = L

xu

xu: (Anonymous function) = $u

Const yellow

yellow: (Anonymous function) = colorIfAllowed((text: string) => `\x1B[38;5;3m${text}\x1B[39m`,)

yu

yu: (Anonymous function)

Const z

z: z

Const zip_1

zip_1: "D:/TS-doc/nest/packages/microservices/node_modules/iterare/lib/zip" = require("./zip")

zlib

zlib: any = _interopDefault(require('zlib'))

Functions

A

  • A(u: any): any
  • Parameters

    • u: any

    Returns any

AbortError

  • AbortError(message: any): void
  • Create AbortError instance

    Parameters

    • message: any

    Returns void

    AbortError

Bind

  • Bind(...decorators: any[]): (Anonymous function)
  • Decorator that binds parameter decorators to the method that follows.

    Useful when the language doesn't provide a 'Parameter Decorator' feature (i.e., vanilla JavaScript).

    publicapi

    Parameters

    • Rest ...decorators: any[]

      one or more parameter decorators (e.g., Req())

    Returns (Anonymous function)

Body

  • Route handler parameter decorator. Extracts the entire body object property, or optionally a named property of the body object, from the req object and populates the decorated parameter with that value. Also applies pipes to the bound body parameter.

    For example:

    async create(@Body('role', new ValidationPipe()) role: string)
    see

    Request object

    see

    Working with pipes

    publicapi

    Parameters

    • property: any

      name of single property to extract from the body object

    • Rest ...pipes: any[]

      one or more pipes - either instances or classes - to apply to the bound body parameter.

    Returns (Anonymous function)

    Void

  • Route handler parameter decorator. Extracts the entire body object from the req object and populates the decorated parameter with the value of body.

    For example:

    async create(@Body() cat: CreateCatDto)
    see

    Request object

    publicapi

    Returns ParameterDecorator

    Void

  • Route handler parameter decorator. Extracts the entire body object from the req object and populates the decorated parameter with the value of body. Also applies the specified pipes to that parameter.

    For example:

    async create(@Body(new ValidationPipe()) cat: CreateCatDto)
    see

    Request object

    see

    Working with pipes

    publicapi

    Parameters

    Returns ParameterDecorator

    Void

  • Route handler parameter decorator. Extracts a single property from the body object property of the req object and populates the decorated parameter with the value of that property. Also applies pipes to the bound body parameter.

    For example:

    async create(@Body('role', new ValidationPipe()) role: string)
    see

    Request object

    see

    Working with pipes

    publicapi

    Parameters

    • property: string

      name of single property to extract from the body object

    • Rest ...pipes: (Type<PipeTransform> | PipeTransform)[]

      one or more pipes - either instances or classes - to apply to the bound body parameter.

    Returns ParameterDecorator

    Void

Const CacheKey

Const CacheTTL

Cancel

  • Cancel(message: string): void
  • A Cancel is an object that is thrown when an operation is canceled.

    Parameters

    • message: string

      The message.

    Returns void

CancelToken

  • A CancelToken is an object that can be used to request cancellation of an operation.

    Parameters

    • executor: Function

      The executor function.

    Returns void

Catch

  • Catch(...exceptions: any[]): (Anonymous function)
  • Decorator that marks a class as a Nest exception filter. An exception filter handles exceptions thrown by or not handled by your application code.

    The decorated class must implement the ExceptionFilter interface.

    see

    Exception Filters

    usagenotes

    Exception filters are applied using the @UseFilters() decorator, or (globally) with app.useGlobalFilters().

    publicapi

    Parameters

    • Rest ...exceptions: any[]

      one or more exception types specifying the exceptions to be caught and handled by this filter.

    Returns (Anonymous function)

Chalk

  • Chalk(options: any): (Anonymous function)
  • Parameters

    • options: any

    Returns (Anonymous function)

Controller

  • Controller(prefixOrOptions: any): (Anonymous function)
  • Controller(): ClassDecorator
  • Controller(prefix: string): ClassDecorator
  • Controller(options: ControllerOptions): ClassDecorator
  • Decorator that marks a class as a Nest controller that can receive inbound requests and produce responses.

    An HTTP Controller responds to inbound HTTP Requests and produces HTTP Responses. It defines a class that provides the context for one or more related route handlers that correspond to HTTP request methods and associated routes for example GET /api/profile, POST /user/resume

    A Microservice Controller responds to requests as well as events, running over a variety of transports (read more here). It defines a class that provides a context for one or more message or event handlers.

    see

    Routing

    see

    Controllers

    see

    Microservices

    see

    Scope

    publicapi

    Parameters

    • prefixOrOptions: any

      a route path prefix or a ControllerOptions object. A route path prefix is pre-pended to the path specified in any request decorator in the class. ControllerOptions is an options configuration object specifying:

      • scope - symbol that determines the lifetime of a Controller instance. See Scope for more details.
      • prefix - string that defines a route path prefix. The prefix is pre-pended to the path specified in any request decorator in the class.

    Returns (Anonymous function)

  • Decorator that marks a class as a Nest controller that can receive inbound requests and produce responses.

    An HTTP Controller responds to inbound HTTP Requests and produces HTTP Responses. It defines a class that provides the context for one or more related route handlers that correspond to HTTP request methods and associated routes for example GET /api/profile, POST /user/resume.

    A Microservice Controller responds to requests as well as events, running over a variety of transports (read more here). It defines a class that provides a context for one or more message or event handlers.

    see

    Controllers

    see

    Microservices

    publicapi

    Returns ClassDecorator

  • Decorator that marks a class as a Nest controller that can receive inbound requests and produce responses.

    An HTTP Controller responds to inbound HTTP Requests and produces HTTP Responses. It defines a class that provides the context for one or more related route handlers that correspond to HTTP request methods and associated routes for example GET /api/profile, POST /user/resume.

    A Microservice Controller responds to requests as well as events, running over a variety of transports (read more here). It defines a class that provides a context for one or more message or event handlers.

    see

    Routing

    see

    Controllers

    see

    Microservices

    publicapi

    Parameters

    • prefix: string

      string that defines a route path prefix. The prefix is pre-pended to the path specified in any request decorator in the class.

    Returns ClassDecorator

  • Decorator that marks a class as a Nest controller that can receive inbound requests and produce responses.

    An HTTP Controller responds to inbound HTTP Requests and produces HTTP Responses. It defines a class that provides the context for one or more related route handlers that correspond to HTTP request methods and associated routes for example GET /api/profile, POST /user/resume.

    A Microservice Controller responds to requests as well as events, running over a variety of transports (read more here). It defines a class that provides a context for one or more message or event handlers.

    see

    Routing

    see

    Controllers

    see

    Microservices

    publicapi

    Parameters

    • options: ControllerOptions

      configuration object specifying:

      • scope - symbol that determines the lifetime of a Controller instance. See Scope for more details.
      • prefix - string that defines a route path prefix. The prefix is pre-pended to the path specified in any request decorator in the class.

    Returns ClassDecorator

Const DEFAULT_TEARDOWN

  • DEFAULT_TEARDOWN(): never
  • Returns never

Const Dependencies

  • Dependencies(...dependencies: Array<unknown>): ClassDecorator

Eu

  • Eu(u: any, D: any): any[]
  • Parameters

    • u: any
    • D: any

    Returns any[]

Const EventPattern

  • EventPattern<T>(metadata?: T, transport?: Transport): MethodDecorator

FetchError

  • FetchError(message: any, type: any, systemError: any): void
  • Create FetchError instance

    Parameters

    • message: any
    • type: any
    • systemError: any

    Returns void

    FetchError

Global

  • Global(): (Anonymous function)
  • Decorator that makes a module global-scoped.

    Once imported into any module, a global-scoped module will be visible in all modules. Thereafter, modules that wish to inject a service exported from a global module do not need to import the provider module.

    see

    Global modules

    publicapi

    Returns (Anonymous function)

GrpcMethod

  • GrpcMethod(service?: string): MethodDecorator
  • GrpcMethod(service: string, method?: string): MethodDecorator

GrpcStreamCall

  • GrpcStreamCall(service?: string): MethodDecorator
  • GrpcStreamCall(service: string, method?: string): MethodDecorator

GrpcStreamMethod

  • GrpcStreamMethod(service?: string): MethodDecorator
  • GrpcStreamMethod(service: string, method?: string): MethodDecorator

Header

  • Header(name: any, value: any): (Anonymous function)
  • Request method Decorator. Sets a response header.

    For example: @Header('Cache-Control', 'none')

    see

    Headers

    publicapi

    Parameters

    • name: any

      string to be used for header name

    • value: any

      string to be used for header value

    Returns (Anonymous function)

HostParam

  • HostParam(property: any): (Anonymous function)
  • HostParam(): ParameterDecorator
  • HostParam(property: string): ParameterDecorator
  • Route handler parameter decorator. Extracts the hosts property from the req object and populates the decorated parameter with the value of params. May also apply pipes to the bound parameter.

    For example, extracting all params:

    findOne(@HostParam() params: string[])

    For example, extracting a single param:

    findOne(@HostParam('id') id: string)
    see

    Request object

    publicapi

    Parameters

    • property: any

      name of single property to extract from the req object

    Returns (Anonymous function)

  • Route handler parameter decorator. Extracts the hosts property from the req object and populates the decorated parameter with the value of hosts. May also apply pipes to the bound parameter.

    For example, extracting all params:

    findOne(@HostParam() params: string[])

    For example, extracting a single param:

    findOne(@HostParam('id') id: string)
    see

    Request object

    publicapi

    Returns ParameterDecorator

  • Route handler parameter decorator. Extracts the hosts property from the req object and populates the decorated parameter with the value of hosts. May also apply pipes to the bound parameter.

    For example, extracting all params:

    findOne(@HostParam() params: string[])

    For example, extracting a single param:

    findOne(@HostParam('id') id: string)
    see

    Request object

    publicapi

    Parameters

    • property: string

      name of single property to extract from the req object

    Returns ParameterDecorator

HttpCode

  • HttpCode(statusCode: any): (Anonymous function)
  • Request method Decorator. Defines the HTTP response status code. Overrides default status code for the decorated request method.

    see

    Http Status Codes

    publicapi

    Parameters

    • statusCode: any

      HTTP response code to be returned by route handler.

    Returns (Anonymous function)

I

  • I(u: any): any
  • Parameters

    • u: any

    Returns any

Const INVALID_CLASS_MESSAGE

  • INVALID_CLASS_MESSAGE(text: TemplateStringsArray, value: any): string

Const INVALID_CLASS_SCOPE_MESSAGE

  • INVALID_CLASS_SCOPE_MESSAGE(text: TemplateStringsArray, name: string | undefined): string

Const INVALID_MIDDLEWARE_MESSAGE

  • INVALID_MIDDLEWARE_MESSAGE(text: TemplateStringsArray, name: string): string

Const INVALID_MODULE_CONFIG_MESSAGE

  • INVALID_MODULE_CONFIG_MESSAGE(text: TemplateStringsArray, property: string): string

Const INVALID_MODULE_MESSAGE

  • INVALID_MODULE_MESSAGE(parentModule: any, index: number, scope: any[]): string

Inject

  • Inject(token: any): (Anonymous function)
  • Decorator that marks a constructor parameter as a target for Dependency Injection (DI).

    Any injected provider must be visible within the module scope (loosely speaking, the containing module) of the class it is being injected into. This can be done by:

    • defining the provider in the same module scope
    • exporting the provider from one module scope and importing that module into the module scope of the class being injected into
    • exporting the provider from a module that is marked as global using the @Global() decorator

    Injection tokens

    Can be types (class names), strings or symbols. This depends on how the provider with which it is associated was defined. Providers defined with the @Injectable() decorator use the class name. Custom Providers may use strings or symbols as the injection token.

    see

    Providers

    see

    Custom Providers

    see

    Injection Scopes

    publicapi

    Parameters

    • token: any

      lookup key for the provider to be injected (assigned to the constructor parameter).

    Returns (Anonymous function)

Injectable

  • Injectable(options: any): (Anonymous function)
  • Decorator that marks a class as a provider. Providers can be injected into other classes via constructor parameter injection using Nest's built-in Dependency Injection (DI) system.

    When injecting a provider, it must be visible within the module scope (loosely speaking, the containing module) of the class it is being injected into. This can be done by:

    • defining the provider in the same module scope
    • exporting the provider from one module scope and importing that module into the module scope of the class being injected into
    • exporting the provider from a module that is marked as global using the @Global() decorator

    Providers can also be defined in a more explicit and imperative form using various custom provider techniques that expose more capabilities of the DI system.

    see

    Providers

    see

    Custom Providers

    see

    Injection Scopes

    publicapi

    Parameters

    • options: any

      options specifying scope of injectable

    Returns (Anonymous function)

Const Iu

  • Iu(u: any, D: any, e: any): { close: any; closeAll: any; open: any; openAll: any; parent: any }
  • Parameters

    • u: any
    • D: any
    • e: any

    Returns { close: any; closeAll: any; open: any; openAll: any; parent: any }

    • close: any
    • closeAll: any
    • open: any
    • openAll: any
    • parent: any

JsonSocket

  • JsonSocket(socket: any, opts: any): void
  • Parameters

    • socket: any
    • opts: any

    Returns void

constructor

Private buffer

buffer: string = ""

Private contentLength

contentLength: number | null = null

Private Readonly delimeter

delimeter: "#" = "#"

Private isClosed

isClosed: boolean = false

Readonly socket

socket: Socket

Private Readonly stringDecoder

stringDecoder: StringDecoder = new StringDecoder()

netSocket

  • get netSocket(): Socket

connect

  • connect(port: number, host: string): this

end

  • end(): this

Private formatMessageData

  • formatMessageData(message: any): string

Private handleData

  • handleData(data: string): void

Private handleMessage

  • handleMessage(data: string): void

on

  • on(event: string, callback: (err?: any) => void): this

Private onData

  • onData(dataRaw: Buffer | string): void

once

  • once(event: string, callback: (err?: any) => void): this

sendMessage

  • sendMessage(message: any, callback?: (err?: any) => void): void

K

  • K(u: any): u
  • Parameters

    • u: any

    Returns u

Const KafkaLogger

  • KafkaLogger(logger: any): (Anonymous function)

Const L

  • L(u: any): number
  • Parameters

    • u: any

    Returns number

Const Lu

  • Lu(u: any, ...D: any[]): any
  • Parameters

    • u: any
    • Rest ...D: any[]

    Returns any

Const M

  • M(u: any): string
  • Parameters

    • u: any

    Returns string

Const MISSING_REQUIRED_DEPENDENCY

  • MISSING_REQUIRED_DEPENDENCY(name: any, reason: any): string
  • MISSING_REQUIRED_DEPENDENCY(defaultPlatform: any, transport: any): string
  • MISSING_REQUIRED_DEPENDENCY(name: string, reason: string): string
  • Parameters

    • name: any
    • reason: any

    Returns string

  • Parameters

    • defaultPlatform: any
    • transport: any

    Returns string

  • Parameters

    • name: string
    • reason: string

    Returns string

Const MessagePattern

  • MessagePattern<T>(metadata?: T, transport?: Transport): MethodDecorator

Optional

  • Optional(): (Anonymous function)
  • Parameter decorator for an injected dependency marking the dependency as optional.

    For example:

    constructor(@Optional() @Inject('HTTP_OPTIONS')private readonly httpClient: T) {}
    see

    Optional providers

    publicapi

    Returns (Anonymous function)

Ou

  • Ou(u: any): (Anonymous function)
  • Parameters

    • u: any

    Returns (Anonymous function)

Param

  • Route handler parameter decorator. Extracts the params property from the req object and populates the decorated parameter with the value of params. May also apply pipes to the bound parameter.

    For example, extracting all params:

    findOne(@Param() params: string[])

    For example, extracting a single param:

    findOne(@Param('id') id: string)
    see

    Request object

    see

    Working with pipes

    publicapi

    Parameters

    • property: any

      name of single property to extract from the req object

    • Rest ...pipes: any[]

      one or more pipes - either instances or classes - to apply to the bound parameter.

    Returns (Anonymous function)

  • Route handler parameter decorator. Extracts the params property from the req object and populates the decorated parameter with the value of params. May also apply pipes to the bound parameter.

    For example, extracting all params:

    findOne(@Param() params: string[])

    For example, extracting a single param:

    findOne(@Param('id') id: string)
    see

    Request object

    see

    Working with pipes

    publicapi

    Returns ParameterDecorator

  • Route handler parameter decorator. Extracts the params property from the req object and populates the decorated parameter with the value of params. May also apply pipes to the bound parameter.

    For example, extracting all params:

    findOne(@Param() params: string[])

    For example, extracting a single param:

    findOne(@Param('id') id: string)
    see

    Request object

    see

    Working with pipes

    publicapi

    Parameters

    Returns ParameterDecorator

  • Route handler parameter decorator. Extracts the params property from the req object and populates the decorated parameter with the value of params. May also apply pipes to the bound parameter.

    For example, extracting all params:

    findOne(@Param() params: string[])

    For example, extracting a single param:

    findOne(@Param('id') id: string)
    see

    Request object

    see

    Working with pipes

    publicapi

    Parameters

    • property: string

      name of single property to extract from the req object

    • Rest ...pipes: (Type<PipeTransform> | PipeTransform)[]

      one or more pipes - either instances or classes - to apply to the bound parameter.

    Returns ParameterDecorator

Payload

  • Payload(): ParameterDecorator
  • Payload(...pipes: (Type<PipeTransform> | PipeTransform)[]): ParameterDecorator

Query

  • Route handler parameter decorator. Extracts the query property from the req object and populates the decorated parameter with the value of query. May also apply pipes to the bound query parameter.

    For example:

    async find(@Query('user') user: string)
    see

    Request object

    publicapi

    Parameters

    • property: any

      name of single property to extract from the query object

    • Rest ...pipes: any[]

      one or more pipes to apply to the bound query parameter

    Returns (Anonymous function)

  • Route handler parameter decorator. Extracts the query property from the req object and populates the decorated parameter with the value of query. May also apply pipes to the bound query parameter.

    For example:

    async find(@Query('user') user: string)
    see

    Request object

    publicapi

    Returns ParameterDecorator

  • Route handler parameter decorator. Extracts the query property from the req object and populates the decorated parameter with the value of query. May also apply pipes to the bound query parameter.

    For example:

    async find(@Query('user') user: string)
    see

    Request object

    publicapi

    Parameters

    Returns ParameterDecorator

  • Route handler parameter decorator. Extracts the query property from the req object and populates the decorated parameter with the value of query. May also apply pipes to the bound query parameter.

    For example:

    async find(@Query('user') user: string)
    see

    Request object

    publicapi

    Parameters

    • property: string

      name of single property to extract from the query object

    • Rest ...pipes: (Type<PipeTransform> | PipeTransform)[]

      one or more pipes to apply to the bound query parameter

    Returns ParameterDecorator

ROTL

  • ROTL(x: any, n: any): number
  • Parameters

    • x: any
    • n: any

    Returns number

Redirect

  • Redirect(url?: string, statusCode: any): (Anonymous function)
  • Redirects request to the specified URL.

    publicapi

    Parameters

    • Default value url: string = ""
    • statusCode: any

    Returns (Anonymous function)

RedirectableRequest

  • RedirectableRequest(options: any, responseCallback: any): void
  • Parameters

    • options: any
    • responseCallback: any

    Returns void

Render

  • Render(template: any): (Anonymous function)
  • Route handler method Decorator. Defines a template to be rendered by the controller.

    For example: @Render('index')

    see

    Model-View-Controller

    publicapi

    Parameters

    • template: any

      name of the render engine template file

    Returns (Anonymous function)

Const RequestMapping

Const Response

constructor

  • Returns Response

headers

  • Returns Headers

ok

  • get ok(): boolean
  • Convenience property representing if the request ended normally

    Returns boolean

redirected

  • get redirected(): boolean
  • Returns boolean

status

  • get status(): any
  • Returns any

statusText

  • get statusText(): any
  • Returns any

url

  • get url(): any
  • Returns any

clone

  • Clone this response

    Returns Response

    Response

Const Ru

  • Ru(u: any, D: any): any
  • Parameters

    • u: any
    • D: any

    Returns any

Const SerializeOptions

Const SetMetadata

  • Decorator that assigns metadata to the class/function using the specified key.

    Requires two parameters:

    • key - a value defining the key under which the metadata is stored
    • value - metadata to be associated with key

    This metadata can be reflected using the Reflector class.

    Example: @SetMetadata('roles', ['admin'])

    see

    Reflection

    publicapi

    Type parameters

    • K = string

    • V = any

    Parameters

    • metadataKey: K
    • metadataValue: V

    Returns CustomDecorator<K>

Sse

  • Sse(path: any): (Anonymous function)
  • Declares this route as a Server-Sent-Events endpoint

    publicapi

    Parameters

    • path: any

    Returns (Anonymous function)

U

  • U(u: any): string
  • Parameters

    • u: any

    Returns string

Const UNDEFINED_FORWARDREF_MESSAGE

  • UNDEFINED_FORWARDREF_MESSAGE(scope: Type<any>[]): string

Const UNDEFINED_MODULE_MESSAGE

  • UNDEFINED_MODULE_MESSAGE(parentModule: any, index: number, scope: any[]): string

Const UNKNOWN_DEPENDENCIES_MESSAGE

  • UNKNOWN_DEPENDENCIES_MESSAGE(type: string | symbol, unknownDependencyContext: InjectorDependencyContext, module: Module): string

Const UNKNOWN_EXPORT_MESSAGE

  • UNKNOWN_EXPORT_MESSAGE(token?: string | symbol, module: string): string

Const UseFilters

  • Decorator that binds exception filters to the scope of the controller or method, depending on its context.

    When @UseFilters is used at the controller level, the filter will be applied to every handler (method) in the controller.

    When @UseFilters is used at the individual handler level, the filter will apply only to that specific method.

    see

    Exception filters

    usagenotes

    Exception filters can also be set up globally for all controllers and routes using app.useGlobalFilters(). See here for details

    publicapi

    Parameters

    • Rest ...filters: (ExceptionFilter | Function)[]

      exception filter instance or class, or a list of exception filter instances or classes.

    Returns MethodDecorator & ClassDecorator

UseGuards

  • UseGuards(...guards: any[]): (Anonymous function)
  • Decorator that binds guards to the scope of the controller or method, depending on its context.

    When @UseGuards is used at the controller level, the guard will be applied to every handler (method) in the controller.

    When @UseGuards is used at the individual handler level, the guard will apply only to that specific method.

    see

    Guards

    usagenotes

    Guards can also be set up globally for all controllers and routes using app.useGlobalGuards(). See here for details

    publicapi

    Parameters

    • Rest ...guards: any[]

      a single guard instance or class, or a list of guard instances or classes.

    Returns (Anonymous function)

UseInterceptors

  • UseInterceptors(...interceptors: any[]): (Anonymous function)
  • Decorator that binds interceptors to the scope of the controller or method, depending on its context.

    When @UseInterceptors is used at the controller level, the interceptor will be applied to every handler (method) in the controller.

    When @UseInterceptors is used at the individual handler level, the interceptor will apply only to that specific method.

    see

    Interceptors

    usagenotes

    Interceptors can also be set up globally for all controllers and routes using app.useGlobalInterceptors(). See here for details

    publicapi

    Parameters

    • Rest ...interceptors: any[]

      a single interceptor instance or class, or a list of interceptor instances or classes.

    Returns (Anonymous function)

UsePipes

  • UsePipes(...pipes: any[]): (Anonymous function)
  • Decorator that binds pipes to the scope of the controller or method, depending on its context.

    When @UsePipes is used at the controller level, the pipe will be applied to every handler (method) in the controller.

    When @UsePipes is used at the individual handler level, the pipe will apply only to that specific method.

    see

    Pipes

    usagenotes

    Pipes can also be set up globally for all controllers and routes using app.useGlobalPipes(). See here for details

    publicapi

    Parameters

    • Rest ...pipes: any[]

      a single pipe instance or class, or a list of pipe instances or classes.

    Returns (Anonymous function)

Uu

  • Uu(u: any): any
  • Parameters

    • u: any

    Returns any

X

  • X(u: any, D: any): any
  • Parameters

    • u: any
    • D: any

    Returns any

Z

  • Z(u: any, D: any): (Anonymous function)
  • Parameters

    • u: any
    • D: any

    Returns (Anonymous function)

__assign

  • __assign(): any
  • Returns any

_arrayLikeToArray

  • _arrayLikeToArray(arr: any, len: any): any[]
  • Parameters

    • arr: any
    • len: any

    Returns any[]

_arrayWithHoles

  • _arrayWithHoles(arr: any): any[]
  • Parameters

    • arr: any

    Returns any[]

_async

  • _async(f: any): (Anonymous function)
  • Parameters

    • f: any

    Returns (Anonymous function)

_async$1

  • _async$1(f: any): (Anonymous function)
  • Parameters

    • f: any

    Returns (Anonymous function)

_async$2

  • _async$2(f: any): (Anonymous function)
  • Parameters

    • f: any

    Returns (Anonymous function)

_await

  • _await(value: any, then: any, direct: any): any
  • Parameters

    • value: any
    • then: any
    • direct: any

    Returns any

_await$1

  • _await$1(value: any, then: any, direct: any): any
  • Parameters

    • value: any
    • then: any
    • direct: any

    Returns any

_await$2

  • _await$2(value: any, then: any, direct: any): any
  • Parameters

    • value: any
    • then: any
    • direct: any

    Returns any

_catch

  • _catch(body: any, recover: any): any
  • Parameters

    • body: any
    • recover: any

    Returns any

_interopDefault

  • _interopDefault(ex: any): any
  • Parameters

    • ex: any

    Returns any

_interopDefaultLegacy

  • _interopDefaultLegacy(e: any): any
  • Parameters

    • e: any

    Returns any

_interopRequireDefault

  • _interopRequireDefault(obj: any): any
  • Parameters

    • obj: any

    Returns any

_iterableToArrayLimit

  • _iterableToArrayLimit(arr: any, i: any): any[]
  • Parameters

    • arr: any
    • i: any

    Returns any[]

_nonIterableRest

  • _nonIterableRest(): void
  • Returns void

_slicedToArray

  • _slicedToArray(arr: any, i: any): void | any[]
  • Parameters

    • arr: any
    • i: any

    Returns void | any[]

_unsupportedIterableToArray

  • _unsupportedIterableToArray(o: any, minLen: any): any[]
  • Parameters

    • o: any
    • minLen: any

    Returns any[]

addExceptionFiltersMetadata

  • addExceptionFiltersMetadata(...filters: any[]): (Anonymous function)
  • Parameters

    • Rest ...filters: any[]

    Returns (Anonymous function)

align

  • align(alignment: any, str: any, len: any, space?: string): any
  • Parameters

    • alignment: any
    • str: any
    • len: any
    • Default value space: string = " "

    Returns any

Const ansi2ansi

  • ansi2ansi(n: any): any
  • Parameters

    • n: any

    Returns any

applyDecorators

  • applyDecorators(...decorators: any[]): (Anonymous function)
  • Function that returns a new decorator that applies all decorators provided by param

    Useful to build new decorators (or a decorator factory) encapsulating multiple decorators related with the same feature

    publicapi

    Parameters

    • Rest ...decorators: any[]

      one or more decorators (e.g., ApplyGuard(...))

    Returns (Anonymous function)

applyDefaults

  • applyDefaults(object: any, sourceOptions: any): __type
  • Parameters

    • object: any
    • sourceOptions: any

    Returns __type

Const applyOptions

  • applyOptions(object: any, options?: {}): void
  • Parameters

    • object: any
    • Default value options: {} = {}

    Returns void

Const applyStyle

  • applyStyle(self: any, string: any): any
  • Parameters

    • self: any
    • string: any

    Returns any

arrayToRegexp

  • arrayToRegexp(path: any[], keys: any[], options: any): RegExp
  • Transform an array into a regexp.

    Parameters

    • path: any[]
    • keys: any[]
    • options: any

    Returns RegExp

assembleStyles

  • assembleStyles(): { bgColor: object; color: object; modifier: object }
  • Returns { bgColor: object; color: object; modifier: object }

    • bgColor: object
      • bgBlack: number[]
      • bgBlackBright: number[]
      • bgBlue: number[]
      • bgBlueBright: number[]
      • bgCyan: number[]
      • bgCyanBright: number[]
      • bgGreen: number[]
      • bgGreenBright: number[]
      • bgMagenta: number[]
      • bgMagentaBright: number[]
      • bgRed: number[]
      • bgRedBright: number[]
      • bgWhite: number[]
      • bgWhiteBright: number[]
      • bgYellow: number[]
      • bgYellowBright: number[]
    • color: object
      • black: number[]
      • blackBright: number[]
      • blue: number[]
      • blueBright: number[]
      • cyan: number[]
      • cyanBright: number[]
      • green: number[]
      • greenBright: number[]
      • magenta: number[]
      • magentaBright: number[]
      • red: number[]
      • redBright: number[]
      • white: number[]
      • whiteBright: number[]
      • yellow: number[]
      • yellowBright: number[]
    • modifier: object
      • bold: number[]
      • dim: number[]
      • hidden: number[]
      • inverse: number[]
      • italic: number[]
      • reset: number[]
      • strikethrough: number[]
      • underline: number[]

assignCustomParameterMetadata

  • assignCustomParameterMetadata(args: any, paramtype: any, index: any, factory: any, data: any, ...pipes: any[]): any
  • Parameters

    • args: any
    • paramtype: any
    • index: any
    • factory: any
    • data: any
    • Rest ...pipes: any[]

    Returns any

assignGlobalConsola

  • assignGlobalConsola(newConsola: any): any
  • Parameters

    • newConsola: any

    Returns any

assignGlobalReference

  • assignGlobalReference(newInstance: any, referenceKey: any): any
  • Parameters

    • newInstance: any
    • referenceKey: any

    Returns any

assignMetadata

  • assignMetadata(args: any, paramtype: any, index: any, data: any, ...pipes: any[]): any
  • Parameters

    • args: any
    • paramtype: any
    • index: any
    • data: any
    • Rest ...pipes: any[]

    Returns any

assignToken

  • assignToken(metatype: any, token?: any): any
  • Parameters

    • metatype: any
    • Default value token: any = uuid_1.v4()

    Returns any

bitRotateLeft

  • bitRotateLeft(num: any, cnt: any): number
  • Parameters

    • num: any
    • cnt: any

    Returns number

Const bracket

  • bracket(x: any): string
  • Parameters

    • x: any

    Returns string

buildGraph

  • buildGraph(): graph
  • Returns graph

buildStyle

  • buildStyle(chalk: any, styles: any): any
  • Parameters

    • chalk: any
    • styles: any

    Returns any

bytesToWords

  • bytesToWords(input: any): any[] | Uint32Array
  • Parameters

    • input: any

    Returns any[] | Uint32Array

callAppShutdownHook

  • callAppShutdownHook(module: any, signal: any): Promise<void>
  • Calls the onApplicationShutdown function on the module and its children (providers / controllers).

    Parameters

    • module: any

      The module which will be initialized

    • signal: any

    Returns Promise<void>

callBeforeAppShutdownHook

  • callBeforeAppShutdownHook(module: any, signal: any): Promise<void>
  • Calls the beforeApplicationShutdown function on the module and its children (providers / controllers).

    Parameters

    • module: any

      The module which will be initialized

    • signal: any

      The signal which caused the shutdown

    Returns Promise<void>

callModuleBootstrapHook

  • callModuleBootstrapHook(module: any): Promise<void>
  • Calls the onApplicationBootstrap function on the module and its children (providers / controllers).

    Parameters

    • module: any

      The module which will be initialized

    Returns Promise<void>

callModuleDestroyHook

  • callModuleDestroyHook(module: any): Promise<void>
  • Calls the onModuleDestroy function on the module and its children (providers / controllers).

    Parameters

    • module: any

      The module which will be initialized

    Returns Promise<void>

callModuleInitHook

  • callModuleInitHook(module: any): Promise<void>
  • Calls the onModuleInit function on the module and its children (providers / controllers).

    Parameters

    • module: any

      The module which will be initialized

    Returns Promise<void>

callOperator

  • callOperator(instances: any, signal: any): Promise<any>[]
  • Calls the given instances

    Parameters

    • instances: any
    • signal: any

    Returns Promise<any>[]

centerAlign

  • centerAlign(str: any, len: any, space?: string): any
  • Parameters

    • str: any
    • len: any
    • Default value space: string = " "

    Returns any

chalkBgColor

  • chalkBgColor(name: any): any
  • Parameters

    • name: any

    Returns any

chalkColor

  • chalkColor(name: any): any
  • Parameters

    • name: any

    Returns any

Const chalkFactory

  • chalkFactory(options: any): (Anonymous function)
  • Parameters

    • options: any

    Returns (Anonymous function)

Const chalkTag

  • chalkTag(chalk: any, ...strings: any[]): any
  • Parameters

    • chalk: any
    • Rest ...strings: any[]

    Returns any

clearTimer

  • clearTimer(): void
  • Returns void

collectiveDonationText

  • collectiveDonationText(pkg: any): any
  • Parameters

    • pkg: any

    Returns any

collectiveDonationUrl

  • collectiveDonationUrl(pkg: any): string
  • Parameters

    • pkg: any

    Returns string

collectiveLogoUrl

  • collectiveLogoUrl(pkg: any): any
  • Parameters

    • pkg: any

    Returns any

collectiveSlugFromUrl

  • collectiveSlugFromUrl(url: any): any
  • Parameters

    • url: any

    Returns any

collectiveUrl

  • collectiveUrl(pkg: any): any
  • Parameters

    • pkg: any

    Returns any

Const colorIfAllowed

  • colorIfAllowed(colorFn: ColorTextFn): (Anonymous function)

comparativeDistance

  • comparativeDistance(x: any, y: any): number
  • Parameters

    • x: any
    • y: any

    Returns number

compareFunction

  • compareFunction(a: any, b: any): 0 | 1 | -1
  • Parameters

    • a: any
    • b: any

    Returns 0 | 1 | -1

compile

  • compile(str: string, options: any): {}
  • Compile a string to a template function for the path.

    Parameters

    • str: string
    • options: any

    Returns {}

compileFormat

  • compileFormat(format: any): any
  • Parameters

    • format: any

    Returns any

consumeBody

  • consumeBody(): Promise<any>

convertBody

  • convertBody(buffer: any, headers: any): any

Const createBuilder

  • createBuilder(self: any, _styler: any, _isEmpty: any): builder
  • Parameters

    • self: any
    • _styler: any
    • _isEmpty: any

    Returns builder

createCacheManager

  • createCacheManager(): { inject: string[]; provide: string; useFactory: any }
  • Creates a CacheManager Provider.

    publicapi

    Returns { inject: string[]; provide: string; useFactory: any }

    • inject: string[]
    • provide: string
    • useFactory: function
      • useFactory(options: any): any
      • Parameters

        • options: any

        Returns any

createClient

  • createClient(server: Server, callback: (err?: any, clientSocket?: JsonSocket, serverSocket?: JsonSocket) => void): void

createConsola

  • Returns Consola

createContextId

  • createContextId(): { id: number }
  • Returns { id: number }

    • id: number

createErrorType

  • createErrorType(code: any, defaultMessage: any): CustomError
  • Parameters

    • code: any
    • defaultMessage: any

    Returns CustomError

createGrpcMethodMetadata

createHeadersIterator

  • createHeadersIterator(target: any, kind: any): any
  • Parameters

    • target: any
    • kind: any

    Returns any

createHeadersLenient

  • createHeadersLenient(obj: any): Headers
  • Create a Headers object from an object of headers, ignoring those that do not conform to HTTP grammar productions.

    Parameters

    • obj: any

    Returns Headers

    Headers

createInstance

  • createInstance(defaultConfig: any): Axios
  • Create an instance of Axios

    Parameters

    • defaultConfig: any

      The default config for the instance

    Returns Axios

    A new instance of Axios

Const createMappingDecorator

  • createMappingDecorator(method: any): (Anonymous function)
  • createMappingDecorator(method: RequestMethod): (Anonymous function)

createParamDecorator

  • createParamDecorator(factory: any, enhancers?: any[]): (Anonymous function)
  • Defines HTTP route param decorator

    Parameters

    • factory: any
    • Default value enhancers: any[] = []

    Returns (Anonymous function)

Const createPipesRouteParamDecorator

  • createPipesRouteParamDecorator(paramtype: any): (Anonymous function)
  • createPipesRouteParamDecorator(paramtype: RouteParamtypes): (Anonymous function)

Const createPipesRpcParamDecorator

  • createPipesRpcParamDecorator(paramtype: RpcParamtype): (Anonymous function)

createRouteParamDecorator

  • createRouteParamDecorator(paramtype: any): (Anonymous function)
  • Parameters

    • paramtype: any

    Returns (Anonymous function)

createRpcParamDecorator

  • createRpcParamDecorator(paramtype: RpcParamtype): (...pipes: (Type<PipeTransform> | PipeTransform)[]) => ParameterDecorator
  • Parameters

    Returns (...pipes: (Type<PipeTransform> | PipeTransform)[]) => ParameterDecorator

      • (...pipes: (Type<PipeTransform> | PipeTransform)[]): ParameterDecorator
      • Parameters

        • Rest ...pipes: (Type<PipeTransform> | PipeTransform)[]

        Returns ParameterDecorator

createServer

  • createServer(callback: (err?: any, server?: Server) => void): void

createServerAndClient

  • createServerAndClient(callback: (err?: any, server?: Server, clientSocket?: JsonSocket, serverSocket?: JsonSocket) => void): void

Const createStyler

  • createStyler(open: any, close: any, parent: any): { close: any; closeAll: any; open: any; openAll: any; parent: any }
  • Parameters

    • open: any
    • close: any
    • parent: any

    Returns { close: any; closeAll: any; open: any; openAll: any; parent: any }

    • close: any
    • closeAll: any
    • open: any
    • openAll: any
    • parent: any

d

  • d(u: any): boolean
  • Parameters

    • u: any

    Returns boolean

decirc

  • decirc(val: any, k: any, stack: any, parent: any): void
  • Parameters

    • val: any
    • k: any
    • stack: any
    • parent: any

    Returns void

default

  • default(name: any, version: any, hashfunc: any): generateUUID
  • Parameters

    • name: any
    • version: any
    • hashfunc: any

    Returns generateUUID

deriveBFS

  • deriveBFS(fromModel: any): graph
  • Parameters

    • fromModel: any

    Returns graph

deterministicDecirc

  • deterministicDecirc(val: any, k: any, stack: any, parent: any): tmp
  • Parameters

    • val: any
    • k: any
    • stack: any
    • parent: any

    Returns tmp

deterministicStringify

  • deterministicStringify(obj: any, replacer: any, spacer: any): string
  • Parameters

    • obj: any
    • replacer: any
    • spacer: any

    Returns string

du

  • du(u: any): string[][]
  • Parameters

    • u: any

    Returns string[][]

emoji

  • emoji(_emoji: any): any
  • Only show emoji on OSx (Windows shell doesn't like them that much ¯_(ツ)_/¯ )

    Parameters

    • _emoji: any

    Returns any

encode

  • encode(val: any): string
  • Parameters

    • val: any

    Returns string

equalTest

  • equalTest<R>(testPatterns: MsPattern[], expectedResults: R[]): void

escapeGroup

  • escapeGroup(group: string): string
  • Escape the capturing group by escaping special characters and meaning.

    Parameters

    • group: string

    Returns string

escapeString

  • escapeString(str: string): string
  • Escape a regular expression string.

    Parameters

    • str: string

    Returns string

exportNodeCompatibleHeaders

  • exportNodeCompatibleHeaders(headers: any): any
  • Export the Headers object in a form that Node.js can consume.

    Parameters

    • headers: any

    Returns any

    Object

extend

  • extend(a: any, b: any, thisArg: any): any
  • Extends object a by mutably adding to it the properties of object b.

    Parameters

    • a: any

      The object to be extended

    • b: any

      The object to copy properties from

    • thisArg: any

      The object to bind function to

    Returns any

    The resulting value of object a

extendArrayMetadata

  • extendArrayMetadata(key: any, metadata: any, target: any): void
  • Parameters

    • key: any
    • metadata: any
    • target: any

    Returns void

extendStatics

  • extendStatics(d: any, b: any): any
  • Parameters

    • d: any
    • b: any

    Returns any

extractContentType

  • extractContentType(body: any): any
  • Performs the operation "extract a Content-Type value from |object|" as specified in the specification: https://fetch.spec.whatwg.org/#concept-bodyinit-extract

    This function assumes that instance.body is present.

    Parameters

    • body: any

    Returns any

fetchPkg

  • fetchPkg(pathToPkg: any): any
  • Parameters

    • pathToPkg: any

    Returns any

find

  • find(map: any, name: any): string
  • Find the key in the map object given a header name.

    Returns undefined if not found.

    Parameters

    • map: any
    • name: any

    Returns string

    String|Undefined

flags

  • flags(options: any): string
  • Get the flags for a regexp from the options.

    Parameters

    • options: any

    Returns string

flatten

  • flatten(arr: any): any
  • Parameters

    • arr: any

    Returns any

forEach

  • Iterate over an Array or an Object invoking a function for each item.

    If obj is an Array callback will be called passing the value, index, and complete array for each item.

    If 'obj' is an Object callback will be called passing the value, key, and complete object for each property.

    Parameters

    • obj: any

      The object to iterate

    • fn: Function

      The callback to invoke for each item

    Returns void

formatDate

  • formatDate(timeFormat: any, date: any): any
  • Parameters

    • timeFormat: any
    • date: any

    Returns any

formatMoney

  • formatMoney(currency: any): (Anonymous function)
  • Parameters

    • currency: any

    Returns (Anonymous function)

formatString

  • formatString(format: any, argv: any): any
  • Parameters

    • format: any
    • argv: any

    Returns any

Const forwardRef

fu

  • fu(u: any): any
  • Parameters

    • u: any

    Returns any

getClassScope

  • getClassScope(provider: any): any
  • Parameters

    • provider: any

    Returns any

getDefaultAdapter

  • getDefaultAdapter(): xhrAdapter
  • Returns xhrAdapter

Const getDependencyName

  • getDependencyName(dependency: any): any
  • getDependencyName(dependency: InjectorDependency): string
  • Returns the name of the dependency Tries to get the class name, otherwise the string value (= injection token). As fallback it returns '+' Returns the name of the dependency Tries to get the class name, otherwise the string value (= injection token). As fallback it returns '+'

    Parameters

    • dependency: any

      The dependency whichs name should get displayed

    Returns any

  • Returns the name of the dependency Tries to get the class name, otherwise the string value (= injection token). As fallback it returns '+' Returns the name of the dependency Tries to get the class name, otherwise the string value (= injection token). As fallback it returns '+'

    Parameters

    Returns string

getGlobal

  • getGlobal(): any
  • Returns any

getHeaders

  • getHeaders(headers: any): any[]
  • Parameters

    • headers: any

    Returns any[]

Const getInstanceName

  • getInstanceName(instance: any): any
  • getInstanceName(instance: unknown): string
  • Returns the name of an instance Returns the name of an instance

    Parameters

    • instance: any

      The instance which should get the name from

    Returns any

  • Returns the name of an instance Returns the name of an instance

    Parameters

    • instance: unknown

    Returns string

Const getModuleName

  • getModuleName(module: any): any
  • getModuleName(module: Module): string
  • Returns the name of the module Tries to get the class name. As fallback it returns 'current'. Returns the name of the module Tries to get the class name. As fallback it returns 'current'.

    Parameters

    • module: any

      The module which should get displayed

    Returns any

  • Returns the name of the module Tries to get the class name. As fallback it returns 'current'. Returns the name of the module Tries to get the class name. As fallback it returns 'current'.

    Parameters

    • module: Module

    Returns string

getNodeRequestOptions

  • getNodeRequestOptions(request: any): any
  • Convert a Request to Node.js http request options.

    Parameters

    • request: any

    Returns any

    Object The options object to be passed to http.request

getNonTransientInstances

  • getNonTransientInstances(instances: any): any[]
  • Returns the instances which are not transient

    Parameters

    • instances: any

      The instances which should be checked whether they are transcient

    Returns any[]

getOutputLength

  • getOutputLength(inputLength8: any): number
  • Calculate output length with padding and bit length

    Parameters

    • inputLength8: any

    Returns number

getSupportLevel

  • getSupportLevel(stream: any): false | { has16m: boolean; has256: boolean; hasBasic: boolean; level: any }
  • Parameters

    • stream: any

    Returns false | { has16m: boolean; has256: boolean; hasBasic: boolean; level: any }

getTotalBytes

  • getTotalBytes(instance: any): any
  • The Fetch Standard treats this as if "total bytes" is a property on the body. For us, we have to explicitly get it with a function.

    ref: https://fetch.spec.whatwg.org/#concept-body-total-bytes

    Parameters

    • instance: any

    Returns any

    Number? Number of bytes, or null if not possible

getTransientInstances

  • getTransientInstances(instances: any): any[]
  • Returns the instances which are transient

    Parameters

    • instances: any

      The instances which should be checked whether they are transcient

    Returns any[]

gu

  • gu(u: any, D: any): any
  • Parameters

    • u: any
    • D: any

    Returns any

hasBeforeApplicationShutdownHook

  • hasBeforeApplicationShutdownHook(instance: any): boolean
  • Checks if the given instance has the beforeApplicationShutdown function

    Parameters

    • instance: any

      The instance which should be checked

    Returns boolean

hasOnAppBootstrapHook

  • hasOnAppBootstrapHook(instance: any): boolean
  • Checks if the given instance has the onApplicationBootstrap function

    Parameters

    • instance: any

      The instance which should be checked

    Returns boolean

hasOnAppShutdownHook

  • hasOnAppShutdownHook(instance: any): boolean
  • Checks if the given instance has the onApplicationShutdown function

    Parameters

    • instance: any

      The instance which should be checked

    Returns boolean

hasOnModuleDestroyHook

  • hasOnModuleDestroyHook(instance: any): boolean
  • Returns true or false if the given instance has a onModuleDestroy function

    Parameters

    • instance: any

      The instance which should be checked

    Returns boolean

hasOnModuleInitHook

  • hasOnModuleInitHook(instance: any): boolean
  • Returns true or false if the given instance has a onModuleInit function

    Parameters

    • instance: any

      The instance which should be checked

    Returns boolean

hideMessage

  • hideMessage(): boolean
  • Returns boolean

isAbortSignal

  • isAbortSignal(signal: any): boolean
  • Parameters

    • signal: any

    Returns boolean

isArray

  • isArray(val: any): boolean
  • Determine if a value is an Array

    Parameters

    • val: any

      The value to test

    Returns boolean

    True if value is an Array, otherwise false

isArrayBuffer

  • isArrayBuffer(val: any): boolean
  • Determine if a value is an ArrayBuffer

    Parameters

    • val: any

      The value to test

    Returns boolean

    True if value is an ArrayBuffer, otherwise false

isArrayBufferView

  • isArrayBufferView(val: any): boolean
  • Determine if a value is a view on an ArrayBuffer

    Parameters

    • val: any

      The value to test

    Returns boolean

    True if value is a view on an ArrayBuffer, otherwise false

isBlob

  • isBlob(val: any): boolean
  • Determine if a value is a Blob

    Parameters

    • val: any

      The value to test

    Returns boolean

    True if value is a Blob, otherwise false

isBuffer

  • isBuffer(val: any): boolean
  • Determine if a value is a Buffer

    Parameters

    • val: any

      The value to test

    Returns boolean

    True if value is a Buffer, otherwise false

isClass

  • isClass(middleware: any): boolean
  • Parameters

    • middleware: any

    Returns boolean

Const isColorAllowed

  • isColorAllowed(): boolean

Const isConstructor

  • isConstructor(fn: any): boolean

isDate

  • isDate(val: any): boolean
  • Determine if a value is a Date

    Parameters

    • val: any

      The value to test

    Returns boolean

    True if value is a Date, otherwise false

Const isEmpty

  • isEmpty(array: any): boolean

isFile

  • isFile(val: any): boolean
  • Determine if a value is a File

    Parameters

    • val: any

      The value to test

    Returns boolean

    True if value is a File, otherwise false

isFormData

  • isFormData(val: any): boolean
  • Determine if a value is a FormData

    Parameters

    • val: any

      The value to test

    Returns boolean

    True if value is an FormData, otherwise false

Const isFunction

  • isFunction(val: any): boolean
  • isFunction(fn: any): boolean
  • Determine if a value is a Function

    Parameters

    • val: any

      The value to test

    Returns boolean

    True if value is a Function, otherwise false

  • Parameters

    • fn: any

    Returns boolean

isIterable

  • isIterable(candidate: any): boolean
  • Parameters

    • candidate: any

    Returns boolean

isIterator

  • isIterator(candidate: any): boolean
  • Parameters

    • candidate: any

    Returns boolean

isLogObj

  • isLogObj(arg: any): boolean
  • Parameters

    • arg: any

    Returns boolean

isLogoResponseWellFormatted

  • isLogoResponseWellFormatted(res: any): any
  • Parameters

    • res: any

    Returns any

isNativeFunction

  • isNativeFunction(f: any): boolean
  • Check if the given function is a native function

    Parameters

    • f: any

    Returns boolean

Const isNil

  • isNil(obj: any): obj is null | undefined

isNumber

  • isNumber(val: any): boolean
  • Determine if a value is a Number

    Parameters

    • val: any

      The value to test

    Returns boolean

    True if value is a Number, otherwise false

Const isObject

  • isObject(val: any): boolean
  • isObject(fn: any): fn is object
  • Determine if a value is an Object

    Parameters

    • val: any

      The value to test

    Returns boolean

    True if value is an Object, otherwise false

  • Parameters

    • fn: any

    Returns fn is object

Const isPlainObject

  • isPlainObject(val: any): boolean
  • isPlainObject(fn: any): fn is object
  • Determine if a value is a plain Object

    Parameters

    • val: any

      The value to test

    Returns boolean

    True if value is a plain Object, otherwise false

  • Parameters

    • fn: any

    Returns fn is object

isRequest

  • isRequest(input: any): boolean
  • Check if a value is an instance of Request.

    Parameters

    • input: any

    Returns boolean

    Boolean

isRouteExcluded

  • isRouteExcluded(req: any, excludedRoutes: any, httpAdapter: any): any
  • Parameters

    • req: any
    • excludedRoutes: any
    • httpAdapter: any

    Returns any

isStandardBrowserEnv

  • isStandardBrowserEnv(): boolean
  • Determine if we're running in a standard browser environment

    This allows axios to run in a web worker, and react-native. Both environments support XMLHttpRequest, but not fully standard globals.

    web workers: typeof window -> undefined typeof document -> undefined

    react-native: navigator.product -> 'ReactNative' nativescript navigator.product -> 'NativeScript' or 'NS'

    Returns boolean

isStream

  • isStream(val: any): boolean
  • Determine if a value is a Stream

    Parameters

    • val: any

      The value to test

    Returns boolean

    True if value is a Stream, otherwise false

Const isString

  • isString(val: any): boolean
  • isString(fn: any): fn is string
  • Determine if a value is a String

    Parameters

    • val: any

      The value to test

    Returns boolean

    True if value is a String, otherwise false

  • Parameters

    • fn: any

    Returns fn is string

Const isSymbol

  • isSymbol(fn: any): fn is symbol

isURLSearchParams

  • isURLSearchParams(val: any): boolean
  • Determine if a value is a URLSearchParams object

    Parameters

    • val: any

      The value to test

    Returns boolean

    True if value is a URLSearchParams object, otherwise false

isUUID

  • isUUID(str: any, version?: string): any
  • Parameters

    • str: any
    • Default value version: string = "all"

    Returns any

Const isUndefined

  • isUndefined(val: any): boolean
  • isUndefined(obj: any): obj is undefined
  • Determine if a value is undefined

    Parameters

    • val: any

      The value to test

    Returns boolean

    True if the value is undefined, otherwise false

  • Parameters

    • obj: any

    Returns obj is undefined

iterate

  • Creates an Iterator with advanced chainable operator methods for any Iterable or Iterator

    Parameters

    • collection: any

    Returns IteratorWithOperators

Const k

  • k(u: any): boolean
  • Parameters

    • u: any

    Returns boolean

Const ku

  • ku(u: any, D: any, e: any): t
  • Parameters

    • u: any
    • D: any
    • e: any

    Returns t

leftAlign

  • leftAlign(str: any, len: any, space?: string): string
  • Parameters

    • str: any
    • len: any
    • Default value space: string = " "

    Returns string

link

  • link(from: any, to: any): (Anonymous function)
  • Parameters

    • from: any
    • to: any

    Returns (Anonymous function)

loadAdapter

  • loadAdapter(defaultPlatform: any, transport: any, loaderFn: any): any
  • Parameters

    • defaultPlatform: any
    • transport: any
    • loaderFn: any

    Returns any

loadPackage

  • loadPackage(packageName: any, context: any, loaderFn: any): any
  • Parameters

    • packageName: any
    • context: any
    • loaderFn: any

    Returns any

Const makeDynamicStyles

  • makeDynamicStyles(wrap: any, targetSpace: any, identity: any, isBackground: any): __type
  • Parameters

    • wrap: any
    • targetSpace: any
    • identity: any
    • isBackground: any

    Returns __type

match

  • match(str: any, options: any): (Anonymous function)
  • Create path match function from path-to-regexp spec.

    Parameters

    • str: any
    • options: any

    Returns (Anonymous function)

md5

  • md5(bytes: any): number[]
  • Parameters

    • bytes: any

    Returns number[]

md5ToHexEncodedArray

  • md5ToHexEncodedArray(input: any): number[]
  • Parameters

    • input: any

    Returns number[]

md5cmn

  • md5cmn(q: any, a: any, b: any, x: any, s: any, t: any): number
  • Parameters

    • q: any
    • a: any
    • b: any
    • x: any
    • s: any
    • t: any

    Returns number

md5ff

  • md5ff(a: any, b: any, c: any, d: any, x: any, s: any, t: any): number
  • Parameters

    • a: any
    • b: any
    • c: any
    • d: any
    • x: any
    • s: any
    • t: any

    Returns number

md5gg

  • md5gg(a: any, b: any, c: any, d: any, x: any, s: any, t: any): number
  • Parameters

    • a: any
    • b: any
    • c: any
    • d: any
    • x: any
    • s: any
    • t: any

    Returns number

md5hh

  • md5hh(a: any, b: any, c: any, d: any, x: any, s: any, t: any): number
  • Parameters

    • a: any
    • b: any
    • c: any
    • d: any
    • x: any
    • s: any
    • t: any

    Returns number

md5ii

  • md5ii(a: any, b: any, c: any, d: any, x: any, s: any, t: any): number
  • Parameters

    • a: any
    • b: any
    • c: any
    • d: any
    • x: any
    • s: any
    • t: any

    Returns number

merge

  • merge(): any
  • Accepts varargs expecting each argument to be an object, then immutably merges the properties of each object and returns result.

    When multiple objects contain the same key the later object in the arguments list will take precedence.

    Example:

    var result = merge({foo: 123}, {foo: 456});
    console.log(result.foo); // outputs 456

    Returns any

    Result of all merge properties

mixin

  • mixin(mixinClass: any): any
  • Parameters

    • mixinClass: any

    Returns any

Const noop

  • noop(): void
  • noop(): void
  • noop(): void
  • noop(): void

objectHash

  • objectHash(object: any, options: any): any
  • Parameters

    • object: any
    • options: any

    Returns any

optionalRequire

  • optionalRequire(packageName: any, loaderFn: any): any
  • Parameters

    • packageName: any
    • loaderFn: any

    Returns any

ou

  • ou(u: any, D: any): 0 | 1 | 2 | 3
  • Parameters

    • u: any
    • D: any

    Returns 0 | 1 | 2 | 3

parse

  • parse(str: string, options: any): any[]
  • Parse a string for the raw tokens.

    Parameters

    • str: string
    • options: any

    Returns any[]

parseArguments

  • parseArguments(name: any, arguments_: any): any[]
  • Parameters

    • name: any
    • arguments_: any

    Returns any[]

parseStack

  • parseStack(stack: any): any
  • Parameters

    • stack: any

    Returns any

parseStyle

  • parseStyle(style: any): string[][]
  • Parameters

    • style: any

    Returns string[][]

print

  • print(): (Anonymous function)
  • Returns (Anonymous function)

printFooter

  • printFooter(collective: any): void
  • Parameters

    • collective: any

    Returns void

printLogo

  • printLogo(logoText: any): void
  • Parameters

    • logoText: any

    Returns void

printStats

  • printStats(stats: any, color: any): void
  • Parameters

    • stats: any
    • color: any

    Returns void

pu

  • pu(u: any, D: any): string
  • Parameters

    • u: any
    • D: any

    Returns string

Const randomStringGenerator

  • randomStringGenerator(): any

range

  • range(start: number, end: number): any[]

regexpToFunction

  • regexpToFunction(re: any, keys: any): (Anonymous function)
  • Create a path match function from path-to-regexp output.

    Parameters

    • re: any
    • keys: any

    Returns (Anonymous function)

regexpToRegexp

  • regexpToRegexp(path: RegExp, keys: any[]): RegExp
  • Pull out keys from a regexp.

    Parameters

    • path: RegExp
    • keys: any[]

    Returns RegExp

removeMatchingHeaders

  • removeMatchingHeaders(regex: any, headers: any): any
  • Parameters

    • regex: any
    • headers: any

    Returns any

replaceGetterValues

  • replaceGetterValues(replacer: any): (Anonymous function)
  • Parameters

    • replacer: any

    Returns (Anonymous function)

report

  • report(message: any): void
  • Parameters

    • message: any

    Returns void

reportAndThrowError

  • reportAndThrowError(msg: any): never
  • Parameters

    • msg: any

    Returns never

retrieveDonationSlug

  • retrieveDonationSlug(pkg: any): any
  • Parameters

    • pkg: any

    Returns any

Const rgb2rgb

  • rgb2rgb(r: any, g: any, b: any): any[]
  • Parameters

    • r: any
    • g: any
    • b: any

    Returns any[]

rightAlign

  • rightAlign(str: any, len: any, space?: string): any
  • Parameters

    • str: any
    • len: any
    • Default value space: string = " "

    Returns any

rng

  • rng(): any
  • Returns any

Const s

  • s(u: any, D: any): any
  • Parameters

    • u: any
    • D: any

    Returns any

safeAdd

  • safeAdd(x: any, y: any): number
  • Parameters

    • x: any
    • y: any

    Returns number

setContentTypeIfUnset

  • setContentTypeIfUnset(headers: any, value: any): void
  • Parameters

    • headers: any
    • value: any

    Returns void

Const setLazyProperty

  • setLazyProperty(object: any, property: any, get: any): void
  • Parameters

    • object: any
    • property: any
    • get: any

    Returns void

sha1

  • sha1(bytes: any): number[]
  • Parameters

    • bytes: any

    Returns number[]

startTimer

  • startTimer(request: any, msecs: any): void
  • Parameters

    • request: any
    • msecs: any

    Returns void

stringCleaner

  • stringCleaner(str: any): any
  • Parameters

    • str: any

    Returns any

Const stringEncaseCRLFWithFirstIndex

  • stringEncaseCRLFWithFirstIndex(string: any, prefix: any, postfix: any, index: any): string
  • Parameters

    • string: any
    • prefix: any
    • postfix: any
    • index: any

    Returns string

Const stringReplaceAll

  • stringReplaceAll(string: any, substring: any, replacer: any): any
  • Parameters

    • string: any
    • substring: any
    • replacer: any

    Returns any

stringToBytes

  • stringToBytes(str: any): any[]
  • Parameters

    • str: any

    Returns any[]

stringToRegexp

  • stringToRegexp(path: string, keys: any[], options: any): RegExp
  • Create a path regexp from string input.

    Parameters

    • path: string
    • keys: any[]
    • options: any

    Returns RegExp

stringify

  • stringify(obj: any, replacer: any, spacer: any): string
  • Parameters

    • obj: any
    • replacer: any
    • spacer: any

    Returns string

Const stringifyScope

  • stringifyScope(scope: any): any
  • stringifyScope(scope: any[]): string
  • Parameters

    • scope: any

    Returns any

  • Parameters

    • scope: any[]

    Returns string

stripBOM

  • stripBOM(content: string): string
  • Remove byte order marker. This catches EF BB BF (the UTF-8 BOM)

    Parameters

    • content: string

      with BOM

    Returns string

    content value without BOM

stripLeadingSlash

  • stripLeadingSlash(s: any): any
  • Parameters

    • s: any

    Returns any

stripTrailingSlash

  • stripTrailingSlash(s: any): any
  • Parameters

    • s: any

    Returns any

su

  • su(u: any): { has16m: boolean; has256: boolean; hasBasic: boolean; level: any }
  • Parameters

    • u: any

    Returns { has16m: boolean; has256: boolean; hasBasic: boolean; level: any }

    • has16m: boolean
    • has256: boolean
    • hasBasic: boolean
    • level: any

supportsColor

  • supportsColor(haveStream: any, streamIsTTY: any): 0 | 1 | 2 | 3
  • Parameters

    • haveStream: any
    • streamIsTTY: any

    Returns 0 | 1 | 2 | 3

throwIfCancellationRequested

  • throwIfCancellationRequested(config: any): void
  • Throws a Cancel if cancellation has been requested.

    Parameters

    • config: any

    Returns void

toDataString

  • toDataString(data: any): any
  • Parameters

    • data: any

    Returns any

toIterator

  • toIterator(collection: any): any
  • Parameters

    • collection: any

    Returns any

tokensToFunction

  • tokensToFunction(tokens: any, options: any): (Anonymous function)
  • Expose a method for transforming tokens into the path function.

    Parameters

    • tokens: any
    • options: any

    Returns (Anonymous function)

tokensToRegExp

  • tokensToRegExp(tokens: any[], keys: any[], options: any): RegExp
  • Expose a function for taking tokens and returning a RegExp.

    Parameters

    • tokens: any[]
    • keys: any[]
    • options: any

    Returns RegExp

transformPatternToRoute

  • transformPatternToRoute(pattern: MsPattern): string
  • Transforms the Pattern to Route.

    1. If Pattern is a string, it will be returned as it is.
    2. If Pattern is a number, it will be converted to string.
    3. If Pattern is a JSON object, it will be transformed to Route. For that end, the function will sort properties of JSON Object and creates route string according to the following template: :/:/.../:

    Parameters

    Returns string

    string

translateLevel

  • translateLevel(level: any): false | { has16m: boolean; has256: boolean; hasBasic: boolean; level: any }
  • Parameters

    • level: any

    Returns false | { has16m: boolean; has256: boolean; hasBasic: boolean; level: any }

trim

  • trim(str: string): string
  • Trim excess whitespace off the beginning and end of a string

    Parameters

    • str: string

      The String to trim

    Returns string

    The String freed of excess whitespace

tu

  • tu(u: any, D?: string[]): boolean
  • Parameters

    • u: any
    • Default value D: string[] = process.argv

    Returns boolean

typeHasher

  • typeHasher(options: any, writeTo: any, context: any): { _array: any; _arraybuffer: any; _blob: any; _boolean: any; _connection: any; _context: any; _dataview: any; _date: any; _domwindow: any; _error: any; _float32array: any; _float64array: any; _fsevent: any; _function: any; _httpparser: any; _int16array: any; _int32array: any; _int8array: any; _map: any; _nodescript: any; _null: any; _number: any; _object: any; _pipe: any; _process: any; _regexp: any; _securecontext: any; _set: any; _signal: any; _statwatcher: any; _string: any; _symbol: any; _tcp: any; _timer: any; _tlswrap: any; _tty: any; _udp: any; _uint16array: any; _uint32array: any; _uint8array: any; _uint8clampedarray: any; _undefined: any; _url: any; _xml: any; _zlib: any; dispatch: any }
  • Parameters

    • options: any
    • writeTo: any
    • context: any

    Returns { _array: any; _arraybuffer: any; _blob: any; _boolean: any; _connection: any; _context: any; _dataview: any; _date: any; _domwindow: any; _error: any; _float32array: any; _float64array: any; _fsevent: any; _function: any; _httpparser: any; _int16array: any; _int32array: any; _int8array: any; _map: any; _nodescript: any; _null: any; _number: any; _object: any; _pipe: any; _process: any; _regexp: any; _securecontext: any; _set: any; _signal: any; _statwatcher: any; _string: any; _symbol: any; _tcp: any; _timer: any; _tlswrap: any; _tty: any; _udp: any; _uint16array: any; _uint32array: any; _uint8array: any; _uint8clampedarray: any; _undefined: any; _url: any; _xml: any; _zlib: any; dispatch: any }

    • _array: function
      • _array(arr: any, unordered: any): any
      • Parameters

        • arr: any
        • unordered: any

        Returns any

    • _arraybuffer: function
      • _arraybuffer(arr: any): any
      • Parameters

        • arr: any

        Returns any

    • _blob: function
      • _blob(): any
      • Returns any

    • _boolean: function
      • _boolean(bool: any): any
      • Parameters

        • bool: any

        Returns any

    • _connection: function
      • _connection(): any
      • Returns any

    • _context: function
      • _context(): any
      • Returns any

    • _dataview: function
      • _dataview(): any
      • Returns any

    • _date: function
      • _date(date: any): any
      • Parameters

        • date: any

        Returns any

    • _domwindow: function
      • _domwindow(): any
      • Returns any

    • _error: function
      • _error(err: any): any
      • Parameters

        • err: any

        Returns any

    • _float32array: function
      • _float32array(arr: any): any
      • Parameters

        • arr: any

        Returns any

    • _float64array: function
      • _float64array(arr: any): any
      • Parameters

        • arr: any

        Returns any

    • _fsevent: function
      • _fsevent(): any
      • Returns any

    • _function: function
      • _function(fn: any): void
      • Parameters

        • fn: any

        Returns void

    • _httpparser: function
      • _httpparser(): any
      • Returns any

    • _int16array: function
      • _int16array(arr: any): any
      • Parameters

        • arr: any

        Returns any

    • _int32array: function
      • _int32array(arr: any): any
      • Parameters

        • arr: any

        Returns any

    • _int8array: function
      • _int8array(arr: any): any
      • Parameters

        • arr: any

        Returns any

    • _map: function
      • _map(map: any): any
      • Parameters

        • map: any

        Returns any

    • _nodescript: function
      • _nodescript(): any
      • Returns any

    • _null: function
      • _null(): any
      • Returns any

    • _number: function
      • _number(number: any): any
      • Parameters

        • number: any

        Returns any

    • _object: function
      • _object(object: any): any
      • Parameters

        • object: any

        Returns any

    • _pipe: function
      • _pipe(): any
      • Returns any

    • _process: function
      • _process(): any
      • Returns any

    • _regexp: function
      • _regexp(regex: any): any
      • Parameters

        • regex: any

        Returns any

    • _securecontext: function
      • _securecontext(): any
      • Returns any

    • _set: function
      • _set(set: any): any
      • Parameters

        • set: any

        Returns any

    • _signal: function
      • _signal(): any
      • Returns any

    • _statwatcher: function
      • _statwatcher(): any
      • Returns any

    • _string: function
      • _string(string: any): void
      • Parameters

        • string: any

        Returns void

    • _symbol: function
      • _symbol(sym: any): any
      • Parameters

        • sym: any

        Returns any

    • _tcp: function
      • _tcp(): any
      • Returns any

    • _timer: function
      • _timer(): any
      • Returns any

    • _tlswrap: function
      • _tlswrap(): any
      • Returns any

    • _tty: function
      • _tty(): any
      • Returns any

    • _udp: function
      • _udp(): any
      • Returns any

    • _uint16array: function
      • _uint16array(arr: any): any
      • Parameters

        • arr: any

        Returns any

    • _uint32array: function
      • _uint32array(arr: any): any
      • Parameters

        • arr: any

        Returns any

    • _uint8array: function
      • _uint8array(arr: any): any
      • Parameters

        • arr: any

        Returns any

    • _uint8clampedarray: function
      • _uint8clampedarray(arr: any): any
      • Parameters

        • arr: any

        Returns any

    • _undefined: function
      • _undefined(): any
      • Returns any

    • _url: function
      • _url(url: any): any
      • Parameters

        • url: any

        Returns any

    • _xml: function
      • _xml(xml: any): any
      • Parameters

        • xml: any

        Returns any

    • _zlib: function
      • _zlib(): any
      • Returns any

    • dispatch: function
      • dispatch(value: any): any
      • Parameters

        • value: any

        Returns any

u

  • u(u: any): any
  • Parameters

    • u: any

    Returns any

unescape

  • unescape(c: any): any
  • Parameters

    • c: any

    Returns any

urlToOptions

  • urlToOptions(urlObject: any): { hash: any; hostname: any; href: any; path: any; pathname: any; protocol: any; search: any }
  • Parameters

    • urlObject: any

    Returns { hash: any; hostname: any; href: any; path: any; pathname: any; protocol: any; search: any }

    • hash: any
    • hostname: any
    • href: any
    • path: any
    • pathname: any
    • protocol: any
    • search: any

usage

  • usage(): void
  • Returns void

v1

  • v1(options: any, buf: any, offset: any): any
  • Parameters

    • options: any
    • buf: any
    • offset: any

    Returns any

v4

  • v4(options: any, buf: any, offset: any): any
  • Parameters

    • options: any
    • buf: any
    • offset: any

    Returns any

validate

  • validate(uuid: any): boolean
  • Parameters

    • uuid: any

    Returns boolean

validateEach

  • validateEach(context: any, arr: any, predicate: any, decorator: any, item: any): boolean
  • Parameters

    • context: any
    • arr: any
    • predicate: any
    • decorator: any
    • item: any

    Returns boolean

validateModuleKeys

  • validateModuleKeys(keys: any): void
  • Parameters

    • keys: any

    Returns void

validateName

  • validateName(name: any): void
  • Parameters

    • name: any

    Returns void

Const validatePath

  • validatePath(path?: string): string

validateValue

  • validateValue(value: any): void
  • Parameters

    • value: any

    Returns void

Const version

  • version(uuid: any): number
  • Parameters

    • uuid: any

    Returns number

wordsToMd5

  • wordsToMd5(x: any, len: any): number[]
  • Parameters

    • x: any
    • len: any

    Returns number[]

wrap

  • wrap(protocols: any): { maxBodyLength: number; maxRedirects: number }
  • Parameters

    • protocols: any

    Returns { maxBodyLength: number; maxRedirects: number }

    • maxBodyLength: number
    • maxRedirects: number

Const wrapAnsi16

  • wrapAnsi16(fn: any, offset: any): (Anonymous function)
  • Parameters

    • fn: any
    • offset: any

    Returns (Anonymous function)

Const wrapAnsi16m

  • wrapAnsi16m(fn: any, offset: any): (Anonymous function)
  • Parameters

    • fn: any
    • offset: any

    Returns (Anonymous function)

Const wrapAnsi256

  • wrapAnsi256(fn: any, offset: any): (Anonymous function)
  • Parameters

    • fn: any
    • offset: any

    Returns (Anonymous function)

wrapConversion

  • wrapConversion(toModel: any, graph: any): any
  • Parameters

    • toModel: any
    • graph: any

    Returns any

wrapRaw

  • wrapRaw(fn: any): wrappedFn
  • Parameters

    • fn: any

    Returns wrappedFn

wrapRounded

  • wrapRounded(fn: any): wrappedFn
  • Parameters

    • fn: any

    Returns wrappedFn

writeStream

  • writeStream(data: any, stream: any, mode?: string): any
  • Parameters

    • data: any
    • stream: any
    • Default value mode: string = "default"

    Returns any

writeToStream

  • writeToStream(dest: any, instance: any): void
  • Write a Body to a Node.js WritableStream (e.g. http.Request) object.

    Parameters

    • dest: any
    • instance: any

    Returns void

    Void

Const wu

  • wu(u: any): (Anonymous function)
  • Parameters

    • u: any

    Returns (Anonymous function)

y

  • y(u: any): boolean
  • Parameters

    • u: any

    Returns boolean

zip

  • Creates an Iterator that emits pairs of values from the two passed Iterators

    Parameters

    • a: any
    • b: any

    Returns IteratorWithOperators

Object literals

Const DEFAULTS

DEFAULTS: object

dateFormat

dateFormat: string = "HH:mm:ss"

secondaryColor

secondaryColor: string = "grey"

formatOptions

formatOptions: object

colors

colors: boolean = true

compact

compact: boolean = false

date

date: boolean = true

Const DEFAULT_CALLBACK_METADATA

DEFAULT_CALLBACK_METADATA: object

[`${RpcParamtype.PAYLOAD}:0`]

[`${RpcParamtype.PAYLOAD}:0`]: object

data

data: undefined = undefined

index

index: number = 0

pipes

pipes: undefined[] = []

DEFAULT_CONTENT_TYPE

DEFAULT_CONTENT_TYPE: object

Content-Type

Content-Type: string = "application/x-www-form-urlencoded"

Const DEFAULT_GRPC_CALLBACK_METADATA

DEFAULT_GRPC_CALLBACK_METADATA: object

[`${RpcParamtype.CONTEXT}:1`]

[`${RpcParamtype.CONTEXT}:1`]: object

data

data: undefined = undefined

index

index: number = 1

pipes

pipes: undefined[] = []

[`${RpcParamtype.GRPC_CALL}:2`]

[`${RpcParamtype.GRPC_CALL}:2`]: object

data

data: undefined = undefined

index

index: number = 2

pipes

pipes: undefined[] = []

G

G: object

aliceblue

aliceblue: number[] = [240,248,255]

antiquewhite

antiquewhite: number[] = [250,235,215]

aqua

aqua: number[] = [0,255,255]

aquamarine

aquamarine: number[] = [127,255,212]

azure

azure: number[] = [240,255,255]

beige

beige: number[] = [245,245,220]

bisque

bisque: number[] = [255,228,196]

black

black: number[] = [0,0,0]

blanchedalmond

blanchedalmond: number[] = [255,235,205]

blue

blue: number[] = [0,0,255]

blueviolet

blueviolet: number[] = [138,43,226]

brown

brown: number[] = [165,42,42]

burlywood

burlywood: number[] = [222,184,135]

cadetblue

cadetblue: number[] = [95,158,160]

chartreuse

chartreuse: number[] = [127,255,0]

chocolate

chocolate: number[] = [210,105,30]

coral

coral: number[] = [255,127,80]

cornflowerblue

cornflowerblue: number[] = [100,149,237]

cornsilk

cornsilk: number[] = [255,248,220]

crimson

crimson: number[] = [220,20,60]

cyan

cyan: number[] = [0,255,255]

darkblue

darkblue: number[] = [0,0,139]

darkcyan

darkcyan: number[] = [0,139,139]

darkgoldenrod

darkgoldenrod: number[] = [184,134,11]

darkgray

darkgray: number[] = [169,169,169]

darkgreen

darkgreen: number[] = [0,100,0]

darkgrey

darkgrey: number[] = [169,169,169]

darkkhaki

darkkhaki: number[] = [189,183,107]

darkmagenta

darkmagenta: number[] = [139,0,139]

darkolivegreen

darkolivegreen: number[] = [85,107,47]

darkorange

darkorange: number[] = [255,140,0]

darkorchid

darkorchid: number[] = [153,50,204]

darkred

darkred: number[] = [139,0,0]

darksalmon

darksalmon: number[] = [233,150,122]

darkseagreen

darkseagreen: number[] = [143,188,143]

darkslateblue

darkslateblue: number[] = [72,61,139]

darkslategray

darkslategray: number[] = [47,79,79]

darkslategrey

darkslategrey: number[] = [47,79,79]

darkturquoise

darkturquoise: number[] = [0,206,209]

darkviolet

darkviolet: number[] = [148,0,211]

deeppink

deeppink: number[] = [255,20,147]

deepskyblue

deepskyblue: number[] = [0,191,255]

dimgray

dimgray: number[] = [105,105,105]

dimgrey

dimgrey: number[] = [105,105,105]

dodgerblue

dodgerblue: number[] = [30,144,255]

firebrick

firebrick: number[] = [178,34,34]

floralwhite

floralwhite: number[] = [255,250,240]

forestgreen

forestgreen: number[] = [34,139,34]

fuchsia

fuchsia: number[] = [255,0,255]

gainsboro

gainsboro: number[] = [220,220,220]

ghostwhite

ghostwhite: number[] = [248,248,255]

gold

gold: number[] = [255,215,0]

goldenrod

goldenrod: number[] = [218,165,32]

gray

gray: number[] = [128,128,128]

green

green: number[] = [0,128,0]

greenyellow

greenyellow: number[] = [173,255,47]

grey

grey: number[] = [128,128,128]

honeydew

honeydew: number[] = [240,255,240]

hotpink

hotpink: number[] = [255,105,180]

indianred

indianred: number[] = [205,92,92]

indigo

indigo: number[] = [75,0,130]

ivory

ivory: number[] = [255,255,240]

khaki

khaki: number[] = [240,230,140]

lavender

lavender: number[] = [230,230,250]

lavenderblush

lavenderblush: number[] = [255,240,245]

lawngreen

lawngreen: number[] = [124,252,0]

lemonchiffon

lemonchiffon: number[] = [255,250,205]

lightblue

lightblue: number[] = [173,216,230]

lightcoral

lightcoral: number[] = [240,128,128]

lightcyan

lightcyan: number[] = [224,255,255]

lightgoldenrodyellow

lightgoldenrodyellow: number[] = [250,250,210]

lightgray

lightgray: number[] = [211,211,211]

lightgreen

lightgreen: number[] = [144,238,144]

lightgrey

lightgrey: number[] = [211,211,211]

lightpink

lightpink: number[] = [255,182,193]

lightsalmon

lightsalmon: number[] = [255,160,122]

lightseagreen

lightseagreen: number[] = [32,178,170]

lightskyblue

lightskyblue: number[] = [135,206,250]

lightslategray

lightslategray: number[] = [119,136,153]

lightslategrey

lightslategrey: number[] = [119,136,153]

lightsteelblue

lightsteelblue: number[] = [176,196,222]

lightyellow

lightyellow: number[] = [255,255,224]

lime

lime: number[] = [0,255,0]

limegreen

limegreen: number[] = [50,205,50]

linen

linen: number[] = [250,240,230]

magenta

magenta: number[] = [255,0,255]

maroon

maroon: number[] = [128,0,0]

mediumaquamarine

mediumaquamarine: number[] = [102,205,170]

mediumblue

mediumblue: number[] = [0,0,205]

mediumorchid

mediumorchid: number[] = [186,85,211]

mediumpurple

mediumpurple: number[] = [147,112,219]

mediumseagreen

mediumseagreen: number[] = [60,179,113]

mediumslateblue

mediumslateblue: number[] = [123,104,238]

mediumspringgreen

mediumspringgreen: number[] = [0,250,154]

mediumturquoise

mediumturquoise: number[] = [72,209,204]

mediumvioletred

mediumvioletred: number[] = [199,21,133]

midnightblue

midnightblue: number[] = [25,25,112]

mintcream

mintcream: number[] = [245,255,250]

mistyrose

mistyrose: number[] = [255,228,225]

moccasin

moccasin: number[] = [255,228,181]

navajowhite

navajowhite: number[] = [255,222,173]

navy

navy: number[] = [0,0,128]

oldlace

oldlace: number[] = [253,245,230]

olive

olive: number[] = [128,128,0]

olivedrab

olivedrab: number[] = [107,142,35]

orange

orange: number[] = [255,165,0]

orangered

orangered: number[] = [255,69,0]

orchid

orchid: number[] = [218,112,214]

palegoldenrod

palegoldenrod: number[] = [238,232,170]

palegreen

palegreen: number[] = [152,251,152]

paleturquoise

paleturquoise: number[] = [175,238,238]

palevioletred

palevioletred: number[] = [219,112,147]

papayawhip

papayawhip: number[] = [255,239,213]

peachpuff

peachpuff: number[] = [255,218,185]

peru

peru: number[] = [205,133,63]

pink

pink: number[] = [255,192,203]

plum

plum: number[] = [221,160,221]

powderblue

powderblue: number[] = [176,224,230]

purple

purple: number[] = [128,0,128]

rebeccapurple

rebeccapurple: number[] = [102,51,153]

red

red: number[] = [255,0,0]

rosybrown

rosybrown: number[] = [188,143,143]

royalblue

royalblue: number[] = [65,105,225]

saddlebrown

saddlebrown: number[] = [139,69,19]

salmon

salmon: number[] = [250,128,114]

sandybrown

sandybrown: number[] = [244,164,96]

seagreen

seagreen: number[] = [46,139,87]

seashell

seashell: number[] = [255,245,238]

sienna

sienna: number[] = [160,82,45]

silver

silver: number[] = [192,192,192]

skyblue

skyblue: number[] = [135,206,235]

slateblue

slateblue: number[] = [106,90,205]

slategray

slategray: number[] = [112,128,144]

slategrey

slategrey: number[] = [112,128,144]

snow

snow: number[] = [255,250,250]

springgreen

springgreen: number[] = [0,255,127]

steelblue

steelblue: number[] = [70,130,180]

tan

tan: number[] = [210,180,140]

teal

teal: number[] = [0,128,128]

thistle

thistle: number[] = [216,191,216]

tomato

tomato: number[] = [255,99,71]

turquoise

turquoise: number[] = [64,224,208]

violet

violet: number[] = [238,130,238]

wheat

wheat: number[] = [245,222,179]

white

white: number[] = [255,255,255]

whitesmoke

whitesmoke: number[] = [245,245,245]

yellow

yellow: number[] = [255,255,0]

yellowgreen

yellowgreen: number[] = [154,205,50]

Const HttpErrorByCode

HttpErrorByCode: object

[HttpStatus.BAD_GATEWAY]

[HttpStatus.BAD_GATEWAY]: BadGatewayException = BadGatewayException

[HttpStatus.BAD_REQUEST]

[HttpStatus.BAD_REQUEST]: BadRequestException = BadRequestException

[HttpStatus.CONFLICT]

[HttpStatus.CONFLICT]: ConflictException = ConflictException

[HttpStatus.FORBIDDEN]

[HttpStatus.FORBIDDEN]: ForbiddenException = ForbiddenException

[HttpStatus.GATEWAY_TIMEOUT]

[HttpStatus.GATEWAY_TIMEOUT]: GatewayTimeoutException = GatewayTimeoutException

[HttpStatus.GONE]

[HttpStatus.GONE]: GoneException = GoneException

[HttpStatus.INTERNAL_SERVER_ERROR]

[HttpStatus.INTERNAL_SERVER_ERROR]: InternalServerErrorException = InternalServerErrorException

[HttpStatus.I_AM_A_TEAPOT]

[HttpStatus.I_AM_A_TEAPOT]: ImATeapotException = ImATeapotException

[HttpStatus.METHOD_NOT_ALLOWED]

[HttpStatus.METHOD_NOT_ALLOWED]: MethodNotAllowedException = MethodNotAllowedException

[HttpStatus.NOT_ACCEPTABLE]

[HttpStatus.NOT_ACCEPTABLE]: NotAcceptableException = NotAcceptableException

[HttpStatus.NOT_FOUND]

[HttpStatus.NOT_FOUND]: NotFoundException = NotFoundException

[HttpStatus.NOT_IMPLEMENTED]

[HttpStatus.NOT_IMPLEMENTED]: NotImplementedException = NotImplementedException

[HttpStatus.PAYLOAD_TOO_LARGE]

[HttpStatus.PAYLOAD_TOO_LARGE]: PayloadTooLargeException = PayloadTooLargeException

[HttpStatus.PRECONDITION_FAILED]

[HttpStatus.PRECONDITION_FAILED]: PreconditionFailedException = PreconditionFailedException

[HttpStatus.REQUEST_TIMEOUT]

[HttpStatus.REQUEST_TIMEOUT]: RequestTimeoutException = RequestTimeoutException

[HttpStatus.SERVICE_UNAVAILABLE]

[HttpStatus.SERVICE_UNAVAILABLE]: ServiceUnavailableException = ServiceUnavailableException

[HttpStatus.UNAUTHORIZED]

[HttpStatus.UNAUTHORIZED]: UnauthorizedException = UnauthorizedException

[HttpStatus.UNPROCESSABLE_ENTITY]

[HttpStatus.UNPROCESSABLE_ENTITY]: UnprocessableEntityException = UnprocessableEntityException

[HttpStatus.UNSUPPORTED_MEDIA_TYPE]

[HttpStatus.UNSUPPORTED_MEDIA_TYPE]: UnsupportedMediaTypeException = UnsupportedMediaTypeException

Const Hu

Hu: object

debug

debug: any = H("›")

info

info: any = H("ℹ")

log

log: string = ""

success

success: any = H("✔")

trace

trace: any = H("›")

Const LEVEL_COLOR_MAP

LEVEL_COLOR_MAP: object

0

0: string = "red"

1

1: string = "yellow"

2

2: string = "white"

3

3: string = "green"

Const MESSAGES

MESSAGES: object

APPLICATION_READY

APPLICATION_READY: string = `Nest application successfully started`

APPLICATION_START

APPLICATION_START: string = `Starting Nest application...`

CALL_LISTEN_FIRST

CALL_LISTEN_FIRST: string = "app.listen() needs to be called before calling app.getUrl()"

ERROR_DURING_SHUTDOWN

ERROR_DURING_SHUTDOWN: string = "Error happened during shutdown"

MICROSERVICE_READY

MICROSERVICE_READY: string = `Nest microservice successfully started`

UNKNOWN_EXCEPTION_MESSAGE

UNKNOWN_EXCEPTION_MESSAGE: string = "Internal server error"

Const MODULE_METADATA

MODULE_METADATA: object

CONTROLLERS

CONTROLLERS: string = "controllers"

EXPORTS

EXPORTS: string = "exports"

IMPORTS

IMPORTS: string = "imports"

PROVIDERS

PROVIDERS: string = "providers"

Const N

N: object

arrowDown

arrowDown: string = "↓"

arrowLeft

arrowLeft: string = "←"

arrowRight

arrowRight: string = "→"

arrowUp

arrowUp: string = "↑"

bullet

bullet: string = "●"

checkboxCircleOff

checkboxCircleOff: string = "Ⓘ"

checkboxCircleOn

checkboxCircleOn: string = "ⓧ"

checkboxOff

checkboxOff: string = "☐"

checkboxOn

checkboxOn: string = "☒"

circle

circle: string = "◯"

circleCircle

circleCircle: string = "ⓞ"

circleCross

circleCross: string = "ⓧ"

circleDotted

circleDotted: string = "◌"

circleDouble

circleDouble: string = "◎"

circleFilled

circleFilled: string = "◉"

circlePipe

circlePipe: string = "Ⓘ"

circleQuestionMark

circleQuestionMark: string = "?⃝"

cross

cross: string = "✖"

dot

dot: string = "․"

ellipsis

ellipsis: string = "…"

fiveEighths

fiveEighths: string = "⅝"

fiveSixths

fiveSixths: string = "⅚"

fourFifths

fourFifths: string = "⅘"

hamburger

hamburger: string = "☰"

heart

heart: string = "♥"

info

info: string = "ℹ"

line

line: string = "─"

mustache

mustache: string = "෴"

nodejs

nodejs: string = "⬢"

oneEighth

oneEighth: string = "⅛"

oneFifth

oneFifth: string = "⅕"

oneHalf

oneHalf: string = "½"

oneNinth

oneNinth: string = "⅑"

oneQuarter

oneQuarter: string = "¼"

oneSeventh

oneSeventh: string = "⅐"

oneSixth

oneSixth: string = "⅙"

oneTenth

oneTenth: string = "⅒"

oneThird

oneThird: string = "⅓"

play

play: string = "▶"

pointer

pointer: string = "❯"

pointerSmall

pointerSmall: string = "›"

questionMarkPrefix

questionMarkPrefix: string = "?⃝"

radioOff

radioOff: string = "◯"

radioOn

radioOn: string = "◉"

sevenEighths

sevenEighths: string = "⅞"

smiley

smiley: string = "㋡"

square

square: string = "▇"

squareSmall

squareSmall: string = "◻"

squareSmallFilled

squareSmallFilled: string = "◼"

star

star: string = "★"

threeEighths

threeEighths: string = "⅜"

threeFifths

threeFifths: string = "⅗"

threeQuarters

threeQuarters: string = "¾"

tick

tick: string = "✔"

twoFifths

twoFifths: string = "⅖"

twoThirds

twoThirds: string = "⅔"

warning

warning: string = "⚠"

Const Nu

Nu: object

info

info: string = "cyan"

Const O

O: object

dateFormat

dateFormat: string = "HH:mm:ss"

formatOptions

formatOptions: object

colors

colors: boolean = !1

compact

compact: boolean = !0

date

date: boolean = !0

Const Q

Q: object

ansi16

ansi16: object

channels

channels: number = 1

labels

labels: string[] = ["ansi16"]

ansi256

ansi256: object

channels

channels: number = 1

labels

labels: string[] = ["ansi256"]

apple

apple: object

channels

channels: number = 3

labels

labels: string[] = ["r16","g16","b16"]

cmyk

cmyk: object

channels

channels: number = 4

labels

labels: string = "cmyk"

gray

gray: object

channels

channels: number = 1

labels

labels: string[] = ["gray"]

hcg

hcg: object

channels

channels: number = 3

labels

labels: string[] = ["h","c","g"]

hex

hex: object

channels

channels: number = 1

labels

labels: string[] = ["hex"]

hsl

hsl: object

channels

channels: number = 3

labels

labels: string = "hsl"

hsv

hsv: object

channels

channels: number = 3

labels

labels: string = "hsv"

hwb

hwb: object

channels

channels: number = 3

labels

labels: string = "hwb"

keyword

keyword: object

channels

channels: number = 1

labels

labels: string[] = ["keyword"]

lab

lab: object

channels

channels: number = 3

labels

labels: string = "lab"

lch

lch: object

channels

channels: number = 3

labels

labels: string = "lch"

rgb

rgb: object

channels

channels: number = 3

labels

labels: string = "rgb"

xyz

xyz: object

channels

channels: number = 3

labels

labels: string = "xyz"

Const Qu

Qu: object

0

0: string = "error"

1

1: string = "warn"

2

2: string = "info"

3

3: string = "verbose"

4

4: string = "debug"

5

5: string = "silly"

Const TYPE_COLOR_MAP

TYPE_COLOR_MAP: object

info

info: string = "cyan"

Const TYPE_ICONS

TYPE_ICONS: object

debug

debug: any = figures('›')

info

info: any = figures('ℹ')

log

log: string = ""

success

success: any = figures('✔')

trace

trace: any = figures('›')

Const Yu

Yu: object

secondaryColor

secondaryColor: string = "grey"

formatOptions

formatOptions: object

colors

colors: boolean = !0

compact

compact: boolean = !1

date

date: boolean = !0

au

au: object

stringEncaseCRLFWithFirstIndex

  • stringEncaseCRLFWithFirstIndex(u: any, D: any, e: any, t: any): string
  • Parameters

    • u: any
    • D: any
    • e: any
    • t: any

    Returns string

stringReplaceAll

  • stringReplaceAll(u: any, D: any, e: any): any
  • Parameters

    • u: any
    • D: any
    • e: any

    Returns any

b

b: object

debug

debug: object

level

level: number = m.Debug

error

error: object

level

level: number = m.Error

fatal

fatal: object

level

level: number = m.Fatal

info

info: object

level

level: number = m.Info

log

log: object

level

level: number = m.Log

ready

ready: object

level

level: number = m.Info

silent

silent: object

level

level: number = -1

start

start: object

level

level: number = m.Info

success

success: object

level

level: number = m.Success

trace

trace: object

level

level: number = m.Trace

verbose

verbose: object

level

level: number = m.Trace

warn

warn: object

level

level: number = m.Warn

Const clc

clc: object

cyanBright

cyanBright: (Anonymous function) = colorIfAllowed((text: string) => `\x1B[96m${text}\x1B[39m`)

green

green: (Anonymous function) = colorIfAllowed((text: string) => `\x1B[32m${text}\x1B[39m`)

magentaBright

magentaBright: (Anonymous function) = colorIfAllowed((text: string) => `\x1B[95m${text}\x1B[39m`)

red

red: (Anonymous function) = colorIfAllowed((text: string) => `\x1B[31m${text}\x1B[39m`)

yellow

yellow: (Anonymous function) = colorIfAllowed((text: string) => `\x1B[33m${text}\x1B[39m`)

Let convert

convert: object

ansi16

ansi16: object

channels

channels: number = 1

labels

labels: string[] = ['ansi16']

ansi256

ansi256: object

channels

channels: number = 1

labels

labels: string[] = ['ansi256']

apple

apple: object

channels

channels: number = 3

labels

labels: string[] = ['r16', 'g16', 'b16']

cmyk

cmyk: object

channels

channels: number = 4

labels

labels: string = "cmyk"

gray

gray: object

channels

channels: number = 1

labels

labels: string[] = ['gray']

hcg

hcg: object

channels

channels: number = 3

labels

labels: string[] = ['h', 'c', 'g']

hex

hex: object

channels

channels: number = 1

labels

labels: string[] = ['hex']

hsl

hsl: object

channels

channels: number = 3

labels

labels: string = "hsl"

hsv

hsv: object

channels

channels: number = 3

labels

labels: string = "hsv"

hwb

hwb: object

channels

channels: number = 3

labels

labels: string = "hwb"

keyword

keyword: object

channels

channels: number = 1

labels

labels: string[] = ['keyword']

lab

lab: object

channels

channels: number = 3

labels

labels: string = "lab"

lch

lch: object

channels

channels: number = 3

labels

labels: string = "lch"

rgb

rgb: object

channels

channels: number = 3

labels

labels: string = "rgb"

xyz

xyz: object

channels

channels: number = 3

labels

labels: string = "xyz"

Const defaultCacheOptions

defaultCacheOptions: object

max

max: number = 100

store

store: string = "memory"

ttl

ttl: number = 5

Const defaultMetadata

defaultMetadata: object

[METHOD_METADATA]

[METHOD_METADATA]: RequestMethod = RequestMethod.GET

[PATH_METADATA]

[PATH_METADATA]: string = "/"

[constants_1.METHOD_METADATA]

[constants_1.METHOD_METADATA]: RequestMethod = request_method_enum_1.RequestMethod.GET

[constants_1.PATH_METADATA]

[constants_1.PATH_METADATA]: string = "/"

defaults

defaults: object = require('../defaults')

adapter

adapter: xhrAdapter = getDefaultAdapter()

maxBodyLength

maxBodyLength: number = -1

maxContentLength

maxContentLength: number = -1

timeout

timeout: number = 0

A timeout in milliseconds to abort a request. If set to 0 (default) a timeout is not created.

transformRequest

transformRequest: transformRequest[] = [function transformRequest(data, headers) {normalizeHeaderName(headers, 'Accept');normalizeHeaderName(headers, 'Content-Type');if (utils.isFormData(data) ||utils.isArrayBuffer(data) ||utils.isBuffer(data) ||utils.isStream(data) ||utils.isFile(data) ||utils.isBlob(data)) {return data;}if (utils.isArrayBufferView(data)) {return data.buffer;}if (utils.isURLSearchParams(data)) {setContentTypeIfUnset(headers, 'application/x-www-form-urlencoded;charset=utf-8');return data.toString();}if (utils.isObject(data)) {setContentTypeIfUnset(headers, 'application/json;charset=utf-8');return JSON.stringify(data);}return data;}]

transformResponse

transformResponse: transformResponse[] = [function transformResponse(data) {/*eslint no-param-reassign:0*/if (typeof data === 'string') {try {data = JSON.parse(data);} catch (e) { /* Ignore */ }}return data;}]

xsrfCookieName

xsrfCookieName: string = "XSRF-TOKEN"

xsrfHeaderName

xsrfHeaderName: string = "X-XSRF-TOKEN"

validateStatus

  • validateStatus(status: any): boolean
  • Parameters

    • status: any

    Returns boolean

Const entry

entry: object

message

message: string = "message"

other

other: object

stuff

stuff: string = "here"

g

g: object

browser

browser: boolean = C

ci

ci: boolean = l

darwin

darwin: boolean = /^darwin/i.test(f)

debug

debug: boolean = c

dev

dev: boolean = "development"===F||"dev"===F

linux

linux: boolean = /^linux/i.test(f)

minimal

minimal: undefined = void 0

minimalCLI

minimalCLI: undefined = void 0

production

production: boolean = "production"===F

test

test: boolean = "test"===F

tty

tty: boolean = h

windows

windows: boolean = /^win/i.test(f)

Const inquirerProvider

inquirerProvider: object

provide

provide: string = INQUIRER

scope

scope: TRANSIENT = Scope.TRANSIENT

useFactory

useFactory: noop = noop

iu

iu: object

stderr

stderr: { has16m: boolean; has256: boolean; hasBasic: boolean; level: any } = su(ou(!0,n.isatty(2)))

Type declaration

  • has16m: boolean
  • has256: boolean
  • hasBasic: boolean
  • level: any

stdout

stdout: { has16m: boolean; has256: boolean; hasBasic: boolean; level: any } = su(ou(!0,n.isatty(1)))

Type declaration

  • has16m: boolean
  • has256: boolean
  • hasBasic: boolean
  • level: any

supportsColor

  • supportsColor(u: any): { has16m: boolean; has256: boolean; hasBasic: boolean; level: any }
  • Parameters

    • u: any

    Returns { has16m: boolean; has256: boolean; hasBasic: boolean; level: any }

    • has16m: boolean
    • has256: boolean
    • hasBasic: boolean
    • level: any

Const levels

levels: object

0

0: string = "error"

1

1: string = "warn"

2

2: string = "info"

3

3: string = "verbose"

4

4: string = "debug"

5

5: string = "silly"

Const obj

obj: object

foo

foo: number[] = array

Const q

q: object

arrowDown

arrowDown: string = N.arrowDown

arrowLeft

arrowLeft: string = N.arrowLeft

arrowRight

arrowRight: string = N.arrowRight

arrowUp

arrowUp: string = N.arrowUp

bullet

bullet: string = "*"

checkboxCircleOff

checkboxCircleOff: string = "( )"

checkboxCircleOn

checkboxCircleOn: string = "(×)"

checkboxOff

checkboxOff: string = "[ ]"

checkboxOn

checkboxOn: string = "[×]"

circle

circle: string = "( )"

circleCircle

circleCircle: string = "(○)"

circleCross

circleCross: string = "(×)"

circleDotted

circleDotted: string = "( )"

circleDouble

circleDouble: string = "( )"

circleFilled

circleFilled: string = "(*)"

circlePipe

circlePipe: string = "(│)"

circleQuestionMark

circleQuestionMark: string = "(?)"

cross

cross: string = "×"

dot

dot: string = "."

ellipsis

ellipsis: string = "..."

fiveEighths

fiveEighths: string = "5/8"

fiveSixths

fiveSixths: string = "5/6"

fourFifths

fourFifths: string = "4/5"

hamburger

hamburger: string = "≡"

heart

heart: string = N.heart

info

info: string = "i"

line

line: string = "─"

mustache

mustache: string = "┌─┐"

nodejs

nodejs: string = "♦"

oneEighth

oneEighth: string = "1/8"

oneFifth

oneFifth: string = "1/5"

oneHalf

oneHalf: string = "1/2"

oneNinth

oneNinth: string = "1/9"

oneQuarter

oneQuarter: string = "1/4"

oneSeventh

oneSeventh: string = "1/7"

oneSixth

oneSixth: string = "1/6"

oneTenth

oneTenth: string = "1/10"

oneThird

oneThird: string = "1/3"

play

play: string = "►"

pointer

pointer: string = ">"

pointerSmall

pointerSmall: string = "»"

questionMarkPrefix

questionMarkPrefix: string = "?"

radioOff

radioOff: string = "( )"

radioOn

radioOn: string = "(*)"

sevenEighths

sevenEighths: string = "7/8"

smiley

smiley: string = "☺"

square

square: string = "█"

squareSmall

squareSmall: string = "[ ]"

squareSmallFilled

squareSmallFilled: string = "[█]"

star

star: string = "*"

threeEighths

threeEighths: string = "3/8"

threeFifths

threeFifths: string = "3/5"

threeQuarters

threeQuarters: string = "3/4"

tick

tick: string = "√"

twoFifths

twoFifths: string = "2/5"

twoThirds

twoThirds: string = "2/3"

warning

warning: string = "‼"

Const qu

qu: object

0

0: string = "red"

1

1: string = "yellow"

2

2: string = "white"

3

3: string = "green"

Const requestProvider

requestProvider: object

provide

provide: string = REQUEST

scope

scope: REQUEST = Scope.REQUEST

useFactory

useFactory: noop = noop

Const uuid

uuid: object

3

3: RegExp = /^[0-9A-F]{8}-[0-9A-F]{4}-3[0-9A-F]{3}-[0-9A-F]{4}-[0-9A-F]{12}$/i

4

4: RegExp = /^[0-9A-F]{8}-[0-9A-F]{4}-4[0-9A-F]{3}-[89AB][0-9A-F]{3}-[0-9A-F]{12}$/i

5

5: RegExp = /^[0-9A-F]{8}-[0-9A-F]{4}-5[0-9A-F]{3}-[89AB][0-9A-F]{3}-[0-9A-F]{12}$/i

all

all: RegExp = /^[0-9A-F]{8}-[0-9A-F]{4}-[0-9A-F]{4}-[0-9A-F]{4}-[0-9A-F]{12}$/i

Generated using TypeDoc