Skip to content

Commit

Permalink
Fixed typos
Browse files Browse the repository at this point in the history
  • Loading branch information
pborreli committed Mar 23, 2018
1 parent 8ca5144 commit 3561c36
Show file tree
Hide file tree
Showing 35 changed files with 51 additions and 51 deletions.
2 changes: 1 addition & 1 deletion docker-compose.yml
Original file line number Diff line number Diff line change
Expand Up @@ -18,7 +18,7 @@ services:
environment:
- AMQP_DSN=amqp://guest:guest@rabbitmq:5672/mqdev
- AMQPS_DSN=amqps://guest:guest@rabbitmqssl:5671
- DOCTINE_DSN=mysql://root:rootpass@mysql/mqdev
- DOCTRINE_DSN=mysql://root:rootpass@mysql/mqdev
- RABBITMQ_HOST=rabbitmq
- RABBITMQ_USER=guest
- RABBITMQ_PASSWORD=guest
Expand Down
File renamed without changes.
2 changes: 1 addition & 1 deletion docs/bundle/functional_testing.md
Original file line number Diff line number Diff line change
Expand Up @@ -7,7 +7,7 @@ In this chapter we give some advices on how to test message queue related logic.

## NULL transport

While testing the application you dont usually need to send real message to real broker.
While testing the application you don't usually need to send real message to real broker.
Or even have a dependency on a MQ broker.
Here's the purpose of the NULL transport.
It simple do nothing when you ask it to send a message.
Expand Down
2 changes: 1 addition & 1 deletion docs/bundle/job_queue.md
Original file line number Diff line number Diff line change
Expand Up @@ -75,7 +75,7 @@ $ bin/console doctrine:schema:update

Guarantee that there is only one job with such name running at a time.
For example you have a task that builds a search index.
It takes quite a lot of time and you dont want another instance of same task working at the same time.
It takes quite a lot of time and you don't want another instance of same task working at the same time.
Here's how to do it:

* Write a job processor class:
Expand Down
2 changes: 1 addition & 1 deletion docs/client/message_examples.md
Original file line number Diff line number Diff line change
Expand Up @@ -82,7 +82,7 @@ $producer->sendEvent('aTopic', $message);
## Timestamp, Content type, Message id

Those are self describing things.
Usually they are set by Client so you dont have to worry about them.
Usually they are set by Client so you don't have to worry about them.
If you do not like what Client set you can always set custom values:

```php
Expand Down
2 changes: 1 addition & 1 deletion docs/client/supported_brokers.md
Original file line number Diff line number Diff line change
Expand Up @@ -31,6 +31,6 @@ Here's the list of protocols and Client features supported by them

* \* Possible if a RabbitMQ delay plugin is installed.
* \*\* Possible if topics (exchanges) are configured on broker side manually.
* \*\*\* Possible if RabbitMQ Managment Plugin is installed.
* \*\*\* Possible if RabbitMQ Management Plugin is installed.

[back to index](../index.md)
2 changes: 1 addition & 1 deletion docs/consumption/message_processor.md
Original file line number Diff line number Diff line change
Expand Up @@ -113,7 +113,7 @@ class SendMailProcessor implements PsrProcessor

The consumption component provide some useful extensions, for example there is an extension that makes RPC processing simpler.
The producer might wait for a reply from a consumer and in order to send it a processor has to return a reply result.
Dont forget to add `ReplyExtension`.
Don't forget to add `ReplyExtension`.

```php
<?php
Expand Down
2 changes: 1 addition & 1 deletion docs/contribution.md
Original file line number Diff line number Diff line change
Expand Up @@ -23,7 +23,7 @@ To run tests simply run

## Commit

When you try to commit changes `php-cs-fixer` is run. It fixes all coding style issues. Dont forget to stage them and commit everything.
When you try to commit changes `php-cs-fixer` is run. It fixes all coding style issues. Don't forget to stage them and commit everything.
Once everything is done open a pull request on official repository.

