summaryrefslogtreecommitdiff
path: root/databases
AgeCommit message (Collapse)AuthorFilesLines
2017-01-26Allow db6 and set up the environment correctly so this buildswiz1-2/+4
automatically against it. Users have to have accepted the db6 license already for installing it anyway.
2017-01-26Updated py-bsddb3 to 6.2.4.wiz2-7/+7
6.2.4: * More complete fix for pkgsrc. 6.2.3: * Update copyright notices. * Solve a conflict between different installations of Berkeley DB on some pkgsrc configurations. 6.2.2: * Correctly detect Berkeley DB installations in SmartOS native zones. * "Probably" (not tested) correctly detect Berkeley DB in pkgsrc systems.
2017-01-26Changes 6.2.23:adam7-61/+202
New Features/Improvements ------------------------- Added support for global message prefixes. Added Replication Manager write forwarding, which enables a client to perform simple put and delete operations by forwarding them to the master. Improved the way we mark a password as consumed. Added support for IPv6. Added support for Java 8. Added support for ARMv7 and above, and for ARM64. ARMv6 and below are no longer supported. Add a new SMP-optimized data model that is especially valuable for highly multithreaded applications. A sliced Berkeley DB instance contains a collection of related Berkeley DB environments, known as slices, each containing a disjoint subset of records. Transactional consistency is individually maintained within each slice, rather than across multiple slices. DB now supports the client-server architecture by providing a stand-alone server program and Java client driver APIs. The server program offers remote access to DB features. The client driver APIs provide building blocks for applications that communicate with a database server. Multiple client applications can communicate with a single server simultaneously. Enabled support of the SQLite user authentication extension. Added Visual Studio 2012 projects. Encryption and checksum can now be enabled with external files (formerly known as BLOBs). Note that only the data stored in the database will be encrypted and checksum protected. The data in the external files will not be encrypted or checksum protected. The BLOB files feature has been renamed external files to reduce confusion with the SQL BLOB datatype. The BLOB related functions have been deprecated, and replaced with new function names; for example, ext_file_threshold has replaced blob_threshold, and blob_threshold is deprecated. See the Upgrading section of the documentation for more details.
2017-01-22Postgis no longer supports PostgreSQL < 9.2.fhajny1-2/+2
2017-01-21Update databases/erlang-p1_pgsql to 1.1.2.fhajny3-9/+9
- Add SSL support.
2017-01-19Convert all occurrences (353 by my count) ofagc8-38/+38
MASTER_SITES= site1 \ site2 style continuation lines to be simple repeated MASTER_SITES+= site1 MASTER_SITES+= site2 lines. As previewed on tech-pkg. With thanks to rillig for fixing pkglint accordingly.
2017-01-18Support postgresql96.jperkin1-2/+2
2017-01-17Update databases/elasticsearch to 5.1.2.fhajny2-7/+7
Aggregations:: - Allow terms aggregations on pure boolean scripts. - IP range masks exclude the maximum address of the range. - Fix `other_bucket` on the `filters` agg to be enabled if a key is set. Allocation:: - Promote shadow replica to primary when initializing primary fails - Trim in-sync allocations set only when it grows Analysis:: - Pre-built analysis factories do not implement MultiTermAware correctly. CRUD:: - Reject external versioning and explicit version numbers on create Core:: - Support negative numbers in readVLong Exceptions:: - Fixing shard recovery error message to report the number of docs correctly for each node Index APIs:: - Ensure shrunk indices carry over version information from its source Internal:: - Don't output null source node in RecoveryFailedException Java REST Client:: - Don't use null charset in RequestLogger Logging:: - Restores the original default format of search slow log Mapping:: - Only update DocumentMapper if field type changes - The `_all` default mapper is not completely configured. - Fix MapperService.allEnabled(). Network:: - Disable the Netty recycler - Tell Netty not to be unsafe in transport client Nested Docs:: - Fix bug in query builder rewrite that ignores the ignore_unmapped option Packaging:: - Another fix for handling of paths on Windows Percolator:: - Fix NPE in percolator's 'now' range check for percolator queries with range queries Plugins:: - Provide helpful error message if a plugin exists - Add shutdown hook for closing CLI commands Plugin Lang Painless:: - Update Painless Loop Counter to be Higher Plugin Repository Azure:: - readonly on azure repository must be taken into account Recovery:: - Fix primary relocation for shadow replicas - Don't close store under CancellableThreads - Use a fresh recovery id when retrying recoveries - Allow flush/force_merge/upgrade on shard marked as relocated Reindex API:: - Don't close rest client from its callback Search:: - Improve concurrency of ShardCoreKeyMap. - Make `-0` compare less than `+0` consistently. - FiltersAggregationBuilder: rewriting filter queries, the same way as in FilterAggregationBuilder Stats:: - Implement stats for geo_point and geo_shape field - Use reader for doc stats - Avoid NPE in NodeService#stats if HTTP is disabled - Add support for "include_segment_file_sizes" in indices stats REST handler Term Vectors:: - Fix _termvectors with preference to not hit NPE - Return correct term statistics when a field is not found in a shard
2017-01-16Reset PKGREVISION after sqlrelay master package update.fhajny10-20/+10
2017-01-16Update databases/sqlrelay to 1.0.0.fhajny8-59/+92
sqlrelay 1.0.0 - updated md5 pwdenc to use rudiments md5 class - solved a long-standing hang that could occur if the database password expired while sqlrelay was running, and the sqlr-scaler attempted to start new connections - added convertcase, convertcasedoublequotes, and removedoublequotes parameters to normalize translation module - added ColumnCaseName parameter to ODBC driver - fixed a subtle bug in the ODBC driver that caused the first row to be skipped if columns were not bound - added -backtrace option for debugging - fixed mysql connection module so it can use the statement API on Windows - fixed semaphore reference-before-init bug in sqlrservercontroller - added support for db, debug, columnnamecase, dontgetcolumninfo, nullsasnulls, and lazyconnect connect-string options to all drivers (though in some they are camel-case and others lower-case) - in DB-abstraction-layer drivers, the debug, dontgetcolumninfo, nullsasnulls, lazyconnect, krb, and tls connect-string options now support any yes/no equivalent such as yes, Yes, y, Y, true, True, 1, (and similar for no) - fixed a regression that could cause crashes in the C#/ADO driver when binding null or date values - added all parameters to ODBC config screen - removed calls to mysql_stmt_store_result/mysql_stmt_num_rows from mysql connection to improve performance. mysql connection doesn't know the total number of rows prior to full fetch now (which is consistent with most other databases). - updated postgresql connection to use an unnamed cursor instead of naming it and having to deallocate it over an over - tweaked skipWhitespaceAndComments and related methods to use charstring::isNullOrEmpty and character::isWhitespace - replaced regular expression comparisons in sap/freetds connections with simpler charstring comparisons - updated db2 connection to reuse the statement instead of recreating it with each prepare - made column-lookup by name case sensitive to improve performance - fixed nagle-disable and sizing of socket read/write buffers - changed default maxcursors to 5 - fixed an uninitialized variable in the firebird connection - python api's are installed in dist-packages subdirectory on systems that have that instead of site-packages - added route-entire-session option to router modules sqlrelay 0.67.0 - general documenation clean-up - added missing all: target to man/Makefile - mysql_info in drop-in library for mysql returns NULL instead of "" now - mysql_errno in the drop-in library now returns the error number from the DB, instead of CR_UNKNOWN_ERROR, if no error map is provided, and the backend database is known to be mysql - mysql_refresh in the drop-in library works with options other than REFRESH_GRANT now - mysql_shutdown/kill in the drop-in library return 1 on failure now rather than 2000 - date/time and timestamp types are recognized as binary types now - year/timestamp types are recognized as unsigned types now - TINY/MEDIUM/LONG_TEXT types are recognized as blobs now - mapping date/time to MYSQL_TYPE_DATE/TIME, rather than MYSQL_TYPE_DATETIME is the default in the drop-in library now and SQLR_MAP_DATETIME_TO_DATE has been removed - mysql drop-in library sets column flags correctly now - mysql drop-in library runs appropriate kill/shutdown queries now - mysql connection uses non-stmt api for "show *" queries now - mysql drop-in library runs "show processlist" for mysql_list_processes - mysql drop-in library supports date/time/datetime input binds now instead of just treating them all as datetimes - connection modules differentiate between date/time/datetime binds now instead of just treating them all as datetimes - added result set row translation module framework - updated firebird connection module to the fieldstruct.textbuffer instead of fieldbuffer for non-text to text translations - added support for negative times in mysql connection module and drop-in library - added translation-failure event - general refactoring of server module API - consolidated sqlr-scaler code - fixed a 1-byte empty-blob memory leak in the client - /etc/alternatives/java_sdk is preferred, if found, now
2017-01-13Update ruby-sequel to 4.42.1.taca3-8/+20
=== 4.42.1 (2017-01-12) * Make dataset_module inherited to subclasses when using the single_table_inheritance plugin (jeremyevans) (#1284) === 4.42.0 (2017-01-01) * Handle eager load callbacks correctly for one_to_one associations with orders or offsets when window functions are not supported (jeremyevans) * Raise Sequel::Error if using an :eager_limit dataset option when eager loading a singular association (jeremyevans) * Replace internal uses of Dataset#select_more with #select_append to save a method call (jeremyevans) * Make Dataset#order_append the primary method, and #order_more the alias, for similarity to #select_append and #select_more (jeremyevans) * Replace internal uses of Dataset#filter with #where to save a method call (jeremyevans) * Do not set :auto_increment in the schema information for integer columns that are part of a composite primary key on SQLite (jeremyevans) * Use autoincrement setting on integer primary key columns when emulating table modification methods on SQLite (thenrio, jeremyevans) (#1277, #1278) * Make the pagination extension work on frozen datasets (jeremyevans) * Make Dataset#server work for frozen model datasets using the sharding plugin (jeremyevans) * Make Dataset#nullify in the null_dataset extension work on frozen datasets (jeremyevans) * Make Model#set_server work when using a frozen model dataset (jeremyevans) * Make Dataset#ungraphed work on a frozen model dataset (jeremyevans) * Add Dataset#with_{autoid,fetch,numrows} to the mock adapter, returning cloned datasets with the setting changed (jeremyevans) * Make looser_typecasting extension handle the strict BigDecimal parsing introduced in ruby 2.4rc1 (jeremyevans) * Make Database#{db,opts}= in the sequel_3_dataset_methods extension raise for frozen datasets (jeremyevans) * Speed up repeated calls to Dataset#{interval,range} for frozen datasets using a cached placeholder literalizer (jeremyevans) * Speed up repeated calls to Dataset#get with a single argument for frozen datasets using a cached placeholder literalizer (jeremyevans) * Speed up repeated calls to Dataset#{first,last} with arguments/blocks for frozen datasets using a cached placeholder literalizer (jeremyevans) * Speed up repeated calls to Dataset#{avg,min,max,sum} for frozen datasets using a cached placeholder literalizer (jeremyevans) * Cache dataset returned by Dataset#skip_locked for frozen datasets (jeremyevans) * Cache dataset returned by Dataset#for_update for frozen datasets (jeremyevans) * Cache dataset returned by Dataset#un{filtered,grouped,limited,ordered} for frozen datasets (jeremyevans) * Cache dataset returned by Dataset#reverse (no args) for frozen datasets (jeremyevans) * Cache dataset returned by Dataset#invert for frozen datasets (jeremyevans) * Speed up repeated calls to Dataset#count with an argument or block for frozen datasets using a cached placeholder literalizer (jeremyevans) * Using :on_duplicate_columns=>:warn Database option with duplicate_columns_handler now prepends file/line to the warning message (jeremyevans) * Move identifier mangling code to identifier_mangling extension, load by default unless using :identifier_mangling=>false Database option (jeremyevans) * Allow Dataset#with_extend to accept a block and create a module with that block that the object is extended with (jeremyevans) * Speed up repeated calls to with_pk on the same frozen model dataset using a cached placeholder literalizer (jeremyevans) * Add dataset_module methods such as select and order that define dataset methods which support caching for frozen datasets (jeremyevans) * Cache subset datasets if they don't use blocks or procs for frozen model datasets (jeremyevans) * Cache intermediate dataset used in Dataset#{last,paged_each} for frozen model datasets without an order (jeremyevans) * Cache dataset returned by Dataset#naked for frozen datasets (jeremyevans) * Cache intermediate dataset used in Dataset#last (no args) for frozen datasets (jeremyevans) * Cache intermediate dataset used in Dataset#first (no args) and #single_record for frozen datasets (jeremyevans) * Cache intermediate dataset used in Dataset#empty? for frozen datasets (jeremyevans) * Cache intermediate dataset used in Dataset#count (no args) for frozen datasets (jeremyevans) * Warn if :conditions option may be unexpectedly ignored during eager_graph/association_join (jeremyevans) (#1272) * Cache SELECT and DELETE SQL for most frozen datasets (jeremyevans) * Freeze most SQL::Expression objects and internal state by default (jeremyevans) * Freeze Dataset::PlaceholderLiteralizer and Dataset::PlaceholderLiteralizer::Argument instances (jeremyevans) * Freeze most dataset opts values to avoid unintentional modification (jeremyevans) * Add Dataset#with_convert_smallint_to_bool on DB2, returning a clone with convert_smallint_to_bool set (jeremyevans) * Make Dataset#freeze actually freeze the dataset on ruby 2.4+ (jeremyevans) * Avoid using instance variables other than @opts for dataset data storage (jeremyevans) * Add freeze_datasets extension, making all datasets for a given Database frozen (jeremyevans) * Refactor prepared statement internals, using opts instead of instance variables (jeremyevans) * Model.set_dataset now operates on a clone of the dataset given instead of modifying it, so it works with frozen datasets (jeremyevans) === 4.41.0 (2016-12-01) * Add Dataset#with_mssql_unicode_strings on Microsoft SQL Server, returning a clone with mssql_unicode_strings set (jeremyevans) * Add Dataset#with_identifier_output_method, returning a clone with identifier_output_method set (jeremyevans) * Add Dataset#with_identifier_input_method, returning a clone with identifier_input_method set (jeremyevans) * Add Dataset#with_quote_identifiers, returning a clone with quote_identifiers set (jeremyevans) * Add Dataset#with_extend, returning a clone extended with given modules (jeremyevans) * Add Dataset#with_row_proc, returning a clone with row_proc set (jeremyevans) * Support use of SQL::AliasedExpressions as Model#to_json :include option keys in the json_serializer plugin (sensadrome) (#1269) * Major improvements to type conversion in the ado adapter (vais, jeremyevans) (#1265) * Avoid memory leak in ado adapter by closing result sets after yielding them (vais, jeremyevans) (#1259) * Fix hook_class_methods plugin handling of commit hooks (jeremyevans) * Make association dataset method correctly handle cases where key fields are nil (jeremyevans) * Handle pure java exceptions that don't support message= when reraising the exception in the jdbc adapter (jeremyevans) * Add support for :offset_strategy Database option on DB2, with :limit_offset and :offset_fetch values, to disable OFFSET emulation (#1254) (jeremyevans) * Remove deprecated support for using Bignum class as a generic type (jeremyevans)
2017-01-13Update ruby-moneta to 0.8.1.taca3-11/+9
0.8.1 * Adapters::TokyoTyrant - more consistent error handling * Adapters::MongoMoped - support for moped gem v2.0 * Adapters::MongoOfficial - support for mongo gem versions 2-4 * Adapters::File - fix a bug in #load (#74) * Adapters::LRUHash - allow to disable the limits by passing nil for max_size, max_count * Transformer - don't use OpenSSL::Digest::Digest namespace * Adapters::Sequel - fix issue with unknown "blob" type * Rack::Cache - fix deprecated require paths * Adapters::MemcachedNative - properly close connections * Transformer - support bson gem versions 2-4 * Transformer - switch to rbzip2 gem for bzip2 support * Adapters::MemcachedDalli - #create returns a boolean
2017-01-12Update databases/mongo-c-driver to 1.5.3.fhajny2-7/+7
Changes since 1.5.0: - allow mixed $ and non-$ query ops. - Missing exports of mongoc_gridfs_file_set_*() functions. - update define constants for "find" opts to be unique. - Windows CA stores should be opened with read-only flag. - Fix SEGFAULT with performance counters on NUMA (thanks to Jonathan Wang). - Prevent rare assertion error in mongoc_cluster_stream_for_server. - Improve error messages from auth failure. - Escape quotes when appending CFLAGS to handshake metadata. - Fix OpenSSL header lookups in non-default paths. - Fix build failure with LibreSSL.
2017-01-12GA 1.1.8:adam4-45/+16
- Add connect options MYSQL_OPT_MAX_ALLOWED_PACKET, MYSQL_OPT_NET_BUFFER_LENGTH, MYSQL_OPT_TLS_VERSION and MYSQL_OPT_SSL_MODE - Fix Visual Studio 2015 build. - Fix segmentation fault when inserting a large string - Fix Compilation Failure with PRE-5.7 C API
2017-01-12Update to latest release 0.7.11. No changelog. Assume "more/better/faster".rodent2-10/+7
2017-01-12Don't depend on rpcgen, just use the pre-generated headers. Fixes buildjperkin2-1/+17
on SmartOS.
2017-01-09Update databases/apache-cassandra2 to 2.1.16.fhajny3-12/+40
2.1.16 - Avoid infinitely looping result set when paging SELECT queries with an IN clause with duplicate keys by treating the IN values as a set instead of a list - Add system property to set the max number of native transport requests in queue - Include column family parameter when -st and -et are provided - Fix queries with empty ByteBuffer values in clustering column restrictions - Disable passing control to post-flush after flush failure to prevent data loss - Allow STCS-in-L0 compactions to reduce scope with LCS - cannot use cql since upgrading python to 2.7.11+ - Fix filtering on clustering columns when 2i is used - Improve digest calculation in the presence of overlapping tombstones 2.1.15 - Account for partition deletions in tombstone histogram - Avoid stalling paxos when the paxos state expires - Remove finished incoming streaming connections from MessagingService - Don't try to get sstables for non-repairing column families - Prevent select statements with clustering key > 64k - Avoid marking too many sstables as repaired - Fix clock skew corrupting other nodes with paxos - Remove distinction between non-existing static columns and existing but null in LWTs - Support mlockall on IBM POWER arch - Cache local ranges when calculating repair neighbors - Allow LWT operation on static column with only partition keys - Create interval tree over canonical sstables to avoid missing sstables during streaming - cqlsh COPY FROM: shutdown parent cluster after forking, to avoid corrupting SSL connections - Updated cqlsh Python driver to fix DESCRIBE problem for legacy tables - cqlsh: apply current keyspace to source command - Backport CASSANDRA-11578 - Clear out parent repair session if repair coordinator dies - Set default streaming_socket_timeout_in_ms to 24 hours - Do not consider local node a valid source during replace - Avoid holding SSTableReaders for duration of incremental repair - Add message dropped tasks to nodetool netstats - Don't compute expensive MaxPurgeableTimestamp until we've verified there's an expired tombstone - Fix paging on DISTINCT queries repeats result when first row in partition changes - Add option to disable use of severity in DynamicEndpointSnitch - cqlsh COPY FROM fails for null values with non-prepared statements - Make cython optional in pylib/setup.py - Change order of directory searching for cassandra.in.sh to favor local one - cqlsh COPY FROM fails with []{} chars in UDT/tuple fields/values - clqsh: COPY FROM throws TypeError with Cython extensions enabled - cqlsh: COPY FROM ignores NULL values in conversion - Validate levels when building LeveledScanner to avoid overlaps with orphaned sstables 2.1.14 - Start L0 STCS-compactions even if there is a L0 -> L1 compaction going - (cqlsh) Fix potential COPY deadlock when parent process is terminating child processes - Replace sstables on DataTracker before marking them as non-compacting during anti-compaction - Checking if an unlogged batch is local is inefficient - Fix paging for COMPACT tables without clustering columns - Fix out-of-space error treatment in memtable flushing - Backport CASSANDRA-10859 - COPY FROM fails when importing blob - Backport CASSANDRA-10679 - Don't do defragmentation if reading from repaired sstables - Fix streaming_socket_timeout_in_ms not enforced - Avoid dropping message too quickly due to missing unit conversion - COPY FROM on large datasets: fix progress report and debug performance - InvalidateKeys should have a weak ref to key cache - Don't remove FailureDetector history on removeEndpoint - Only notify if repair status changed - Add partition key to TombstoneOverwhelmingException error message - Use logback setting for 'cassandra -v' command - Fix sstableloader to unthrottle streaming by default - Fix incorrect warning in 'nodetool status' - Properly release sstable ref when doing offline scrub - Improve nodetool status performance for large cluster - Make it clear what DTCS timestamp_resolution is used for - Gossiper#isEnabled is not thread safe - Avoid major compaction mixing repaired and unrepaired sstables in DTCS - test_bulk_round_trip_blogposts is failing occasionally - Add a -j parameter to scrub/cleanup/upgradesstables to state how many threads to use 2.1.13 - Fix isJoined return true only after becoming cluster member (CASANDRA-11007) - Fix bad gossip generation seen in long-running clusters - Avoid NPE when incremental repair fails - Unmark sstables compacting once they are done in cleanup/scrub/upgradesstables - Revert CASSANDRA-10012 and add more logging - Allow simultaneous bootstrapping with strict consistency when no vnodes are used - Log a message when major compaction does not result in a single file - (cqlsh) fix cqlsh_copy_tests when vnodes are disabled - (cqlsh) fix formatting bytearray values - (cqlsh) Add request timeout option to cqlsh - Avoid AssertionError while submitting hint with LWT - If CompactionMetadata is not in stats file, use index summary instead - Retry sending gossip syn multiple times during shadow round - Fix pending range calculation during moves - Sane default (200Mbps) for inter-DC streaming througput - Match cassandra-loader options in COPY FROM - Fix binding to any address in CqlBulkRecordWriter - Fix the way we replace sstables after anticompaction - cqlsh fails to decode utf-8 characters for text typed columns - Log error when stream session fails - Fix bugs in commit log archiving startup behavior - (cqlsh) further optimise COPY FROM - Allow CREATE TABLE WITH ID - Make Stress compiles within eclipse - Cassandra Daemon should print JVM arguments - Allow cancellation of index summary redistribution - sstableloader will fail if there are collections in the schema tables - Disable reloading of GossipingPropertyFileSnitch - Fix Stress profile parsing on Windows 2.1.12 - Fix incremental repair hang when replica is down - Avoid writing range tombstones after END_OF_ROW marker - Optimize the way we check if a token is repaired in anticompaction - Add proper error handling to stream receiver - Warn or fail when changing cluster topology live - Status command in debian/ubuntu init script doesn't work - Some DROP ... IF EXISTS incorrectly result in exceptions on non-existing KS - DeletionTime.compareTo wrong in rare cases - Force encoding when computing statement ids - Properly reject counters as map keys - Fix the sstable-needs-cleanup check - (cqlsh) Print column names before COPY operation - Add Native-Transport-Requests back to tpstats - Make paging logic consistent between searcher impls - Fix CompressedInputStream for proper cleanup - (cqlsh) Support counters in COPY commands - Try next replica if not possible to connect to primary replica on ColumnFamilyRecordReader - Limit window size in DTCS - sstableloader does not use MAX_HEAP_SIZE env parameter - (cqlsh) Improve COPY TO performance and error handling - Don't remove level info when running upgradesstables - Create compression chunk for sending file only - Make buffered read size configurable - Forbid compact clustering column type changes in ALTER TABLE - Reject incremental repair with subrange repair - Add a nodetool command to refresh size_estimates - Shutdown compaction in drain to prevent leak - Invalidate cache after stream receive task is completed - Reject counter writes in CQLSSTableWriter - Remove superfluous COUNTER_MUTATION stage mapping - Improve json2sstable error reporting on nonexistent columns - (cqlsh) fix COPY using wrong variable name for time_format - Do not run SizeEstimatesRecorder if a node is not a member of the ring - Improve handling of dead nodes in gossip - Fix logback-tools.xml incorrectly configured for outputing to System.err - Fix streaming to catch exception so retry not fail - Add validation method to PerRowSecondaryIndex - Support encrypted and plain traffic on the same port - Do STCS in DTCS windows - Don't try to get ancestors from half-renamed sstables - Avoid repetition of JVM_OPTS in debian package - Fix potential NPE from handling result of SIM.highestSelectivityIndex - Fix paging issues with partitions containing only static columns data - Fix conditions on static columns - AssertionError: attempted to delete non-existing file CommitLog - Merge range tombstones during compaction - (cqlsh) Distinguish negative and positive infinity in output - (cqlsh) allow custom time_format for COPY TO - Don't allow startup if the node's rack has changed - Fix sorting for queries with an IN condition on partition key columns
2017-01-07Changes 3.16.2:adam5-19/+20
Fix the REPLACE statement for WITHOUT ROWID tables that lack secondary indexes so that it works correctly with triggers and foreign keys. This was a new bug caused by performance optimizations added in version 3.16.0. Ticket 30027b613b4 Fix the sqlite3_value_text() interface so that it correctly translates content generated by zeroblob() into a string of all 0x00 characters. This is a long-standing issue discovered after the 3.16.1 release by OSS-Fuzz Fix the bytecode generator to deal with a subquery in the FROM clause that is itself a UNION ALL where one side of the UNION ALL is a view that contains an ORDER BY. This is a long-standing issue that was discovered after the release of 3.16.1. See ticket 190c2507. Adjust the sqlite3_column_count() API so it more often returns the same values for PRAGMA statements as it did in prior releases, to minimize disruption to applications that might be using that interface in unexpected ways.
2017-01-05Changes 3.16.1:adam5-19/+20
Fix a bug concerning the use of row values within triggers (see ticket 8c9458e7) that was in version 3.15.0 but was not reported until moments after the 3.16.0 release was published.
2017-01-04Use curses framework.roy3-7/+19
2017-01-04Use the curses framework.roy1-4/+6
2017-01-04Added buildlink3.mk file. No other changes.jaapb1-0/+18
2017-01-03Update databases/erlang-p1_pgsql to 1.1.1.fhajny2-7/+7
- adding timeout to pgsql:squery - Decode int4 and int8 as signed integers - Better error handling in pgsql:squery
2017-01-03Update databases/erlang-p1_mysql to 1.0.2.fhajny2-7/+7
- accepting query as iodata() on p1_mysql_conn:squery/4 function
2017-01-03Use "${MV} || ${TRUE}" and "${RM} -f" consistently in post-install targets.jperkin2-7/+7
2017-01-03Do not attempt to detect ISA, it conflicts with wrappers. Fixes SunOS.jperkin2-1/+24
2017-01-03Update databases/elasticsearch to 5.1.1.fhajny3-36/+35
== 5.1.1 Release Notes === Breaking changes Aliases:: - Validate alias names the same as index names REST:: - Remove lenient stats parsing 5.x === Breaking Java changes Discovery:: - Remove pluggability of ElectMasterService Exceptions:: - Remove `IndexTemplateAlreadyExistsException` and `IndexShardAlreadyExistsException` - Replace IndexAlreadyExistsException with ResourceAlreadyExistsException - Backport: Replace IndexAlreadyExistsException with ResourceAlreadyExistsException Internal:: - Pass executor name to request interceptor to support async intercept calls Network:: - Unguice Transport and friends Plugins:: - Plugins: Remove support for onModule === Deprecations Analysis:: - Deprecating request parameters of _analyze API in 5.x CRUD:: - Deprecate VersionType.FORCE Core:: - Add deprecation logging for users that explicitly opt in for the `default` fs type. Mapping:: - Deprecate `timestamp` and `ttl` on index requests. Query DSL:: - Add deprecation logging for lenient boolean queries - Add deprecation logging message for 'fuzzy' query Search:: - Deprecate ignored type parameter in search_shards api Settings:: - Add deprecation logging for the case that store throttling is used. === New features Analysis:: - Expose Lucenes Ukrainian analyzer CAT API:: - Provides a cat api endpoint for templates. Query DSL:: - Add "all fields" execution mode to simple_query_string query - Add support for `quote_field_suffix` to `simple_query_string`. - Add "all field" execution mode to query_string query Reindex API:: - Add automatic parallelization support to reindex and friends === Enhancements Aggregations:: - Rescorer should be applied in the TopHits aggregation Allocation:: - Balance step in BalancedShardsAllocator for a single shard - Process more expensive allocation deciders last - Separates decision making from decision application in BalancedShardsAllocator - Split allocator decision making from decision application Analysis:: - Remove AnalysisService and reduce it to a simple name to analyzer mapping CAT API:: - Adding built-in sorting capability to _cat apis. - Add health status parameter to cat indices API Cache:: - Do not cache term queries. - Parse alias filters on the coordinating node Cluster:: - Cache successful shard deletion checks Core:: - Reduce memory pressure when sending large terms queries. - Install a security manager on startup - Log node ID on startup - Ensure source filtering automatons are only compiled once - Improve scheduling fairness when batching cluster state changes with equal priority - Do not log full bootstrap checks exception Exceptions:: - Add BWC layer for Exceptions Geo:: - Optimize geo-distance sorting. Ingest:: - add `ignore_missing` option to SplitProcessor Internal:: - Rename ClusterState#lookupPrototypeSafe to `lookupPrototype` and remove "unsafe" unused variant - ShardActiveResponseHandler shouldn't hold to an entire cluster state - Remove unused ClusterService dependency from SearchPhaseController - Remove special case in case no action filters are registered - Use TimveValue instead of long for CacheBuilder methods - Remove SearchContext#current and all it's threadlocals Java REST Client:: - Provide error message when rest request path is null Logging:: - Log failure to connect to node at info instead of debug - Truncate log messages from the end - Logging shutdown hack - Disable console logging Mapping:: - Create the QueryShardContext lazily in DocumentMapperParser. Network:: - Grant Netty permission to read system somaxconn - Lazy resolve unicast hosts - Fix handler name on message not fully read - Handle rejected pings on shutdown gracefully Packaging:: - Add empty plugins dir for archive distributions - Make explicit missing settings for Windows service - Change permissions on config files Plugin Lang Painless:: - Add Debug.explain to painless - Implement the ?: operator in painless - In painless suggest a long constant if int won't do - Support decimal constants with trailing [dD] in painless - Implement reading from null safe dereferences - Painless negative offsets Plugin Repository S3:: - Make the default S3 buffer size depend on the available memory. Plugins:: - Clarify that plugins can be closed - Plugins: Convert custom discovery to pull based plugin - Removing plugin that isn't installed shouldn't trigger usage information - Remove pluggability of ZenPing - Make UnicastHostsProvider extension pull based Query DSL:: - Using ObjectParser in MatchAllQueryBuilder and IdsQueryBuilder - Expose splitOnWhitespace in `Query String Query` - Throw error if query element doesn't end with END_OBJECT - Remove `lowercase_expanded_terms` and `locale` from query-parser options. Reindex API:: - Make reindex-from-remote ignore unknown fields Scripting:: - Wrap VerifyError in ScriptException - Support binary field type in script values - Mustache: Add - Expose `ctx._now` in update scripts Search:: - Add indices and filter information to search shards api output - remove pointless catch exception in TransportSearchAction - Optimize query with types filter in the URL (t/t/_search) - Makes search action cancelable by task management API Search Templates:: - Add profile and explain parameters to template API Snapshot/Restore:: - Abort snapshots on a node that leaves the cluster Stats:: - Remove load average leniency - Strengthen handling of unavailable cgroup stats - Add basic cgroup CPU metrics Task Manager:: - Add search task descriptions Tribe Node:: - Add support for merging custom meta data in tribe node === Bug fixes Aggregations:: - Rewrite Queries/Filter in FilterAggregationBuilder and ensure client usage marks query as non-cachable - Percentiles bucket fails for 100th percentile - Thread safety for scripted significance heuristics Allocation:: - Allow master to assign primary shard to node that has shard store locked during shard state fetching Analysis:: - Can load non-PreBuiltTokenFilter in Analyze API CAT API:: - Consume `full_id` request parameter early Cache:: - Fix the request cache keys to not hold references to the SearchContext. Circuit Breakers:: - ClusterState publishing shouldn't trigger circuit breakers Cluster:: - Remove cluster update task when task times out Core:: - Add a StreamInput#readArraySize method that ensures sane array sizes - Use a buffer to do character to byte conversion in StreamOutput#writeString - Fix ShardInfo#toString - Protect BytesStreamOutput against overflows of the current number of written bytes. - Return target index name even if _rollover conditions are not met - .es_temp_file remains after system crash, causing it not to start again Dates:: - Fix time zone rounding edge case for DST overlaps Engine:: - Die with dignity on the Lucene layer - Fix `InternalEngine#isThrottled` to not always return `false`. - Retrying replication requests on replica doesn't call `onRetry` Highlighting:: - Fix FiltersFunctionScoreQuery highlighting - Fix highlighting on a stored keyword field Index APIs:: - Validate the `_rollover` target index name early to also fail if dry_run=true Index Templates:: - Fix integer overflows when dealing with templates. Ingest:: - fix trace_match behavior for when there is only one grok pattern - Stored scripts and ingest node configurations should be included into a snapshot Inner Hits:: - Skip adding a parent field to nested documents. Internal:: - Rethrow ExecutionException from the loader to concurrent callers of Cache#computeIfAbsent - Restore thread's original context before returning to the ThreadPool - Fix NPE in SearchContext.toString() - Source filtering should treat dots in field names as sub objects. Java API:: - Transport client: Fix remove address to actually work - Add a HostFailureListener to notify client code if a node got disconnected - Fix InternalSearchHit#hasSource to return the proper boolean value - Null checked for source when calling sourceRef - ClusterAdminClient.prepareDeletePipeline method should accept pipeline id to delete Java REST Client:: - Rest client: don't reuse the same HttpAsyncResponseConsumer across multiple retries Logging:: - Do not prematurely shutdown Log4j - Assert status logger does not warn on Log4j usage - Fix logger names for Netty Mapping:: - Fail to index fields with dots in field names when one of the intermediate objects is nested. - Uncommitted mapping updates should not efect existing indices Network:: - DiscoveryNode and TransportAddress should preserve host information - Die with dignity on the network layer - Prevent double release in TcpTransport if send listener throws an exception Packaging:: - Set vm.max_map_count on systemd package install - Export ES_JVM_OPTIONS for SysV init - Debian: configure start-stop-daemon to not go into background - Generate POM files with non-wildcard excludes Plugin Lang Painless:: - Test fix for def equals in Painless - Fix a VerifyError bug in Painless - Fix Lambdas in Painless to be Able to Use Top-Level Variables Such as params and doc Plugin Mapper Attachment:: - NPE is raised when defining a non existing type within attachments type Query DSL:: - Fixes date range query using epoch with timezone - Allow overriding all-field leniency when `lenient` option is specified - Max score should be updated when a rescorer is used REST:: - Strict level parsing for indices stats - The routing query string param is supported by mget but was missing from the rest spec - fix thread_pool_patterns path variable definition - ensure the XContentBuilder is always closed in RestBuilderListener - XContentBuilder: Avoid building self-referencing objects Reindex API:: - Ignore IllegalArgumentException with assertVersionSerializable - Bump reindex-from-remote's buffer to 200mb - Fix reindex-from-remote for parent/child from <2.0 Search:: - Fix match_phrase_prefix on boosted fields - Respect default search timeout - Remove LateParsingQuery to prevent timestamp access after context is frozen Search Templates:: - SearchTemplateRequest to implement CompositeIndicesRequest Settings:: - Handle spaces in `action.auto_create_index` gracefully - Fix settings diff generation for affix and group settings - Don't reset non-dynamic settings unless explicitly requested Snapshot/Restore:: - Fixes shard level snapshot metadata loading when index-N file is missing - Ensures cleanup of temporary index-* generational blobs during snapshotting - Fixes get snapshot duplicates when asking for _all - Keep snapshot restore state and routing table in sync (5.x backport) Task Manager:: - Task cancellation command should wait for all child nodes to receive cancellation request before returning Tribe Node:: - Add socket permissions for tribe nodes === Upgrades Core:: - Upgrade to lucene-6.3.0. Dates:: - Update Joda Time to version 2.9.5 Logging:: - Upgrade Log4j 2 to version 2.7 Network:: - Upgrade to Netty 4.1.6 Plugin Ingest Attachment:: - Update to Tika 1.14 == 5.0.2 Release Notes === Enhancements Core:: - Install a security manager on startup Exceptions:: - Add BWC layer for Exceptions Logging:: - Truncate log messages from the end Scripting:: - Wrap VerifyError in ScriptException Snapshot/Restore:: - Abort snapshots on a node that leaves the cluster === Bug fixes Allocation:: - Allow master to assign primary shard to node that has shard store locked during shard state fetching Cluster:: - Remove cluster update task when task times out Core:: - Add a StreamInput#readArraySize method that ensures sane array sizes - Use a buffer to do character to byte conversion in StreamOutput#writeString Engine:: - Die with dignity on the Lucene layer - Fix `InternalEngine#isThrottled` to not always return `false`. Index Templates:: - Fix integer overflows when dealing with templates. Ingest:: - fix trace_match behavior for when there is only one grok pattern Internal:: - Rethrow ExecutionException from the loader to concurrent callers of Cache#computeIfAbsent - Fixes potential NullPointerException on shard closing Java API:: - Transport client: Fix remove address to actually work - Add a HostFailureListener to notify client code if a node got disconnected Logging:: - Do not prematurely shutdown Log4j Network:: - Die with dignity on the network layer Plugin Lang Painless:: - Fix a VerifyError bug in Painless - Fix Lambdas in Painless to be Able to Use Top-Level Variables Such as params and doc Search:: - Respect default search timeout Settings:: - Don't reset non-dynamic settings unless explicitly requested Tribe Node:: - Add socket permissions for tribe nodes
2017-01-03Update databases/redis to 3.2.6.fhajny2-7/+7
This release mainly fixes three bugs: 1. A bug with BITFIELD that may cause the bitmap corruption when setting offsets larger than the current string size. 2. A GEORADIUS bug that may happen when using very large radius lengths, in the range of 10000km or alike, due to wrong bounding box calculation. 3. A bug with Redis Cluster which crashes when reading a nodes configuration file with zero bytes at the end, which sometimes happens with certain ext4 configurations after a system crash.
2017-01-02+ jdbc-mysql51joerg1-1/+2
2017-01-02SQLite Release 3.16.0 On 2017-01-02adam7-26/+28
Uses 9% fewer CPU cycles. (See the CPU performance measurement report for details on how the this performance increase was computed.) Added experimental support for PRAGMA functions. Added the SQLITE_DBCONFIG_NO_CKPT_ON_CLOSE option to sqlite3_db_config(). Enhance the date and time functions so that the 'unixepoch' modifier works for the full span of supported dates. Changed the default configuration of the lookaside memory allocator from 500 slots of 128 bytes each into 125 slots of 512 bytes each. Enhanced "WHERE x NOT NULL" partial indexes so that they are usable if the "x" column appears in a LIKE or GLOB operator. Enhanced sqlite3_interrupt() so that it interrupts checkpoint operations that are in process. Enhanced the LIKE and GLOB matching algorithm to be faster for cases when the pattern contains multiple wildcards. Added the SQLITE_FCNTL_WIN32_GET_HANDLE file control opcode. Added ".mode quote" to the command-line shell. Added ".lint fkey-indexes" to the command-line shell. Added the .imposter dot-command to the command-line shell. Added the remember(V,PTR) SQL function as a loadable extension. Rename the SQLITE_OMIT_BUILTIN_TEST compile-time option to SQLITE_UNTESTABLE to better reflect the implications of using it. Bug Fixes: Fix a long-standing bug in the query planner that caused incorrect results on a LEFT JOIN where the left-hand table is a subquery and the join constraint is a bare column name coming from the left-hand subquery. Ticket 2df0107b. Correctly handle the integer literal -0x8000000000000000 in the query planner.
2017-01-02Update to 1.56wen2-7/+7
Upstream changes: 1.56 2016-10-06 Full release of the 1.53 development series One version skipped because of indexing problems. 1.53_2 2016-02-03 [MISCELLANEOUS] Add new FAQs 1.53_1 2015-10-16 [BUG FIXES] Strictly speaking this is a bug fix to DBI and not DBD::ODBC but DBI now supports 64 bit row counts where an IV in perl is 64 bits. However, it necessitated changes to DBD::ODBC to pick up the fix. odbc_rows (my workaround since 2012) is still supported but should no longer be required so long as you use this DBD::ODBC and DBI 1.633_92 or above. [INTERNALS] Removed dbd_st_rows and now setting DBIc_ROW_COUNT. [DOCUMENTATION] Add tables and table_info section to deviations from the DBI spec. [MISCELLANEOUS] Change column name in t/rt_101579.t as "method" is a reserved word in. Teradata Thanks to Zhenyi Zhou. Remove duplicate dynamic_config from META.yml.
2017-01-01jdbc-mysql version 5.1spz4-0/+51
2017-01-01Revbump after boost updateadam21-35/+49
2017-01-01Changes 2.2.5:adam2-8/+7
This release includes the following bug fixes * Bug 359 dditional parameter to GetConfigOptionByName() in PG 9.6 * Misc other fixes to compile against PG 9.6 * PG 9.5 makefile fix for win32 * Remove 'unsupported' warning for PG 9.5
2017-01-01Add python-3.6 to incompatible versions.wiz30-61/+61
2017-01-01Updated p5-DBD-SQLite to 1.54.wiz2-8/+7
1.54 2016-12-24 - Switched to a production version. - Resolved RT#119219: Trivial documentation bug in DBL::SQLite 1.52 1.53_01 2016-11-26 - Re-enabled perl tokenizer by calling sqlite_db_config if SQLite >= 3.12
2017-01-01Updated p5-DB_File to 1.840.wiz2-7/+7
1.840 29 Dec 2016 * #119569: Failed to install DB_File-1.839 into Linux 1.839 29 Dec 2016 * #119557: DB_File.xs: unused-parameter warnings * #107642: unused arg
2016-12-30Fix options framework abuse by sqsh*.wiz7-95/+100
2016-12-30Updated package to force usage of camlp4. Bumped revision. No upstreamjaapb2-7/+9
changes.
2016-12-30Recursive revbump associated with ocaml update to 4.04.jaapb6-10/+12
2016-12-30Update phpmyadmin to 4.6.5.2, including security fixes.taca3-9/+10
4.6.5.2 (2016-12-05) - issue #12765 Fixed SQL export with newlines 4.6.5.1 (2016-11-25) - issue #12735 Incorrect parameters to escapeString in Node.php - issue #12734 Fix PHP error when mbstring is not installed - issue #12736 Don't force partition count to be specified when creating a new table 4.6.5 (2016-11-24) - issue Remove potentionally license problematic sRGB profile - issue #12459 Display read only fields as read only when editing - issue #12384 Fix expanding of navigation pane when clicking on database - issue #12430 Impove partitioning support - issue #12374 Reintroduced simplified PmaAbsoluteUri configuration directive - issue Always use UTC time in HTTP headers - issue #12479 Simplified validation of external links - issue #12483 Fix browsing tables with built in transformations - issue #12485 Do not show warning about short blowfish_secret if none is set - issue #12251 Fixed random logouts due to wrong cookie path - issue #12480 Fixed editing of ENUM/SET/DECIMAL fields structure - issue #12497 Missing escaping of configuration used in SQL (hide_db and only_db) - issue #12476 Add error checking in reading advisory rules file - issue #12477 Add checking missing elements and confirming element types from json_decode - issue #12251 Automatically save SQL query in browser local storage rather than in cookie - issue #12292 Unable to edit transformations - issue #12502 Remove unused paramenter when connecting to MySQLi - issue #12303 Fix number formatting with different settings of precision in PHP - issue #12405 Use single quotes in PHP code - issue #12534 Option for the dropped column is not removed from 'after_field' select, after the column is dropped - issue #12531 Properly detect DROP DATABASE queries - issue #12470 Fix possible race condition in setting URL hash - issue #11924 Remove caching of server information - issue #11628 Proper parsing of INSERT ... ON DUPLICATE KEY queries - issue #12545 Proper parsing of CREATE TABLE ... PARTITION queries - issue #12473 Code can throw unhandled exception - issue #12550 Do not try to keep alive session even after expiry - issue #12512 Fixed rendering BBCode links in setup - issue #12518 Fixed copy of table with generated columns - issue #12221 Fixed export of table with generated columns - issue #12320 Copying a user does not copy usergroup - issue #12272 Adding a new row with default enum goes to no selection when you want to add more then 2 rows - issue #12487 Drag and drop import prevents file dropping to blob column file selector on the insert tab - issue #12554 Absence of scrolling makes it impossible to read longer text values in grid editing - issue #12530 "Edit routine" crashes when the current user is not the definer, even if privileges are adequate - issue #12300 Export selective tables by-default dumps Events also - issue #12298 Fixed export of view definitions - issue #12242 Edit routine detail dialog does not fill "Return length" field in mysql functions - issue #12575 New index Confirm adds whitespace around the field name - issue #12382 Bug in zoom search - issue #12321 Assign LIMIT clause only to syntactically correct queries - issue #12461 Can't Execute SQL With Sub-Query Due To "LIMIT 0,25" Inserted At Wrong Place - issue #12511 Clarify documentation on ArbitraryServerRegexp - issue #12508 Remove duplicate code in SQL escaping - issue #12475 Cleanup code for getting table information - issue #12579 phpMyAdmin's export of a Select statment without a FROM clause generates Wrong SQL - issue #12316 Correct export of complex SELECT statements - issue #12080 Fixed parsing of subselect queries - issue #11740 Fixed handling DELETE ... USING queries - issue #12100 Fixed handling of CASE operator - issue #12455 Query history stores separate entry for every letter typed - issue #12327 Create PHP code no longer works - issue #12179 Fixed bookmarking of query with multiple statements - issue #12419 Wrong description on GRANT OPTION - issue #12615 Fixed regexp for matching browser versions - issue #12569 Avoid showing import errors twice - issue #12362 prefs_manage.php can leave an orphaned temporary file - issue #12619 Unable to export csv when using union select - issue #12625 Broken Edit links in query results of JOIN query - issue #12634 Drop DB error in import if DB doesn't exist - issue #12338 Designer reverts to first saved ER after EACH relation create or delete - issue #12639 'Show trace' in Console generates JS error for functions in query's trace called without any arguments - issue #12366 Fix user creation with certain MariaDB setups - issue #12616 Refuse to work with mbstring.func_overload enabled - issue #12472 Properly report connection without password in setup - issue #12365 Fix records count for large tables - issue #12533 Fix records count for complex queries - issue #12454 Query history not updated in console until page refresh - issue #12344 Fixed parsing of labels in loop - issue #12228 Fixed parsing of BEGIN labels - issue #12637 Fixed editing some timestamp values - issue #12622 Fixed javascript error in designer - issue #12334 Missing page indicator or VIEWs - issue #12610 Export of tables with Timestamp/Datetime/Time columns defined with ON UPDATE clause with precision fails - issue #12661 Error inserting into pma__history after timeout - issue #12195 Row_format = fixed not visible - issue #12665 Cannot add a foreign key - non-indexed fields not listed in InnoDB tables - issue #12674 Allow for proper MySQL-allowed strings as identifiers - issue #12651 Allow for partial dates on table insert page - issue #12681 Fixed designer with tables using special chars - issue #12652 Fixed visual query builder for foreign keys with more fields - issue #12257 Improved search page performance - issue #12322 Avoid selecting default function for foreign keys - issue #12453 Fixed escaping of SQL parts in some corner cases - issue #12542 Missing table name in account privileges editor - issue #12691 Remove ksort call on empty array in PMA_getPlugins function - issue #12443 Check parameter type before processing - issue #12299 Avoid generating too long URLs in search - issue #12361 Fix self SQL injection in table-specific privileges - issue #12698 Add link to release notes and download on new version notification - issue #12712 Error when trying to setup replication (fatal error in call to an old PMA_DBI_connect function) - issue [security] Unsafe generation of $cfg['blowfish_secret'], see PMASA-2016-58 - issue [security] phpMyAdmin's phpinfo functionality is removed, see PMASA-2016-59 - issue [security] AllowRoot and allow/deny rule bypass with specially-crafted username, see PMASA-2016-60 - issue [security] Username matching weaknesses with allow/deny rules, see PMASA-2016-61 - issue [security] Possible to bypass logout timeout, see PMASA-2016-62 - issue [security] Full path disclosure (FPD) weaknesses, see PMASA-2016-63 - issue [security] Multiple XSS weaknesses, see PMASA-2016-64 - issue [security] Multiple denial-of-service (DOS) vulnerabilities, see PMASA-2016-65 - issue [security] Possible to bypass white-list protection for URL redirection, see PMASA-2016-66 - issue [security] BBCode injection to login page, see PMASA-2016-67 - issue [security] Denial-of-service (DOS) vulnerability in table partitioning, see PMASA-2016-68 - issue [security] Multiple SQL injection vulnerabilities, see PMASA-2016-69 - issue [security] Incorrect serialized string parsing, see PMASA-2016-70 - issue [security] CSRF token not stripped from the URL, see PMASA-2016-71
2016-12-21minor edits for grammar/usagedholland1-3/+3
2016-12-20Add missing sqlite 3.15.2 commitadam3-11/+12
2016-12-19Revert nonsensical changes.asau1-9/+9
2016-12-17Add missing Python build dependency. Deal with MAX/MIN macros on NetBSDjoerg3-2/+33
and possibly other systems.
2016-12-17Sorted PLIST to appease pkglint.rillig1-29/+29
2016-12-17Fixed pkglint warnings.rillig1-9/+9
2016-12-16Revert, the real culprit is GNU make.joerg1-4/+1
2016-12-16Backport section from MySQL 5.7 to fix SunOS/gcc. PR#51725jperkin2-1/+23
2016-12-15Disable jobs to workaround WAF thread creation problems.joerg1-1/+4