You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@airavata.apache.org by sm...@apache.org on 2015/05/03 14:40:02 UTC

[22/51] [partial] airavata-php-gateway git commit: removing vendor files

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/CHANGELOG.mdown
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/CHANGELOG.mdown b/vendor/monolog/monolog/CHANGELOG.mdown
deleted file mode 100644
index cf8db7b..0000000
--- a/vendor/monolog/monolog/CHANGELOG.mdown
+++ /dev/null
@@ -1,217 +0,0 @@
-### 1.13.1 (2015-03-09)
-
-  * Fixed regression in HipChat requiring a new token to be created
-
-### 1.13.0 (2015-03-05)
-
-  * Added Registry::hasLogger to check for the presence of a logger instance
-  * Added context.user support to RavenHandler
-  * Added HipChat API v2 support in the HipChatHandler
-  * Added NativeMailerHandler::addParameter to pass params to the mail() process
-  * Added context data to SlackHandler when $includeContextAndExtra is true
-  * Added ability to customize the Swift_Message per-email in SwiftMailerHandler
-  * Fixed SwiftMailerHandler to lazily create message instances if a callback is provided
-  * Fixed serialization of INF and NaN values in Normalizer and LineFormatter
-
-### 1.12.0 (2014-12-29)
-
-  * Break: HandlerInterface::isHandling now receives a partial record containing only a level key. This was always the intent and does not break any Monolog handler but is strictly speaking a BC break and you should check if you relied on any other field in your own handlers.
-  * Added PsrHandler to forward records to another PSR-3 logger
-  * Added SamplingHandler to wrap around a handler and include only every Nth record
-  * Added MongoDBFormatter to support better storage with MongoDBHandler (it must be enabled manually for now)
-  * Added exception codes in the output of most formatters
-  * Added LineFormatter::includeStacktraces to enable exception stack traces in logs (uses more than one line)
-  * Added $useShortAttachment to SlackHandler to minify attachment size and $includeExtra to append extra data
-  * Added $host to HipChatHandler for users of private instances
-  * Added $transactionName to NewRelicHandler and support for a transaction_name context value
-  * Fixed MandrillHandler to avoid outputing API call responses
-  * Fixed some non-standard behaviors in SyslogUdpHandler
-
-### 1.11.0 (2014-09-30)
-
-  * Break: The NewRelicHandler extra and context data are now prefixed with extra_ and context_ to avoid clashes. Watch out if you have scripts reading those from the API and rely on names
-  * Added WhatFailureGroupHandler to suppress any exception coming from the wrapped handlers and avoid chain failures if a logging service fails
-  * Added MandrillHandler to send emails via the Mandrillapp.com API
-  * Added SlackHandler to log records to a Slack.com account
-  * Added FleepHookHandler to log records to a Fleep.io account
-  * Added LogglyHandler::addTag to allow adding tags to an existing handler
-  * Added $ignoreEmptyContextAndExtra to LineFormatter to avoid empty [] at the end
-  * Added $useLocking to StreamHandler and RotatingFileHandler to enable flock() while writing
-  * Added support for PhpAmqpLib in the AmqpHandler
-  * Added FingersCrossedHandler::clear and BufferHandler::clear to reset them between batches in long running jobs
-  * Added support for adding extra fields from $_SERVER in the WebProcessor
-  * Fixed support for non-string values in PrsLogMessageProcessor
-  * Fixed SwiftMailer messages being sent with the wrong date in long running scripts
-  * Fixed minor PHP 5.6 compatibility issues
-  * Fixed BufferHandler::close being called twice
-
-### 1.10.0 (2014-06-04)
-
-  * Added Logger::getHandlers() and Logger::getProcessors() methods
-  * Added $passthruLevel argument to FingersCrossedHandler to let it always pass some records through even if the trigger level is not reached
-  * Added support for extra data in NewRelicHandler
-  * Added $expandNewlines flag to the ErrorLogHandler to create multiple log entries when a message has multiple lines
-
-### 1.9.1 (2014-04-24)
-
-  * Fixed regression in RotatingFileHandler file permissions
-  * Fixed initialization of the BufferHandler to make sure it gets flushed after receiving records
-  * Fixed ChromePHPHandler and FirePHPHandler's activation strategies to be more conservative
-
-### 1.9.0 (2014-04-20)
-
-  * Added LogEntriesHandler to send logs to a LogEntries account
-  * Added $filePermissions to tweak file mode on StreamHandler and RotatingFileHandler
-  * Added $useFormatting flag to MemoryProcessor to make it send raw data in bytes
-  * Added support for table formatting in FirePHPHandler via the table context key
-  * Added a TagProcessor to add tags to records, and support for tags in RavenHandler
-  * Added $appendNewline flag to the JsonFormatter to enable using it when logging to files
-  * Added sound support to the PushoverHandler
-  * Fixed multi-threading support in StreamHandler
-  * Fixed empty headers issue when ChromePHPHandler received no records
-  * Fixed default format of the ErrorLogHandler
-
-### 1.8.0 (2014-03-23)
-
-  * Break: the LineFormatter now strips newlines by default because this was a bug, set $allowInlineLineBreaks to true if you need them
-  * Added BrowserConsoleHandler to send logs to any browser's console via console.log() injection in the output
-  * Added FilterHandler to filter records and only allow those of a given list of levels through to the wrapped handler
-  * Added FlowdockHandler to send logs to a Flowdock account
-  * Added RollbarHandler to send logs to a Rollbar account
-  * Added HtmlFormatter to send prettier log emails with colors for each log level
-  * Added GitProcessor to add the current branch/commit to extra record data
-  * Added a Monolog\Registry class to allow easier global access to pre-configured loggers
-  * Added support for the new official graylog2/gelf-php lib for GelfHandler, upgrade if you can by replacing the mlehner/gelf-php requirement
-  * Added support for HHVM
-  * Added support for Loggly batch uploads
-  * Added support for tweaking the content type and encoding in NativeMailerHandler
-  * Added $skipClassesPartials to tweak the ignored classes in the IntrospectionProcessor
-  * Fixed batch request support in GelfHandler
-
-### 1.7.0 (2013-11-14)
-
-  * Added ElasticSearchHandler to send logs to an Elastic Search server
-  * Added DynamoDbHandler and ScalarFormatter to send logs to Amazon's Dynamo DB
-  * Added SyslogUdpHandler to send logs to a remote syslogd server
-  * Added LogglyHandler to send logs to a Loggly account
-  * Added $level to IntrospectionProcessor so it only adds backtraces when needed
-  * Added $version to LogstashFormatter to allow using the new v1 Logstash format
-  * Added $appName to NewRelicHandler
-  * Added configuration of Pushover notification retries/expiry
-  * Added $maxColumnWidth to NativeMailerHandler to change the 70 chars default
-  * Added chainability to most setters for all handlers
-  * Fixed RavenHandler batch processing so it takes the message from the record with highest priority
-  * Fixed HipChatHandler batch processing so it sends all messages at once
-  * Fixed issues with eAccelerator
-  * Fixed and improved many small things
-
-### 1.6.0 (2013-07-29)
-
-  * Added HipChatHandler to send logs to a HipChat chat room
-  * Added ErrorLogHandler to send logs to PHP's error_log function
-  * Added NewRelicHandler to send logs to NewRelic's service
-  * Added Monolog\ErrorHandler helper class to register a Logger as exception/error/fatal handler
-  * Added ChannelLevelActivationStrategy for the FingersCrossedHandler to customize levels by channel
-  * Added stack traces output when normalizing exceptions (json output & co)
-  * Added Monolog\Logger::API constant (currently 1)
-  * Added support for ChromePHP's v4.0 extension
-  * Added support for message priorities in PushoverHandler, see $highPriorityLevel and $emergencyLevel
-  * Added support for sending messages to multiple users at once with the PushoverHandler
-  * Fixed RavenHandler's support for batch sending of messages (when behind a Buffer or FingersCrossedHandler)
-  * Fixed normalization of Traversables with very large data sets, only the first 1000 items are shown now
-  * Fixed issue in RotatingFileHandler when an open_basedir restriction is active
-  * Fixed minor issues in RavenHandler and bumped the API to Raven 0.5.0
-  * Fixed SyslogHandler issue when many were used concurrently with different facilities
-
-### 1.5.0 (2013-04-23)
-
-  * Added ProcessIdProcessor to inject the PID in log records
-  * Added UidProcessor to inject a unique identifier to all log records of one request/run
-  * Added support for previous exceptions in the LineFormatter exception serialization
-  * Added Monolog\Logger::getLevels() to get all available levels
-  * Fixed ChromePHPHandler so it avoids sending headers larger than Chrome can handle
-
-### 1.4.1 (2013-04-01)
-
-  * Fixed exception formatting in the LineFormatter to be more minimalistic
-  * Fixed RavenHandler's handling of context/extra data, requires Raven client >0.1.0
-  * Fixed log rotation in RotatingFileHandler to work with long running scripts spanning multiple days
-  * Fixed WebProcessor array access so it checks for data presence
-  * Fixed Buffer, Group and FingersCrossed handlers to make use of their processors
-
-### 1.4.0 (2013-02-13)
-
-  * Added RedisHandler to log to Redis via the Predis library or the phpredis extension
-  * Added ZendMonitorHandler to log to the Zend Server monitor
-  * Added the possibility to pass arrays of handlers and processors directly in the Logger constructor
-  * Added `$useSSL` option to the PushoverHandler which is enabled by default
-  * Fixed ChromePHPHandler and FirePHPHandler issue when multiple instances are used simultaneously
-  * Fixed header injection capability in the NativeMailHandler
-
-### 1.3.1 (2013-01-11)
-
-  * Fixed LogstashFormatter to be usable with stream handlers
-  * Fixed GelfMessageFormatter levels on Windows
-
-### 1.3.0 (2013-01-08)
-
-  * Added PSR-3 compliance, the `Monolog\Logger` class is now an instance of `Psr\Log\LoggerInterface`
-  * Added PsrLogMessageProcessor that you can selectively enable for full PSR-3 compliance
-  * Added LogstashFormatter (combine with SocketHandler or StreamHandler to send logs to Logstash)
-  * Added PushoverHandler to send mobile notifications
-  * Added CouchDBHandler and DoctrineCouchDBHandler
-  * Added RavenHandler to send data to Sentry servers
-  * Added support for the new MongoClient class in MongoDBHandler
-  * Added microsecond precision to log records' timestamps
-  * Added `$flushOnOverflow` param to BufferHandler to flush by batches instead of losing
-    the oldest entries
-  * Fixed normalization of objects with cyclic references
-
-### 1.2.1 (2012-08-29)
-
-  * Added new $logopts arg to SyslogHandler to provide custom openlog options
-  * Fixed fatal error in SyslogHandler
-
-### 1.2.0 (2012-08-18)
-
-  * Added AmqpHandler (for use with AMQP servers)
-  * Added CubeHandler
-  * Added NativeMailerHandler::addHeader() to send custom headers in mails
-  * Added the possibility to specify more than one recipient in NativeMailerHandler
-  * Added the possibility to specify float timeouts in SocketHandler
-  * Added NOTICE and EMERGENCY levels to conform with RFC 5424
-  * Fixed the log records to use the php default timezone instead of UTC
-  * Fixed BufferHandler not being flushed properly on PHP fatal errors
-  * Fixed normalization of exotic resource types
-  * Fixed the default format of the SyslogHandler to avoid duplicating datetimes in syslog
-
-### 1.1.0 (2012-04-23)
-
-  * Added Monolog\Logger::isHandling() to check if a handler will
-    handle the given log level
-  * Added ChromePHPHandler
-  * Added MongoDBHandler
-  * Added GelfHandler (for use with Graylog2 servers)
-  * Added SocketHandler (for use with syslog-ng for example)
-  * Added NormalizerFormatter
-  * Added the possibility to change the activation strategy of the FingersCrossedHandler
-  * Added possibility to show microseconds in logs
-  * Added `server` and `referer` to WebProcessor output
-
-### 1.0.2 (2011-10-24)
-
-  * Fixed bug in IE with large response headers and FirePHPHandler
-
-### 1.0.1 (2011-08-25)
-
-  * Added MemoryPeakUsageProcessor and MemoryUsageProcessor
-  * Added Monolog\Logger::getName() to get a logger's channel name
-
-### 1.0.0 (2011-07-06)
-
-  * Added IntrospectionProcessor to get info from where the logger was called
-  * Fixed WebProcessor in CLI
-
-### 1.0.0-RC1 (2011-07-01)
-
-  * Initial release

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/LICENSE
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/LICENSE b/vendor/monolog/monolog/LICENSE
deleted file mode 100644
index 3572704..0000000
--- a/vendor/monolog/monolog/LICENSE
+++ /dev/null
@@ -1,19 +0,0 @@
-Copyright (c) 2011-2014 Jordi Boggiano
-
-Permission is hereby granted, free of charge, to any person obtaining a copy
-of this software and associated documentation files (the "Software"), to deal
-in the Software without restriction, including without limitation the rights
-to use, copy, modify, merge, publish, distribute, sublicense, and/or sell
-copies of the Software, and to permit persons to whom the Software is furnished
-to do so, subject to the following conditions:
-
-The above copyright notice and this permission notice shall be included in all
-copies or substantial portions of the Software.
-
-THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS OR
-IMPLIED, INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF MERCHANTABILITY,
-FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE
-AUTHORS OR COPYRIGHT HOLDERS BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER
-LIABILITY, WHETHER IN AN ACTION OF CONTRACT, TORT OR OTHERWISE, ARISING FROM,
-OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEALINGS IN
-THE SOFTWARE.

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/README.mdown
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/README.mdown b/vendor/monolog/monolog/README.mdown
deleted file mode 100644
index 7ac9904..0000000
--- a/vendor/monolog/monolog/README.mdown
+++ /dev/null
@@ -1,292 +0,0 @@
-Monolog - Logging for PHP 5.3+ [![Build Status](https://secure.travis-ci.org/Seldaek/monolog.png)](http://travis-ci.org/Seldaek/monolog)
-==============================
-
-[![Total Downloads](https://poser.pugx.org/monolog/monolog/downloads.png)](https://packagist.org/packages/monolog/monolog)
-[![Latest Stable Version](https://poser.pugx.org/monolog/monolog/v/stable.png)](https://packagist.org/packages/monolog/monolog)
-[![Reference Status](https://www.versioneye.com/php/monolog:monolog/reference_badge.svg)](https://www.versioneye.com/php/monolog:monolog/references)
-
-
-Monolog sends your logs to files, sockets, inboxes, databases and various
-web services. See the complete list of handlers below. Special handlers
-allow you to build advanced logging strategies.
-
-This library implements the [PSR-3](https://github.com/php-fig/fig-standards/blob/master/accepted/PSR-3-logger-interface.md)
-interface that you can type-hint against in your own libraries to keep
-a maximum of interoperability. You can also use it in your applications to
-make sure you can always use another compatible logger at a later time.
-As of 1.11.0 Monolog public APIs will also accept PSR-3 log levels.
-Internally Monolog still uses its own level scheme since it predates PSR-3.
-
-Usage
------
-
-Install the latest version with `composer require monolog/monolog`
-
-```php
-<?php
-
-use Monolog\Logger;
-use Monolog\Handler\StreamHandler;
-
-// create a log channel
-$log = new Logger('name');
-$log->pushHandler(new StreamHandler('path/to/your.log', Logger::WARNING));
-
-// add records to the log
-$log->addWarning('Foo');
-$log->addError('Bar');
-```
-
-Core Concepts
--------------
-
-Every `Logger` instance has a channel (name) and a stack of handlers. Whenever
-you add a record to the logger, it traverses the handler stack. Each handler
-decides whether it fully handled the record, and if so, the propagation of the
-record ends there.
-
-This allows for flexible logging setups, for example having a `StreamHandler` at
-the bottom of the stack that will log anything to disk, and on top of that add
-a `MailHandler` that will send emails only when an error message is logged.
-Handlers also have a `$bubble` property which defines whether they block the
-record or not if they handled it. In this example, setting the `MailHandler`'s
-`$bubble` argument to false means that records handled by the `MailHandler` will
-not propagate to the `StreamHandler` anymore.
-
-You can create many `Logger`s, each defining a channel (e.g.: db, request,
-router, ..) and each of them combining various handlers, which can be shared
-or not. The channel is reflected in the logs and allows you to easily see or
-filter records.
-
-Each Handler also has a Formatter, a default one with settings that make sense
-will be created if you don't set one. The formatters normalize and format
-incoming records so that they can be used by the handlers to output useful
-information.
-
-Custom severity levels are not available. Only the eight
-[RFC 5424](http://tools.ietf.org/html/rfc5424) levels (debug, info, notice,
-warning, error, critical, alert, emergency) are present for basic filtering
-purposes, but for sorting and other use cases that would require
-flexibility, you should add Processors to the Logger that can add extra
-information (tags, user ip, ..) to the records before they are handled.
-
-Log Levels
-----------
-
-Monolog supports the logging levels described by [RFC 5424](http://tools.ietf.org/html/rfc5424).
-
-- **DEBUG** (100): Detailed debug information.
-
-- **INFO** (200): Interesting events. Examples: User logs in, SQL logs.
-
-- **NOTICE** (250): Normal but significant events.
-
-- **WARNING** (300): Exceptional occurrences that are not errors. Examples:
-  Use of deprecated APIs, poor use of an API, undesirable things that are not
-  necessarily wrong.
-
-- **ERROR** (400): Runtime errors that do not require immediate action but
-  should typically be logged and monitored.
-
-- **CRITICAL** (500): Critical conditions. Example: Application component
-  unavailable, unexpected exception.
-
-- **ALERT** (550): Action must be taken immediately. Example: Entire website
-  down, database unavailable, etc. This should trigger the SMS alerts and wake
-  you up.
-
-- **EMERGENCY** (600): Emergency: system is unusable.
-
-Docs
-====
-
-**See the `doc` directory for more detailed documentation.
-The following is only a list of all parts that come with Monolog.**
-
-Handlers
---------
-
-### Log to files and syslog
-
-- _StreamHandler_: Logs records into any PHP stream, use this for log files.
-- _RotatingFileHandler_: Logs records to a file and creates one logfile per day.
-  It will also delete files older than `$maxFiles`. You should use
-  [logrotate](http://linuxcommand.org/man_pages/logrotate8.html) for high profile
-  setups though, this is just meant as a quick and dirty solution.
-- _SyslogHandler_: Logs records to the syslog.
-- _ErrorLogHandler_: Logs records to PHP's
-  [`error_log()`](http://docs.php.net/manual/en/function.error-log.php) function.
-
-### Send alerts and emails
-
-- _NativeMailerHandler_: Sends emails using PHP's
-  [`mail()`](http://php.net/manual/en/function.mail.php) function.
-- _SwiftMailerHandler_: Sends emails using a [`Swift_Mailer`](http://swiftmailer.org/) instance.
-- _PushoverHandler_: Sends mobile notifications via the [Pushover](https://www.pushover.net/) API.
-- _HipChatHandler_: Logs records to a [HipChat](http://hipchat.com) chat room using its API.
-- _FlowdockHandler_: Logs records to a [Flowdock](https://www.flowdock.com/) account.
-- _SlackHandler_: Logs records to a [Slack](https://www.slack.com/) account.
-- _MandrillHandler_: Sends emails via the Mandrill API using a [`Swift_Message`](http://swiftmailer.org/) instance.
-- _FleepHookHandler_: Logs records to a [Fleep](https://fleep.io/) conversation using Webhooks.
-
-### Log specific servers and networked logging
-
-- _SocketHandler_: Logs records to [sockets](http://php.net/fsockopen), use this
-  for UNIX and TCP sockets. See an [example](https://github.com/Seldaek/monolog/blob/master/doc/sockets.md).
-- _AmqpHandler_: Logs records to an [amqp](http://www.amqp.org/) compatible
-  server. Requires the [php-amqp](http://pecl.php.net/package/amqp) extension (1.0+).
-- _GelfHandler_: Logs records to a [Graylog2](http://www.graylog2.org) server.
-- _CubeHandler_: Logs records to a [Cube](http://square.github.com/cube/) server.
-- _RavenHandler_: Logs records to a [Sentry](http://getsentry.com/) server using
-  [raven](https://packagist.org/packages/raven/raven).
-- _ZendMonitorHandler_: Logs records to the Zend Monitor present in Zend Server.
-- _NewRelicHandler_: Logs records to a [NewRelic](http://newrelic.com/) application.
-- _LogglyHandler_: Logs records to a [Loggly](http://www.loggly.com/) account.
-- _RollbarHandler_: Logs records to a [Rollbar](https://rollbar.com/) account.
-- _SyslogUdpHandler_: Logs records to a remote [Syslogd](http://www.rsyslog.com/) server.
-- _LogEntriesHandler_: Logs records to a [LogEntries](http://logentries.com/) account.
-
-### Logging in development
-
-- _FirePHPHandler_: Handler for [FirePHP](http://www.firephp.org/), providing
-  inline `console` messages within [FireBug](http://getfirebug.com/).
-- _ChromePHPHandler_: Handler for [ChromePHP](http://www.chromephp.com/), providing
-  inline `console` messages within Chrome.
-- _BrowserConsoleHandler_: Handler to send logs to browser's Javascript `console` with
-  no browser extension required. Most browsers supporting `console` API are supported.
-
-### Log to databases
-
-- _RedisHandler_: Logs records to a [redis](http://redis.io) server.
-- _MongoDBHandler_: Handler to write records in MongoDB via a
-  [Mongo](http://pecl.php.net/package/mongo) extension connection.
-- _CouchDBHandler_: Logs records to a CouchDB server.
-- _DoctrineCouchDBHandler_: Logs records to a CouchDB server via the Doctrine CouchDB ODM.
-- _ElasticSearchHandler_: Logs records to an Elastic Search server.
-- _DynamoDbHandler_: Logs records to a DynamoDB table with the [AWS SDK](https://github.com/aws/aws-sdk-php).
-
-### Wrappers / Special Handlers
-
-- _FingersCrossedHandler_: A very interesting wrapper. It takes a logger as
-  parameter and will accumulate log records of all levels until a record
-  exceeds the defined severity level. At which point it delivers all records,
-  including those of lower severity, to the handler it wraps. This means that
-  until an error actually happens you will not see anything in your logs, but
-  when it happens you will have the full information, including debug and info
-  records. This provides you with all the information you need, but only when
-  you need it.
-- _WhatFailureGroupHandler_: This handler extends the _GroupHandler_ ignoring
-   exceptions raised by each child handler. This allows you to ignore issues
-   where a remote tcp connection may have died but you do not want your entire
-   application to crash and may wish to continue to log to other handlers.
-- _BufferHandler_: This handler will buffer all the log records it receives
-  until `close()` is called at which point it will call `handleBatch()` on the
-  handler it wraps with all the log messages at once. This is very useful to
-  send an email with all records at once for example instead of having one mail
-  for every log record.
-- _GroupHandler_: This handler groups other handlers. Every record received is
-  sent to all the handlers it is configured with.
-- _FilterHandler_: This handler only lets records of the given levels through
-   to the wrapped handler.
-- _SamplingHandler_: Wraps around another handler and lets you sample records
-   if you only want to store some of them.
-- _NullHandler_: Any record it can handle will be thrown away. This can be used
-  to put on top of an existing handler stack to disable it temporarily.
-- _PsrHandler_: Can be used to forward log records to an existing PSR-3 logger
-- _TestHandler_: Used for testing, it records everything that is sent to it and
-  has accessors to read out the information.
-
-Formatters
-----------
-
-- _LineFormatter_: Formats a log record into a one-line string.
-- _HtmlFormatter_: Used to format log records into a human readable html table, mainly suitable for emails.
-- _NormalizerFormatter_: Normalizes objects/resources down to strings so a record can easily be serialized/encoded.
-- _ScalarFormatter_: Used to format log records into an associative array of scalar values.
-- _JsonFormatter_: Encodes a log record into json.
-- _WildfireFormatter_: Used to format log records into the Wildfire/FirePHP protocol, only useful for the FirePHPHandler.
-- _ChromePHPFormatter_: Used to format log records into the ChromePHP format, only useful for the ChromePHPHandler.
-- _GelfMessageFormatter_: Used to format log records into Gelf message instances, only useful for the GelfHandler.
-- _LogstashFormatter_: Used to format log records into [logstash](http://logstash.net/) event json, useful for any handler listed under inputs [here](http://logstash.net/docs/latest).
-- _ElasticaFormatter_: Used to format log records into an Elastica\Document object, only useful for the ElasticSearchHandler.
-- _LogglyFormatter_: Used to format log records into Loggly messages, only useful for the LogglyHandler.
-- _FlowdockFormatter_: Used to format log records into Flowdock messages, only useful for the FlowdockHandler.
-- _MongoDBFormatter_: Converts \DateTime instances to \MongoDate and objects recursively to arrays, only useful with the MongoDBHandler.
-
-Processors
-----------
-
-- _IntrospectionProcessor_: Adds the line/file/class/method from which the log call originated.
-- _WebProcessor_: Adds the current request URI, request method and client IP to a log record.
-- _MemoryUsageProcessor_: Adds the current memory usage to a log record.
-- _MemoryPeakUsageProcessor_: Adds the peak memory usage to a log record.
-- _ProcessIdProcessor_: Adds the process id to a log record.
-- _UidProcessor_: Adds a unique identifier to a log record.
-- _GitProcessor_: Adds the current git branch and commit to a log record.
-- _TagProcessor_: Adds an array of predefined tags to a log record.
-
-Utilities
----------
-
-- _Registry_: The `Monolog\Registry` class lets you configure global loggers that you
-  can then statically access from anywhere. It is not really a best practice but can
-  help in some older codebases or for ease of use.
-- _ErrorHandler_: The `Monolog\ErrorHandler` class allows you to easily register
-  a Logger instance as an exception handler, error handler or fatal error handler.
-- _ErrorLevelActivationStrategy_: Activates a FingersCrossedHandler when a certain log
-  level is reached.
-- _ChannelLevelActivationStrategy_: Activates a FingersCrossedHandler when a certain
-  log level is reached, depending on which channel received the log record.
-
-Third Party Packages
---------------------
-
-Third party handlers, formatters and processors are
-[listed in the wiki](https://github.com/Seldaek/monolog/wiki/Third-Party-Packages). You
-can also add your own there if you publish one.
-
-About
-=====
-
-Requirements
-------------
-
-- Monolog works with PHP 5.3 or above, and is also tested to work with HHVM.
-
-Submitting bugs and feature requests
-------------------------------------
-
-Bugs and feature request are tracked on [GitHub](https://github.com/Seldaek/monolog/issues)
-
-Frameworks Integration
-----------------------
-
-- Frameworks and libraries using [PSR-3](https://github.com/php-fig/fig-standards/blob/master/accepted/PSR-3-logger-interface.md)
-  can be used very easily with Monolog since it implements the interface.
-- [Symfony2](http://symfony.com) comes out of the box with Monolog.
-- [Silex](http://silex.sensiolabs.org/) comes out of the box with Monolog.
-- [Laravel 4 & 5](http://laravel.com/) come out of the box with Monolog.
-- [PPI](http://www.ppi.io/) comes out of the box with Monolog.
-- [CakePHP](http://cakephp.org/) is usable with Monolog via the [cakephp-monolog](https://github.com/jadb/cakephp-monolog) plugin.
-- [Slim](http://www.slimframework.com/) is usable with Monolog via the [Slim-Monolog](https://github.com/Flynsarmy/Slim-Monolog) log writer.
-- [XOOPS 2.6](http://xoops.org/) comes out of the box with Monolog.
-- [Aura.Web_Project](https://github.com/auraphp/Aura.Web_Project) comes out of the box with Monolog.
-- [Nette Framework](http://nette.org/en/) can be used with Monolog via [Kdyby/Monolog](https://github.com/Kdyby/Monolog) extension.
-- [Proton Micro Framework](https://github.com/alexbilbie/Proton) comes out of the box with Monolog. 
-
-Author
-------
-
-Jordi Boggiano - <j....@seld.be> - <http://twitter.com/seldaek><br />
-See also the list of [contributors](https://github.com/Seldaek/monolog/contributors) which participated in this project.
-
-License
--------
-
-Monolog is licensed under the MIT License - see the `LICENSE` file for details
-
-Acknowledgements
-----------------
-
-This library is heavily inspired by Python's [Logbook](http://packages.python.org/Logbook/)
-library, although most concepts have been adjusted to fit to the PHP world.

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/composer.json
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/composer.json b/vendor/monolog/monolog/composer.json
deleted file mode 100644
index 9fec07a..0000000
--- a/vendor/monolog/monolog/composer.json
+++ /dev/null
@@ -1,54 +0,0 @@
-{
-    "name": "monolog/monolog",
-    "description": "Sends your logs to files, sockets, inboxes, databases and various web services",
-    "keywords": ["log", "logging", "psr-3"],
-    "homepage": "http://github.com/Seldaek/monolog",
-    "type": "library",
-    "license": "MIT",
-    "authors": [
-        {
-            "name": "Jordi Boggiano",
-            "email": "j.boggiano@seld.be",
-            "homepage": "http://seld.be"
-        }
-    ],
-    "require": {
-        "php": ">=5.3.0",
-        "psr/log": "~1.0"
-    },
-    "require-dev": {
-        "phpunit/phpunit": "~4.0",
-        "graylog2/gelf-php": "~1.0",
-        "raven/raven": "~0.5",
-        "ruflin/elastica": "0.90.*",
-        "doctrine/couchdb": "~1.0@dev",
-        "aws/aws-sdk-php": "~2.4, >2.4.8",
-        "videlalvaro/php-amqplib": "~2.4",
-        "swiftmailer/swiftmailer": "~5.3"
-    },
-    "suggest": {
-        "graylog2/gelf-php": "Allow sending log messages to a GrayLog2 server",
-        "raven/raven": "Allow sending log messages to a Sentry server",
-        "doctrine/couchdb": "Allow sending log messages to a CouchDB server",
-        "ruflin/elastica": "Allow sending log messages to an Elastic Search server",
-        "videlalvaro/php-amqplib": "Allow sending log messages to an AMQP server using php-amqplib",
-        "ext-amqp": "Allow sending log messages to an AMQP server (1.0+ required)",
-        "ext-mongo": "Allow sending log messages to a MongoDB server",
-        "aws/aws-sdk-php": "Allow sending log messages to AWS services like DynamoDB",
-        "rollbar/rollbar": "Allow sending log messages to Rollbar"
-    },
-    "autoload": {
-        "psr-4": {"Monolog\\": "src/Monolog"}
-    },
-    "provide": {
-        "psr/log-implementation": "1.0.0"
-    },
-    "extra": {
-        "branch-alias": {
-            "dev-master": "1.13.x-dev"
-        }
-    },
-    "scripts": {
-        "test": "phpunit"
-    }
-}

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/doc/extending.md
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/doc/extending.md b/vendor/monolog/monolog/doc/extending.md
deleted file mode 100644
index bb39ddc..0000000
--- a/vendor/monolog/monolog/doc/extending.md
+++ /dev/null
@@ -1,76 +0,0 @@
-Extending Monolog
-=================
-
-Monolog is fully extensible, allowing you to adapt your logger to your needs.
-
-Writing your own handler
-------------------------
-
-Monolog provides many built-in handlers. But if the one you need does not
-exist, you can write it and use it in your logger. The only requirement is
-to implement `Monolog\Handler\HandlerInterface`.
-
-Let's write a PDOHandler to log records to a database. We will extend the
-abstract class provided by Monolog to keep things DRY.
-
-```php
-<?php
-
-use Monolog\Logger;
-use Monolog\Handler\AbstractProcessingHandler;
-
-class PDOHandler extends AbstractProcessingHandler
-{
-    private $initialized = false;
-    private $pdo;
-    private $statement;
-
-    public function __construct(PDO $pdo, $level = Logger::DEBUG, $bubble = true)
-    {
-        $this->pdo = $pdo;
-        parent::__construct($level, $bubble);
-    }
-
-    protected function write(array $record)
-    {
-        if (!$this->initialized) {
-            $this->initialize();
-        }
-
-        $this->statement->execute(array(
-            'channel' => $record['channel'],
-            'level' => $record['level'],
-            'message' => $record['formatted'],
-            'time' => $record['datetime']->format('U'),
-        ));
-    }
-
-    private function initialize()
-    {
-        $this->pdo->exec(
-            'CREATE TABLE IF NOT EXISTS monolog '
-            .'(channel VARCHAR(255), level INTEGER, message LONGTEXT, time INTEGER UNSIGNED)'
-        );
-        $this->statement = $this->pdo->prepare(
-            'INSERT INTO monolog (channel, level, message, time) VALUES (:channel, :level, :message, :time)'
-        );
-
-        $this->initialized = true;
-    }
-}
-```
-
-You can now use this handler in your logger:
-
-```php
-<?php
-
-$logger->pushHandler(new PDOHandler(new PDO('sqlite:logs.sqlite')));
-
-// You can now use your logger
-$logger->addInfo('My logger is now ready');
-```
-
-The `Monolog\Handler\AbstractProcessingHandler` class provides most of the
-logic needed for the handler, including the use of processors and the formatting
-of the record (which is why we use ``$record['formatted']`` instead of ``$record['message']``).

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/doc/sockets.md
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/doc/sockets.md b/vendor/monolog/monolog/doc/sockets.md
deleted file mode 100644
index fad30a9..0000000
--- a/vendor/monolog/monolog/doc/sockets.md
+++ /dev/null
@@ -1,37 +0,0 @@
-Sockets Handler
-===============
-
-This handler allows you to write your logs to sockets using [fsockopen](http://php.net/fsockopen)
-or [pfsockopen](http://php.net/pfsockopen).
-
-Persistent sockets are mainly useful in web environments where you gain some performance not closing/opening
-the connections between requests.
-
-Basic Example
--------------
-
-```php
-<?php
-
-use Monolog\Logger;
-use Monolog\Handler\SocketHandler;
-
-// Create the logger
-$logger = new Logger('my_logger');
-
-// Create the handler
-$handler = new SocketHandler('unix:///var/log/httpd_app_log.socket');
-$handler->setPersistent(true);
-
-// Now add the handler
-$logger->pushHandler($handler, Logger::DEBUG);
-
-// You can now use your logger
-$logger->addInfo('My logger is now ready');
-
-```
-
-In this example, using syslog-ng, you should see the log on the log server:
-
-    cweb1 [2012-02-26 00:12:03] my_logger.INFO: My logger is now ready [] []
-

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/doc/usage.md
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/doc/usage.md b/vendor/monolog/monolog/doc/usage.md
deleted file mode 100644
index 7585fa2..0000000
--- a/vendor/monolog/monolog/doc/usage.md
+++ /dev/null
@@ -1,162 +0,0 @@
-Using Monolog
-=============
-
-Installation
-------------
-
-Monolog is available on Packagist ([monolog/monolog](http://packagist.org/packages/monolog/monolog))
-and as such installable via [Composer](http://getcomposer.org/).
-
-```bash
-php composer.phar require monolog/monolog
-```
-
-If you do not use Composer, you can grab the code from GitHub, and use any
-PSR-0 compatible autoloader (e.g. the [Symfony2 ClassLoader component](https://github.com/symfony/ClassLoader))
-to load Monolog classes.
-
-Configuring a logger
---------------------
-
-Here is a basic setup to log to a file and to firephp on the DEBUG level:
-
-```php
-<?php
-
-use Monolog\Logger;
-use Monolog\Handler\StreamHandler;
-use Monolog\Handler\FirePHPHandler;
-
-// Create the logger
-$logger = new Logger('my_logger');
-// Now add some handlers
-$logger->pushHandler(new StreamHandler(__DIR__.'/my_app.log', Logger::DEBUG));
-$logger->pushHandler(new FirePHPHandler());
-
-// You can now use your logger
-$logger->addInfo('My logger is now ready');
-```
-
-Let's explain it. The first step is to create the logger instance which will
-be used in your code. The argument is a channel name, which is useful when
-you use several loggers (see below for more details about it).
-
-The logger itself does not know how to handle a record. It delegates it to
-some handlers. The code above registers two handlers in the stack to allow
-handling records in two different ways.
-
-Note that the FirePHPHandler is called first as it is added on top of the
-stack. This allows you to temporarily add a logger with bubbling disabled if
-you want to override other configured loggers.
-
-Adding extra data in the records
---------------------------------
-
-Monolog provides two different ways to add extra informations along the simple
-textual message.
-
-### Using the logging context
-
-The first way is the context, allowing to pass an array of data along the
-record:
-
-```php
-<?php
-
-$logger->addInfo('Adding a new user', array('username' => 'Seldaek'));
-```
-
-Simple handlers (like the StreamHandler for instance) will simply format
-the array to a string but richer handlers can take advantage of the context
-(FirePHP is able to display arrays in pretty way for instance).
-
-### Using processors
-
-The second way is to add extra data for all records by using a processor.
-Processors can be any callable. They will get the record as parameter and
-must return it after having eventually changed the `extra` part of it. Let's
-write a processor adding some dummy data in the record:
-
-```php
-<?php
-
-$logger->pushProcessor(function ($record) {
-    $record['extra']['dummy'] = 'Hello world!';
-
-    return $record;
-});
-```
-
-Monolog provides some built-in processors that can be used in your project.
-Look at the [README file](https://github.com/Seldaek/monolog/blob/master/README.mdown) for the list.
-
-> Tip: processors can also be registered on a specific handler instead of
-  the logger to apply only for this handler.
-
-Leveraging channels
--------------------
-
-Channels are a great way to identify to which part of the application a record
-is related. This is useful in big applications (and is leveraged by
-MonologBundle in Symfony2).
-
-Picture two loggers sharing a handler that writes to a single log file.
-Channels would allow you to identify the logger that issued every record.
-You can easily grep through the log files filtering this or that channel.
-
-```php
-<?php
-
-use Monolog\Logger;
-use Monolog\Handler\StreamHandler;
-use Monolog\Handler\FirePHPHandler;
-
-// Create some handlers
-$stream = new StreamHandler(__DIR__.'/my_app.log', Logger::DEBUG);
-$firephp = new FirePHPHandler();
-
-// Create the main logger of the app
-$logger = new Logger('my_logger');
-$logger->pushHandler($stream);
-$logger->pushHandler($firephp);
-
-// Create a logger for the security-related stuff with a different channel
-$securityLogger = new Logger('security');
-$securityLogger->pushHandler($stream);
-$securityLogger->pushHandler($firephp);
-```
-
-Customizing log format
-----------------------
-
-In Monolog it's easy to customize the format of the logs written into files,
-sockets, mails, databases and other handlers. Most of the handlers use the
-
-```php
-$record['formatted']
-```
-
-value to be automatically put into the log device. This value depends on the
-formatter settings. You can choose between predefined formatter classes or
-write your own (e.g. a multiline text file for human-readable output).
-
-To configure a predefined formatter class, just set it as the handler's field:
-
-```php
-// the default date format is "Y-m-d H:i:s"
-$dateFormat = "Y n j, g:i a";
-// the default output format is "[%datetime%] %channel%.%level_name%: %message% %context% %extra%\n"
-$output = "%datetime% > %level_name% > %message% %context% %extra%\n";
-// finally, create a formatter
-$formatter = new LineFormatter($output, $dateFormat);
-
-// Create a handler
-$stream = new StreamHandler(__DIR__.'/my_app.log', Logger::DEBUG);
-$stream->setFormatter($formatter);
-// bind it to a logger object
-$securityLogger = new Logger('security');
-$securityLogger->pushHandler($stream);
-```
-
-You may also reuse the same formatter between multiple handlers and share those
-handlers between multiple loggers.

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/phpunit.xml.dist
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/phpunit.xml.dist b/vendor/monolog/monolog/phpunit.xml.dist
deleted file mode 100644
index 1754570..0000000
--- a/vendor/monolog/monolog/phpunit.xml.dist
+++ /dev/null
@@ -1,15 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-
-<phpunit bootstrap="tests/bootstrap.php" colors="true">
-    <testsuites>
-        <testsuite name="Monolog Test Suite">
-            <directory>tests/Monolog/</directory>
-        </testsuite>
-    </testsuites>
-
-    <filter>
-        <whitelist>
-            <directory suffix=".php">src/Monolog/</directory>
-        </whitelist>
-    </filter>
-</phpunit>

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/src/Monolog/ErrorHandler.php
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/src/Monolog/ErrorHandler.php b/vendor/monolog/monolog/src/Monolog/ErrorHandler.php
deleted file mode 100644
index c892335..0000000
--- a/vendor/monolog/monolog/src/Monolog/ErrorHandler.php
+++ /dev/null
@@ -1,208 +0,0 @@
-<?php
-
-/*
- * This file is part of the Monolog package.
- *
- * (c) Jordi Boggiano <j....@seld.be>
- *
- * For the full copyright and license information, please view the LICENSE
- * file that was distributed with this source code.
- */
-
-namespace Monolog;
-
-use Psr\Log\LoggerInterface;
-use Psr\Log\LogLevel;
-
-/**
- * Monolog error handler
- *
- * A facility to enable logging of runtime errors, exceptions and fatal errors.
- *
- * Quick setup: <code>ErrorHandler::register($logger);</code>
- *
- * @author Jordi Boggiano <j....@seld.be>
- */
-class ErrorHandler
-{
-    private $logger;
-
-    private $previousExceptionHandler;
-    private $uncaughtExceptionLevel;
-
-    private $previousErrorHandler;
-    private $errorLevelMap;
-
-    private $fatalLevel;
-    private $reservedMemory;
-    private static $fatalErrors = array(E_ERROR, E_PARSE, E_CORE_ERROR, E_COMPILE_ERROR, E_USER_ERROR);
-
-    public function __construct(LoggerInterface $logger)
-    {
-        $this->logger = $logger;
-    }
-
-    /**
-     * Registers a new ErrorHandler for a given Logger
-     *
-     * By default it will handle errors, exceptions and fatal errors
-     *
-     * @param  LoggerInterface $logger
-     * @param  array|false     $errorLevelMap  an array of E_* constant to LogLevel::* constant mapping, or false to disable error handling
-     * @param  int|false       $exceptionLevel a LogLevel::* constant, or false to disable exception handling
-     * @param  int|false       $fatalLevel     a LogLevel::* constant, or false to disable fatal error handling
-     * @return ErrorHandler
-     */
-    public static function register(LoggerInterface $logger, $errorLevelMap = array(), $exceptionLevel = null, $fatalLevel = null)
-    {
-        $handler = new static($logger);
-        if ($errorLevelMap !== false) {
-            $handler->registerErrorHandler($errorLevelMap);
-        }
-        if ($exceptionLevel !== false) {
-            $handler->registerExceptionHandler($exceptionLevel);
-        }
-        if ($fatalLevel !== false) {
-            $handler->registerFatalHandler($fatalLevel);
-        }
-
-        return $handler;
-    }
-
-    public function registerExceptionHandler($level = null, $callPrevious = true)
-    {
-        $prev = set_exception_handler(array($this, 'handleException'));
-        $this->uncaughtExceptionLevel = $level;
-        if ($callPrevious && $prev) {
-            $this->previousExceptionHandler = $prev;
-        }
-    }
-
-    public function registerErrorHandler(array $levelMap = array(), $callPrevious = true, $errorTypes = -1)
-    {
-        $prev = set_error_handler(array($this, 'handleError'), $errorTypes);
-        $this->errorLevelMap = array_replace($this->defaultErrorLevelMap(), $levelMap);
-        if ($callPrevious) {
-            $this->previousErrorHandler = $prev ?: true;
-        }
-    }
-
-    public function registerFatalHandler($level = null, $reservedMemorySize = 20)
-    {
-        register_shutdown_function(array($this, 'handleFatalError'));
-
-        $this->reservedMemory = str_repeat(' ', 1024 * $reservedMemorySize);
-        $this->fatalLevel = $level;
-    }
-
-    protected function defaultErrorLevelMap()
-    {
-        return array(
-            E_ERROR             => LogLevel::CRITICAL,
-            E_WARNING           => LogLevel::WARNING,
-            E_PARSE             => LogLevel::ALERT,
-            E_NOTICE            => LogLevel::NOTICE,
-            E_CORE_ERROR        => LogLevel::CRITICAL,
-            E_CORE_WARNING      => LogLevel::WARNING,
-            E_COMPILE_ERROR     => LogLevel::ALERT,
-            E_COMPILE_WARNING   => LogLevel::WARNING,
-            E_USER_ERROR        => LogLevel::ERROR,
-            E_USER_WARNING      => LogLevel::WARNING,
-            E_USER_NOTICE       => LogLevel::NOTICE,
-            E_STRICT            => LogLevel::NOTICE,
-            E_RECOVERABLE_ERROR => LogLevel::ERROR,
-            E_DEPRECATED        => LogLevel::NOTICE,
-            E_USER_DEPRECATED   => LogLevel::NOTICE,
-        );
-    }
-
-    /**
-     * @private
-     */
-    public function handleException(\Exception $e)
-    {
-        $this->logger->log(
-            $this->uncaughtExceptionLevel === null ? LogLevel::ERROR : $this->uncaughtExceptionLevel,
-            sprintf('Uncaught Exception %s: "%s" at %s line %s', get_class($e), $e->getMessage(), $e->getFile(), $e->getLine()),
-            array('exception' => $e)
-        );
-
-        if ($this->previousExceptionHandler) {
-            call_user_func($this->previousExceptionHandler, $e);
-        }
-    }
-
-    /**
-     * @private
-     */
-    public function handleError($code, $message, $file = '', $line = 0, $context = array())
-    {
-        if (!(error_reporting() & $code)) {
-            return;
-        }
-
-        $level = isset($this->errorLevelMap[$code]) ? $this->errorLevelMap[$code] : LogLevel::CRITICAL;
-        $this->logger->log($level, self::codeToString($code).': '.$message, array('code' => $code, 'message' => $message, 'file' => $file, 'line' => $line));
-
-        if ($this->previousErrorHandler === true) {
-            return false;
-        } elseif ($this->previousErrorHandler) {
-            return call_user_func($this->previousErrorHandler, $code, $message, $file, $line, $context);
-        }
-    }
-
-    /**
-     * @private
-     */
-    public function handleFatalError()
-    {
-        $this->reservedMemory = null;
-
-        $lastError = error_get_last();
-        if ($lastError && in_array($lastError['type'], self::$fatalErrors)) {
-            $this->logger->log(
-                $this->fatalLevel === null ? LogLevel::ALERT : $this->fatalLevel,
-                'Fatal Error ('.self::codeToString($lastError['type']).'): '.$lastError['message'],
-                array('code' => $lastError['type'], 'message' => $lastError['message'], 'file' => $lastError['file'], 'line' => $lastError['line'])
-            );
-        }
-    }
-
-    private static function codeToString($code)
-    {
-        switch ($code) {
-            case E_ERROR:
-                return 'E_ERROR';
-            case E_WARNING:
-                return 'E_WARNING';
-            case E_PARSE:
-                return 'E_PARSE';
-            case E_NOTICE:
-                return 'E_NOTICE';
-            case E_CORE_ERROR:
-                return 'E_CORE_ERROR';
-            case E_CORE_WARNING:
-                return 'E_CORE_WARNING';
-            case E_COMPILE_ERROR:
-                return 'E_COMPILE_ERROR';
-            case E_COMPILE_WARNING:
-                return 'E_COMPILE_WARNING';
-            case E_USER_ERROR:
-                return 'E_USER_ERROR';
-            case E_USER_WARNING:
-                return 'E_USER_WARNING';
-            case E_USER_NOTICE:
-                return 'E_USER_NOTICE';
-            case E_STRICT:
-                return 'E_STRICT';
-            case E_RECOVERABLE_ERROR:
-                return 'E_RECOVERABLE_ERROR';
-            case E_DEPRECATED:
-                return 'E_DEPRECATED';
-            case E_USER_DEPRECATED:
-                return 'E_USER_DEPRECATED';
-        }
-
-        return 'Unknown PHP error';
-    }
-}

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/src/Monolog/Formatter/ChromePHPFormatter.php
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/src/Monolog/Formatter/ChromePHPFormatter.php b/vendor/monolog/monolog/src/Monolog/Formatter/ChromePHPFormatter.php
deleted file mode 100644
index 56d3e27..0000000
--- a/vendor/monolog/monolog/src/Monolog/Formatter/ChromePHPFormatter.php
+++ /dev/null
@@ -1,79 +0,0 @@
-<?php
-
-/*
- * This file is part of the Monolog package.
- *
- * (c) Jordi Boggiano <j....@seld.be>
- *
- * For the full copyright and license information, please view the LICENSE
- * file that was distributed with this source code.
- */
-
-namespace Monolog\Formatter;
-
-use Monolog\Logger;
-
-/**
- * Formats a log message according to the ChromePHP array format
- *
- * @author Christophe Coevoet <st...@notk.org>
- */
-class ChromePHPFormatter implements FormatterInterface
-{
-    /**
-     * Translates Monolog log levels to Wildfire levels.
-     */
-    private $logLevels = array(
-        Logger::DEBUG     => 'log',
-        Logger::INFO      => 'info',
-        Logger::NOTICE    => 'info',
-        Logger::WARNING   => 'warn',
-        Logger::ERROR     => 'error',
-        Logger::CRITICAL  => 'error',
-        Logger::ALERT     => 'error',
-        Logger::EMERGENCY => 'error',
-    );
-
-    /**
-     * {@inheritdoc}
-     */
-    public function format(array $record)
-    {
-        // Retrieve the line and file if set and remove them from the formatted extra
-        $backtrace = 'unknown';
-        if (isset($record['extra']['file']) && isset($record['extra']['line'])) {
-            $backtrace = $record['extra']['file'].' : '.$record['extra']['line'];
-            unset($record['extra']['file']);
-            unset($record['extra']['line']);
-        }
-
-        $message = array('message' => $record['message']);
-        if ($record['context']) {
-            $message['context'] = $record['context'];
-        }
-        if ($record['extra']) {
-            $message['extra'] = $record['extra'];
-        }
-        if (count($message) === 1) {
-            $message = reset($message);
-        }
-
-        return array(
-            $record['channel'],
-            $message,
-            $backtrace,
-            $this->logLevels[$record['level']],
-        );
-    }
-
-    public function formatBatch(array $records)
-    {
-        $formatted = array();
-
-        foreach ($records as $record) {
-            $formatted[] = $this->format($record);
-        }
-
-        return $formatted;
-    }
-}

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/src/Monolog/Formatter/ElasticaFormatter.php
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/src/Monolog/Formatter/ElasticaFormatter.php b/vendor/monolog/monolog/src/Monolog/Formatter/ElasticaFormatter.php
deleted file mode 100644
index b0b0cf0..0000000
--- a/vendor/monolog/monolog/src/Monolog/Formatter/ElasticaFormatter.php
+++ /dev/null
@@ -1,87 +0,0 @@
-<?php
-
-/*
- * This file is part of the Monolog package.
- *
- * (c) Jordi Boggiano <j....@seld.be>
- *
- * For the full copyright and license information, please view the LICENSE
- * file that was distributed with this source code.
- */
-
-namespace Monolog\Formatter;
-
-use Elastica\Document;
-
-/**
- * Format a log message into an Elastica Document
- *
- * @author Jelle Vink <je...@gmail.com>
- */
-class ElasticaFormatter extends NormalizerFormatter
-{
-    /**
-     * @var string Elastic search index name
-     */
-    protected $index;
-
-    /**
-     * @var string Elastic search document type
-     */
-    protected $type;
-
-    /**
-     * @param string $index Elastic Search index name
-     * @param string $type  Elastic Search document type
-     */
-    public function __construct($index, $type)
-    {
-        parent::__construct(\DateTime::ISO8601);
-        $this->index = $index;
-        $this->type = $type;
-    }
-
-    /**
-     * {@inheritdoc}
-     */
-    public function format(array $record)
-    {
-        $record = parent::format($record);
-
-        return $this->getDocument($record);
-    }
-
-    /**
-     * Getter index
-     * @return string
-     */
-    public function getIndex()
-    {
-        return $this->index;
-    }
-
-    /**
-     * Getter type
-     * @return string
-     */
-    public function getType()
-    {
-        return $this->type;
-    }
-
-    /**
-     * Convert a log message into an Elastica Document
-     *
-     * @param  array    $record Log message
-     * @return Document
-     */
-    protected function getDocument($record)
-    {
-        $document = new Document();
-        $document->setData($record);
-        $document->setType($this->type);
-        $document->setIndex($this->index);
-
-        return $document;
-    }
-}

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/src/Monolog/Formatter/FlowdockFormatter.php
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/src/Monolog/Formatter/FlowdockFormatter.php b/vendor/monolog/monolog/src/Monolog/Formatter/FlowdockFormatter.php
deleted file mode 100644
index af63d01..0000000
--- a/vendor/monolog/monolog/src/Monolog/Formatter/FlowdockFormatter.php
+++ /dev/null
@@ -1,104 +0,0 @@
-<?php
-
-/*
- * This file is part of the Monolog package.
- *
- * (c) Jordi Boggiano <j....@seld.be>
- *
- * For the full copyright and license information, please view the LICENSE
- * file that was distributed with this source code.
- */
-
-namespace Monolog\Formatter;
-
-/**
- * formats the record to be used in the FlowdockHandler
- *
- * @author Dominik Liebler <li...@gmail.com>
- */
-class FlowdockFormatter implements FormatterInterface
-{
-    /**
-     * @var string
-     */
-    private $source;
-
-    /**
-     * @var string
-     */
-    private $sourceEmail;
-
-    /**
-     * @param string $source
-     * @param string $sourceEmail
-     */
-    public function __construct($source, $sourceEmail)
-    {
-        $this->source = $source;
-        $this->sourceEmail = $sourceEmail;
-    }
-
-    /**
-     * {@inheritdoc}
-     */
-    public function format(array $record)
-    {
-        $tags = array(
-            '#logs',
-            '#' . strtolower($record['level_name']),
-            '#' . $record['channel'],
-        );
-
-        foreach ($record['extra'] as $value) {
-            $tags[] = '#' . $value;
-        }
-
-        $subject = sprintf(
-            'in %s: %s - %s',
-            $this->source,
-            $record['level_name'],
-            $this->getShortMessage($record['message'])
-        );
-
-        $record['flowdock'] = array(
-            'source' => $this->source,
-            'from_address' => $this->sourceEmail,
-            'subject' => $subject,
-            'content' => $record['message'],
-            'tags' => $tags,
-            'project' => $this->source,
-        );
-
-        return $record;
-    }
-
-    /**
-     * {@inheritdoc}
-     */
-    public function formatBatch(array $records)
-    {
-        $formatted = array();
-
-        foreach ($records as $record) {
-            $formatted[] = $this->format($record);
-        }
-
-        return $formatted;
-    }
-
-    /**
-     * @param string $message
-     *
-     * @return string
-     */
-    public function getShortMessage($message)
-    {
-        $maxLength = 45;
-
-        if (strlen($message) > $maxLength) {
-            $message = substr($message, 0, $maxLength - 4) . ' ...';
-        }
-
-        return $message;
-    }
-}

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/src/Monolog/Formatter/FormatterInterface.php
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/src/Monolog/Formatter/FormatterInterface.php b/vendor/monolog/monolog/src/Monolog/Formatter/FormatterInterface.php
deleted file mode 100644
index b5de751..0000000
--- a/vendor/monolog/monolog/src/Monolog/Formatter/FormatterInterface.php
+++ /dev/null
@@ -1,36 +0,0 @@
-<?php
-
-/*
- * This file is part of the Monolog package.
- *
- * (c) Jordi Boggiano <j....@seld.be>
- *
- * For the full copyright and license information, please view the LICENSE
- * file that was distributed with this source code.
- */
-
-namespace Monolog\Formatter;
-
-/**
- * Interface for formatters
- *
- * @author Jordi Boggiano <j....@seld.be>
- */
-interface FormatterInterface
-{
-    /**
-     * Formats a log record.
-     *
-     * @param  array $record A record to format
-     * @return mixed The formatted record
-     */
-    public function format(array $record);
-
-    /**
-     * Formats a set of log records.
-     *
-     * @param  array $records A set of records to format
-     * @return mixed The formatted set of records
-     */
-    public function formatBatch(array $records);
-}

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/src/Monolog/Formatter/GelfMessageFormatter.php
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/src/Monolog/Formatter/GelfMessageFormatter.php b/vendor/monolog/monolog/src/Monolog/Formatter/GelfMessageFormatter.php
deleted file mode 100644
index 1e43175..0000000
--- a/vendor/monolog/monolog/src/Monolog/Formatter/GelfMessageFormatter.php
+++ /dev/null
@@ -1,111 +0,0 @@
-<?php
-
-/*
- * This file is part of the Monolog package.
- *
- * (c) Jordi Boggiano <j....@seld.be>
- *
- * For the full copyright and license information, please view the LICENSE
- * file that was distributed with this source code.
- */
-
-namespace Monolog\Formatter;
-
-use Monolog\Logger;
-use Gelf\Message;
-
-/**
- * Serializes a log message to GELF
- * @see http://www.graylog2.org/about/gelf
- *
- * @author Matt Lehner <ml...@gmail.com>
- */
-class GelfMessageFormatter extends NormalizerFormatter
-{
-    /**
-     * @var string the name of the system for the Gelf log message
-     */
-    protected $systemName;
-
-    /**
-     * @var string a prefix for 'extra' fields from the Monolog record (optional)
-     */
-    protected $extraPrefix;
-
-    /**
-     * @var string a prefix for 'context' fields from the Monolog record (optional)
-     */
-    protected $contextPrefix;
-
-    /**
-     * Translates Monolog log levels to Graylog2 log priorities.
-     */
-    private $logLevels = array(
-        Logger::DEBUG     => 7,
-        Logger::INFO      => 6,
-        Logger::NOTICE    => 5,
-        Logger::WARNING   => 4,
-        Logger::ERROR     => 3,
-        Logger::CRITICAL  => 2,
-        Logger::ALERT     => 1,
-        Logger::EMERGENCY => 0,
-    );
-
-    public function __construct($systemName = null, $extraPrefix = null, $contextPrefix = 'ctxt_')
-    {
-        parent::__construct('U.u');
-
-        $this->systemName = $systemName ?: gethostname();
-
-        $this->extraPrefix = $extraPrefix;
-        $this->contextPrefix = $contextPrefix;
-    }
-
-    /**
-     * {@inheritdoc}
-     */
-    public function format(array $record)
-    {
-        $record = parent::format($record);
-
-        if (!isset($record['datetime'], $record['message'], $record['level'])) {
-            throw new \InvalidArgumentException('The record should at least contain datetime, message and level keys, '.var_export($record, true).' given');
-        }
-
-        $message = new Message();
-        $message
-            ->setTimestamp($record['datetime'])
-            ->setShortMessage((string) $record['message'])
-            ->setHost($this->systemName)
-            ->setLevel($this->logLevels[$record['level']]);
-
-        if (isset($record['channel'])) {
-            $message->setFacility($record['channel']);
-        }
-        if (isset($record['extra']['line'])) {
-            $message->setLine($record['extra']['line']);
-            unset($record['extra']['line']);
-        }
-        if (isset($record['extra']['file'])) {
-            $message->setFile($record['extra']['file']);
-            unset($record['extra']['file']);
-        }
-
-        foreach ($record['extra'] as $key => $val) {
-            $message->setAdditional($this->extraPrefix . $key, is_scalar($val) ? $val : $this->toJson($val));
-        }
-
-        foreach ($record['context'] as $key => $val) {
-            $message->setAdditional($this->contextPrefix . $key, is_scalar($val) ? $val : $this->toJson($val));
-        }
-
-        if (null === $message->getFile() && isset($record['context']['exception']['file'])) {
-            if (preg_match("/^(.+):([0-9]+)$/", $record['context']['exception']['file'], $matches)) {
-                $message->setFile($matches[1]);
-                $message->setLine($matches[2]);
-            }
-        }
-
-        return $message;
-    }
-}

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/src/Monolog/Formatter/HtmlFormatter.php
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/src/Monolog/Formatter/HtmlFormatter.php b/vendor/monolog/monolog/src/Monolog/Formatter/HtmlFormatter.php
deleted file mode 100644
index 255d288..0000000
--- a/vendor/monolog/monolog/src/Monolog/Formatter/HtmlFormatter.php
+++ /dev/null
@@ -1,140 +0,0 @@
-<?php
-/*
- * This file is part of the Monolog package.
- *
- * (c) Jordi Boggiano <j....@seld.be>
- *
- * For the full copyright and license information, please view the LICENSE
- * file that was distributed with this source code.
- */
-
-namespace Monolog\Formatter;
-
-use Monolog\Logger;
-
-/**
- * Formats incoming records into an HTML table
- *
- * This is especially useful for html email logging
- *
- * @author Tiago Brito <tl...@gmail.com>
- */
-class HtmlFormatter extends NormalizerFormatter
-{
-    /**
-     * Translates Monolog log levels to html color priorities.
-     */
-    private $logLevels = array(
-        Logger::DEBUG     => '#cccccc',
-        Logger::INFO      => '#468847',
-        Logger::NOTICE    => '#3a87ad',
-        Logger::WARNING   => '#c09853',
-        Logger::ERROR     => '#f0ad4e',
-        Logger::CRITICAL  => '#FF7708',
-        Logger::ALERT     => '#C12A19',
-        Logger::EMERGENCY => '#000000',
-    );
-
-    /**
-     * @param string $dateFormat The format of the timestamp: one supported by DateTime::format
-     */
-    public function __construct($dateFormat = null)
-    {
-        parent::__construct($dateFormat);
-    }
-
-    /**
-     * Creates an HTML table row
-     *
-     * @param  string $th       Row header content
-     * @param  string $td       Row standard cell content
-     * @param  bool   $escapeTd false if td content must not be html escaped
-     * @return string
-     */
-    private function addRow($th, $td = ' ', $escapeTd = true)
-    {
-        $th = htmlspecialchars($th, ENT_NOQUOTES, 'UTF-8');
-        if ($escapeTd) {
-            $td = '<pre>'.htmlspecialchars($td, ENT_NOQUOTES, 'UTF-8').'</pre>';
-        }
-
-        return "<tr style=\"padding: 4px;spacing: 0;text-align: left;\">\n<th style=\"background: #cccccc\" width=\"100px\">$th:</th>\n<td style=\"padding: 4px;spacing: 0;text-align: left;background: #eeeeee\">".$td."</td>\n</tr>";
-    }
-
-    /**
-     * Create a HTML h1 tag
-     *
-     * @param  string  $title Text to be in the h1
-     * @param  integer $level Error level
-     * @return string
-     */
-    private function addTitle($title, $level)
-    {
-        $title = htmlspecialchars($title, ENT_NOQUOTES, 'UTF-8');
-
-        return '<h1 style="background: '.$this->logLevels[$level].';color: #ffffff;padding: 5px;" class="monolog-output">'.$title.'</h1>';
-    }
-    /**
-     * Formats a log record.
-     *
-     * @param  array $record A record to format
-     * @return mixed The formatted record
-     */
-    public function format(array $record)
-    {
-        $output = $this->addTitle($record['level_name'], $record['level']);
-        $output .= '<table cellspacing="1" width="100%" class="monolog-output">';
-
-        $output .= $this->addRow('Message', (string) $record['message']);
-        $output .= $this->addRow('Time', $record['datetime']->format($this->dateFormat));
-        $output .= $this->addRow('Channel', $record['channel']);
-        if ($record['context']) {
-            $embeddedTable = '<table cellspacing="1" width="100%">';
-            foreach ($record['context'] as $key => $value) {
-                $embeddedTable .= $this->addRow($key, $this->convertToString($value));
-            }
-            $embeddedTable .= '</table>';
-            $output .= $this->addRow('Context', $embeddedTable, false);
-        }
-        if ($record['extra']) {
-            $embeddedTable = '<table cellspacing="1" width="100%">';
-            foreach ($record['extra'] as $key => $value) {
-                $embeddedTable .= $this->addRow($key, $this->convertToString($value));
-            }
-            $embeddedTable .= '</table>';
-            $output .= $this->addRow('Extra', $embeddedTable, false);
-        }
-
-        return $output.'</table>';
-    }
-
-    /**
-     * Formats a set of log records.
-     *
-     * @param  array $records A set of records to format
-     * @return mixed The formatted set of records
-     */
-    public function formatBatch(array $records)
-    {
-        $message = '';
-        foreach ($records as $record) {
-            $message .= $this->format($record);
-        }
-
-        return $message;
-    }
-
-    protected function convertToString($data)
-    {
-        if (null === $data || is_scalar($data)) {
-            return (string) $data;
-        }
-
-        $data = $this->normalize($data);
-        if (version_compare(PHP_VERSION, '5.4.0', '>=')) {
-            return json_encode($data, JSON_PRETTY_PRINT | JSON_UNESCAPED_SLASHES | JSON_UNESCAPED_UNICODE);
-        }
-
-        return str_replace('\\/', '/', json_encode($data));
-    }
-}

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/src/Monolog/Formatter/JsonFormatter.php
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/src/Monolog/Formatter/JsonFormatter.php b/vendor/monolog/monolog/src/Monolog/Formatter/JsonFormatter.php
deleted file mode 100644
index e5a1d2c..0000000
--- a/vendor/monolog/monolog/src/Monolog/Formatter/JsonFormatter.php
+++ /dev/null
@@ -1,116 +0,0 @@
-<?php
-
-/*
- * This file is part of the Monolog package.
- *
- * (c) Jordi Boggiano <j....@seld.be>
- *
- * For the full copyright and license information, please view the LICENSE
- * file that was distributed with this source code.
- */
-
-namespace Monolog\Formatter;
-
-/**
- * Encodes whatever record data is passed to it as json
- *
- * This can be useful to log to databases or remote APIs
- *
- * @author Jordi Boggiano <j....@seld.be>
- */
-class JsonFormatter implements FormatterInterface
-{
-    const BATCH_MODE_JSON = 1;
-    const BATCH_MODE_NEWLINES = 2;
-
-    protected $batchMode;
-    protected $appendNewline;
-
-    /**
-     * @param int $batchMode
-     */
-    public function __construct($batchMode = self::BATCH_MODE_JSON, $appendNewline = true)
-    {
-        $this->batchMode = $batchMode;
-        $this->appendNewline = $appendNewline;
-    }
-
-    /**
-     * The batch mode option configures the formatting style for
-     * multiple records. By default, multiple records will be
-     * formatted as a JSON-encoded array. However, for
-     * compatibility with some API endpoints, alternative styles
-     * are available.
-     *
-     * @return int
-     */
-    public function getBatchMode()
-    {
-        return $this->batchMode;
-    }
-
-    /**
-     * True if newlines are appended to every formatted record
-     *
-     * @return bool
-     */
-    public function isAppendingNewlines()
-    {
-        return $this->appendNewline;
-    }
-
-    /**
-     * {@inheritdoc}
-     */
-    public function format(array $record)
-    {
-        return json_encode($record) . ($this->appendNewline ? "\n" : '');
-    }
-
-    /**
-     * {@inheritdoc}
-     */
-    public function formatBatch(array $records)
-    {
-        switch ($this->batchMode) {
-            case static::BATCH_MODE_NEWLINES:
-                return $this->formatBatchNewlines($records);
-
-            case static::BATCH_MODE_JSON:
-            default:
-                return $this->formatBatchJson($records);
-        }
-    }
-
-    /**
-     * Return a JSON-encoded array of records.
-     *
-     * @param  array  $records
-     * @return string
-     */
-    protected function formatBatchJson(array $records)
-    {
-        return json_encode($records);
-    }
-
-    /**
-     * Use new lines to separate records instead of a
-     * JSON-encoded array.
-     *
-     * @param  array  $records
-     * @return string
-     */
-    protected function formatBatchNewlines(array $records)
-    {
-        $instance = $this;
-
-        $oldNewline = $this->appendNewline;
-        $this->appendNewline = false;
-        array_walk($records, function (&$value, $key) use ($instance) {
-            $value = $instance->format($value);
-        });
-        $this->appendNewline = $oldNewline;
-
-        return implode("\n", $records);
-    }
-}

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/src/Monolog/Formatter/LineFormatter.php
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/src/Monolog/Formatter/LineFormatter.php b/vendor/monolog/monolog/src/Monolog/Formatter/LineFormatter.php
deleted file mode 100644
index 6983d1a..0000000
--- a/vendor/monolog/monolog/src/Monolog/Formatter/LineFormatter.php
+++ /dev/null
@@ -1,159 +0,0 @@
-<?php
-
-/*
- * This file is part of the Monolog package.
- *
- * (c) Jordi Boggiano <j....@seld.be>
- *
- * For the full copyright and license information, please view the LICENSE
- * file that was distributed with this source code.
- */
-
-namespace Monolog\Formatter;
-
-use Exception;
-
-/**
- * Formats incoming records into a one-line string
- *
- * This is especially useful for logging to files
- *
- * @author Jordi Boggiano <j....@seld.be>
- * @author Christophe Coevoet <st...@notk.org>
- */
-class LineFormatter extends NormalizerFormatter
-{
-    const SIMPLE_FORMAT = "[%datetime%] %channel%.%level_name%: %message% %context% %extra%\n";
-
-    protected $format;
-    protected $allowInlineLineBreaks;
-    protected $ignoreEmptyContextAndExtra;
-    protected $includeStacktraces;
-
-    /**
-     * @param string $format                     The format of the message
-     * @param string $dateFormat                 The format of the timestamp: one supported by DateTime::format
-     * @param bool   $allowInlineLineBreaks      Whether to allow inline line breaks in log entries
-     * @param bool   $ignoreEmptyContextAndExtra
-     */
-    public function __construct($format = null, $dateFormat = null, $allowInlineLineBreaks = false, $ignoreEmptyContextAndExtra = false)
-    {
-        $this->format = $format ?: static::SIMPLE_FORMAT;
-        $this->allowInlineLineBreaks = $allowInlineLineBreaks;
-        $this->ignoreEmptyContextAndExtra = $ignoreEmptyContextAndExtra;
-        parent::__construct($dateFormat);
-    }
-
-    public function includeStacktraces($include = true)
-    {
-        $this->includeStacktraces = $include;
-        if ($this->includeStacktraces) {
-            $this->allowInlineLineBreaks = true;
-        }
-    }
-
-    public function allowInlineLineBreaks($allow = true)
-    {
-        $this->allowInlineLineBreaks = $allow;
-    }
-
-    public function ignoreEmptyContextAndExtra($ignore = true)
-    {
-        $this->ignoreEmptyContextAndExtra = $ignore;
-    }
-
-    /**
-     * {@inheritdoc}
-     */
-    public function format(array $record)
-    {
-        $vars = parent::format($record);
-
-        $output = $this->format;
-
-        foreach ($vars['extra'] as $var => $val) {
-            if (false !== strpos($output, '%extra.'.$var.'%')) {
-                $output = str_replace('%extra.'.$var.'%', $this->stringify($val), $output);
-                unset($vars['extra'][$var]);
-            }
-        }
-
-        if ($this->ignoreEmptyContextAndExtra) {
-            if (empty($vars['context'])) {
-                unset($vars['context']);
-                $output = str_replace('%context%', '', $output);
-            }
-
-            if (empty($vars['extra'])) {
-                unset($vars['extra']);
-                $output = str_replace('%extra%', '', $output);
-            }
-        }
-
-        foreach ($vars as $var => $val) {
-            if (false !== strpos($output, '%'.$var.'%')) {
-                $output = str_replace('%'.$var.'%', $this->stringify($val), $output);
-            }
-        }
-
-        return $output;
-    }
-
-    public function formatBatch(array $records)
-    {
-        $message = '';
-        foreach ($records as $record) {
-            $message .= $this->format($record);
-        }
-
-        return $message;
-    }
-
-    public function stringify($value)
-    {
-        return $this->replaceNewlines($this->convertToString($value));
-    }
-
-    protected function normalizeException(Exception $e)
-    {
-        $previousText = '';
-        if ($previous = $e->getPrevious()) {
-            do {
-                $previousText .= ', '.get_class($previous).'(code: '.$previous->getCode().'): '.$previous->getMessage().' at '.$previous->getFile().':'.$previous->getLine();
-            } while ($previous = $previous->getPrevious());
-        }
-
-        $str = '[object] ('.get_class($e).'(code: '.$e->getCode().'): '.$e->getMessage().' at '.$e->getFile().':'.$e->getLine().$previousText.')';
-        if ($this->includeStacktraces) {
-            $str .= "\n[stacktrace]\n".$e->getTraceAsString();
-        }
-
-        return $str;
-    }
-
-    protected function convertToString($data)
-    {
-        if (null === $data || is_bool($data)) {
-            return var_export($data, true);
-        }
-
-        if (is_scalar($data)) {
-            return (string) $data;
-        }
-
-        if (version_compare(PHP_VERSION, '5.4.0', '>=')) {
-            return $this->toJson($data, true);
-        }
-
-        return str_replace('\\/', '/', @json_encode($data));
-    }
-
-    protected function replaceNewlines($str)
-    {
-        if ($this->allowInlineLineBreaks) {
-            return $str;
-        }
-
-        return strtr($str, array("\r\n" => ' ', "\r" => ' ', "\n" => ' '));
-    }
-}

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/src/Monolog/Formatter/LogglyFormatter.php
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/src/Monolog/Formatter/LogglyFormatter.php b/vendor/monolog/monolog/src/Monolog/Formatter/LogglyFormatter.php
deleted file mode 100644
index f02bceb..0000000
--- a/vendor/monolog/monolog/src/Monolog/Formatter/LogglyFormatter.php
+++ /dev/null
@@ -1,47 +0,0 @@
-<?php
-
-/*
- * This file is part of the Monolog package.
- *
- * (c) Jordi Boggiano <j....@seld.be>
- *
- * For the full copyright and license information, please view the LICENSE
- * file that was distributed with this source code.
- */
-
-namespace Monolog\Formatter;
-
-/**
- * Encodes message information into JSON in a format compatible with Loggly.
- *
- * @author Adam Pancutt <ad...@pancutt.com>
- */
-class LogglyFormatter extends JsonFormatter
-{
-    /**
-     * Overrides the default batch mode to new lines for compatibility with the
-     * Loggly bulk API.
-     *
-     * @param integer $batchMode
-     */
-    public function __construct($batchMode = self::BATCH_MODE_NEWLINES, $appendNewline = false)
-    {
-        parent::__construct($batchMode, $appendNewline);
-    }
-
-    /**
-     * Appends the 'timestamp' parameter for indexing by Loggly.
-     *
-     * @see https://www.loggly.com/docs/automated-parsing/#json
-     * @see \Monolog\Formatter\JsonFormatter::format()
-     */
-    public function format(array $record)
-    {
-        if (isset($record["datetime"]) && ($record["datetime"] instanceof \DateTime)) {
-            $record["timestamp"] = $record["datetime"]->format("Y-m-d\TH:i:s.uO");
-            // TODO 2.0 unset the 'datetime' parameter, retained for BC
-        }
-
-        return parent::format($record);
-    }
-}

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/src/Monolog/Formatter/LogstashFormatter.php
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/src/Monolog/Formatter/LogstashFormatter.php b/vendor/monolog/monolog/src/Monolog/Formatter/LogstashFormatter.php
deleted file mode 100644
index 7a7b3b3..0000000
--- a/vendor/monolog/monolog/src/Monolog/Formatter/LogstashFormatter.php
+++ /dev/null
@@ -1,165 +0,0 @@
-<?php
-
-/*
- * This file is part of the Monolog package.
- *
- * (c) Jordi Boggiano <j....@seld.be>
- *
- * For the full copyright and license information, please view the LICENSE
- * file that was distributed with this source code.
- */
-
-namespace Monolog\Formatter;
-
-/**
- * Serializes a log message to Logstash Event Format
- *
- * @see http://logstash.net/
- * @see https://github.com/logstash/logstash/blob/master/lib/logstash/event.rb
- *
- * @author Tim Mower <ti...@gmail.com>
- */
-class LogstashFormatter extends NormalizerFormatter
-{
-    const V0 = 0;
-    const V1 = 1;
-
-    /**
-     * @var string the name of the system for the Logstash log message, used to fill the @source field
-     */
-    protected $systemName;
-
-    /**
-     * @var string an application name for the Logstash log message, used to fill the @type field
-     */
-    protected $applicationName;
-
-    /**
-     * @var string a prefix for 'extra' fields from the Monolog record (optional)
-     */
-    protected $extraPrefix;
-
-    /**
-     * @var string a prefix for 'context' fields from the Monolog record (optional)
-     */
-    protected $contextPrefix;
-
-    /**
-     * @var integer logstash format version to use
-     */
-    protected $version;
-
-    /**
-     * @param string $applicationName the application that sends the data, used as the "type" field of logstash
-     * @param string $systemName      the system/machine name, used as the "source" field of logstash, defaults to the hostname of the machine
-     * @param string $extraPrefix     prefix for extra keys inside logstash "fields"
-     * @param string $contextPrefix   prefix for context keys inside logstash "fields", defaults to ctxt_
-     */
-    public function __construct($applicationName, $systemName = null, $extraPrefix = null, $contextPrefix = 'ctxt_', $version = self::V0)
-    {
-        // logstash requires a ISO 8601 format date with optional millisecond precision.
-        parent::__construct('Y-m-d\TH:i:s.uP');
-
-        $this->systemName = $systemName ?: gethostname();
-        $this->applicationName = $applicationName;
-        $this->extraPrefix = $extraPrefix;
-        $this->contextPrefix = $contextPrefix;
-        $this->version = $version;
-    }
-
-    /**
-     * {@inheritdoc}
-     */
-    public function format(array $record)
-    {
-        $record = parent::format($record);
-
-        if ($this->version === self::V1) {
-            $message = $this->formatV1($record);
-        } else {
-            $message = $this->formatV0($record);
-        }
-
-        return $this->toJson($message) . "\n";
-    }
-
-    protected function formatV0(array $record)
-    {
-        if (empty($record['datetime'])) {
-            $record['datetime'] = gmdate('c');
-        }
-        $message = array(
-            '@timestamp' => $record['datetime'],
-            '@source' => $this->systemName,
-            '@fields' => array()
-        );
-        if (isset($record['message'])) {
-            $message['@message'] = $record['message'];
-        }
-        if (isset($record['channel'])) {
-            $message['@tags'] = array($record['channel']);
-            $message['@fields']['channel'] = $record['channel'];
-        }
-        if (isset($record['level'])) {
-            $message['@fields']['level'] = $record['level'];
-        }
-        if ($this->applicationName) {
-            $message['@type'] = $this->applicationName;
-        }
-        if (isset($record['extra']['server'])) {
-            $message['@source_host'] = $record['extra']['server'];
-        }
-        if (isset($record['extra']['url'])) {
-            $message['@source_path'] = $record['extra']['url'];
-        }
-        if (!empty($record['extra'])) {
-            foreach ($record['extra'] as $key => $val) {
-                $message['@fields'][$this->extraPrefix . $key] = $val;
-            }
-        }
-        if (!empty($record['context'])) {
-            foreach ($record['context'] as $key => $val) {
-                $message['@fields'][$this->contextPrefix . $key] = $val;
-            }
-        }
-
-        return $message;
-    }
-
-    protected function formatV1(array $record)
-    {
-        if (empty($record['datetime'])) {
-            $record['datetime'] = gmdate('c');
-        }
-        $message = array(
-            '@timestamp' => $record['datetime'],
-            '@version' => 1,
-            'host' => $this->systemName,
-        );
-        if (isset($record['message'])) {
-            $message['message'] = $record['message'];
-        }
-        if (isset($record['channel'])) {
-            $message['type'] = $record['channel'];
-            $message['channel'] = $record['channel'];
-        }
-        if (isset($record['level_name'])) {
-            $message['level'] = $record['level_name'];
-        }
-        if ($this->applicationName) {
-            $message['type'] = $this->applicationName;
-        }
-        if (!empty($record['extra'])) {
-            foreach ($record['extra'] as $key => $val) {
-                $message[$this->extraPrefix . $key] = $val;
-            }
-        }
-        if (!empty($record['context'])) {
-            foreach ($record['context'] as $key => $val) {
-                $message[$this->contextPrefix . $key] = $val;
-            }
-        }
-
-        return $message;
-    }
-}

http://git-wip-us.apache.org/repos/asf/airavata-php-gateway/blob/80fd786e/vendor/monolog/monolog/src/Monolog/Formatter/MongoDBFormatter.php
----------------------------------------------------------------------
diff --git a/vendor/monolog/monolog/src/Monolog/Formatter/MongoDBFormatter.php b/vendor/monolog/monolog/src/Monolog/Formatter/MongoDBFormatter.php
deleted file mode 100644
index eb067bb..0000000
--- a/vendor/monolog/monolog/src/Monolog/Formatter/MongoDBFormatter.php
+++ /dev/null
@@ -1,105 +0,0 @@
-<?php
-
-/*
- * This file is part of the Monolog package.
- *
- * (c) Jordi Boggiano <j....@seld.be>
- *
- * For the full copyright and license information, please view the LICENSE
- * file that was distributed with this source code.
- */
-
-namespace Monolog\Formatter;
-
-/**
- * Formats a record for use with the MongoDBHandler.
- *
- * @author Florian Plattner <me...@florianplattner.de>
- */
-class MongoDBFormatter implements FormatterInterface
-{
-    private $exceptionTraceAsString;
-    private $maxNestingLevel;
-
-    /**
-     * @param int  $maxNestingLevel        0 means infinite nesting, the $record itself is level 1, $record['context'] is 2
-     * @param bool $exceptionTraceAsString set to false to log exception traces as a sub documents instead of strings
-     */
-    public function __construct($maxNestingLevel = 3, $exceptionTraceAsString = true)
-    {
-        $this->maxNestingLevel = max($maxNestingLevel, 0);
-        $this->exceptionTraceAsString = (bool) $exceptionTraceAsString;
-    }
-
-    /**
-     * {@inheritDoc}
-     */
-    public function format(array $record)
-    {
-        return $this->formatArray($record);
-    }
-
-    /**
-     * {@inheritDoc}
-     */
-    public function formatBatch(array $records)
-    {
-        foreach ($records as $key => $record) {
-            $records[$key] = $this->format($record);
-        }
-
-        return $records;
-    }
-
-    protected function formatArray(array $record, $nestingLevel = 0)
-    {
-        if ($this->maxNestingLevel == 0 || $nestingLevel <= $this->maxNestingLevel) {
-            foreach ($record as $name => $value) {
-                if ($value instanceof \DateTime) {
-                    $record[$name] = $this->formatDate($value, $nestingLevel + 1);
-                } elseif ($value instanceof \Exception) {
-                    $record[$name] = $this->formatException($value, $nestingLevel + 1);
-                } elseif (is_array($value)) {
-                    $record[$name] = $this->formatArray($value, $nestingLevel + 1);
-                } elseif (is_object($value)) {
-                    $record[$name] = $this->formatObject($value, $nestingLevel + 1);
-                }
-            }
-        } else {
-            $record = '[...]';
-        }
-
-        return $record;
-    }
-
-    protected function formatObject($value, $nestingLevel)
-    {
-        $objectVars = get_object_vars($value);
-        $objectVars['class'] = get_class($value);
-
-        return $this->formatArray($objectVars, $nestingLevel);
-    }
-
-    protected function formatException(\Exception $exception, $nestingLevel)
-    {
-        $formattedException = array(
-            'class' => get_class($exception),
-            'message' => $exception->getMessage(),
-            'code' => $exception->getCode(),
-            'file' => $exception->getFile() . ':' . $exception->getLine(),
-        );
-
-        if ($this->exceptionTraceAsString === true) {
-            $formattedException['trace'] = $exception->getTraceAsString();
-        } else {
-            $formattedException['trace'] = $exception->getTrace();
-        }
-
-        return $this->formatArray($formattedException, $nestingLevel);
-    }
-
-    protected function formatDate(\DateTime $value, $nestingLevel)
-    {
-        return new \MongoDate($value->getTimestamp());
-    }
-}