[back to index](index.md)
2 changes: 1 addition & 1 deletion docs/index.md
Original file line number Diff line number Diff line change
Expand Up @@ -36,7 +36,7 @@
- [Job queue](bundle/job_queue.md)
- [Consumption extension](bundle/consumption_extension.md)
- [Production settings](bundle/production_settings.md)
- [Debuging](bundle/debuging.md)
- [Debugging](bundle/debugging.md)
- [Functional testing](bundle/functional_testing.md)
* [Laravel](#laravel)
- [Quick tour](laravel/quick_tour.md)
Expand Down
2 changes: 1 addition & 1 deletion docs/laravel/queues.md
Original file line number Diff line number Diff line change
Expand Up @@ -52,7 +52,7 @@ $ php artisan queue:work interop

While interop connector can send\consume messages from any queue interop compatible transports.
But it does not support some AMQP specific features, such as queue declaration and delays.
To cover those cases the package provides a AmqpQueue. It can work with any amqp interop [compatible trnasport](https://github.com/queue-interop/queue-interop#compatible-projects-1), for example `enqueue/amqp-bunny`.
To cover those cases the package provides a AmqpQueue. It can work with any amqp interop [compatible transport](https://github.com/queue-interop/queue-interop#compatible-projects-1), for example `enqueue/amqp-bunny`.
Here's how it could be configured:

```php
Expand Down
6 changes: 3 additions & 3 deletions docs/quick_tour.md
Original file line number Diff line number Diff line change
Expand Up @@ -74,12 +74,12 @@ use Enqueue\Consumption\QueueConsumer;
$queueConsumer = new QueueConsumer($psrContext);

$queueConsumer->bind('foo_queue', function(PsrMessage $message) {
// process messsage
// process message

return PsrProcessor::ACK;
});
$queueConsumer->bind('bar_queue', function(PsrMessage $message) {
// process messsage
// process message

return PsrProcessor::ACK;
});
Expand Down Expand Up @@ -158,7 +158,7 @@ $queueConsumer->consume();

It provides an easy to use high level abstraction.
The goal of the component is hide as much as possible low level details so you can concentrate on things that really matters.
For example, It configure a broker for you by creating queuest, exchanges and bind them.
For example, It configure a broker for you by creating queues, exchanges and bind them.
It provides easy to use services for producing and processing messages.
It supports unified format for setting message expiration, delay, timestamp, correlation id.
It supports [message bus](http://www.enterpriseintegrationpatterns.com/patterns/messaging/MessageBus.html) so different applications can talk to each other.
Expand Down
2 changes: 1 addition & 1 deletion docs/transport/amqp.md
Original file line number Diff line number Diff line change
Expand Up @@ -181,7 +181,7 @@ $psrContext->createProducer()
## Send delayed message

AMQP specification says nothing about message delaying hence the producer throws `DeliveryDelayNotSupportedException`.
Though the producer (and the context) accepts a delivry delay strategy and if it is set it uses it to send delayed message.
Though the producer (and the context) accepts a delivery delay strategy and if it is set it uses it to send delayed message.
The `enqueue/amqp-tools` package provides two RabbitMQ delay strategies, to use them you have to install that package

```php
Expand Down
2 changes: 1 addition & 1 deletion docs/transport/amqp_bunny.md
Original file line number Diff line number Diff line change
Expand Up @@ -171,7 +171,7 @@ $psrContext->createProducer()
## Send delayed message

AMQP specification says nothing about message delaying hence the producer throws `DeliveryDelayNotSupportedException`.
Though the producer (and the context) accepts a delivry delay strategy and if it is set it uses it to send delayed message.
Though the producer (and the context) accepts a delivery delay strategy and if it is set it uses it to send delayed message.
The `enqueue/amqp-tools` package provides two RabbitMQ delay strategies, to use them you have to install that package

```php
Expand Down
2 changes: 1 addition & 1 deletion docs/transport/amqp_lib.md
Original file line number Diff line number Diff line change
Expand Up @@ -179,7 +179,7 @@ $psrContext->createProducer()
## Send delayed message

AMQP specification says nothing about message delaying hence the producer throws `DeliveryDelayNotSupportedException`.
Though the producer (and the context) accepts a delivry delay strategy and if it is set it uses it to send delayed message.
Though the producer (and the context) accepts a delivery delay strategy and if it is set it uses it to send delayed message.
The `enqueue/amqp-tools` package provides two RabbitMQ delay strategies, to use them you have to install that package

```php
Expand Down
2 changes: 1 addition & 1 deletion docs/transport/kafka.md
Original file line number Diff line number Diff line change
Expand Up @@ -8,7 +8,7 @@ The transport uses [Kafka](https://kafka.apache.org/) streaming platform as a MQ
* [Send message to queue](#send-message-to-queue)
* [Consume message](#consume-message)
* [Serialize message](#serialize-message)
* [Chnage offset](#change-offset)
* [Change offset](#change-offset)

## Installation

Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -8,7 +8,7 @@
/**
* @group functional
*/
class AmqpSendAndReceiveTimestampAsIntengerTest extends SendAndReceiveTimestampAsIntegerSpec
class AmqpSendAndReceiveTimestampAsIntegerTest extends SendAndReceiveTimestampAsIntegerSpec
{
/**
* {@inheritdoc}
Expand Down
4 changes: 2 additions & 2 deletions pkg/amqp-ext/Tests/Functional/AmqpCommonUseCasesTest.php
Original file line number Diff line number Diff line change
Expand Up @@ -4,7 +4,7 @@

use Enqueue\AmqpExt\AmqpContext;
use Enqueue\Test\RabbitmqAmqpExtension;
use Enqueue\Test\RabbitmqManagmentExtensionTrait;
use Enqueue\Test\RabbitManagementExtensionTrait;
use Interop\Amqp\Impl\AmqpBind;
use Interop\Amqp\Impl\AmqpMessage;
use PHPUnit\Framework\TestCase;
Expand All @@ -15,7 +15,7 @@
class AmqpCommonUseCasesTest extends TestCase
{
use RabbitmqAmqpExtension;
use RabbitmqManagmentExtensionTrait;
use RabbitManagementExtensionTrait;

/**
* @var AmqpContext
Expand Down
4 changes: 2 additions & 2 deletions pkg/amqp-ext/Tests/Functional/AmqpConsumptionUseCasesTest.php
Original file line number Diff line number Diff line change
Expand Up @@ -10,7 +10,7 @@
use Enqueue\Consumption\QueueConsumer;
use Enqueue\Consumption\Result;
use Enqueue\Test\RabbitmqAmqpExtension;
use Enqueue\Test\RabbitmqManagmentExtensionTrait;
use Enqueue\Test\RabbitManagementExtensionTrait;
use Interop\Queue\PsrContext;
use Interop\Queue\PsrMessage;
use Interop\Queue\PsrProcessor;
Expand All @@ -22,7 +22,7 @@
class AmqpConsumptionUseCasesTest extends TestCase
{
use RabbitmqAmqpExtension;
use RabbitmqManagmentExtensionTrait;
use RabbitManagementExtensionTrait;

/**
* @var AmqpContext
Expand Down
4 changes: 2 additions & 2 deletions pkg/amqp-ext/Tests/Functional/AmqpRpcUseCasesTest.php
Original file line number Diff line number Diff line change
Expand Up @@ -6,7 +6,7 @@
use Enqueue\Rpc\Promise;
use Enqueue\Rpc\RpcClient;
use Enqueue\Test\RabbitmqAmqpExtension;
use Enqueue\Test\RabbitmqManagmentExtensionTrait;
use Enqueue\Test\RabbitManagementExtensionTrait;
use Interop\Amqp\Impl\AmqpMessage;
use PHPUnit\Framework\TestCase;

Expand All @@ -16,7 +16,7 @@
class AmqpRpcUseCasesTest extends TestCase
{
use RabbitmqAmqpExtension;
use RabbitmqManagmentExtensionTrait;
use RabbitManagementExtensionTrait;

/**
* @var AmqpContext
Expand Down
10 changes: 5 additions & 5 deletions pkg/async-event-dispatcher/Tests/ProxyEventDispatcherTest.php
Original file line number Diff line number Diff line change
Expand Up @@ -20,7 +20,7 @@ public function testShouldBeSubClassOfEventDispatcher()

public function testShouldSetSyncModeForGivenEventNameOnDispatchAsyncListenersOnly()
{
$asyncListenerMock = $this->createAsyncLisenerMock();
$asyncListenerMock = $this->createAsyncListenerMock();
$asyncListenerMock
->expects($this->once())
->method('resetSyncMode')
Expand Down Expand Up @@ -49,7 +49,7 @@ public function testShouldCallAsyncEventButNotOtherOnDispatchAsyncListenersOnly(
});

$asyncEventWasCalled = false;
$dispatcher = new AsyncEventDispatcher($trueEventDispatcher, $this->createAsyncLisenerMock());
$dispatcher = new AsyncEventDispatcher($trueEventDispatcher, $this->createAsyncListenerMock());
$dispatcher->addListener('theEvent', function () use (&$asyncEventWasCalled) {
$this->assertInstanceOf(AsyncEventDispatcher::class, func_get_arg(2));

Expand All @@ -74,7 +74,7 @@ public function testShouldCallOtherEventIfDispatchedFromAsyncEventOnDispatchAsyn
});

$asyncEventWasCalled = false;
$dispatcher = new AsyncEventDispatcher($trueEventDispatcher, $this->createAsyncLisenerMock());
$dispatcher = new AsyncEventDispatcher($trueEventDispatcher, $this->createAsyncListenerMock());
$dispatcher->addListener('theEvent', function () use (&$asyncEventWasCalled) {
$this->assertInstanceOf(AsyncEventDispatcher::class, func_get_arg(2));

Expand All @@ -97,7 +97,7 @@ public function testShouldNotCallAsyncEventIfDispatchedFromOtherEventOnDispatchA
func_get_arg(2)->dispatch('theOtherAsyncEvent');
});

$dispatcher = new AsyncEventDispatcher($trueEventDispatcher, $this->createAsyncLisenerMock());
$dispatcher = new AsyncEventDispatcher($trueEventDispatcher, $this->createAsyncListenerMock());
$dispatcher->addListener('theAsyncEvent', function () {
func_get_arg(2)->dispatch('theOtherEvent');
});
Expand All @@ -115,7 +115,7 @@ public function testShouldNotCallAsyncEventIfDispatchedFromOtherEventOnDispatchA
/**
* @return \PHPUnit_Framework_MockObject_MockObject|AsyncListener
*/
private function createAsyncLisenerMock()
private function createAsyncListenerMock()
{
return $this->createMock(AsyncListener::class);
}
Expand Down
2 changes: 1 addition & 1 deletion pkg/dbal/Tests/DbalContextTest.php
Original file line number Diff line number Diff line change
Expand Up @@ -135,7 +135,7 @@ public function testShouldReturnConfig()
$this->assertSame($connection, $context->getDbalConnection());
}

public function testShouldThrowBadMethodCallExceptiOnOncreateTemporaryQueueCall()
public function testShouldThrowBadMethodCallExceptionOncreateTemporaryQueueCall()
{
$context = new DbalContext($connection = $this->createConnectionMock());

Expand Down
2 changes: 1 addition & 1 deletion pkg/dbal/Tests/Spec/CreateDbalContextTrait.php
Original file line number Diff line number Diff line change
Expand Up @@ -8,7 +8,7 @@ trait CreateDbalContextTrait
{
protected function createDbalContext()
{
if (false == $env = getenv('DOCTINE_DSN')) {
if (false == $env = getenv('DOCTRINE_DSN')) {
$this->markTestSkipped('The DOCTRINE_DSN env is not available. Skip tests');
}

Expand Down
6 changes: 3 additions & 3 deletions pkg/enqueue-bundle/EnqueueBundle.php
Original file line number Diff line number Diff line change
Expand Up @@ -69,9 +69,9 @@ class_exists(AmqpLibConnectionFactory::class)
$extension->setTransportFactory(new AmqpTransportFactory('amqp'));
$extension->setTransportFactory(new RabbitMqAmqpTransportFactory('rabbitmq_amqp'));
} else {
$amppPackages = ['enqueue/amqp-ext', 'enqueue/amqp-bunny', 'enqueue/amqp-lib'];
$extension->setTransportFactory(new MissingTransportFactory('amqp', $amppPackages));
$extension->setTransportFactory(new MissingTransportFactory('rabbitmq_amqp', $amppPackages));
$amqpPackages = ['enqueue/amqp-ext', 'enqueue/amqp-bunny', 'enqueue/amqp-lib'];
$extension->setTransportFactory(new MissingTransportFactory('amqp', $amqpPackages));
$extension->setTransportFactory(new MissingTransportFactory('rabbitmq_amqp', $amqpPackages));
}

if (class_exists(FsConnectionFactory::class)) {
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -28,7 +28,7 @@ class CustomAppKernel extends Kernel
public function setEnqueueConfig(array $config)
{
$this->enqueueConfig = array_replace_recursive($this->enqueueConfig, $config);
$this->enqueueConfig['client']['app_name'] = str_replace('.', '', uniqid(true));
$this->enqueueConfig['client']['app_name'] = str_replace('.', '', uniqid('app_name', true));
$this->enqueueConfigId = md5(json_encode($this->enqueueConfig));

$fs = new Filesystem();
Expand Down
4 changes: 2 additions & 2 deletions pkg/enqueue-bundle/Tests/Functional/UseCasesTest.php
Original file line number Diff line number Diff line change
Expand Up @@ -104,7 +104,7 @@ public function provideEnqueueConfigs()

yield 'default_dbal_as_dsn' => [[
'transport' => [
'default' => getenv('DOCTINE_DSN'),
'default' => getenv('DOCTRINE_DSN'),
],
]];

Expand Down Expand Up @@ -188,7 +188,7 @@ public function provideEnqueueConfigs()
yield 'dbal_dsn' => [[
'transport' => [
'default' => 'dbal',
'dbal' => getenv('DOCTINE_DSN'),
'dbal' => getenv('DOCTRINE_DSN'),
],
]];

Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -24,7 +24,7 @@ public function testCouldBeConstructedWithoutAnyArguments()
new BuildClientExtensionsPass();
}

public function testShouldReplaceFirstArgumentOfExtensionsServiceConstructorWithTaggsExtensions()
public function testShouldReplaceFirstArgumentOfExtensionsServiceConstructorWithTagsExtensions()
{
$container = new ContainerBuilder();

Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -24,7 +24,7 @@ public function testCouldBeConstructedWithoutAnyArguments()
new BuildConsumptionExtensionsPass();
}

public function testShouldReplaceFirstArgumentOfExtensionsServiceConstructorWithTaggsExtensions()
public function testShouldReplaceFirstArgumentOfExtensionsServiceConstructorWithTagsExtensions()
{
$container = new ContainerBuilder();

Expand Down
4 changes: 2 additions & 2 deletions pkg/enqueue/Tests/Rpc/PromiseTest.php
Original file line number Diff line number Diff line change
Expand Up @@ -31,10 +31,10 @@ public function testOnReceiveShouldCallReceiveCallBack()
$receiveInvoked = false;
$receivePromise = null;
$receiveTimeout = null;
$receivecb = function ($promise, $timout) use (&$receiveInvoked, &$receivePromise, &$receiveTimeout) {
$receivecb = function ($promise, $timeout) use (&$receiveInvoked, &$receivePromise, &$receiveTimeout) {
$receiveInvoked = true;
$receivePromise = $promise;
$receiveTimeout = $timout;
$receiveTimeout = $timeout;
};

$promise = new Promise($receivecb, function () {}, function () {});
Expand Down
2 changes: 1 addition & 1 deletion pkg/null/Tests/NullContextTest.php
Original file line number Diff line number Diff line change
Expand Up @@ -90,7 +90,7 @@ public function testShouldAllowCreateProducer()
$this->assertInstanceOf(NullProducer::class, $producer);
}

public function testShouldCreateTempraryQueueWithUnqiueName()
public function testShouldCreateTemporaryQueueWithUniqueName()
{
$context = new NullContext();

Expand Down
4 changes: 2 additions & 2 deletions pkg/simple-client/Tests/Functional/SimpleClientTest.php
Original file line number Diff line number Diff line change
Expand Up @@ -8,7 +8,7 @@
use Enqueue\Consumption\Result;
use Enqueue\SimpleClient\SimpleClient;
use Enqueue\Test\RabbitmqAmqpExtension;
use Enqueue\Test\RabbitmqManagmentExtensionTrait;
use Enqueue\Test\RabbitManagementExtensionTrait;
use Interop\Queue\PsrMessage;
use PHPUnit\Framework\TestCase;

Expand All @@ -18,7 +18,7 @@
class SimpleClientTest extends TestCase
{
use RabbitmqAmqpExtension;
use RabbitmqManagmentExtensionTrait;
use RabbitManagementExtensionTrait;

public function setUp()
{
Expand Down
2 changes: 1 addition & 1 deletion pkg/stomp/Tests/Client/StompDriverTest.php
Original file line number Diff line number Diff line change
Expand Up @@ -277,7 +277,7 @@ public function testShouldThrowExceptionIfProcessorQueueNameParameterIsNotSet()
$driver->sendToProcessor($message);
}

public function testSetupBrokerShouldOnlyLogMessageThatStompDoesNotSupprtBrokerSetup()
public function testSetupBrokerShouldOnlyLogMessageThatStompDoesNotSupportBrokerSetup()
{
$driver = new StompDriver(
$this->createPsrContextMock(),
Expand Down
4 changes: 2 additions & 2 deletions pkg/stomp/Tests/Functional/StompCommonUseCasesTest.php
Original file line number Diff line number Diff line change
Expand Up @@ -4,7 +4,7 @@

use Enqueue\Stomp\StompContext;
use Enqueue\Stomp\StompMessage;
use Enqueue\Test\RabbitmqManagmentExtensionTrait;
use Enqueue\Test\RabbitManagementExtensionTrait;
use Enqueue\Test\RabbitmqStompExtension;

/**
Expand All @@ -13,7 +13,7 @@
class StompCommonUseCasesTest extends \PHPUnit\Framework\TestCase
{
use RabbitmqStompExtension;
use RabbitmqManagmentExtensionTrait;
use RabbitManagementExtensionTrait;

/**
* @var StompContext
Expand Down
Loading

0 comments on commit 3561c36

Please sign in to comment.