├── LICENSE.md ├── README.md ├── composer.json ├── config-stubs └── app.php ├── config ├── app.php ├── auth.php ├── broadcasting.php ├── cache.php ├── concurrency.php ├── cors.php ├── database.php ├── filesystems.php ├── hashing.php ├── logging.php ├── mail.php ├── queue.php ├── services.php ├── session.php └── view.php ├── pint.json └── src └── Illuminate ├── Auth ├── Access │ ├── AuthorizationException.php │ ├── Events │ │ └── GateEvaluated.php │ ├── Gate.php │ ├── HandlesAuthorization.php │ └── Response.php ├── AuthManager.php ├── AuthServiceProvider.php ├── Authenticatable.php ├── AuthenticationException.php ├── Console │ ├── ClearResetsCommand.php │ └── stubs │ │ └── make │ │ └── views │ │ └── layouts │ │ └── app.stub ├── CreatesUserProviders.php ├── DatabaseUserProvider.php ├── EloquentUserProvider.php ├── Events │ ├── Attempting.php │ ├── Authenticated.php │ ├── CurrentDeviceLogout.php │ ├── Failed.php │ ├── Lockout.php │ ├── Login.php │ ├── Logout.php │ ├── OtherDeviceLogout.php │ ├── PasswordReset.php │ ├── PasswordResetLinkSent.php │ ├── Registered.php │ ├── Validated.php │ └── Verified.php ├── GenericUser.php ├── GuardHelpers.php ├── LICENSE.md ├── Listeners │ └── SendEmailVerificationNotification.php ├── Middleware │ ├── Authenticate.php │ ├── AuthenticateWithBasicAuth.php │ ├── Authorize.php │ ├── EnsureEmailIsVerified.php │ ├── RedirectIfAuthenticated.php │ └── RequirePassword.php ├── MustVerifyEmail.php ├── Notifications │ ├── ResetPassword.php │ └── VerifyEmail.php ├── Passwords │ ├── CacheTokenRepository.php │ ├── CanResetPassword.php │ ├── DatabaseTokenRepository.php │ ├── PasswordBroker.php │ ├── PasswordBrokerManager.php │ ├── PasswordResetServiceProvider.php │ └── TokenRepositoryInterface.php ├── Recaller.php ├── RequestGuard.php ├── SessionGuard.php ├── TokenGuard.php └── composer.json ├── Broadcasting ├── AnonymousEvent.php ├── BroadcastController.php ├── BroadcastEvent.php ├── BroadcastException.php ├── BroadcastManager.php ├── BroadcastServiceProvider.php ├── Broadcasters │ ├── AblyBroadcaster.php │ ├── Broadcaster.php │ ├── LogBroadcaster.php │ ├── NullBroadcaster.php │ ├── PusherBroadcaster.php │ ├── RedisBroadcaster.php │ └── UsePusherChannelConventions.php ├── Channel.php ├── EncryptedPrivateChannel.php ├── InteractsWithBroadcasting.php ├── InteractsWithSockets.php ├── LICENSE.md ├── PendingBroadcast.php ├── PresenceChannel.php ├── PrivateChannel.php ├── UniqueBroadcastEvent.php └── composer.json ├── Bus ├── Batch.php ├── BatchFactory.php ├── BatchRepository.php ├── Batchable.php ├── BusServiceProvider.php ├── ChainedBatch.php ├── DatabaseBatchRepository.php ├── Dispatcher.php ├── DynamoBatchRepository.php ├── Events │ └── BatchDispatched.php ├── LICENSE.md ├── PendingBatch.php ├── PrunableBatchRepository.php ├── Queueable.php ├── UniqueLock.php ├── UpdatedBatchJobCounts.php └── composer.json ├── Cache ├── ApcStore.php ├── ApcWrapper.php ├── ArrayLock.php ├── ArrayStore.php ├── CacheLock.php ├── CacheManager.php ├── CacheServiceProvider.php ├── Console │ ├── CacheTableCommand.php │ ├── ClearCommand.php │ ├── ForgetCommand.php │ ├── PruneStaleTagsCommand.php │ └── stubs │ │ └── cache.stub ├── DatabaseLock.php ├── DatabaseStore.php ├── DynamoDbLock.php ├── DynamoDbStore.php ├── Events │ ├── CacheEvent.php │ ├── CacheFlushFailed.php │ ├── CacheFlushed.php │ ├── CacheFlushing.php │ ├── CacheHit.php │ ├── CacheMissed.php │ ├── ForgettingKey.php │ ├── KeyForgetFailed.php │ ├── KeyForgotten.php │ ├── KeyWriteFailed.php │ ├── KeyWritten.php │ ├── RetrievingKey.php │ ├── RetrievingManyKeys.php │ ├── WritingKey.php │ └── WritingManyKeys.php ├── FileLock.php ├── FileStore.php ├── HasCacheLock.php ├── LICENSE.md ├── Lock.php ├── LuaScripts.php ├── MemcachedConnector.php ├── MemcachedLock.php ├── MemcachedStore.php ├── MemoizedStore.php ├── NoLock.php ├── NullStore.php ├── PhpRedisLock.php ├── RateLimiter.php ├── RateLimiting │ ├── GlobalLimit.php │ ├── Limit.php │ └── Unlimited.php ├── RedisLock.php ├── RedisStore.php ├── RedisTagSet.php ├── RedisTaggedCache.php ├── Repository.php ├── RetrievesMultipleKeys.php ├── TagSet.php ├── TaggableStore.php ├── TaggedCache.php └── composer.json ├── Collections ├── Arr.php ├── Collection.php ├── Enumerable.php ├── HigherOrderCollectionProxy.php ├── ItemNotFoundException.php ├── LICENSE.md ├── LazyCollection.php ├── MultipleItemsFoundException.php ├── Traits │ ├── EnumeratesValues.php │ └── TransformsToResourceCollection.php ├── composer.json ├── functions.php └── helpers.php ├── Concurrency ├── ConcurrencyManager.php ├── ConcurrencyServiceProvider.php ├── Console │ └── InvokeSerializedClosureCommand.php ├── ForkDriver.php ├── LICENSE.md ├── ProcessDriver.php ├── SyncDriver.php └── composer.json ├── Conditionable ├── HigherOrderWhenProxy.php ├── LICENSE.md ├── Traits │ └── Conditionable.php └── composer.json ├── Config ├── LICENSE.md ├── Repository.php └── composer.json ├── Console ├── Application.php ├── BufferedConsoleOutput.php ├── CacheCommandMutex.php ├── Command.php ├── CommandMutex.php ├── Concerns │ ├── CallsCommands.php │ ├── ConfiguresPrompts.php │ ├── CreatesMatchingTest.php │ ├── HasParameters.php │ ├── InteractsWithIO.php │ ├── InteractsWithSignals.php │ └── PromptsForMissingInput.php ├── ConfirmableTrait.php ├── ContainerCommandLoader.php ├── Contracts │ └── NewLineAware.php ├── Events │ ├── ArtisanStarting.php │ ├── CommandFinished.php │ ├── CommandStarting.php │ ├── ScheduledBackgroundTaskFinished.php │ ├── ScheduledTaskFailed.php │ ├── ScheduledTaskFinished.php │ ├── ScheduledTaskSkipped.php │ └── ScheduledTaskStarting.php ├── GeneratorCommand.php ├── LICENSE.md ├── ManuallyFailedException.php ├── MigrationGeneratorCommand.php ├── OutputStyle.php ├── Parser.php ├── Prohibitable.php ├── PromptValidationException.php ├── QuestionHelper.php ├── Scheduling │ ├── CacheAware.php │ ├── CacheEventMutex.php │ ├── CacheSchedulingMutex.php │ ├── CallbackEvent.php │ ├── CommandBuilder.php │ ├── Event.php │ ├── EventMutex.php │ ├── ManagesAttributes.php │ ├── ManagesFrequencies.php │ ├── PendingEventAttributes.php │ ├── Schedule.php │ ├── ScheduleClearCacheCommand.php │ ├── ScheduleFinishCommand.php │ ├── ScheduleInterruptCommand.php │ ├── ScheduleListCommand.php │ ├── ScheduleRunCommand.php │ ├── ScheduleTestCommand.php │ ├── ScheduleWorkCommand.php │ └── SchedulingMutex.php ├── Signals.php ├── View │ ├── Components │ │ ├── Alert.php │ │ ├── Ask.php │ │ ├── AskWithCompletion.php │ │ ├── BulletList.php │ │ ├── Choice.php │ │ ├── Component.php │ │ ├── Confirm.php │ │ ├── Error.php │ │ ├── Factory.php │ │ ├── Info.php │ │ ├── Line.php │ │ ├── Mutators │ │ │ ├── EnsureDynamicContentIsHighlighted.php │ │ │ ├── EnsureNoPunctuation.php │ │ │ ├── EnsurePunctuation.php │ │ │ └── EnsureRelativePaths.php │ │ ├── Secret.php │ │ ├── Success.php │ │ ├── Task.php │ │ ├── TwoColumnDetail.php │ │ └── Warn.php │ └── TaskResult.php ├── composer.json └── resources │ └── views │ └── components │ ├── alert.php │ ├── bullet-list.php │ ├── line.php │ └── two-column-detail.php ├── Container ├── Attributes │ ├── Auth.php │ ├── Authenticated.php │ ├── Cache.php │ ├── Config.php │ ├── Context.php │ ├── CurrentUser.php │ ├── DB.php │ ├── Database.php │ ├── Give.php │ ├── Log.php │ ├── RouteParameter.php │ ├── Storage.php │ └── Tag.php ├── BoundMethod.php ├── Container.php ├── ContextualBindingBuilder.php ├── EntryNotFoundException.php ├── LICENSE.md ├── RewindableGenerator.php ├── Util.php └── composer.json ├── Contracts ├── Auth │ ├── Access │ │ ├── Authorizable.php │ │ └── Gate.php │ ├── Authenticatable.php │ ├── CanResetPassword.php │ ├── Factory.php │ ├── Guard.php │ ├── Middleware │ │ └── AuthenticatesRequests.php │ ├── MustVerifyEmail.php │ ├── PasswordBroker.php │ ├── PasswordBrokerFactory.php │ ├── StatefulGuard.php │ ├── SupportsBasicAuth.php │ └── UserProvider.php ├── Broadcasting │ ├── Broadcaster.php │ ├── Factory.php │ ├── HasBroadcastChannel.php │ ├── ShouldBeUnique.php │ ├── ShouldBroadcast.php │ └── ShouldBroadcastNow.php ├── Bus │ ├── Dispatcher.php │ └── QueueingDispatcher.php ├── Cache │ ├── Factory.php │ ├── Lock.php │ ├── LockProvider.php │ ├── LockTimeoutException.php │ ├── Repository.php │ └── Store.php ├── Concurrency │ └── Driver.php ├── Config │ └── Repository.php ├── Console │ ├── Application.php │ ├── Isolatable.php │ ├── Kernel.php │ └── PromptsForMissingInput.php ├── Container │ ├── BindingResolutionException.php │ ├── CircularDependencyException.php │ ├── Container.php │ ├── ContextualAttribute.php │ └── ContextualBindingBuilder.php ├── Cookie │ ├── Factory.php │ └── QueueingFactory.php ├── Database │ ├── Eloquent │ │ ├── Builder.php │ │ ├── Castable.php │ │ ├── CastsAttributes.php │ │ ├── CastsInboundAttributes.php │ │ ├── ComparesCastableAttributes.php │ │ ├── DeviatesCastableAttributes.php │ │ ├── SerializesCastableAttributes.php │ │ └── SupportsPartialRelations.php │ ├── Events │ │ └── MigrationEvent.php │ ├── ModelIdentifier.php │ └── Query │ │ ├── Builder.php │ │ ├── ConditionExpression.php │ │ └── Expression.php ├── Debug │ ├── ExceptionHandler.php │ └── ShouldntReport.php ├── Encryption │ ├── DecryptException.php │ ├── EncryptException.php │ ├── Encrypter.php │ └── StringEncrypter.php ├── Events │ ├── Dispatcher.php │ ├── ShouldDispatchAfterCommit.php │ └── ShouldHandleEventsAfterCommit.php ├── Filesystem │ ├── Cloud.php │ ├── Factory.php │ ├── FileNotFoundException.php │ ├── Filesystem.php │ └── LockTimeoutException.php ├── Foundation │ ├── Application.php │ ├── CachesConfiguration.php │ ├── CachesRoutes.php │ ├── ExceptionRenderer.php │ └── MaintenanceMode.php ├── Hashing │ └── Hasher.php ├── Http │ └── Kernel.php ├── LICENSE.md ├── Log │ └── ContextLogProcessor.php ├── Mail │ ├── Attachable.php │ ├── Factory.php │ ├── MailQueue.php │ ├── Mailable.php │ └── Mailer.php ├── Notifications │ ├── Dispatcher.php │ └── Factory.php ├── Pagination │ ├── CursorPaginator.php │ ├── LengthAwarePaginator.php │ └── Paginator.php ├── Pipeline │ ├── Hub.php │ └── Pipeline.php ├── Process │ ├── InvokedProcess.php │ └── ProcessResult.php ├── Queue │ ├── ClearableQueue.php │ ├── EntityNotFoundException.php │ ├── EntityResolver.php │ ├── Factory.php │ ├── Job.php │ ├── Monitor.php │ ├── Queue.php │ ├── QueueableCollection.php │ ├── QueueableEntity.php │ ├── ShouldBeEncrypted.php │ ├── ShouldBeUnique.php │ ├── ShouldBeUniqueUntilProcessing.php │ ├── ShouldQueue.php │ └── ShouldQueueAfterCommit.php ├── Redis │ ├── Connection.php │ ├── Connector.php │ ├── Factory.php │ └── LimiterTimeoutException.php ├── Routing │ ├── BindingRegistrar.php │ ├── Registrar.php │ ├── ResponseFactory.php │ ├── UrlGenerator.php │ └── UrlRoutable.php ├── Session │ ├── Middleware │ │ └── AuthenticatesSessions.php │ └── Session.php ├── Support │ ├── Arrayable.php │ ├── CanBeEscapedWhenCastToString.php │ ├── DeferrableProvider.php │ ├── DeferringDisplayableValue.php │ ├── Htmlable.php │ ├── Jsonable.php │ ├── MessageBag.php │ ├── MessageProvider.php │ ├── Renderable.php │ ├── Responsable.php │ └── ValidatedData.php ├── Translation │ ├── HasLocalePreference.php │ ├── Loader.php │ └── Translator.php ├── Validation │ ├── CompilableRules.php │ ├── DataAwareRule.php │ ├── Factory.php │ ├── ImplicitRule.php │ ├── InvokableRule.php │ ├── Rule.php │ ├── UncompromisedVerifier.php │ ├── ValidatesWhenResolved.php │ ├── ValidationRule.php │ ├── Validator.php │ └── ValidatorAwareRule.php ├── View │ ├── Engine.php │ ├── Factory.php │ ├── View.php │ └── ViewCompilationException.php └── composer.json ├── Cookie ├── CookieJar.php ├── CookieServiceProvider.php ├── CookieValuePrefix.php ├── LICENSE.md ├── Middleware │ ├── AddQueuedCookiesToResponse.php │ └── EncryptCookies.php └── composer.json ├── Database ├── Capsule │ └── Manager.php ├── ClassMorphViolationException.php ├── Concerns │ ├── BuildsQueries.php │ ├── BuildsWhereDateClauses.php │ ├── CompilesJsonPaths.php │ ├── ExplainsQueries.php │ ├── ManagesTransactions.php │ └── ParsesSearchPath.php ├── ConfigurationUrlParser.php ├── Connection.php ├── ConnectionInterface.php ├── ConnectionResolver.php ├── ConnectionResolverInterface.php ├── Connectors │ ├── ConnectionFactory.php │ ├── Connector.php │ ├── ConnectorInterface.php │ ├── MariaDbConnector.php │ ├── MySqlConnector.php │ ├── PostgresConnector.php │ ├── SQLiteConnector.php │ └── SqlServerConnector.php ├── Console │ ├── DatabaseInspectionCommand.php │ ├── DbCommand.php │ ├── DumpCommand.php │ ├── Factories │ │ ├── FactoryMakeCommand.php │ │ └── stubs │ │ │ └── factory.stub │ ├── Migrations │ │ ├── BaseCommand.php │ │ ├── FreshCommand.php │ │ ├── InstallCommand.php │ │ ├── MigrateCommand.php │ │ ├── MigrateMakeCommand.php │ │ ├── RefreshCommand.php │ │ ├── ResetCommand.php │ │ ├── RollbackCommand.php │ │ ├── StatusCommand.php │ │ └── TableGuesser.php │ ├── MonitorCommand.php │ ├── PruneCommand.php │ ├── Seeds │ │ ├── SeedCommand.php │ │ ├── SeederMakeCommand.php │ │ ├── WithoutModelEvents.php │ │ └── stubs │ │ │ └── seeder.stub │ ├── ShowCommand.php │ ├── ShowModelCommand.php │ ├── TableCommand.php │ └── WipeCommand.php ├── DatabaseManager.php ├── DatabaseServiceProvider.php ├── DatabaseTransactionRecord.php ├── DatabaseTransactionsManager.php ├── DeadlockException.php ├── DetectsConcurrencyErrors.php ├── DetectsLostConnections.php ├── Eloquent │ ├── Attributes │ │ ├── CollectedBy.php │ │ ├── ObservedBy.php │ │ ├── Scope.php │ │ ├── ScopedBy.php │ │ ├── UseFactory.php │ │ └── UsePolicy.php │ ├── BroadcastableModelEventOccurred.php │ ├── BroadcastsEvents.php │ ├── BroadcastsEventsAfterCommit.php │ ├── Builder.php │ ├── Casts │ │ ├── ArrayObject.php │ │ ├── AsArrayObject.php │ │ ├── AsCollection.php │ │ ├── AsEncryptedArrayObject.php │ │ ├── AsEncryptedCollection.php │ │ ├── AsEnumArrayObject.php │ │ ├── AsEnumCollection.php │ │ ├── AsHtmlString.php │ │ ├── AsStringable.php │ │ ├── AsUri.php │ │ ├── Attribute.php │ │ └── Json.php │ ├── Collection.php │ ├── Concerns │ │ ├── GuardsAttributes.php │ │ ├── HasAttributes.php │ │ ├── HasEvents.php │ │ ├── HasGlobalScopes.php │ │ ├── HasRelationships.php │ │ ├── HasTimestamps.php │ │ ├── HasUlids.php │ │ ├── HasUniqueIds.php │ │ ├── HasUniqueStringIds.php │ │ ├── HasUuids.php │ │ ├── HasVersion4Uuids.php │ │ ├── HidesAttributes.php │ │ ├── PreventsCircularRecursion.php │ │ ├── QueriesRelationships.php │ │ └── TransformsToResource.php │ ├── Factories │ │ ├── BelongsToManyRelationship.php │ │ ├── BelongsToRelationship.php │ │ ├── CrossJoinSequence.php │ │ ├── Factory.php │ │ ├── HasFactory.php │ │ ├── Relationship.php │ │ └── Sequence.php │ ├── HasBuilder.php │ ├── HasCollection.php │ ├── HigherOrderBuilderProxy.php │ ├── InvalidCastException.php │ ├── JsonEncodingException.php │ ├── MassAssignmentException.php │ ├── MassPrunable.php │ ├── MissingAttributeException.php │ ├── Model.php │ ├── ModelInspector.php │ ├── ModelNotFoundException.php │ ├── PendingHasThroughRelationship.php │ ├── Prunable.php │ ├── QueueEntityResolver.php │ ├── RelationNotFoundException.php │ ├── Relations │ │ ├── BelongsTo.php │ │ ├── BelongsToMany.php │ │ ├── Concerns │ │ │ ├── AsPivot.php │ │ │ ├── CanBeOneOfMany.php │ │ │ ├── ComparesRelatedModels.php │ │ │ ├── InteractsWithDictionary.php │ │ │ ├── InteractsWithPivotTable.php │ │ │ ├── SupportsDefaultModels.php │ │ │ └── SupportsInverseRelations.php │ │ ├── HasMany.php │ │ ├── HasManyThrough.php │ │ ├── HasOne.php │ │ ├── HasOneOrMany.php │ │ ├── HasOneOrManyThrough.php │ │ ├── HasOneThrough.php │ │ ├── MorphMany.php │ │ ├── MorphOne.php │ │ ├── MorphOneOrMany.php │ │ ├── MorphPivot.php │ │ ├── MorphTo.php │ │ ├── MorphToMany.php │ │ ├── Pivot.php │ │ └── Relation.php │ ├── Scope.php │ ├── SoftDeletes.php │ └── SoftDeletingScope.php ├── Events │ ├── ConnectionEstablished.php │ ├── ConnectionEvent.php │ ├── DatabaseBusy.php │ ├── DatabaseRefreshed.php │ ├── MigrationEnded.php │ ├── MigrationEvent.php │ ├── MigrationStarted.php │ ├── MigrationsEnded.php │ ├── MigrationsEvent.php │ ├── MigrationsPruned.php │ ├── MigrationsStarted.php │ ├── ModelPruningFinished.php │ ├── ModelPruningStarting.php │ ├── ModelsPruned.php │ ├── NoPendingMigrations.php │ ├── QueryExecuted.php │ ├── SchemaDumped.php │ ├── SchemaLoaded.php │ ├── StatementPrepared.php │ ├── TransactionBeginning.php │ ├── TransactionCommitted.php │ ├── TransactionCommitting.php │ └── TransactionRolledBack.php ├── Grammar.php ├── LICENSE.md ├── LazyLoadingViolationException.php ├── LostConnectionException.php ├── MariaDbConnection.php ├── MigrationServiceProvider.php ├── Migrations │ ├── DatabaseMigrationRepository.php │ ├── Migration.php │ ├── MigrationCreator.php │ ├── MigrationRepositoryInterface.php │ ├── MigrationResult.php │ ├── Migrator.php │ └── stubs │ │ ├── migration.create.stub │ │ ├── migration.stub │ │ └── migration.update.stub ├── MultipleColumnsSelectedException.php ├── MultipleRecordsFoundException.php ├── MySqlConnection.php ├── PostgresConnection.php ├── Query │ ├── Builder.php │ ├── Expression.php │ ├── Grammars │ │ ├── Grammar.php │ │ ├── MariaDbGrammar.php │ │ ├── MySqlGrammar.php │ │ ├── PostgresGrammar.php │ │ ├── SQLiteGrammar.php │ │ └── SqlServerGrammar.php │ ├── IndexHint.php │ ├── JoinClause.php │ ├── JoinLateralClause.php │ └── Processors │ │ ├── MariaDbProcessor.php │ │ ├── MySqlProcessor.php │ │ ├── PostgresProcessor.php │ │ ├── Processor.php │ │ ├── SQLiteProcessor.php │ │ └── SqlServerProcessor.php ├── QueryException.php ├── README.md ├── RecordNotFoundException.php ├── RecordsNotFoundException.php ├── SQLiteConnection.php ├── SQLiteDatabaseDoesNotExistException.php ├── Schema │ ├── Blueprint.php │ ├── BlueprintState.php │ ├── Builder.php │ ├── ColumnDefinition.php │ ├── ForeignIdColumnDefinition.php │ ├── ForeignKeyDefinition.php │ ├── Grammars │ │ ├── Grammar.php │ │ ├── MariaDbGrammar.php │ │ ├── MySqlGrammar.php │ │ ├── PostgresGrammar.php │ │ ├── SQLiteGrammar.php │ │ └── SqlServerGrammar.php │ ├── IndexDefinition.php │ ├── MariaDbBuilder.php │ ├── MariaDbSchemaState.php │ ├── MySqlBuilder.php │ ├── MySqlSchemaState.php │ ├── PostgresBuilder.php │ ├── PostgresSchemaState.php │ ├── SQLiteBuilder.php │ ├── SchemaState.php │ ├── SqlServerBuilder.php │ └── SqliteSchemaState.php ├── Seeder.php ├── SqlServerConnection.php ├── UniqueConstraintViolationException.php └── composer.json ├── Encryption ├── Encrypter.php ├── EncryptionServiceProvider.php ├── LICENSE.md ├── MissingAppKeyException.php └── composer.json ├── Events ├── CallQueuedListener.php ├── Dispatcher.php ├── EventServiceProvider.php ├── InvokeQueuedClosure.php ├── LICENSE.md ├── NullDispatcher.php ├── QueuedClosure.php ├── composer.json └── functions.php ├── Filesystem ├── AwsS3V3Adapter.php ├── Filesystem.php ├── FilesystemAdapter.php ├── FilesystemManager.php ├── FilesystemServiceProvider.php ├── LICENSE.md ├── LocalFilesystemAdapter.php ├── LockableFile.php ├── ServeFile.php ├── composer.json └── functions.php ├── Foundation ├── AliasLoader.php ├── Application.php ├── Auth │ ├── Access │ │ ├── Authorizable.php │ │ └── AuthorizesRequests.php │ ├── EmailVerificationRequest.php │ └── User.php ├── Bootstrap │ ├── BootProviders.php │ ├── HandleExceptions.php │ ├── LoadConfiguration.php │ ├── LoadEnvironmentVariables.php │ ├── RegisterFacades.php │ ├── RegisterProviders.php │ └── SetRequestForConsole.php ├── Bus │ ├── Dispatchable.php │ ├── DispatchesJobs.php │ ├── PendingChain.php │ ├── PendingClosureDispatch.php │ └── PendingDispatch.php ├── CacheBasedMaintenanceMode.php ├── Cloud.php ├── ComposerScripts.php ├── Concerns │ └── ResolvesDumpSource.php ├── Configuration │ ├── ApplicationBuilder.php │ ├── Exceptions.php │ └── Middleware.php ├── Console │ ├── AboutCommand.php │ ├── ApiInstallCommand.php │ ├── BroadcastingInstallCommand.php │ ├── CastMakeCommand.php │ ├── ChannelListCommand.php │ ├── ChannelMakeCommand.php │ ├── ClassMakeCommand.php │ ├── ClearCompiledCommand.php │ ├── CliDumper.php │ ├── ClosureCommand.php │ ├── ComponentMakeCommand.php │ ├── ConfigCacheCommand.php │ ├── ConfigClearCommand.php │ ├── ConfigPublishCommand.php │ ├── ConfigShowCommand.php │ ├── ConsoleMakeCommand.php │ ├── DocsCommand.php │ ├── DownCommand.php │ ├── EnumMakeCommand.php │ ├── EnvironmentCommand.php │ ├── EnvironmentDecryptCommand.php │ ├── EnvironmentEncryptCommand.php │ ├── EventCacheCommand.php │ ├── EventClearCommand.php │ ├── EventGenerateCommand.php │ ├── EventListCommand.php │ ├── EventMakeCommand.php │ ├── ExceptionMakeCommand.php │ ├── InteractsWithComposerPackages.php │ ├── InterfaceMakeCommand.php │ ├── JobMakeCommand.php │ ├── JobMiddlewareMakeCommand.php │ ├── Kernel.php │ ├── KeyGenerateCommand.php │ ├── LangPublishCommand.php │ ├── ListenerMakeCommand.php │ ├── MailMakeCommand.php │ ├── ModelMakeCommand.php │ ├── NotificationMakeCommand.php │ ├── ObserverMakeCommand.php │ ├── OptimizeClearCommand.php │ ├── OptimizeCommand.php │ ├── PackageDiscoverCommand.php │ ├── PolicyMakeCommand.php │ ├── ProviderMakeCommand.php │ ├── QueuedCommand.php │ ├── RequestMakeCommand.php │ ├── ResourceMakeCommand.php │ ├── RouteCacheCommand.php │ ├── RouteClearCommand.php │ ├── RouteListCommand.php │ ├── RuleMakeCommand.php │ ├── ScopeMakeCommand.php │ ├── ServeCommand.php │ ├── StorageLinkCommand.php │ ├── StorageUnlinkCommand.php │ ├── StubPublishCommand.php │ ├── TestMakeCommand.php │ ├── TraitMakeCommand.php │ ├── UpCommand.php │ ├── VendorPublishCommand.php │ ├── ViewCacheCommand.php │ ├── ViewClearCommand.php │ ├── ViewMakeCommand.php │ └── stubs │ │ ├── api-routes.stub │ │ ├── broadcasting-routes.stub │ │ ├── cast.inbound.stub │ │ ├── cast.stub │ │ ├── channel.stub │ │ ├── class.invokable.stub │ │ ├── class.stub │ │ ├── console.stub │ │ ├── echo-bootstrap-js.stub │ │ ├── echo-js-ably.stub │ │ ├── echo-js-pusher.stub │ │ ├── echo-js-reverb.stub │ │ ├── enum.backed.stub │ │ ├── enum.stub │ │ ├── event.stub │ │ ├── exception-render-report.stub │ │ ├── exception-render.stub │ │ ├── exception-report.stub │ │ ├── exception.stub │ │ ├── interface.stub │ │ ├── job.batched.queued.stub │ │ ├── job.middleware.stub │ │ ├── job.queued.stub │ │ ├── job.stub │ │ ├── listener.queued.stub │ │ ├── listener.stub │ │ ├── listener.typed.queued.stub │ │ ├── listener.typed.stub │ │ ├── mail.stub │ │ ├── maintenance-mode.stub │ │ ├── markdown-mail.stub │ │ ├── markdown-notification.stub │ │ ├── markdown.stub │ │ ├── model.morph-pivot.stub │ │ ├── model.pivot.stub │ │ ├── model.stub │ │ ├── notification.stub │ │ ├── observer.plain.stub │ │ ├── observer.stub │ │ ├── pest.stub │ │ ├── pest.unit.stub │ │ ├── policy.plain.stub │ │ ├── policy.stub │ │ ├── provider.stub │ │ ├── request.stub │ │ ├── resource-collection.stub │ │ ├── resource.stub │ │ ├── routes.stub │ │ ├── rule.implicit.stub │ │ ├── rule.stub │ │ ├── scope.stub │ │ ├── test.stub │ │ ├── test.unit.stub │ │ ├── trait.stub │ │ ├── view-component.stub │ │ ├── view-mail.stub │ │ ├── view.pest.stub │ │ ├── view.stub │ │ └── view.test.stub ├── EnvironmentDetector.php ├── Events │ ├── DiagnosingHealth.php │ ├── DiscoverEvents.php │ ├── Dispatchable.php │ ├── LocaleUpdated.php │ ├── MaintenanceModeDisabled.php │ ├── MaintenanceModeEnabled.php │ ├── PublishingStubs.php │ ├── Terminating.php │ └── VendorTagPublished.php ├── Exceptions │ ├── Handler.php │ ├── RegisterErrorViewPaths.php │ ├── Renderer │ │ ├── Exception.php │ │ ├── Frame.php │ │ ├── Listener.php │ │ ├── Mappers │ │ │ └── BladeMapper.php │ │ └── Renderer.php │ ├── ReportableHandler.php │ ├── Whoops │ │ ├── WhoopsExceptionRenderer.php │ │ └── WhoopsHandler.php │ └── views │ │ ├── 401.blade.php │ │ ├── 402.blade.php │ │ ├── 403.blade.php │ │ ├── 404.blade.php │ │ ├── 419.blade.php │ │ ├── 429.blade.php │ │ ├── 500.blade.php │ │ ├── 503.blade.php │ │ ├── layout.blade.php │ │ └── minimal.blade.php ├── FileBasedMaintenanceMode.php ├── Http │ ├── Events │ │ └── RequestHandled.php │ ├── FormRequest.php │ ├── HtmlDumper.php │ ├── Kernel.php │ ├── MaintenanceModeBypassCookie.php │ └── Middleware │ │ ├── CheckForMaintenanceMode.php │ │ ├── Concerns │ │ └── ExcludesPaths.php │ │ ├── ConvertEmptyStringsToNull.php │ │ ├── HandlePrecognitiveRequests.php │ │ ├── InvokeDeferredCallbacks.php │ │ ├── PreventRequestsDuringMaintenance.php │ │ ├── TransformsRequest.php │ │ ├── TrimStrings.php │ │ ├── ValidateCsrfToken.php │ │ ├── ValidatePostSize.php │ │ └── VerifyCsrfToken.php ├── Inspiring.php ├── MaintenanceModeManager.php ├── Mix.php ├── MixFileNotFoundException.php ├── MixManifestNotFoundException.php ├── PackageManifest.php ├── Precognition.php ├── ProviderRepository.php ├── Providers │ ├── ArtisanServiceProvider.php │ ├── ComposerServiceProvider.php │ ├── ConsoleSupportServiceProvider.php │ ├── FormRequestServiceProvider.php │ └── FoundationServiceProvider.php ├── Queue │ ├── InteractsWithUniqueJobs.php │ └── Queueable.php ├── Routing │ ├── PrecognitionCallableDispatcher.php │ └── PrecognitionControllerDispatcher.php ├── Support │ └── Providers │ │ ├── AuthServiceProvider.php │ │ ├── EventServiceProvider.php │ │ └── RouteServiceProvider.php ├── Testing │ ├── Concerns │ │ ├── InteractsWithAuthentication.php │ │ ├── InteractsWithConsole.php │ │ ├── InteractsWithContainer.php │ │ ├── InteractsWithDatabase.php │ │ ├── InteractsWithDeprecationHandling.php │ │ ├── InteractsWithExceptionHandling.php │ │ ├── InteractsWithRedis.php │ │ ├── InteractsWithSession.php │ │ ├── InteractsWithTestCaseLifecycle.php │ │ ├── InteractsWithTime.php │ │ ├── InteractsWithViews.php │ │ ├── MakesHttpRequests.php │ │ └── WithoutExceptionHandlingHandler.php │ ├── DatabaseMigrations.php │ ├── DatabaseTransactions.php │ ├── DatabaseTransactionsManager.php │ ├── DatabaseTruncation.php │ ├── LazilyRefreshDatabase.php │ ├── RefreshDatabase.php │ ├── RefreshDatabaseState.php │ ├── TestCase.php │ ├── Traits │ │ └── CanConfigureMigrationCommands.php │ ├── WithConsoleEvents.php │ ├── WithFaker.php │ ├── WithoutMiddleware.php │ └── Wormhole.php ├── Validation │ └── ValidatesRequests.php ├── Vite.php ├── ViteException.php ├── ViteManifestNotFoundException.php ├── helpers.php ├── resources │ ├── exceptions │ │ └── renderer │ │ │ ├── components │ │ │ ├── card.blade.php │ │ │ ├── context.blade.php │ │ │ ├── editor.blade.php │ │ │ ├── header.blade.php │ │ │ ├── icons │ │ │ │ ├── chevron-down.blade.php │ │ │ │ ├── chevron-up.blade.php │ │ │ │ ├── computer-desktop.blade.php │ │ │ │ ├── moon.blade.php │ │ │ │ └── sun.blade.php │ │ │ ├── layout.blade.php │ │ │ ├── navigation.blade.php │ │ │ ├── theme-switcher.blade.php │ │ │ ├── trace-and-editor.blade.php │ │ │ └── trace.blade.php │ │ │ ├── dark-mode.css │ │ │ ├── dist │ │ │ ├── dark-mode.css │ │ │ ├── light-mode.css │ │ │ ├── scripts.js │ │ │ └── styles.css │ │ │ ├── light-mode.css │ │ │ ├── package-lock.json │ │ │ ├── package.json │ │ │ ├── postcss.config.js │ │ │ ├── scripts.js │ │ │ ├── show.blade.php │ │ │ ├── styles.css │ │ │ ├── tailwind.config.js │ │ │ └── vite.config.js │ ├── health-up.blade.php │ └── server.php └── stubs │ └── facade.stub ├── Hashing ├── AbstractHasher.php ├── Argon2IdHasher.php ├── ArgonHasher.php ├── BcryptHasher.php ├── HashManager.php ├── HashServiceProvider.php ├── LICENSE.md └── composer.json ├── Http ├── Client │ ├── Concerns │ │ └── DeterminesStatusCode.php │ ├── ConnectionException.php │ ├── Events │ │ ├── ConnectionFailed.php │ │ ├── RequestSending.php │ │ └── ResponseReceived.php │ ├── Factory.php │ ├── HttpClientException.php │ ├── PendingRequest.php │ ├── Pool.php │ ├── Request.php │ ├── RequestException.php │ ├── Response.php │ ├── ResponseSequence.php │ └── StrayRequestException.php ├── Concerns │ ├── CanBePrecognitive.php │ ├── InteractsWithContentTypes.php │ ├── InteractsWithFlashData.php │ └── InteractsWithInput.php ├── Exceptions │ ├── HttpResponseException.php │ ├── MalformedUrlException.php │ ├── PostTooLargeException.php │ └── ThrottleRequestsException.php ├── File.php ├── FileHelpers.php ├── JsonResponse.php ├── LICENSE.md ├── Middleware │ ├── AddLinkHeadersForPreloadedAssets.php │ ├── CheckResponseForModifications.php │ ├── FrameGuard.php │ ├── HandleCors.php │ ├── SetCacheHeaders.php │ ├── TrustHosts.php │ ├── TrustProxies.php │ ├── ValidatePathEncoding.php │ └── ValidatePostSize.php ├── RedirectResponse.php ├── Request.php ├── Resources │ ├── CollectsResources.php │ ├── ConditionallyLoadsAttributes.php │ ├── DelegatesToResource.php │ ├── Json │ │ ├── AnonymousResourceCollection.php │ │ ├── JsonResource.php │ │ ├── PaginatedResourceResponse.php │ │ ├── ResourceCollection.php │ │ └── ResourceResponse.php │ ├── MergeValue.php │ ├── MissingValue.php │ └── PotentiallyMissing.php ├── Response.php ├── ResponseTrait.php ├── StreamedEvent.php ├── Testing │ ├── File.php │ ├── FileFactory.php │ └── MimeType.php ├── UploadedFile.php └── composer.json ├── Log ├── Context │ ├── ContextLogProcessor.php │ ├── ContextServiceProvider.php │ ├── Events │ │ ├── ContextDehydrating.php │ │ └── ContextHydrated.php │ └── Repository.php ├── Events │ └── MessageLogged.php ├── LICENSE.md ├── LogManager.php ├── LogServiceProvider.php ├── Logger.php ├── ParsesLogConfiguration.php ├── composer.json └── functions.php ├── Macroable ├── LICENSE.md ├── Traits │ └── Macroable.php └── composer.json ├── Mail ├── Attachment.php ├── Events │ ├── MessageSending.php │ └── MessageSent.php ├── LICENSE.md ├── MailManager.php ├── MailServiceProvider.php ├── Mailable.php ├── Mailables │ ├── Address.php │ ├── Attachment.php │ ├── Content.php │ ├── Envelope.php │ └── Headers.php ├── Mailer.php ├── Markdown.php ├── Message.php ├── PendingMail.php ├── SendQueuedMailable.php ├── SentMessage.php ├── TextMessage.php ├── Transport │ ├── ArrayTransport.php │ ├── LogTransport.php │ ├── ResendTransport.php │ ├── SesTransport.php │ └── SesV2Transport.php ├── composer.json └── resources │ └── views │ ├── html │ ├── button.blade.php │ ├── footer.blade.php │ ├── header.blade.php │ ├── layout.blade.php │ ├── message.blade.php │ ├── panel.blade.php │ ├── subcopy.blade.php │ ├── table.blade.php │ └── themes │ │ └── default.css │ └── text │ ├── button.blade.php │ ├── footer.blade.php │ ├── header.blade.php │ ├── layout.blade.php │ ├── message.blade.php │ ├── panel.blade.php │ ├── subcopy.blade.php │ └── table.blade.php ├── Notifications ├── Action.php ├── AnonymousNotifiable.php ├── ChannelManager.php ├── Channels │ ├── BroadcastChannel.php │ ├── DatabaseChannel.php │ └── MailChannel.php ├── Console │ ├── NotificationTableCommand.php │ └── stubs │ │ └── notifications.stub ├── DatabaseNotification.php ├── DatabaseNotificationCollection.php ├── Events │ ├── BroadcastNotificationCreated.php │ ├── NotificationFailed.php │ ├── NotificationSending.php │ └── NotificationSent.php ├── HasDatabaseNotifications.php ├── LICENSE.md ├── Messages │ ├── BroadcastMessage.php │ ├── DatabaseMessage.php │ ├── MailMessage.php │ └── SimpleMessage.php ├── Notifiable.php ├── Notification.php ├── NotificationSender.php ├── NotificationServiceProvider.php ├── RoutesNotifications.php ├── SendQueuedNotifications.php ├── composer.json └── resources │ └── views │ └── email.blade.php ├── Pagination ├── AbstractCursorPaginator.php ├── AbstractPaginator.php ├── Cursor.php ├── CursorPaginator.php ├── LICENSE.md ├── LengthAwarePaginator.php ├── PaginationServiceProvider.php ├── PaginationState.php ├── Paginator.php ├── UrlWindow.php ├── composer.json └── resources │ └── views │ ├── bootstrap-4.blade.php │ ├── bootstrap-5.blade.php │ ├── default.blade.php │ ├── semantic-ui.blade.php │ ├── simple-bootstrap-4.blade.php │ ├── simple-bootstrap-5.blade.php │ ├── simple-default.blade.php │ ├── simple-tailwind.blade.php │ └── tailwind.blade.php ├── Pipeline ├── Hub.php ├── LICENSE.md ├── Pipeline.php ├── PipelineServiceProvider.php └── composer.json ├── Process ├── Exceptions │ ├── ProcessFailedException.php │ └── ProcessTimedOutException.php ├── Factory.php ├── FakeInvokedProcess.php ├── FakeProcessDescription.php ├── FakeProcessResult.php ├── FakeProcessSequence.php ├── InvokedProcess.php ├── InvokedProcessPool.php ├── LICENSE.md ├── PendingProcess.php ├── Pipe.php ├── Pool.php ├── ProcessPoolResults.php ├── ProcessResult.php └── composer.json ├── Queue ├── Attributes │ ├── DeleteWhenMissingModels.php │ └── WithoutRelations.php ├── BeanstalkdQueue.php ├── CallQueuedClosure.php ├── CallQueuedHandler.php ├── Capsule │ └── Manager.php ├── Connectors │ ├── BeanstalkdConnector.php │ ├── ConnectorInterface.php │ ├── DatabaseConnector.php │ ├── NullConnector.php │ ├── RedisConnector.php │ ├── SqsConnector.php │ └── SyncConnector.php ├── Console │ ├── BatchesTableCommand.php │ ├── ClearCommand.php │ ├── FailedTableCommand.php │ ├── FlushFailedCommand.php │ ├── ForgetFailedCommand.php │ ├── ListFailedCommand.php │ ├── ListenCommand.php │ ├── MonitorCommand.php │ ├── PruneBatchesCommand.php │ ├── PruneFailedJobsCommand.php │ ├── RestartCommand.php │ ├── RetryBatchCommand.php │ ├── RetryCommand.php │ ├── TableCommand.php │ ├── WorkCommand.php │ └── stubs │ │ ├── batches.stub │ │ ├── failed_jobs.stub │ │ └── jobs.stub ├── DatabaseQueue.php ├── Events │ ├── JobAttempted.php │ ├── JobExceptionOccurred.php │ ├── JobFailed.php │ ├── JobPopped.php │ ├── JobPopping.php │ ├── JobProcessed.php │ ├── JobProcessing.php │ ├── JobQueued.php │ ├── JobQueueing.php │ ├── JobReleasedAfterException.php │ ├── JobRetryRequested.php │ ├── JobTimedOut.php │ ├── Looping.php │ ├── QueueBusy.php │ ├── WorkerStarting.php │ └── WorkerStopping.php ├── Failed │ ├── CountableFailedJobProvider.php │ ├── DatabaseFailedJobProvider.php │ ├── DatabaseUuidFailedJobProvider.php │ ├── DynamoDbFailedJobProvider.php │ ├── FailedJobProviderInterface.php │ ├── FileFailedJobProvider.php │ ├── NullFailedJobProvider.php │ └── PrunableFailedJobProvider.php ├── InteractsWithQueue.php ├── InvalidPayloadException.php ├── Jobs │ ├── BeanstalkdJob.php │ ├── DatabaseJob.php │ ├── DatabaseJobRecord.php │ ├── FakeJob.php │ ├── Job.php │ ├── JobName.php │ ├── RedisJob.php │ ├── SqsJob.php │ └── SyncJob.php ├── LICENSE.md ├── Listener.php ├── ListenerOptions.php ├── LuaScripts.php ├── ManuallyFailedException.php ├── MaxAttemptsExceededException.php ├── Middleware │ ├── RateLimited.php │ ├── RateLimitedWithRedis.php │ ├── Skip.php │ ├── SkipIfBatchCancelled.php │ ├── ThrottlesExceptions.php │ ├── ThrottlesExceptionsWithRedis.php │ └── WithoutOverlapping.php ├── NullQueue.php ├── Queue.php ├── QueueManager.php ├── QueueServiceProvider.php ├── README.md ├── RedisQueue.php ├── SerializesAndRestoresModelIdentifiers.php ├── SerializesModels.php ├── SqsQueue.php ├── SyncQueue.php ├── TimeoutExceededException.php ├── Worker.php ├── WorkerOptions.php └── composer.json ├── Redis ├── Connections │ ├── Connection.php │ ├── PacksPhpRedisValues.php │ ├── PhpRedisClusterConnection.php │ ├── PhpRedisConnection.php │ ├── PredisClusterConnection.php │ └── PredisConnection.php ├── Connectors │ ├── PhpRedisConnector.php │ └── PredisConnector.php ├── Events │ └── CommandExecuted.php ├── LICENSE.md ├── Limiters │ ├── ConcurrencyLimiter.php │ ├── ConcurrencyLimiterBuilder.php │ ├── DurationLimiter.php │ └── DurationLimiterBuilder.php ├── RedisManager.php ├── RedisServiceProvider.php └── composer.json ├── Routing ├── AbstractRouteCollection.php ├── CallableDispatcher.php ├── CompiledRouteCollection.php ├── Console │ ├── ControllerMakeCommand.php │ ├── MiddlewareMakeCommand.php │ └── stubs │ │ ├── controller.api.stub │ │ ├── controller.invokable.stub │ │ ├── controller.model.api.stub │ │ ├── controller.model.stub │ │ ├── controller.nested.api.stub │ │ ├── controller.nested.singleton.api.stub │ │ ├── controller.nested.singleton.stub │ │ ├── controller.nested.stub │ │ ├── controller.plain.stub │ │ ├── controller.singleton.api.stub │ │ ├── controller.singleton.stub │ │ ├── controller.stub │ │ └── middleware.stub ├── Contracts │ ├── CallableDispatcher.php │ └── ControllerDispatcher.php ├── Controller.php ├── ControllerDispatcher.php ├── ControllerMiddlewareOptions.php ├── Controllers │ ├── HasMiddleware.php │ └── Middleware.php ├── CreatesRegularExpressionRouteConstraints.php ├── Events │ ├── PreparingResponse.php │ ├── ResponsePrepared.php │ ├── RouteMatched.php │ └── Routing.php ├── Exceptions │ ├── BackedEnumCaseNotFoundException.php │ ├── InvalidSignatureException.php │ ├── MissingRateLimiterException.php │ ├── StreamedResponseException.php │ └── UrlGenerationException.php ├── FiltersControllerMiddleware.php ├── ImplicitRouteBinding.php ├── LICENSE.md ├── Matching │ ├── HostValidator.php │ ├── MethodValidator.php │ ├── SchemeValidator.php │ ├── UriValidator.php │ └── ValidatorInterface.php ├── Middleware │ ├── SubstituteBindings.php │ ├── ThrottleRequests.php │ ├── ThrottleRequestsWithRedis.php │ └── ValidateSignature.php ├── MiddlewareNameResolver.php ├── PendingResourceRegistration.php ├── PendingSingletonResourceRegistration.php ├── Pipeline.php ├── RedirectController.php ├── Redirector.php ├── ResolvesRouteDependencies.php ├── ResourceRegistrar.php ├── ResponseFactory.php ├── Route.php ├── RouteAction.php ├── RouteBinding.php ├── RouteCollection.php ├── RouteCollectionInterface.php ├── RouteDependencyResolverTrait.php ├── RouteFileRegistrar.php ├── RouteGroup.php ├── RouteParameterBinder.php ├── RouteRegistrar.php ├── RouteSignatureParameters.php ├── RouteUri.php ├── RouteUrlGenerator.php ├── Router.php ├── RoutingServiceProvider.php ├── SortedMiddleware.php ├── UrlGenerator.php ├── ViewController.php └── composer.json ├── Session ├── ArraySessionHandler.php ├── CacheBasedSessionHandler.php ├── Console │ ├── SessionTableCommand.php │ └── stubs │ │ └── database.stub ├── CookieSessionHandler.php ├── DatabaseSessionHandler.php ├── EncryptedStore.php ├── ExistenceAwareInterface.php ├── FileSessionHandler.php ├── LICENSE.md ├── Middleware │ ├── AuthenticateSession.php │ └── StartSession.php ├── NullSessionHandler.php ├── SessionManager.php ├── SessionServiceProvider.php ├── Store.php ├── SymfonySessionDecorator.php ├── TokenMismatchException.php └── composer.json ├── Support ├── AggregateServiceProvider.php ├── Benchmark.php ├── Carbon.php ├── Composer.php ├── ConfigurationUrlParser.php ├── DateFactory.php ├── DefaultProviders.php ├── Defer │ ├── DeferredCallback.php │ └── DeferredCallbackCollection.php ├── EncodedHtmlString.php ├── Env.php ├── Exceptions │ └── MathException.php ├── Facades │ ├── App.php │ ├── Artisan.php │ ├── Auth.php │ ├── Blade.php │ ├── Broadcast.php │ ├── Bus.php │ ├── Cache.php │ ├── Concurrency.php │ ├── Config.php │ ├── Context.php │ ├── Cookie.php │ ├── Crypt.php │ ├── DB.php │ ├── Date.php │ ├── Event.php │ ├── Exceptions.php │ ├── Facade.php │ ├── File.php │ ├── Gate.php │ ├── Hash.php │ ├── Http.php │ ├── Lang.php │ ├── Log.php │ ├── Mail.php │ ├── Notification.php │ ├── ParallelTesting.php │ ├── Password.php │ ├── Pipeline.php │ ├── Process.php │ ├── Queue.php │ ├── RateLimiter.php │ ├── Redirect.php │ ├── Redis.php │ ├── Request.php │ ├── Response.php │ ├── Route.php │ ├── Schedule.php │ ├── Schema.php │ ├── Session.php │ ├── Storage.php │ ├── URL.php │ ├── Validator.php │ ├── View.php │ └── Vite.php ├── Fluent.php ├── HigherOrderTapProxy.php ├── HtmlString.php ├── InteractsWithTime.php ├── Js.php ├── LICENSE.md ├── Lottery.php ├── Manager.php ├── MessageBag.php ├── MultipleInstanceManager.php ├── NamespacedItemResolver.php ├── Number.php ├── Once.php ├── Onceable.php ├── Optional.php ├── Pluralizer.php ├── ProcessUtils.php ├── Reflector.php ├── ServiceProvider.php ├── Sleep.php ├── Str.php ├── Stringable.php ├── Testing │ └── Fakes │ │ ├── BatchFake.php │ │ ├── BatchRepositoryFake.php │ │ ├── BusFake.php │ │ ├── ChainedBatchTruthTest.php │ │ ├── EventFake.php │ │ ├── ExceptionHandlerFake.php │ │ ├── Fake.php │ │ ├── MailFake.php │ │ ├── NotificationFake.php │ │ ├── PendingBatchFake.php │ │ ├── PendingChainFake.php │ │ ├── PendingMailFake.php │ │ └── QueueFake.php ├── Timebox.php ├── Traits │ ├── CapsuleManagerTrait.php │ ├── Dumpable.php │ ├── ForwardsCalls.php │ ├── InteractsWithData.php │ ├── Localizable.php │ ├── ReflectsClosures.php │ └── Tappable.php ├── Uri.php ├── UriQueryString.php ├── ValidatedInput.php ├── ViewErrorBag.php ├── composer.json ├── functions.php └── helpers.php ├── Testing ├── Assert.php ├── AssertableJsonString.php ├── Concerns │ ├── AssertsStatusCodes.php │ ├── RunsInParallel.php │ └── TestDatabases.php ├── Constraints │ ├── ArraySubset.php │ ├── CountInDatabase.php │ ├── HasInDatabase.php │ ├── NotSoftDeletedInDatabase.php │ ├── SeeInOrder.php │ └── SoftDeletedInDatabase.php ├── Exceptions │ └── InvalidArgumentException.php ├── Fluent │ ├── AssertableJson.php │ └── Concerns │ │ ├── Debugging.php │ │ ├── Has.php │ │ ├── Interaction.php │ │ └── Matching.php ├── LICENSE.md ├── LoggedExceptionCollection.php ├── ParallelConsoleOutput.php ├── ParallelRunner.php ├── ParallelTesting.php ├── ParallelTestingServiceProvider.php ├── PendingCommand.php ├── TestComponent.php ├── TestResponse.php ├── TestResponseAssert.php ├── TestView.php └── composer.json ├── Translation ├── ArrayLoader.php ├── CreatesPotentiallyTranslatedStrings.php ├── FileLoader.php ├── LICENSE.md ├── MessageSelector.php ├── PotentiallyTranslatedString.php ├── TranslationServiceProvider.php ├── Translator.php ├── composer.json └── lang │ └── en │ ├── auth.php │ ├── pagination.php │ ├── passwords.php │ └── validation.php ├── Validation ├── ClosureValidationRule.php ├── Concerns │ ├── FilterEmailValidation.php │ ├── FormatsMessages.php │ ├── ReplacesAttributes.php │ └── ValidatesAttributes.php ├── ConditionalRules.php ├── DatabasePresenceVerifier.php ├── DatabasePresenceVerifierInterface.php ├── Factory.php ├── InvokableValidationRule.php ├── LICENSE.md ├── NestedRules.php ├── NotPwnedVerifier.php ├── PresenceVerifierInterface.php ├── Rule.php ├── Rules │ ├── AnyOf.php │ ├── ArrayRule.php │ ├── Can.php │ ├── Contains.php │ ├── DatabaseRule.php │ ├── Date.php │ ├── Dimensions.php │ ├── Email.php │ ├── Enum.php │ ├── ExcludeIf.php │ ├── Exists.php │ ├── File.php │ ├── ImageFile.php │ ├── In.php │ ├── NotIn.php │ ├── Numeric.php │ ├── Password.php │ ├── ProhibitedIf.php │ ├── RequiredIf.php │ └── Unique.php ├── UnauthorizedException.php ├── ValidatesWhenResolvedTrait.php ├── ValidationData.php ├── ValidationException.php ├── ValidationRuleParser.php ├── ValidationServiceProvider.php ├── Validator.php └── composer.json └── View ├── AnonymousComponent.php ├── AppendableAttributeValue.php ├── Compilers ├── BladeCompiler.php ├── Compiler.php ├── CompilerInterface.php ├── ComponentTagCompiler.php └── Concerns │ ├── CompilesAuthorizations.php │ ├── CompilesClasses.php │ ├── CompilesComments.php │ ├── CompilesComponents.php │ ├── CompilesConditionals.php │ ├── CompilesEchos.php │ ├── CompilesErrors.php │ ├── CompilesFragments.php │ ├── CompilesHelpers.php │ ├── CompilesIncludes.php │ ├── CompilesInjections.php │ ├── CompilesJs.php │ ├── CompilesJson.php │ ├── CompilesLayouts.php │ ├── CompilesLoops.php │ ├── CompilesRawPhp.php │ ├── CompilesSessions.php │ ├── CompilesStacks.php │ ├── CompilesStyles.php │ ├── CompilesTranslations.php │ └── CompilesUseStatements.php ├── Component.php ├── ComponentAttributeBag.php ├── ComponentSlot.php ├── Concerns ├── ManagesComponents.php ├── ManagesEvents.php ├── ManagesFragments.php ├── ManagesLayouts.php ├── ManagesLoops.php ├── ManagesStacks.php └── ManagesTranslations.php ├── DynamicComponent.php ├── Engines ├── CompilerEngine.php ├── Engine.php ├── EngineResolver.php ├── FileEngine.php └── PhpEngine.php ├── Factory.php ├── FileViewFinder.php ├── InvokableComponentVariable.php ├── LICENSE.md ├── Middleware └── ShareErrorsFromSession.php ├── View.php ├── ViewException.php ├── ViewFinderInterface.php ├── ViewName.php ├── ViewServiceProvider.php └── composer.json /config/concurrency.php: -------------------------------------------------------------------------------- 1 | env('CONCURRENCY_DRIVER', 'process'), 19 | 20 | ]; 21 | -------------------------------------------------------------------------------- /src/Illuminate/Auth/Events/Attempting.php: -------------------------------------------------------------------------------- 1 | request = $request; 24 | } 25 | } 26 | -------------------------------------------------------------------------------- /src/Illuminate/Auth/Events/Login.php: -------------------------------------------------------------------------------- 1 | user instanceof MustVerifyEmail && ! $event->user->hasVerifiedEmail()) { 19 | $event->user->sendEmailVerificationNotification(); 20 | } 21 | } 22 | } 23 | -------------------------------------------------------------------------------- /src/Illuminate/Broadcasting/BroadcastException.php: -------------------------------------------------------------------------------- 1 | broadcastChannel() : $name; 17 | 18 | parent::__construct('private-'.$name); 19 | } 20 | } 21 | -------------------------------------------------------------------------------- /src/Illuminate/Bus/Events/BatchDispatched.php: -------------------------------------------------------------------------------- 1 | value = $value; 27 | } 28 | } 29 | -------------------------------------------------------------------------------- /src/Illuminate/Cache/Events/CacheMissed.php: -------------------------------------------------------------------------------- 1 | keys = $keys; 26 | } 27 | } 28 | -------------------------------------------------------------------------------- /src/Illuminate/Cache/FileLock.php: -------------------------------------------------------------------------------- 1 | store->add($this->name, $this->owner, $this->seconds); 15 | } 16 | } 17 | -------------------------------------------------------------------------------- /src/Illuminate/Cache/RateLimiting/GlobalLimit.php: -------------------------------------------------------------------------------- 1 | usingQuestionHelper( 17 | fn () => $this->output->confirm($question, $default), 18 | ); 19 | } 20 | } 21 | -------------------------------------------------------------------------------- /src/Illuminate/Console/View/Components/Error.php: -------------------------------------------------------------------------------- 1 | output))->render('error', $string, $verbosity); 19 | } 20 | } 21 | -------------------------------------------------------------------------------- /src/Illuminate/Console/View/Components/Info.php: -------------------------------------------------------------------------------- 1 | output))->render('info', $string, $verbosity); 19 | } 20 | } 21 | -------------------------------------------------------------------------------- /src/Illuminate/Console/View/Components/Mutators/EnsureDynamicContentIsHighlighted.php: -------------------------------------------------------------------------------- 1 | [$1]', (string) $string); 16 | } 17 | } 18 | -------------------------------------------------------------------------------- /src/Illuminate/Console/View/Components/Mutators/EnsureNoPunctuation.php: -------------------------------------------------------------------------------- 1 | endsWith(['.', '?', '!', ':'])) { 18 | return substr_replace($string, '', -1); 19 | } 20 | 21 | return $string; 22 | } 23 | } 24 | -------------------------------------------------------------------------------- /src/Illuminate/Console/View/Components/Mutators/EnsurePunctuation.php: -------------------------------------------------------------------------------- 1 | endsWith(['.', '?', '!', ':'])) { 18 | return "$string."; 19 | } 20 | 21 | return $string; 22 | } 23 | } 24 | -------------------------------------------------------------------------------- /src/Illuminate/Console/View/Components/Mutators/EnsureRelativePaths.php: -------------------------------------------------------------------------------- 1 | has('path.base')) { 16 | $string = str_replace(base_path().'/', '', $string); 17 | } 18 | 19 | return $string; 20 | } 21 | } 22 | -------------------------------------------------------------------------------- /src/Illuminate/Console/View/Components/Secret.php: -------------------------------------------------------------------------------- 1 | setHidden(true)->setHiddenFallback($fallback); 21 | 22 | return $this->usingQuestionHelper(fn () => $this->output->askQuestion($question)); 23 | } 24 | } 25 | -------------------------------------------------------------------------------- /src/Illuminate/Console/View/Components/Success.php: -------------------------------------------------------------------------------- 1 | output))->render('success', $string, $verbosity); 19 | } 20 | } 21 | -------------------------------------------------------------------------------- /src/Illuminate/Console/View/Components/Warn.php: -------------------------------------------------------------------------------- 1 | output)) 19 | ->render('warn', $string, $verbosity); 20 | } 21 | } 22 | -------------------------------------------------------------------------------- /src/Illuminate/Console/View/TaskResult.php: -------------------------------------------------------------------------------- 1 | 2 | 3 | 4 | -------------------------------------------------------------------------------- /src/Illuminate/Console/resources/views/components/bullet-list.php: -------------------------------------------------------------------------------- 1 |
2 | 3 |
4 | ⇂ 5 |
6 | 7 |
8 | -------------------------------------------------------------------------------- /src/Illuminate/Console/resources/views/components/line.php: -------------------------------------------------------------------------------- 1 |
2 | 3 | 6 | 7 | 8 |
9 | -------------------------------------------------------------------------------- /src/Illuminate/Console/resources/views/components/two-column-detail.php: -------------------------------------------------------------------------------- 1 |
2 | 3 | 4 | 5 | 6 | 7 | 8 | 9 | 10 | 11 |
12 | -------------------------------------------------------------------------------- /src/Illuminate/Container/Attributes/CurrentUser.php: -------------------------------------------------------------------------------- 1 | |CastsAttributes|CastsInboundAttributes 12 | */ 13 | public static function castUsing(array $arguments); 14 | } 15 | -------------------------------------------------------------------------------- /src/Illuminate/Contracts/Database/Eloquent/CastsInboundAttributes.php: -------------------------------------------------------------------------------- 1 | $attributes 16 | * @return mixed 17 | */ 18 | public function set(Model $model, string $key, mixed $value, array $attributes); 19 | } 20 | -------------------------------------------------------------------------------- /src/Illuminate/Contracts/Database/Eloquent/ComparesCastableAttributes.php: -------------------------------------------------------------------------------- 1 | $attributes 16 | * @return mixed 17 | */ 18 | public function serialize(Model $model, string $key, mixed $value, array $attributes); 19 | } 20 | -------------------------------------------------------------------------------- /src/Illuminate/Contracts/Database/Events/MigrationEvent.php: -------------------------------------------------------------------------------- 1 | 15 | */ 16 | public function toArray(); 17 | } 18 | -------------------------------------------------------------------------------- /src/Illuminate/Contracts/Support/CanBeEscapedWhenCastToString.php: -------------------------------------------------------------------------------- 1 | app->singleton('cookie', function ($app) { 17 | $config = $app->make('config')->get('session'); 18 | 19 | return (new CookieJar)->setDefaultPathAndDomain( 20 | $config['path'], $config['domain'], $config['secure'], $config['same_site'] ?? null 21 | ); 22 | }); 23 | } 24 | } 25 | -------------------------------------------------------------------------------- /src/Illuminate/Database/ClassMorphViolationException.php: -------------------------------------------------------------------------------- 1 | model = $class; 28 | } 29 | } 30 | -------------------------------------------------------------------------------- /src/Illuminate/Database/Concerns/ExplainsQueries.php: -------------------------------------------------------------------------------- 1 | toSql(); 17 | 18 | $bindings = $this->getBindings(); 19 | 20 | $explanation = $this->getConnection()->select('EXPLAIN '.$sql, $bindings); 21 | 22 | return new Collection($explanation); 23 | } 24 | } 25 | -------------------------------------------------------------------------------- /src/Illuminate/Database/Concerns/ParsesSearchPath.php: -------------------------------------------------------------------------------- 1 | 9 | */ 10 | class {{ factory }}Factory extends Factory 11 | { 12 | /** 13 | * Define the model's default state. 14 | * 15 | * @return array 16 | */ 17 | public function definition(): array 18 | { 19 | return [ 20 | // 21 | ]; 22 | } 23 | } 24 | -------------------------------------------------------------------------------- /src/Illuminate/Database/Console/Seeds/WithoutModelEvents.php: -------------------------------------------------------------------------------- 1 | Model::withoutEvents($callback); 18 | } 19 | } 20 | -------------------------------------------------------------------------------- /src/Illuminate/Database/Console/Seeds/stubs/seeder.stub: -------------------------------------------------------------------------------- 1 | > $collectionClass 14 | */ 15 | public function __construct(public string $collectionClass) 16 | { 17 | } 18 | } 19 | -------------------------------------------------------------------------------- /src/Illuminate/Database/Eloquent/Attributes/ObservedBy.php: -------------------------------------------------------------------------------- 1 | $factoryClass 14 | */ 15 | public function __construct(public string $factoryClass) 16 | { 17 | } 18 | } 19 | -------------------------------------------------------------------------------- /src/Illuminate/Database/Eloquent/Attributes/UsePolicy.php: -------------------------------------------------------------------------------- 1 | $class 14 | */ 15 | public function __construct(public string $class) 16 | { 17 | } 18 | } 19 | -------------------------------------------------------------------------------- /src/Illuminate/Database/Eloquent/BroadcastsEventsAfterCommit.php: -------------------------------------------------------------------------------- 1 | |bool 23 | */ 24 | protected $guarded = []; 25 | } 26 | -------------------------------------------------------------------------------- /src/Illuminate/Database/Eloquent/Scope.php: -------------------------------------------------------------------------------- 1 | $builder 13 | * @param TModel $model 14 | * @return void 15 | */ 16 | public function apply(Builder $builder, Model $model); 17 | } 18 | -------------------------------------------------------------------------------- /src/Illuminate/Database/Events/ConnectionEstablished.php: -------------------------------------------------------------------------------- 1 | connection = $connection; 29 | $this->connectionName = $connection->getName(); 30 | } 31 | } 32 | -------------------------------------------------------------------------------- /src/Illuminate/Database/Events/DatabaseBusy.php: -------------------------------------------------------------------------------- 1 | $options The options provided when the migration method was invoked. 14 | */ 15 | public function __construct( 16 | public $method, 17 | public array $options = [], 18 | ) { 19 | } 20 | } 21 | -------------------------------------------------------------------------------- /src/Illuminate/Database/Events/MigrationsStarted.php: -------------------------------------------------------------------------------- 1 | $models The class names of the models that were pruned. 11 | */ 12 | public function __construct( 13 | public $models, 14 | ) { 15 | } 16 | } 17 | -------------------------------------------------------------------------------- /src/Illuminate/Database/Events/ModelPruningStarting.php: -------------------------------------------------------------------------------- 1 | $models The class names of the models that will be pruned. 11 | */ 12 | public function __construct( 13 | public $models 14 | ) { 15 | } 16 | } 17 | -------------------------------------------------------------------------------- /src/Illuminate/Database/Events/ModelsPruned.php: -------------------------------------------------------------------------------- 1 | id(); 16 | $table->timestamps(); 17 | }); 18 | } 19 | 20 | /** 21 | * Reverse the migrations. 22 | */ 23 | public function down(): void 24 | { 25 | Schema::dropIfExists('{{ table }}'); 26 | } 27 | }; 28 | -------------------------------------------------------------------------------- /src/Illuminate/Database/Migrations/stubs/migration.stub: -------------------------------------------------------------------------------- 1 | type = $type; 30 | $this->index = $index; 31 | } 32 | } 33 | -------------------------------------------------------------------------------- /src/Illuminate/Database/Query/JoinLateralClause.php: -------------------------------------------------------------------------------- 1 | path = $path; 26 | } 27 | } 28 | -------------------------------------------------------------------------------- /src/Illuminate/Database/Schema/MariaDbBuilder.php: -------------------------------------------------------------------------------- 1 | $path) { 16 | if (empty($path) && $path !== '0') { 17 | unset($paths[$index]); 18 | } else { 19 | $paths[$index] = DIRECTORY_SEPARATOR.ltrim($path, DIRECTORY_SEPARATOR); 20 | } 21 | } 22 | 23 | return $basePath.implode('', $paths); 24 | } 25 | } 26 | -------------------------------------------------------------------------------- /src/Illuminate/Foundation/Bootstrap/BootProviders.php: -------------------------------------------------------------------------------- 1 | boot(); 18 | } 19 | } 20 | -------------------------------------------------------------------------------- /src/Illuminate/Foundation/Bus/DispatchesJobs.php: -------------------------------------------------------------------------------- 1 | job->onFailure($callback); 18 | 19 | return $this; 20 | } 21 | } 22 | -------------------------------------------------------------------------------- /src/Illuminate/Foundation/Console/stubs/api-routes.stub: -------------------------------------------------------------------------------- 1 | user(); 8 | })->middleware('auth:sanctum'); 9 | -------------------------------------------------------------------------------- /src/Illuminate/Foundation/Console/stubs/broadcasting-routes.stub: -------------------------------------------------------------------------------- 1 | id === (int) $id; 7 | }); 8 | -------------------------------------------------------------------------------- /src/Illuminate/Foundation/Console/stubs/cast.inbound.stub: -------------------------------------------------------------------------------- 1 | $attributes 14 | */ 15 | public function set(Model $model, string $key, mixed $value, array $attributes): mixed 16 | { 17 | return $value; 18 | } 19 | } 20 | -------------------------------------------------------------------------------- /src/Illuminate/Foundation/Console/stubs/channel.stub: -------------------------------------------------------------------------------- 1 | batch()->cancelled()) { 27 | // The batch has been cancelled... 28 | 29 | return; 30 | } 31 | 32 | // 33 | } 34 | } 35 | -------------------------------------------------------------------------------- /src/Illuminate/Foundation/Console/stubs/job.middleware.stub: -------------------------------------------------------------------------------- 1 | 2 | # Introduction 3 | 4 | The body of your message. 5 | 6 | 7 | Button Text 8 | 9 | 10 | Thanks,
11 | {{ config('app.name') }} 12 | 13 | -------------------------------------------------------------------------------- /src/Illuminate/Foundation/Console/stubs/model.morph-pivot.stub: -------------------------------------------------------------------------------- 1 | get('/'); 5 | 6 | $response->assertStatus(200); 7 | }); 8 | -------------------------------------------------------------------------------- /src/Illuminate/Foundation/Console/stubs/pest.unit.stub: -------------------------------------------------------------------------------- 1 | toBeTrue(); 5 | }); 6 | -------------------------------------------------------------------------------- /src/Illuminate/Foundation/Console/stubs/policy.plain.stub: -------------------------------------------------------------------------------- 1 | |string> 21 | */ 22 | public function rules(): array 23 | { 24 | return [ 25 | // 26 | ]; 27 | } 28 | } 29 | -------------------------------------------------------------------------------- /src/Illuminate/Foundation/Console/stubs/resource-collection.stub: -------------------------------------------------------------------------------- 1 | 14 | */ 15 | public function toArray(Request $request): array 16 | { 17 | return parent::toArray($request); 18 | } 19 | } 20 | -------------------------------------------------------------------------------- /src/Illuminate/Foundation/Console/stubs/resource.stub: -------------------------------------------------------------------------------- 1 | 14 | */ 15 | public function toArray(Request $request): array 16 | { 17 | return parent::toArray($request); 18 | } 19 | } 20 | -------------------------------------------------------------------------------- /src/Illuminate/Foundation/Console/stubs/routes.stub: -------------------------------------------------------------------------------- 1 | setCompiledRoutes( 4 | {{routes}} 5 | ); 6 | -------------------------------------------------------------------------------- /src/Illuminate/Foundation/Console/stubs/rule.implicit.stub: -------------------------------------------------------------------------------- 1 | get('/'); 17 | 18 | $response->assertStatus(200); 19 | } 20 | } 21 | -------------------------------------------------------------------------------- /src/Illuminate/Foundation/Console/stubs/test.unit.stub: -------------------------------------------------------------------------------- 1 | assertTrue(true); 15 | } 16 | } 17 | -------------------------------------------------------------------------------- /src/Illuminate/Foundation/Console/stubs/trait.stub: -------------------------------------------------------------------------------- 1 | view('{{ name }}', [ 5 | // 6 | ]); 7 | 8 | $contents->assertSee(''); 9 | }); 10 | -------------------------------------------------------------------------------- /src/Illuminate/Foundation/Console/stubs/view.stub: -------------------------------------------------------------------------------- 1 |
2 | 3 |
4 | -------------------------------------------------------------------------------- /src/Illuminate/Foundation/Console/stubs/view.test.stub: -------------------------------------------------------------------------------- 1 | view('{{ name }}', [ 15 | // 16 | ]); 17 | 18 | $contents->assertSee(''); 19 | } 20 | } 21 | -------------------------------------------------------------------------------- /src/Illuminate/Foundation/Events/DiagnosingHealth.php: -------------------------------------------------------------------------------- 1 | locale = $locale; 22 | } 23 | } 24 | -------------------------------------------------------------------------------- /src/Illuminate/Foundation/Events/MaintenanceModeDisabled.php: -------------------------------------------------------------------------------- 1 | tag = $tag; 30 | $this->paths = $paths; 31 | } 32 | } 33 | -------------------------------------------------------------------------------- /src/Illuminate/Foundation/Exceptions/RegisterErrorViewPaths.php: -------------------------------------------------------------------------------- 1 | map(function ($path) { 18 | return "{$path}/errors"; 19 | })->push(__DIR__.'/views')->all()); 20 | } 21 | } 22 | -------------------------------------------------------------------------------- /src/Illuminate/Foundation/Exceptions/views/401.blade.php: -------------------------------------------------------------------------------- 1 | @extends('errors::minimal') 2 | 3 | @section('title', __('Unauthorized')) 4 | @section('code', '401') 5 | @section('message', __('Unauthorized')) 6 | -------------------------------------------------------------------------------- /src/Illuminate/Foundation/Exceptions/views/402.blade.php: -------------------------------------------------------------------------------- 1 | @extends('errors::minimal') 2 | 3 | @section('title', __('Payment Required')) 4 | @section('code', '402') 5 | @section('message', __('Payment Required')) 6 | -------------------------------------------------------------------------------- /src/Illuminate/Foundation/Exceptions/views/403.blade.php: -------------------------------------------------------------------------------- 1 | @extends('errors::minimal') 2 | 3 | @section('title', __('Forbidden')) 4 | @section('code', '403') 5 | @section('message', __($exception->getMessage() ?: 'Forbidden')) 6 | -------------------------------------------------------------------------------- /src/Illuminate/Foundation/Exceptions/views/404.blade.php: -------------------------------------------------------------------------------- 1 | @extends('errors::minimal') 2 | 3 | @section('title', __('Not Found')) 4 | @section('code', '404') 5 | @section('message', __('Not Found')) 6 | -------------------------------------------------------------------------------- /src/Illuminate/Foundation/Exceptions/views/419.blade.php: -------------------------------------------------------------------------------- 1 | @extends('errors::minimal') 2 | 3 | @section('title', __('Page Expired')) 4 | @section('code', '419') 5 | @section('message', __('Page Expired')) 6 | -------------------------------------------------------------------------------- /src/Illuminate/Foundation/Exceptions/views/429.blade.php: -------------------------------------------------------------------------------- 1 | @extends('errors::minimal') 2 | 3 | @section('title', __('Too Many Requests')) 4 | @section('code', '429') 5 | @section('message', __('Too Many Requests')) 6 | -------------------------------------------------------------------------------- /src/Illuminate/Foundation/Exceptions/views/500.blade.php: -------------------------------------------------------------------------------- 1 | @extends('errors::minimal') 2 | 3 | @section('title', __('Server Error')) 4 | @section('code', '500') 5 | @section('message', __('Server Error')) 6 | -------------------------------------------------------------------------------- /src/Illuminate/Foundation/Exceptions/views/503.blade.php: -------------------------------------------------------------------------------- 1 | @extends('errors::minimal') 2 | 3 | @section('title', __('Service Unavailable')) 4 | @section('code', '503') 5 | @section('message', __('Service Unavailable')) 6 | -------------------------------------------------------------------------------- /src/Illuminate/Foundation/Http/Middleware/CheckForMaintenanceMode.php: -------------------------------------------------------------------------------- 1 | messages()->isEmpty() && $request->headers->has('Precognition-Validate-Only')) { 17 | abort(204, headers: ['Precognition-Success' => 'true']); 18 | } 19 | }; 20 | } 21 | } 22 | -------------------------------------------------------------------------------- /src/Illuminate/Foundation/Providers/ConsoleSupportServiceProvider.php: -------------------------------------------------------------------------------- 1 | resolveParameters($route, $callable); 20 | 21 | abort(204, headers: ['Precognition-Success' => 'true']); 22 | } 23 | } 24 | -------------------------------------------------------------------------------- /src/Illuminate/Foundation/Testing/Concerns/WithoutExceptionHandlingHandler.php: -------------------------------------------------------------------------------- 1 | 11 | */ 12 | public static $inMemoryConnections = []; 13 | 14 | /** 15 | * Indicates if the test database has been migrated. 16 | * 17 | * @var bool 18 | */ 19 | public static $migrated = false; 20 | 21 | /** 22 | * Indicates if a lazy refresh hook has been invoked. 23 | * 24 | * @var bool 25 | */ 26 | public static $lazilyRefreshed = false; 27 | } 28 | -------------------------------------------------------------------------------- /src/Illuminate/Foundation/Testing/WithConsoleEvents.php: -------------------------------------------------------------------------------- 1 | app[ConsoleKernel::class]->rerouteSymfonyCommandEvents(); 17 | } 18 | } 19 | -------------------------------------------------------------------------------- /src/Illuminate/Foundation/Testing/WithoutMiddleware.php: -------------------------------------------------------------------------------- 1 | withoutMiddleware(); 18 | } else { 19 | throw new Exception('Unable to disable middleware. MakesHttpRequests trait not used.'); 20 | } 21 | } 22 | } 23 | -------------------------------------------------------------------------------- /src/Illuminate/Foundation/ViteException.php: -------------------------------------------------------------------------------- 1 | merge(['class' => "@container flex flex-col p-6 sm:p-12 bg-white dark:bg-gray-900/80 text-gray-900 dark:text-gray-100 rounded-lg default:col-span-full default:lg:col-span-6 default:row-span-1 dark:ring-1 dark:ring-gray-800 shadow-xl"]) }} 3 | > 4 | {{ $slot }} 5 | 6 | -------------------------------------------------------------------------------- /src/Illuminate/Foundation/resources/exceptions/renderer/components/icons/chevron-down.blade.php: -------------------------------------------------------------------------------- 1 | 2 | 3 | 4 | -------------------------------------------------------------------------------- /src/Illuminate/Foundation/resources/exceptions/renderer/components/icons/chevron-up.blade.php: -------------------------------------------------------------------------------- 1 | 2 | 3 | 4 | -------------------------------------------------------------------------------- /src/Illuminate/Foundation/resources/exceptions/renderer/components/icons/computer-desktop.blade.php: -------------------------------------------------------------------------------- 1 | 9 | 10 | 11 | -------------------------------------------------------------------------------- /src/Illuminate/Foundation/resources/exceptions/renderer/components/icons/moon.blade.php: -------------------------------------------------------------------------------- 1 | 9 | 10 | 11 | -------------------------------------------------------------------------------- /src/Illuminate/Foundation/resources/exceptions/renderer/components/icons/sun.blade.php: -------------------------------------------------------------------------------- 1 | 9 | 10 | 11 | -------------------------------------------------------------------------------- /src/Illuminate/Foundation/resources/exceptions/renderer/components/trace-and-editor.blade.php: -------------------------------------------------------------------------------- 1 | 2 |
8 |
9 | 10 | 11 |
12 |
13 |
14 | -------------------------------------------------------------------------------- /src/Illuminate/Foundation/resources/exceptions/renderer/dark-mode.css: -------------------------------------------------------------------------------- 1 | @import 'highlight.js/styles/atom-one-dark.min.css'; 2 | -------------------------------------------------------------------------------- /src/Illuminate/Foundation/resources/exceptions/renderer/light-mode.css: -------------------------------------------------------------------------------- 1 | @import 'highlight.js/styles/github.min.css'; 2 | -------------------------------------------------------------------------------- /src/Illuminate/Foundation/resources/exceptions/renderer/package.json: -------------------------------------------------------------------------------- 1 | { 2 | "private": true, 3 | "entry": "show.blade.php", 4 | "scripts": { 5 | "build": "vite build", 6 | "watch": "vite build --watch" 7 | }, 8 | "dependencies": { 9 | "alpinejs": "^3.13.10", 10 | "autoprefixer": "^10.4.19", 11 | "highlight.js": "^11.9.0", 12 | "postcss": "^8.4.38", 13 | "tailwindcss": "^3.4.3", 14 | "tippy.js": "^6.3.7", 15 | "vite": "^5.4.19", 16 | "vite-require": "^0.2.3" 17 | } 18 | } 19 | -------------------------------------------------------------------------------- /src/Illuminate/Foundation/resources/exceptions/renderer/postcss.config.js: -------------------------------------------------------------------------------- 1 | module.exports = { 2 | plugins: { 3 | tailwindcss: {}, 4 | autoprefixer: {}, 5 | }, 6 | }; 7 | -------------------------------------------------------------------------------- /src/Illuminate/Foundation/resources/exceptions/renderer/scripts.js: -------------------------------------------------------------------------------- 1 | import tippy from 'tippy.js'; 2 | import alpine from 'alpinejs'; 3 | import hljs from 'highlight.js/lib/core'; 4 | import php from 'highlight.js/lib/languages/php'; 5 | 6 | alpine.start(); 7 | 8 | hljs.registerLanguage('php', php); 9 | 10 | window.hljs = hljs; 11 | 12 | hljs.highlightElement(document.querySelector('.default-highlightable-code')); 13 | 14 | document.querySelectorAll('.highlightable-code').forEach((block) => { 15 | if (block.dataset.highlighted !== 'yes') { 16 | hljs.highlightElement(block); 17 | } 18 | }); 19 | 20 | tippy('[data-tippy-content]', { 21 | trigger: 'click', 22 | arrow: true, 23 | theme: 'material', 24 | animation: 'scale', 25 | }); 26 | -------------------------------------------------------------------------------- /src/Illuminate/Foundation/resources/exceptions/renderer/show.blade.php: -------------------------------------------------------------------------------- 1 | 2 |
3 | 4 | 5 |
6 |
7 | 8 | 9 | 10 | 11 | 12 |
13 |
14 |
15 |
16 | -------------------------------------------------------------------------------- /src/Illuminate/Foundation/resources/exceptions/renderer/tailwind.config.js: -------------------------------------------------------------------------------- 1 | const defaultTheme = require('tailwindcss/defaultTheme'); 2 | 3 | /** @type {import('tailwindcss').Config} */ 4 | module.exports = { 5 | content: ['./**/*.blade.php'], 6 | darkMode: 'class', 7 | theme: { 8 | extend: { 9 | fontFamily: { 10 | sans: ['Figtree', ...defaultTheme.fontFamily.sans], 11 | }, 12 | }, 13 | }, 14 | plugins: [], 15 | }; 16 | -------------------------------------------------------------------------------- /src/Illuminate/Foundation/resources/exceptions/renderer/vite.config.js: -------------------------------------------------------------------------------- 1 | /** @type {import('vite').UserConfig} */ 2 | export default { 3 | plugins: [], 4 | build: { 5 | assetsDir: '', 6 | rollupOptions: { 7 | input: ['scripts.js', 'styles.css', 'dark-mode.css', 'light-mode.css'], 8 | output: { 9 | assetFileNames: '[name][extname]', 10 | entryFileNames: '[name].js', 11 | }, 12 | }, 13 | }, 14 | }; 15 | -------------------------------------------------------------------------------- /src/Illuminate/Foundation/stubs/facade.stub: -------------------------------------------------------------------------------- 1 | request = $request; 24 | } 25 | } 26 | -------------------------------------------------------------------------------- /src/Illuminate/Http/Client/HttpClientException.php: -------------------------------------------------------------------------------- 1 | isNotModified($request); 23 | } 24 | 25 | return $response; 26 | } 27 | } 28 | -------------------------------------------------------------------------------- /src/Illuminate/Http/Middleware/FrameGuard.php: -------------------------------------------------------------------------------- 1 | headers->set('X-Frame-Options', 'SAMEORIGIN', false); 21 | 22 | return $response; 23 | } 24 | } 25 | -------------------------------------------------------------------------------- /src/Illuminate/Http/Resources/MissingValue.php: -------------------------------------------------------------------------------- 1 | event = $event; 23 | $this->data = $data; 24 | } 25 | } 26 | -------------------------------------------------------------------------------- /src/Illuminate/Log/Context/Events/ContextDehydrating.php: -------------------------------------------------------------------------------- 1 | context = $context; 22 | } 23 | } 24 | -------------------------------------------------------------------------------- /src/Illuminate/Log/Context/Events/ContextHydrated.php: -------------------------------------------------------------------------------- 1 | context = $context; 22 | } 23 | } 24 | -------------------------------------------------------------------------------- /src/Illuminate/Log/LogServiceProvider.php: -------------------------------------------------------------------------------- 1 | app->singleton('log', fn ($app) => new LogManager($app)); 17 | } 18 | } 19 | -------------------------------------------------------------------------------- /src/Illuminate/Log/functions.php: -------------------------------------------------------------------------------- 1 | address = $address; 30 | $this->name = $name; 31 | } 32 | } 33 | -------------------------------------------------------------------------------- /src/Illuminate/Mail/Mailables/Attachment.php: -------------------------------------------------------------------------------- 1 | 'primary', 4 | 'align' => 'center', 5 | ]) 6 | 7 | 8 | 23 | 24 | 25 | -------------------------------------------------------------------------------- /src/Illuminate/Mail/resources/views/html/footer.blade.php: -------------------------------------------------------------------------------- 1 | 2 | 3 | 4 | 5 | 8 | 9 | 10 | 11 | 12 | -------------------------------------------------------------------------------- /src/Illuminate/Mail/resources/views/html/header.blade.php: -------------------------------------------------------------------------------- 1 | @props(['url']) 2 | 3 | 4 | 5 | @if (trim($slot) === 'Laravel') 6 | 7 | @else 8 | {!! $slot !!} 9 | @endif 10 | 11 | 12 | 13 | -------------------------------------------------------------------------------- /src/Illuminate/Mail/resources/views/html/message.blade.php: -------------------------------------------------------------------------------- 1 | 2 | {{-- Header --}} 3 | 4 | 5 | {{ config('app.name') }} 6 | 7 | 8 | 9 | {{-- Body --}} 10 | {!! $slot !!} 11 | 12 | {{-- Subcopy --}} 13 | @isset($subcopy) 14 | 15 | 16 | {!! $subcopy !!} 17 | 18 | 19 | @endisset 20 | 21 | {{-- Footer --}} 22 | 23 | 24 | © {{ date('Y') }} {{ config('app.name') }}. {{ __('All rights reserved.') }} 25 | 26 | 27 | 28 | -------------------------------------------------------------------------------- /src/Illuminate/Mail/resources/views/html/panel.blade.php: -------------------------------------------------------------------------------- 1 | 2 | 3 | 12 | 13 | 14 | 15 | -------------------------------------------------------------------------------- /src/Illuminate/Mail/resources/views/html/subcopy.blade.php: -------------------------------------------------------------------------------- 1 | 2 | 3 | 6 | 7 | 8 | -------------------------------------------------------------------------------- /src/Illuminate/Mail/resources/views/html/table.blade.php: -------------------------------------------------------------------------------- 1 |
2 | {{ Illuminate\Mail\Markdown::parse($slot) }} 3 |
4 | -------------------------------------------------------------------------------- /src/Illuminate/Mail/resources/views/text/button.blade.php: -------------------------------------------------------------------------------- 1 | {{ $slot }}: {{ $url }} 2 | -------------------------------------------------------------------------------- /src/Illuminate/Mail/resources/views/text/footer.blade.php: -------------------------------------------------------------------------------- 1 | {{ $slot }} 2 | -------------------------------------------------------------------------------- /src/Illuminate/Mail/resources/views/text/header.blade.php: -------------------------------------------------------------------------------- 1 | {{ $slot }}: {{ $url }} 2 | -------------------------------------------------------------------------------- /src/Illuminate/Mail/resources/views/text/layout.blade.php: -------------------------------------------------------------------------------- 1 | {!! strip_tags($header ?? '') !!} 2 | 3 | {!! strip_tags($slot) !!} 4 | @isset($subcopy) 5 | 6 | {!! strip_tags($subcopy) !!} 7 | @endisset 8 | 9 | {!! strip_tags($footer ?? '') !!} 10 | -------------------------------------------------------------------------------- /src/Illuminate/Mail/resources/views/text/panel.blade.php: -------------------------------------------------------------------------------- 1 | {{ $slot }} 2 | -------------------------------------------------------------------------------- /src/Illuminate/Mail/resources/views/text/subcopy.blade.php: -------------------------------------------------------------------------------- 1 | {{ $slot }} 2 | -------------------------------------------------------------------------------- /src/Illuminate/Mail/resources/views/text/table.blade.php: -------------------------------------------------------------------------------- 1 | {{ $slot }} 2 | -------------------------------------------------------------------------------- /src/Illuminate/Notifications/Action.php: -------------------------------------------------------------------------------- 1 | url = $url; 30 | $this->text = $text; 31 | } 32 | } 33 | -------------------------------------------------------------------------------- /src/Illuminate/Notifications/Events/NotificationSending.php: -------------------------------------------------------------------------------- 1 | data = $data; 22 | } 23 | } 24 | -------------------------------------------------------------------------------- /src/Illuminate/Notifications/Notifiable.php: -------------------------------------------------------------------------------- 1 | value = $value; 27 | } 28 | } 29 | -------------------------------------------------------------------------------- /src/Illuminate/Queue/ManuallyFailedException.php: -------------------------------------------------------------------------------- 1 | resolveName().' has been attempted too many times.'), function ($e) use ($job) { 25 | $e->job = $job; 26 | }); 27 | } 28 | } 29 | -------------------------------------------------------------------------------- /src/Illuminate/Queue/Middleware/SkipIfBatchCancelled.php: -------------------------------------------------------------------------------- 1 | batch()?->cancelled()) { 17 | return; 18 | } 19 | 20 | $next($job); 21 | } 22 | } 23 | -------------------------------------------------------------------------------- /src/Illuminate/Queue/TimeoutExceededException.php: -------------------------------------------------------------------------------- 1 | resolveName().' has timed out.'), function ($e) use ($job) { 16 | $e->job = $job; 17 | }); 18 | } 19 | } 20 | -------------------------------------------------------------------------------- /src/Illuminate/Redis/Connections/PredisClusterConnection.php: -------------------------------------------------------------------------------- 1 | client as $node) { 22 | $node->executeCommand(tap(new $command)->setArguments(func_get_args())); 23 | } 24 | } 25 | } 26 | -------------------------------------------------------------------------------- /src/Illuminate/Routing/Console/stubs/controller.invokable.stub: -------------------------------------------------------------------------------- 1 | 11 | */ 12 | public static function middleware(); 13 | } 14 | -------------------------------------------------------------------------------- /src/Illuminate/Routing/Events/PreparingResponse.php: -------------------------------------------------------------------------------- 1 | getMethod(), $route->methods()); 20 | } 21 | } 22 | -------------------------------------------------------------------------------- /src/Illuminate/Routing/Matching/UriValidator.php: -------------------------------------------------------------------------------- 1 | getPathInfo(), '/') ?: '/'; 20 | 21 | return preg_match($route->getCompiled()->getRegex(), rawurldecode($path)); 22 | } 23 | } 24 | -------------------------------------------------------------------------------- /src/Illuminate/Routing/Matching/ValidatorInterface.php: -------------------------------------------------------------------------------- 1 | prop($prop)); 20 | 21 | return $this; 22 | } 23 | 24 | /** 25 | * Retrieve a prop within the current scope using "dot" notation. 26 | * 27 | * @param string|null $key 28 | * @return mixed 29 | */ 30 | abstract protected function prop(?string $key = null); 31 | } 32 | -------------------------------------------------------------------------------- /src/Illuminate/Testing/LoggedExceptionCollection.php: -------------------------------------------------------------------------------- 1 | '« Previous', 17 | 'next' => 'Next »', 18 | 19 | ]; 20 | -------------------------------------------------------------------------------- /src/Illuminate/Validation/DatabasePresenceVerifierInterface.php: -------------------------------------------------------------------------------- 1 | table, 21 | $this->column, 22 | $this->formatWheres() 23 | ), ','); 24 | } 25 | } 26 | -------------------------------------------------------------------------------- /src/Illuminate/Validation/UnauthorizedException.php: -------------------------------------------------------------------------------- 1 | value = $value; 24 | } 25 | 26 | /** 27 | * Get the string value. 28 | * 29 | * @return string 30 | */ 31 | public function __toString() 32 | { 33 | return (string) $this->value; 34 | } 35 | } 36 | -------------------------------------------------------------------------------- /src/Illuminate/View/Compilers/CompilerInterface.php: -------------------------------------------------------------------------------- 1 | \""; 18 | } 19 | } 20 | -------------------------------------------------------------------------------- /src/Illuminate/View/Compilers/Concerns/CompilesComments.php: -------------------------------------------------------------------------------- 1 | contentTags[0], $this->contentTags[1]); 16 | 17 | return preg_replace($pattern, '', $value); 18 | } 19 | } 20 | -------------------------------------------------------------------------------- /src/Illuminate/View/Compilers/Concerns/CompilesInjections.php: -------------------------------------------------------------------------------- 1 | "; 22 | } 23 | } 24 | -------------------------------------------------------------------------------- /src/Illuminate/View/Compilers/Concerns/CompilesJs.php: -------------------------------------------------------------------------------- 1 | toHtml() ?>", 19 | Js::class, $this->stripParentheses($expression) 20 | ); 21 | } 22 | } 23 | -------------------------------------------------------------------------------- /src/Illuminate/View/Compilers/Concerns/CompilesStyles.php: -------------------------------------------------------------------------------- 1 | \""; 18 | } 19 | } 20 | -------------------------------------------------------------------------------- /src/Illuminate/View/Engines/Engine.php: -------------------------------------------------------------------------------- 1 | lastRendered; 22 | } 23 | } 24 | -------------------------------------------------------------------------------- /src/Illuminate/View/ViewName.php: -------------------------------------------------------------------------------- 1 |