Skip to content

Commit

Permalink
update angular_dotnet app from 3.x -> 6.x
Browse files Browse the repository at this point in the history
This is a continuation of prev commit but
done separately due to the size of this commit.
All changes to this commit apply to the
fixtures/node_apps/angular_dotnet path only.
  • Loading branch information
arjun024 committed Aug 4, 2022
1 parent d56db80 commit 9badaa3
Show file tree
Hide file tree
Showing 60,862 changed files with 5,313 additions and 5,254,100 deletions.
The diff you're trying to view is too large. We only load the first 3000 changed files.
Binary file not shown.
Binary file not shown.
Original file line number Diff line number Diff line change
@@ -0,0 +1 @@
{"ast":null,"code":"import { argsOrArgArray } from '../util/argsOrArgArray';\nimport { raceWith } from './raceWith';\nexport function race(...args) {\n return raceWith(...argsOrArgArray(args));\n} //# sourceMappingURL=race.js.map","map":null,"metadata":{},"sourceType":"module"}
Original file line number Diff line number Diff line change
@@ -0,0 +1 @@
{"ast":null,"code":"import { createErrorClass } from './createErrorClass';\nexport const ObjectUnsubscribedError = createErrorClass(_super => function ObjectUnsubscribedErrorImpl() {\n _super(this);\n\n this.name = 'ObjectUnsubscribedError';\n this.message = 'object unsubscribed';\n}); //# sourceMappingURL=ObjectUnsubscribedError.js.map","map":null,"metadata":{},"sourceType":"module"}
Original file line number Diff line number Diff line change
@@ -0,0 +1 @@
{"ast":null,"code":"import { AsyncScheduler } from './AsyncScheduler';\nexport class QueueScheduler extends AsyncScheduler {} //# sourceMappingURL=QueueScheduler.js.map","map":null,"metadata":{},"sourceType":"module"}
Original file line number Diff line number Diff line change
@@ -0,0 +1 @@
{"ast":null,"code":"import { operate } from '../util/lift';\nimport { createOperatorSubscriber } from './OperatorSubscriber';\nimport { noop } from '../util/noop';\nexport function ignoreElements() {\n return operate((source, subscriber) => {\n source.subscribe(createOperatorSubscriber(subscriber, noop));\n });\n} //# sourceMappingURL=ignoreElements.js.map","map":null,"metadata":{},"sourceType":"module"}
Original file line number Diff line number Diff line change
@@ -0,0 +1 @@
{"ast":null,"code":"import { AsyncScheduler } from './AsyncScheduler';\nexport class AnimationFrameScheduler extends AsyncScheduler {\n flush(action) {\n this._active = true;\n const flushId = this._scheduled;\n this._scheduled = undefined;\n const {\n actions\n } = this;\n let error;\n action = action || actions.shift();\n\n do {\n if (error = action.execute(action.state, action.delay)) {\n break;\n }\n } while ((action = actions[0]) && action.id === flushId && actions.shift());\n\n this._active = false;\n\n if (error) {\n while ((action = actions[0]) && action.id === flushId && actions.shift()) {\n action.unsubscribe();\n }\n\n throw error;\n }\n }\n\n} //# sourceMappingURL=AnimationFrameScheduler.js.map","map":null,"metadata":{},"sourceType":"module"}

Large diffs are not rendered by default.

