123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374375376377378379380381382383384385386387388389390391392393394395396397398399400401402403404405406407408409410411412413414415416417418419420421422423424425426427428429430431432433434435436437438439440441442443444445446447448449450451452453454455456457458459460461462463464465466467468469470471472473474475476477478479480481482483484485486487488489490491492493494495496497498499500501502503504505506507508509510511512513514515516517518519520521522523524525526527528529530531532533534535536537538539540541542543544545546547548549550551552553554555556557558559560561562563564565566567568569570571572573574575576577578579580581582583584585586587588589590591592593594595596597598599600601602603604605606607608609610611612613614615616617618619620621622623624625626627628629630631632633634635636637638639640641642643644645646647648649650651652653654655656657658659660661662663664665666667668669670671672673674675676677678679680681682683684685686687688689690691692693694695696697698699700701702703704705706707708709710711712713714715716717718719720721722723724725726727728729730731732733734735736737738739740741742743744745746747748749750751752753754755756757758759760761762763764765766767768769770771772773774775776777778779780781782783784785786787788789790791792793794795796797798799800801802803804805806807808809810811812813814815816817818819820821822823824825826827828829830831832833834835836837838839840841842843844845846847848849850851852853854855856857858859860861862863 |
- <?php
- namespace Illuminate\Support\Testing\Fakes;
- use Closure;
- use Illuminate\Bus\BatchRepository;
- use Illuminate\Bus\ChainedBatch;
- use Illuminate\Bus\PendingBatch;
- use Illuminate\Contracts\Bus\QueueingDispatcher;
- use Illuminate\Support\Arr;
- use Illuminate\Support\Collection;
- use Illuminate\Support\Traits\ReflectsClosures;
- use PHPUnit\Framework\Assert as PHPUnit;
- use RuntimeException;
- class BusFake implements Fake, QueueingDispatcher
- {
- use ReflectsClosures;
- /**
- * The original Bus dispatcher implementation.
- *
- * @var \Illuminate\Contracts\Bus\QueueingDispatcher
- */
- public $dispatcher;
- /**
- * The job types that should be intercepted instead of dispatched.
- *
- * @var array
- */
- protected $jobsToFake = [];
- /**
- * The job types that should be dispatched instead of faked.
- *
- * @var array
- */
- protected $jobsToDispatch = [];
- /**
- * The fake repository to track batched jobs.
- *
- * @var \Illuminate\Bus\BatchRepository
- */
- protected $batchRepository;
- /**
- * The commands that have been dispatched.
- *
- * @var array
- */
- protected $commands = [];
- /**
- * The commands that have been dispatched synchronously.
- *
- * @var array
- */
- protected $commandsSync = [];
- /**
- * The commands that have been dispatched after the response has been sent.
- *
- * @var array
- */
- protected $commandsAfterResponse = [];
- /**
- * The batches that have been dispatched.
- *
- * @var array
- */
- protected $batches = [];
- /**
- * Indicates if commands should be serialized and restored when pushed to the Bus.
- *
- * @var bool
- */
- protected bool $serializeAndRestore = false;
- /**
- * Create a new bus fake instance.
- *
- * @param \Illuminate\Contracts\Bus\QueueingDispatcher $dispatcher
- * @param array|string $jobsToFake
- * @param \Illuminate\Bus\BatchRepository|null $batchRepository
- * @return void
- */
- public function __construct(QueueingDispatcher $dispatcher, $jobsToFake = [], ?BatchRepository $batchRepository = null)
- {
- $this->dispatcher = $dispatcher;
- $this->jobsToFake = Arr::wrap($jobsToFake);
- $this->batchRepository = $batchRepository ?: new BatchRepositoryFake;
- }
- /**
- * Specify the jobs that should be dispatched instead of faked.
- *
- * @param array|string $jobsToDispatch
- * @return $this
- */
- public function except($jobsToDispatch)
- {
- $this->jobsToDispatch = array_merge($this->jobsToDispatch, Arr::wrap($jobsToDispatch));
- return $this;
- }
- /**
- * Assert if a job was dispatched based on a truth-test callback.
- *
- * @param string|\Closure $command
- * @param callable|int|null $callback
- * @return void
- */
- public function assertDispatched($command, $callback = null)
- {
- if ($command instanceof Closure) {
- [$command, $callback] = [$this->firstClosureParameterType($command), $command];
- }
- if (is_numeric($callback)) {
- return $this->assertDispatchedTimes($command, $callback);
- }
- PHPUnit::assertTrue(
- $this->dispatched($command, $callback)->count() > 0 ||
- $this->dispatchedAfterResponse($command, $callback)->count() > 0 ||
- $this->dispatchedSync($command, $callback)->count() > 0,
- "The expected [{$command}] job was not dispatched."
- );
- }
- /**
- * Assert if a job was pushed a number of times.
- *
- * @param string|\Closure $command
- * @param int $times
- * @return void
- */
- public function assertDispatchedTimes($command, $times = 1)
- {
- $callback = null;
- if ($command instanceof Closure) {
- [$command, $callback] = [$this->firstClosureParameterType($command), $command];
- }
- $count = $this->dispatched($command, $callback)->count() +
- $this->dispatchedAfterResponse($command, $callback)->count() +
- $this->dispatchedSync($command, $callback)->count();
- PHPUnit::assertSame(
- $times, $count,
- "The expected [{$command}] job was pushed {$count} times instead of {$times} times."
- );
- }
- /**
- * Determine if a job was dispatched based on a truth-test callback.
- *
- * @param string|\Closure $command
- * @param callable|null $callback
- * @return void
- */
- public function assertNotDispatched($command, $callback = null)
- {
- if ($command instanceof Closure) {
- [$command, $callback] = [$this->firstClosureParameterType($command), $command];
- }
- PHPUnit::assertTrue(
- $this->dispatched($command, $callback)->count() === 0 &&
- $this->dispatchedAfterResponse($command, $callback)->count() === 0 &&
- $this->dispatchedSync($command, $callback)->count() === 0,
- "The unexpected [{$command}] job was dispatched."
- );
- }
- /**
- * Assert that no jobs were dispatched.
- *
- * @return void
- */
- public function assertNothingDispatched()
- {
- PHPUnit::assertEmpty($this->commands, 'Jobs were dispatched unexpectedly.');
- }
- /**
- * Assert if a job was explicitly dispatched synchronously based on a truth-test callback.
- *
- * @param string|\Closure $command
- * @param callable|int|null $callback
- * @return void
- */
- public function assertDispatchedSync($command, $callback = null)
- {
- if ($command instanceof Closure) {
- [$command, $callback] = [$this->firstClosureParameterType($command), $command];
- }
- if (is_numeric($callback)) {
- return $this->assertDispatchedSyncTimes($command, $callback);
- }
- PHPUnit::assertTrue(
- $this->dispatchedSync($command, $callback)->count() > 0,
- "The expected [{$command}] job was not dispatched synchronously."
- );
- }
- /**
- * Assert if a job was pushed synchronously a number of times.
- *
- * @param string|\Closure $command
- * @param int $times
- * @return void
- */
- public function assertDispatchedSyncTimes($command, $times = 1)
- {
- $callback = null;
- if ($command instanceof Closure) {
- [$command, $callback] = [$this->firstClosureParameterType($command), $command];
- }
- $count = $this->dispatchedSync($command, $callback)->count();
- PHPUnit::assertSame(
- $times, $count,
- "The expected [{$command}] job was synchronously pushed {$count} times instead of {$times} times."
- );
- }
- /**
- * Determine if a job was dispatched based on a truth-test callback.
- *
- * @param string|\Closure $command
- * @param callable|null $callback
- * @return void
- */
- public function assertNotDispatchedSync($command, $callback = null)
- {
- if ($command instanceof Closure) {
- [$command, $callback] = [$this->firstClosureParameterType($command), $command];
- }
- PHPUnit::assertCount(
- 0, $this->dispatchedSync($command, $callback),
- "The unexpected [{$command}] job was dispatched synchronously."
- );
- }
- /**
- * Assert if a job was dispatched after the response was sent based on a truth-test callback.
- *
- * @param string|\Closure $command
- * @param callable|int|null $callback
- * @return void
- */
- public function assertDispatchedAfterResponse($command, $callback = null)
- {
- if ($command instanceof Closure) {
- [$command, $callback] = [$this->firstClosureParameterType($command), $command];
- }
- if (is_numeric($callback)) {
- return $this->assertDispatchedAfterResponseTimes($command, $callback);
- }
- PHPUnit::assertTrue(
- $this->dispatchedAfterResponse($command, $callback)->count() > 0,
- "The expected [{$command}] job was not dispatched after sending the response."
- );
- }
- /**
- * Assert if a job was pushed after the response was sent a number of times.
- *
- * @param string|\Closure $command
- * @param int $times
- * @return void
- */
- public function assertDispatchedAfterResponseTimes($command, $times = 1)
- {
- $callback = null;
- if ($command instanceof Closure) {
- [$command, $callback] = [$this->firstClosureParameterType($command), $command];
- }
- $count = $this->dispatchedAfterResponse($command, $callback)->count();
- PHPUnit::assertSame(
- $times, $count,
- "The expected [{$command}] job was pushed {$count} times instead of {$times} times."
- );
- }
- /**
- * Determine if a job was dispatched based on a truth-test callback.
- *
- * @param string|\Closure $command
- * @param callable|null $callback
- * @return void
- */
- public function assertNotDispatchedAfterResponse($command, $callback = null)
- {
- if ($command instanceof Closure) {
- [$command, $callback] = [$this->firstClosureParameterType($command), $command];
- }
- PHPUnit::assertCount(
- 0, $this->dispatchedAfterResponse($command, $callback),
- "The unexpected [{$command}] job was dispatched after sending the response."
- );
- }
- /**
- * Assert if a chain of jobs was dispatched.
- *
- * @param array $expectedChain
- * @return void
- */
- public function assertChained(array $expectedChain)
- {
- $command = $expectedChain[0];
- $expectedChain = array_slice($expectedChain, 1);
- $callback = null;
- if ($command instanceof Closure) {
- [$command, $callback] = [$this->firstClosureParameterType($command), $command];
- } elseif ($command instanceof ChainedBatchTruthTest) {
- $instance = $command;
- $command = ChainedBatch::class;
- $callback = fn ($job) => $instance($job->toPendingBatch());
- } elseif (! is_string($command)) {
- $instance = $command;
- $command = get_class($instance);
- $callback = function ($job) use ($instance) {
- return serialize($this->resetChainPropertiesToDefaults($job)) === serialize($instance);
- };
- }
- PHPUnit::assertTrue(
- $this->dispatched($command, $callback)->isNotEmpty(),
- "The expected [{$command}] job was not dispatched."
- );
- $this->assertDispatchedWithChainOfObjects($command, $expectedChain, $callback);
- }
- /**
- * Reset the chain properties to their default values on the job.
- *
- * @param mixed $job
- * @return mixed
- */
- protected function resetChainPropertiesToDefaults($job)
- {
- return tap(clone $job, function ($job) {
- $job->chainConnection = null;
- $job->chainQueue = null;
- $job->chainCatchCallbacks = null;
- $job->chained = [];
- });
- }
- /**
- * Assert if a job was dispatched with an empty chain based on a truth-test callback.
- *
- * @param string|\Closure $command
- * @param callable|null $callback
- * @return void
- */
- public function assertDispatchedWithoutChain($command, $callback = null)
- {
- if ($command instanceof Closure) {
- [$command, $callback] = [$this->firstClosureParameterType($command), $command];
- }
- PHPUnit::assertTrue(
- $this->dispatched($command, $callback)->isNotEmpty(),
- "The expected [{$command}] job was not dispatched."
- );
- $this->assertDispatchedWithChainOfObjects($command, [], $callback);
- }
- /**
- * Assert if a job was dispatched with chained jobs based on a truth-test callback.
- *
- * @param string $command
- * @param array $expectedChain
- * @param callable|null $callback
- * @return void
- */
- protected function assertDispatchedWithChainOfObjects($command, $expectedChain, $callback)
- {
- $chain = $expectedChain;
- PHPUnit::assertTrue(
- $this->dispatched($command, $callback)->filter(function ($job) use ($chain) {
- if (count($chain) !== count($job->chained)) {
- return false;
- }
- foreach ($job->chained as $index => $serializedChainedJob) {
- if ($chain[$index] instanceof ChainedBatchTruthTest) {
- $chainedBatch = unserialize($serializedChainedJob);
- if (! $chainedBatch instanceof ChainedBatch ||
- ! $chain[$index]($chainedBatch->toPendingBatch())) {
- return false;
- }
- } elseif ($chain[$index] instanceof Closure) {
- [$expectedType, $callback] = [$this->firstClosureParameterType($chain[$index]), $chain[$index]];
- $chainedJob = unserialize($serializedChainedJob);
- if (! $chainedJob instanceof $expectedType) {
- throw new RuntimeException('The chained job was expected to be of type '.$expectedType.', '.$chainedJob::class.' chained.');
- }
- if (! $callback($chainedJob)) {
- return false;
- }
- } elseif (is_string($chain[$index])) {
- if ($chain[$index] != get_class(unserialize($serializedChainedJob))) {
- return false;
- }
- } elseif (serialize($chain[$index]) != $serializedChainedJob) {
- return false;
- }
- }
- return true;
- })->isNotEmpty(),
- 'The expected chain was not dispatched.'
- );
- }
- /**
- * Create a new assertion about a chained batch.
- *
- * @param \Closure $callback
- * @return \Illuminate\Support\Testing\Fakes\ChainedBatchTruthTest
- */
- public function chainedBatch(Closure $callback)
- {
- return new ChainedBatchTruthTest($callback);
- }
- /**
- * Assert if a batch was dispatched based on a truth-test callback.
- *
- * @param callable $callback
- * @return void
- */
- public function assertBatched(callable $callback)
- {
- PHPUnit::assertTrue(
- $this->batched($callback)->count() > 0,
- 'The expected batch was not dispatched.'
- );
- }
- /**
- * Assert the number of batches that have been dispatched.
- *
- * @param int $count
- * @return void
- */
- public function assertBatchCount($count)
- {
- PHPUnit::assertCount(
- $count, $this->batches,
- );
- }
- /**
- * Assert that no batched jobs were dispatched.
- *
- * @return void
- */
- public function assertNothingBatched()
- {
- PHPUnit::assertEmpty($this->batches, 'Batched jobs were dispatched unexpectedly.');
- }
- /**
- * Get all of the jobs matching a truth-test callback.
- *
- * @param string $command
- * @param callable|null $callback
- * @return \Illuminate\Support\Collection
- */
- public function dispatched($command, $callback = null)
- {
- if (! $this->hasDispatched($command)) {
- return collect();
- }
- $callback = $callback ?: fn () => true;
- return collect($this->commands[$command])->filter(fn ($command) => $callback($command));
- }
- /**
- * Get all of the jobs dispatched synchronously matching a truth-test callback.
- *
- * @param string $command
- * @param callable|null $callback
- * @return \Illuminate\Support\Collection
- */
- public function dispatchedSync(string $command, $callback = null)
- {
- if (! $this->hasDispatchedSync($command)) {
- return collect();
- }
- $callback = $callback ?: fn () => true;
- return collect($this->commandsSync[$command])->filter(fn ($command) => $callback($command));
- }
- /**
- * Get all of the jobs dispatched after the response was sent matching a truth-test callback.
- *
- * @param string $command
- * @param callable|null $callback
- * @return \Illuminate\Support\Collection
- */
- public function dispatchedAfterResponse(string $command, $callback = null)
- {
- if (! $this->hasDispatchedAfterResponse($command)) {
- return collect();
- }
- $callback = $callback ?: fn () => true;
- return collect($this->commandsAfterResponse[$command])->filter(fn ($command) => $callback($command));
- }
- /**
- * Get all of the pending batches matching a truth-test callback.
- *
- * @param callable $callback
- * @return \Illuminate\Support\Collection
- */
- public function batched(callable $callback)
- {
- if (empty($this->batches)) {
- return collect();
- }
- return collect($this->batches)->filter(fn ($batch) => $callback($batch));
- }
- /**
- * Determine if there are any stored commands for a given class.
- *
- * @param string $command
- * @return bool
- */
- public function hasDispatched($command)
- {
- return isset($this->commands[$command]) && ! empty($this->commands[$command]);
- }
- /**
- * Determine if there are any stored commands for a given class.
- *
- * @param string $command
- * @return bool
- */
- public function hasDispatchedSync($command)
- {
- return isset($this->commandsSync[$command]) && ! empty($this->commandsSync[$command]);
- }
- /**
- * Determine if there are any stored commands for a given class.
- *
- * @param string $command
- * @return bool
- */
- public function hasDispatchedAfterResponse($command)
- {
- return isset($this->commandsAfterResponse[$command]) && ! empty($this->commandsAfterResponse[$command]);
- }
- /**
- * Dispatch a command to its appropriate handler.
- *
- * @param mixed $command
- * @return mixed
- */
- public function dispatch($command)
- {
- if ($this->shouldFakeJob($command)) {
- $this->commands[get_class($command)][] = $this->getCommandRepresentation($command);
- } else {
- return $this->dispatcher->dispatch($command);
- }
- }
- /**
- * Dispatch a command to its appropriate handler in the current process.
- *
- * Queueable jobs will be dispatched to the "sync" queue.
- *
- * @param mixed $command
- * @param mixed $handler
- * @return mixed
- */
- public function dispatchSync($command, $handler = null)
- {
- if ($this->shouldFakeJob($command)) {
- $this->commandsSync[get_class($command)][] = $this->getCommandRepresentation($command);
- } else {
- return $this->dispatcher->dispatchSync($command, $handler);
- }
- }
- /**
- * Dispatch a command to its appropriate handler in the current process.
- *
- * @param mixed $command
- * @param mixed $handler
- * @return mixed
- */
- public function dispatchNow($command, $handler = null)
- {
- if ($this->shouldFakeJob($command)) {
- $this->commands[get_class($command)][] = $this->getCommandRepresentation($command);
- } else {
- return $this->dispatcher->dispatchNow($command, $handler);
- }
- }
- /**
- * Dispatch a command to its appropriate handler behind a queue.
- *
- * @param mixed $command
- * @return mixed
- */
- public function dispatchToQueue($command)
- {
- if ($this->shouldFakeJob($command)) {
- $this->commands[get_class($command)][] = $this->getCommandRepresentation($command);
- } else {
- return $this->dispatcher->dispatchToQueue($command);
- }
- }
- /**
- * Dispatch a command to its appropriate handler.
- *
- * @param mixed $command
- * @return mixed
- */
- public function dispatchAfterResponse($command)
- {
- if ($this->shouldFakeJob($command)) {
- $this->commandsAfterResponse[get_class($command)][] = $this->getCommandRepresentation($command);
- } else {
- return $this->dispatcher->dispatch($command);
- }
- }
- /**
- * Create a new chain of queueable jobs.
- *
- * @param \Illuminate\Support\Collection|array $jobs
- * @return \Illuminate\Foundation\Bus\PendingChain
- */
- public function chain($jobs)
- {
- $jobs = Collection::wrap($jobs);
- $jobs = ChainedBatch::prepareNestedBatches($jobs);
- return new PendingChainFake($this, $jobs->shift(), $jobs->toArray());
- }
- /**
- * Attempt to find the batch with the given ID.
- *
- * @param string $batchId
- * @return \Illuminate\Bus\Batch|null
- */
- public function findBatch(string $batchId)
- {
- return $this->batchRepository->find($batchId);
- }
- /**
- * Create a new batch of queueable jobs.
- *
- * @param \Illuminate\Support\Collection|array $jobs
- * @return \Illuminate\Bus\PendingBatch
- */
- public function batch($jobs)
- {
- return new PendingBatchFake($this, Collection::wrap($jobs));
- }
- /**
- * Dispatch an empty job batch for testing.
- *
- * @param string $name
- * @return \Illuminate\Bus\Batch
- */
- public function dispatchFakeBatch($name = '')
- {
- return $this->batch([])->name($name)->dispatch();
- }
- /**
- * Record the fake pending batch dispatch.
- *
- * @param \Illuminate\Bus\PendingBatch $pendingBatch
- * @return \Illuminate\Bus\Batch
- */
- public function recordPendingBatch(PendingBatch $pendingBatch)
- {
- $this->batches[] = $pendingBatch;
- return $this->batchRepository->store($pendingBatch);
- }
- /**
- * Determine if a command should be faked or actually dispatched.
- *
- * @param mixed $command
- * @return bool
- */
- protected function shouldFakeJob($command)
- {
- if ($this->shouldDispatchCommand($command)) {
- return false;
- }
- if (empty($this->jobsToFake)) {
- return true;
- }
- return collect($this->jobsToFake)
- ->filter(function ($job) use ($command) {
- return $job instanceof Closure
- ? $job($command)
- : $job === get_class($command);
- })->isNotEmpty();
- }
- /**
- * Determine if a command should be dispatched or not.
- *
- * @param mixed $command
- * @return bool
- */
- protected function shouldDispatchCommand($command)
- {
- return collect($this->jobsToDispatch)
- ->filter(function ($job) use ($command) {
- return $job instanceof Closure
- ? $job($command)
- : $job === get_class($command);
- })->isNotEmpty();
- }
- /**
- * Specify if commands should be serialized and restored when being batched.
- *
- * @param bool $serializeAndRestore
- * @return $this
- */
- public function serializeAndRestore(bool $serializeAndRestore = true)
- {
- $this->serializeAndRestore = $serializeAndRestore;
- return $this;
- }
- /**
- * Serialize and unserialize the command to simulate the queueing process.
- *
- * @param mixed $command
- * @return mixed
- */
- protected function serializeAndRestoreCommand($command)
- {
- return unserialize(serialize($command));
- }
- /**
- * Return the command representation that should be stored.
- *
- * @param mixed $command
- * @return mixed
- */
- protected function getCommandRepresentation($command)
- {
- return $this->serializeAndRestore ? $this->serializeAndRestoreCommand($command) : $command;
- }
- /**
- * Set the pipes commands should be piped through before dispatching.
- *
- * @param array $pipes
- * @return $this
- */
- public function pipeThrough(array $pipes)
- {
- $this->dispatcher->pipeThrough($pipes);
- return $this;
- }
- /**
- * Determine if the given command has a handler.
- *
- * @param mixed $command
- * @return bool
- */
- public function hasCommandHandler($command)
- {
- return $this->dispatcher->hasCommandHandler($command);
- }
- /**
- * Retrieve the handler for a command.
- *
- * @param mixed $command
- * @return mixed
- */
- public function getCommandHandler($command)
- {
- return $this->dispatcher->getCommandHandler($command);
- }
- /**
- * Map a command to a handler.
- *
- * @param array $map
- * @return $this
- */
- public function map(array $map)
- {
- $this->dispatcher->map($map);
- return $this;
- }
- }
|