Original file line number Diff line number Diff line change
@@ -0,0 +1 @@
{"ast":null,"code":"import { innerFrom } from '../observable/innerFrom';\nimport { observeOn } from '../operators/observeOn';\nimport { subscribeOn } from '../operators/subscribeOn';\nexport function schedulePromise(input, scheduler) {\n return innerFrom(input).pipe(subscribeOn(scheduler), observeOn(scheduler));\n} //# sourceMappingURL=schedulePromise.js.map","map":null,"metadata":{},"sourceType":"module"}
Original file line number Diff line number Diff line change
@@ -0,0 +1 @@
{"ast":null,"code":"import { Observable } from '../Observable';\nimport { argsArgArrayOrObject } from '../util/argsArgArrayOrObject';\nimport { from } from './from';\nimport { identity } from '../util/identity';\nimport { mapOneOrManyArgs } from '../util/mapOneOrManyArgs';\nimport { popResultSelector, popScheduler } from '../util/args';\nimport { createObject } from '../util/createObject';\nimport { createOperatorSubscriber } from '../operators/OperatorSubscriber';\nimport { executeSchedule } from '../util/executeSchedule';\nexport function combineLatest(...args) {\n const scheduler = popScheduler(args);\n const resultSelector = popResultSelector(args);\n const {\n args: observables,\n keys\n } = argsArgArrayOrObject(args);\n\n if (observables.length === 0) {\n return from([], scheduler);\n }\n\n const result = new Observable(combineLatestInit(observables, scheduler, keys ? values => createObject(keys, values) : identity));\n return resultSelector ? result.pipe(mapOneOrManyArgs(resultSelector)) : result;\n}\nexport function combineLatestInit(observables, scheduler, valueTransform = identity) {\n return subscriber => {\n maybeSchedule(scheduler, () => {\n const {\n length\n } = observables;\n const values = new Array(length);\n let active = length;\n let remainingFirstValues = length;\n\n for (let i = 0; i < length; i++) {\n maybeSchedule(scheduler, () => {\n const source = from(observables[i], scheduler);\n let hasFirstValue = false;\n source.subscribe(createOperatorSubscriber(subscriber, value => {\n values[i] = value;\n\n if (!hasFirstValue) {\n hasFirstValue = true;\n remainingFirstValues--;\n }\n\n if (!remainingFirstValues) {\n subscriber.next(valueTransform(values.slice()));\n }\n }, () => {\n if (! --active) {\n subscriber.complete();\n }\n }));\n }, subscriber);\n }\n }, subscriber);\n };\n}\n\nfunction maybeSchedule(scheduler, execute, subscription) {\n if (scheduler) {\n executeSchedule(subscription, scheduler, execute);\n } else {\n execute();\n }\n} //# sourceMappingURL=combineLatest.js.map","map":null,"metadata":{},"sourceType":"module"}
Original file line number Diff line number Diff line change
@@ -0,0 +1 @@
{"ast":null,"code":"export function executeSchedule(parentSubscription, scheduler, work, delay = 0, repeat = false) {\n const scheduleSubscription = scheduler.schedule(function () {\n work();\n\n if (repeat) {\n parentSubscription.add(this.schedule(null, delay));\n } else {\n this.unsubscribe();\n }\n }, delay);\n parentSubscription.add(scheduleSubscription);\n\n if (!repeat) {\n return scheduleSubscription;\n }\n} //# sourceMappingURL=executeSchedule.js.map","map":null,"metadata":{},"sourceType":"module"}
Original file line number Diff line number Diff line change
@@ -0,0 +1 @@
{"ast":null,"code":"export const config = {\n onUnhandledError: null,\n onStoppedNotification: null,\n Promise: undefined,\n useDeprecatedSynchronousErrorHandling: false,\n useDeprecatedNextContext: false\n}; //# sourceMappingURL=config.js.map","map":null,"metadata":{},"sourceType":"module"}
Original file line number Diff line number Diff line change
@@ -0,0 +1 @@
{"ast":null,"code":"import { operate } from '../util/lift';\nimport { createOperatorSubscriber } from './OperatorSubscriber';\nexport function map(project, thisArg) {\n return operate((source, subscriber) => {\n let index = 0;\n source.subscribe(createOperatorSubscriber(subscriber, value => {\n subscriber.next(project.call(thisArg, value, index++));\n }));\n });\n} //# sourceMappingURL=map.js.map","map":null,"metadata":{},"sourceType":"module"}
Original file line number Diff line number Diff line change
@@ -0,0 +1 @@
{"ast":null,"code":"import { operate } from '../util/lift';\nimport { createOperatorSubscriber } from './OperatorSubscriber';\nimport { identity } from '../util/identity';\nimport { timer } from '../observable/timer';\nimport { innerFrom } from '../observable/innerFrom';\nexport function retry(configOrCount = Infinity) {\n let config;\n\n if (configOrCount && typeof configOrCount === 'object') {\n config = configOrCount;\n } else {\n config = {\n count: configOrCount\n };\n }\n\n const {\n count = Infinity,\n delay,\n resetOnSuccess = false\n } = config;\n return count <= 0 ? identity : operate((source, subscriber) => {\n let soFar = 0;\n let innerSub;\n\n const subscribeForRetry = () => {\n let syncUnsub = false;\n innerSub = source.subscribe(createOperatorSubscriber(subscriber, value => {\n if (resetOnSuccess) {\n soFar = 0;\n }\n\n subscriber.next(value);\n }, undefined, err => {\n if (soFar++ < count) {\n const resub = () => {\n if (innerSub) {\n innerSub.unsubscribe();\n innerSub = null;\n subscribeForRetry();\n } else {\n syncUnsub = true;\n }\n };\n\n if (delay != null) {\n const notifier = typeof delay === 'number' ? timer(delay) : innerFrom(delay(err, soFar));\n const notifierSubscriber = createOperatorSubscriber(subscriber, () => {\n notifierSubscriber.unsubscribe();\n resub();\n }, () => {\n subscriber.complete();\n });\n notifier.subscribe(notifierSubscriber);\n } else {\n resub();\n }\n } else {\n subscriber.error(err);\n }\n }));\n\n if (syncUnsub) {\n innerSub.unsubscribe();\n innerSub = null;\n subscribeForRetry();\n }\n };\n\n subscribeForRetry();\n });\n} //# sourceMappingURL=retry.js.map","map":null,"metadata":{},"sourceType":"module"}
Original file line number Diff line number Diff line change
@@ -0,0 +1 @@
{"ast":null,"code":"import { asyncScheduler } from '../scheduler/async';\nimport { sample } from './sample';\nimport { interval } from '../observable/interval';\nexport function sampleTime(period, scheduler = asyncScheduler) {\n return sample(interval(period, scheduler));\n} //# sourceMappingURL=sampleTime.js.map","map":null,"metadata":{},"sourceType":"module"}
Original file line number Diff line number Diff line change
@@ -0,0 +1 @@
{"ast":null,"code":"import { __asyncGenerator, __await } from \"tslib\";\nimport { isFunction } from './isFunction';\nexport function readableStreamLikeToAsyncGenerator(readableStream) {\n return __asyncGenerator(this, arguments, function* readableStreamLikeToAsyncGenerator_1() {\n const reader = readableStream.getReader();\n\n try {\n while (true) {\n const {\n value,\n done\n } = yield __await(reader.read());\n\n if (done) {\n return yield __await(void 0);\n }\n\n yield yield __await(value);\n }\n } finally {\n reader.releaseLock();\n }\n });\n}\nexport function isReadableStreamLike(obj) {\n return isFunction(obj === null || obj === void 0 ? void 0 : obj.getReader);\n} //# sourceMappingURL=isReadableStreamLike.js.map","map":null,"metadata":{},"sourceType":"module"}
Original file line number Diff line number Diff line change
@@ -0,0 +1 @@
{"ast":null,"code":"import { EmptyError } from '../util/EmptyError';\nimport { SequenceError } from '../util/SequenceError';\nimport { NotFoundError } from '../util/NotFoundError';\nimport { operate } from '../util/lift';\nimport { createOperatorSubscriber } from './OperatorSubscriber';\nexport function single(predicate) {\n return operate((source, subscriber) => {\n let hasValue = false;\n let singleValue;\n let seenValue = false;\n let index = 0;\n source.subscribe(createOperatorSubscriber(subscriber, value => {\n seenValue = true;\n\n if (!predicate || predicate(value, index++, source)) {\n hasValue && subscriber.error(new SequenceError('Too many matching values'));\n hasValue = true;\n singleValue = value;\n }\n }, () => {\n if (hasValue) {\n subscriber.next(singleValue);\n subscriber.complete();\n } else {\n subscriber.error(seenValue ? new NotFoundError('No matching values') : new EmptyError());\n }\n }));\n });\n} //# sourceMappingURL=single.js.map","map":null,"metadata":{},"sourceType":"module"}
Original file line number Diff line number Diff line change
@@ -0,0 +1 @@
{"ast":null,"code":"import { reduce } from './reduce';\nimport { isFunction } from '../util/isFunction';\nexport function max(comparer) {\n return reduce(isFunction(comparer) ? (x, y) => comparer(x, y) > 0 ? x : y : (x, y) => x > y ? x : y);\n} //# sourceMappingURL=max.js.map","map":null,"metadata":{},"sourceType":"module"}
Original file line number Diff line number Diff line change
@@ -0,0 +1 @@
{"ast":null,"code":"import { config } from '../config';\nlet context = null;\nexport function errorContext(cb) {\n if (config.useDeprecatedSynchronousErrorHandling) {\n const isRoot = !context;\n\n if (isRoot) {\n context = {\n errorThrown: false,\n error: null\n };\n }\n\n cb();\n\n if (isRoot) {\n const {\n errorThrown,\n error\n } = context;\n context = null;\n\n if (errorThrown) {\n throw error;\n }\n }\n } else {\n cb();\n }\n}\nexport function captureError(err) {\n if (config.useDeprecatedSynchronousErrorHandling && context) {\n context.errorThrown = true;\n context.error = err;\n }\n} //# sourceMappingURL=errorContext.js.map","map":null,"metadata":{},"sourceType":"module"}

Large diffs are not rendered by default.

Original file line number Diff line number Diff line change
@@ -0,0 +1 @@
{"ast":null,"code":"import { switchMap } from './switchMap';\nimport { isFunction } from '../util/isFunction';\nexport function switchMapTo(innerObservable, resultSelector) {\n return isFunction(resultSelector) ? switchMap(() => innerObservable, resultSelector) : switchMap(() => innerObservable);\n} //# sourceMappingURL=switchMapTo.js.map","map":null,"metadata":{},"sourceType":"module"}
Original file line number Diff line number Diff line change
@@ -0,0 +1 @@
{"ast":null,"code":"import { Subscription } from '../Subscription';\nexport class Action extends Subscription {\n constructor(scheduler, work) {\n super();\n }\n\n schedule(state, delay = 0) {\n return this;\n }\n\n} //# sourceMappingURL=Action.js.map","map":null,"metadata":{},"sourceType":"module"}
Original file line number Diff line number Diff line change
@@ -0,0 +1 @@
{"ast":null,"code":"import { identity } from './identity';\nexport function pipe(...fns) {\n return pipeFromArray(fns);\n}\nexport function pipeFromArray(fns) {\n if (fns.length === 0) {\n return identity;\n }\n\n if (fns.length === 1) {\n return fns[0];\n }\n\n return function piped(input) {\n return fns.reduce((prev, fn) => fn(prev), input);\n };\n} //# sourceMappingURL=pipe.js.map","map":null,"metadata":{},"sourceType":"module"}
Original file line number Diff line number Diff line change
@@ -0,0 +1 @@
{"ast":null,"code":"import { EMPTY } from './observable/empty';\nimport { of } from './observable/of';\nimport { throwError } from './observable/throwError';\nimport { isFunction } from './util/isFunction';\nexport var NotificationKind = /*#__PURE__*/(() => {\n (function (NotificationKind) {\n NotificationKind[\"NEXT\"] = \"N\";\n NotificationKind[\"ERROR\"] = \"E\";\n NotificationKind[\"COMPLETE\"] = \"C\";\n })(NotificationKind || (NotificationKind = {}));\n\n return NotificationKind;\n})();\nexport class Notification {\n constructor(kind, value, error) {\n this.kind = kind;\n this.value = value;\n this.error = error;\n this.hasValue = kind === 'N';\n }\n\n observe(observer) {\n return observeNotification(this, observer);\n }\n\n do(nextHandler, errorHandler, completeHandler) {\n const {\n kind,\n value,\n error\n } = this;\n return kind === 'N' ? nextHandler === null || nextHandler === void 0 ? void 0 : nextHandler(value) : kind === 'E' ? errorHandler === null || errorHandler === void 0 ? void 0 : errorHandler(error) : completeHandler === null || completeHandler === void 0 ? void 0 : completeHandler();\n }\n\n accept(nextOrObserver, error, complete) {\n var _a;\n\n return isFunction((_a = nextOrObserver) === null || _a === void 0 ? void 0 : _a.next) ? this.observe(nextOrObserver) : this.do(nextOrObserver, error, complete);\n }\n\n toObservable() {\n const {\n kind,\n value,\n error\n } = this;\n const result = kind === 'N' ? of(value) : kind === 'E' ? throwError(() => error) : kind === 'C' ? EMPTY : 0;\n\n if (!result) {\n throw new TypeError(`Unexpected notification kind ${kind}`);\n }\n\n return result;\n }\n\n static createNext(value) {\n return new Notification('N', value);\n }\n\n static createError(err) {\n return new Notification('E', undefined, err);\n }\n\n static createComplete() {\n return Notification.completeNotification;\n }\n\n}\nNotification.completeNotification = new Notification('C');\nexport function observeNotification(notification, observer) {\n var _a, _b, _c;\n\n const {\n kind,\n value,\n error\n } = notification;\n\n if (typeof kind !== 'string') {\n throw new TypeError('Invalid notification, missing \"kind\"');\n }\n\n kind === 'N' ? (_a = observer.next) === null || _a === void 0 ? void 0 : _a.call(observer, value) : kind === 'E' ? (_b = observer.error) === null || _b === void 0 ? void 0 : _b.call(observer, error) : (_c = observer.complete) === null || _c === void 0 ? void 0 : _c.call(observer);\n} //# sourceMappingURL=Notification.js.map","map":null,"metadata":{},"sourceType":"module"}
Original file line number Diff line number Diff line change
@@ -0,0 +1 @@
{"ast":null,"code":"export function isFunction(value) {\n return typeof value === 'function';\n} //# sourceMappingURL=isFunction.js.map","map":null,"metadata":{},"sourceType":"module"}
Original file line number Diff line number Diff line change
@@ -0,0 +1 @@
{"ast":null,"code":"import { AsyncAction } from './AsyncAction';\nimport { AsyncScheduler } from './AsyncScheduler';\nexport const asyncScheduler = new AsyncScheduler(AsyncAction);\nexport const async = asyncScheduler; //# sourceMappingURL=async.js.map","map":null,"metadata":{},"sourceType":"module"}
Original file line number Diff line number Diff line change
@@ -0,0 +1 @@
{"ast":null,"code":"import { bindCallbackInternals } from './bindCallbackInternals';\nexport function bindNodeCallback(callbackFunc, resultSelector, scheduler) {\n return bindCallbackInternals(true, callbackFunc, resultSelector, scheduler);\n} //# sourceMappingURL=bindNodeCallback.js.map","map":null,"metadata":{},"sourceType":"module"}
Original file line number Diff line number Diff line change
@@ -0,0 +1 @@
{"ast":null,"code":"import { from } from './from';\nexport function pairs(obj, scheduler) {\n return from(Object.entries(obj), scheduler);\n} //# sourceMappingURL=pairs.js.map","map":null,"metadata":{},"sourceType":"module"}
Original file line number Diff line number Diff line change
@@ -0,0 +1 @@
{"ast":null,"code":"import { createErrorClass } from './createErrorClass';\nexport const EmptyError = createErrorClass(_super => function EmptyErrorImpl() {\n _super(this);\n\n this.name = 'EmptyError';\n this.message = 'no elements in sequence';\n}); //# sourceMappingURL=EmptyError.js.map","map":null,"metadata":{},"sourceType":"module"}
Original file line number Diff line number Diff line change
@@ -0,0 +1 @@
{"ast":null,"code":"import { defer } from './defer';\nexport function iif(condition, trueResult, falseResult) {\n return defer(() => condition() ? trueResult : falseResult);\n} //# sourceMappingURL=iif.js.map","map":null,"metadata":{},"sourceType":"module"}
Original file line number Diff line number Diff line change
@@ -0,0 +1 @@
{"ast":null,"code":"import { mergeMap } from './mergeMap';\nimport { isFunction } from '../util/isFunction';\nexport function mergeMapTo(innerObservable, resultSelector, concurrent = Infinity) {\n if (isFunction(resultSelector)) {\n return mergeMap(() => innerObservable, resultSelector, concurrent);\n }\n\n if (typeof resultSelector === 'number') {\n concurrent = resultSelector;\n }\n\n return mergeMap(() => innerObservable, concurrent);\n} //# sourceMappingURL=mergeMapTo.js.map","map":null,"metadata":{},"sourceType":"module"}
Original file line number Diff line number Diff line change
@@ -0,0 +1 @@
{"ast":null,"code":"import { EMPTY } from './empty';\nimport { onErrorResumeNext as onErrorResumeNextWith } from '../operators/onErrorResumeNext';\nimport { argsOrArgArray } from '../util/argsOrArgArray';\nexport function onErrorResumeNext(...sources) {\n return onErrorResumeNextWith(argsOrArgArray(sources))(EMPTY);\n} //# sourceMappingURL=onErrorResumeNext.js.map","map":null,"metadata":{},"sourceType":"module"}

Large diffs are not rendered by default.

Original file line number Diff line number Diff line change
@@ -0,0 +1 @@
{"ast":null,"code":"import { asyncScheduler } from '../scheduler/async';\nimport { timer } from './timer';\nexport function interval(period = 0, scheduler = asyncScheduler) {\n if (period < 0) {\n period = 0;\n }\n\n return timer(period, period, scheduler);\n} //# sourceMappingURL=interval.js.map","map":null,"metadata":{},"sourceType":"module"}

Large diffs are not rendered by default.

Loading

0 comments on commit 9badaa3

Please sign in to comment.