pkgsrc changes:
- py-h11 and py-requests are no longer needed, delete them from
DEPENDS (`h11' is no more used while `requests' is only an extra
dependency)
Changes:
05 April 2018: mitmproxy 3.0.4
* Fix an issue that caused mitmproxy to not retry HTTP requests on timeout.
* Misc bug fixes and improvements
Updated geography/opencpn-plugin-draw to 1.5_20180405
Updated geography/opencpn-plugin-statusbar to 20180405
Updated geography/opencpn-plugin-watchdog to 20180405
Updated geography/opencpn-plugin-weather_routing to 20180405
support sparse polars with automatic interpolation
ADD cursor bar on the plot to show where we are in time
Add option cursor route enable/disable
Add wind barbs on the weather route.
Updated translations
Lots of UI improvements and general bug fixes
pkgsrc changes:
- Get rid of extra `/' in patches/patch-config-scripts_cups-opsys.m4
(NFCI, pointed out by mkpatches).
- Add to patches/patch-scheduler_auth.c a backport of issue #5283 to fix build
without PAM. This will be not needed in cups-2.2.8.
Changes:
CUPS v2.2.7
-----------
- NOTICE: Raw print queues are now deprecated (Issue #5269)
- Fixed an Avahi crash bug in the scheduler (Issue #5268)
- The IPP Everywhere PPD generator did not include the `cupsJobPassword`
keyword, when supported (Issue #5265)
- Systemd did not restart cupsd when configuration changes were made that
required a restart (Issue #5263)
- The Lexmark Optra E310 printer needs the "no-reattach" USB quirk rule
(Issue #5259)
- The scheduler could crash while adding an IPP Everywhere printer (Issue #5258)
- Label printers supported by the rastertolabel driver don't support SNMP, so
don't delay printing to test it (Issue #5256)
- Fixed a compile issue when PAM is not available (Issue #5253)
- Documentation fixes (Issue #5252)
- Star Micronics printers need the "unidir" USB quirk rule (Issue #5251)
- The scheduler now supports using temporary print queues for older IPP/1.1
print queues like those shared by CUPS 1.3 and earlier (Issue #5241)
- Fixed printing to some IPP Everywhere printers (Issue #5238)
- Kerberized printing to another CUPS server did not work correctly
(Issue #5233)
- The `cupsRasterWritePixels` function did not correctly swap bytes for some
formats (Issue #5225)
- Added a USB quirk rule for Canon MP280 series printers (Issue #5221)
- The `ppdInstallableConflict` tested too many constraints (Issue #5213)
- More fixes for printing to old CUPS servers (Issue #5211)
- The `cupsCopyDest` function now correctly copies the `is_default` value
(Issue #5208)
- The scheduler did not work with older versions of uClibc (Issue #5188)
- The scheduler now substitutes default values for invalid job attributes when
running in "relaxed conformance" mode (Issue #5186)
- Fixed PAM module detection and added support for the common PAM definitions
(Issue #5185)
- Fixed a journald support bug in the scheduler (Issue #5181)
- The cups-driverd program incorrectly stopped scanning PPDs as soon as a loop
was seen (Issue #5170)
- Fixed group validation on OpenBSD (Issue #5166)
- Fixed the `ippserver` sample code when threading is disabled or unavailable
(Issue #5154)
- The `cupsEnumDests` function did not include options from the lpoptions files
(Issue #5144)
- The `SSLOptions` directive now supports `MinTLS` and `MaxTLS` options to
control the minimum and maximum TLS versions that will be allowed,
respectively (Issue #5119)
- The scheduler did not write out dirty configuration and state files if there
were open client connections (Issue #5118)
- The `lpadmin` command now provides a better error message when an unsupported
System V interface script is used (Issue #5111)
- The `lp` and `lpr` commands now provide better error messages when the default
printer cannot be found (Issue #5096)
- No longer support backslash, question mark, or quotes in printer names
(Issue #4966)
- The CUPS library now supports the latest HTTP Digest authentication
specification including support for SHA-256 (Issue #4862)
- The `lpstat` command now reports when new jobs are being held (Issue #4761)
- The `lpoptions` command incorrectly saved default options (Issue #4717)
- The `ppdLocalizeIPPReason` function incorrectly returned a localized version
of "none" (rdar://36566269)
- TLS connections now properly timeout (rdar://34938533)
- The IPP backend did not properly detect failed PDF prints (rdar://34055474)
- Temporary files are now placed in the correct directory for sandboxed
applications on macOS (rdar://problem/37789645)
Add ability to check for the first line crossing as well as the closest line
crossing.
Import csv file to define new boundary and boundary points
Allow right click in Points and Layers tabs of Pathmanager to Hide/Show items
And lots of UI and bug fixes, speedup, cleanup.
info popup on track rollover
drop a mark on boat position on space press if SpaceDropMark is set to 1
in the config file.
GHSS and US Pilotcharts added to charts downloader
Config option "Course-Up Update Period" has been renamed to
"Chart Rotation Averaging Time"
help handle for dragging waypoints in touchscreen mode
The shortcut key "D" now it works for both ENC vector charts and raster charts
in addition to cm93.
If course (COG) and speed (SOG) is not available through the normal NMEA
interface to your gps, these values can be calculated by OpenCPN by using
the position data
A course predictor is now shown on screen even when the actual target,
or the end point, is not visible on screen.
In Options-> User Interface-> Interface Options there are now three sliders
for user control of different features
A new Own ship range ring colour picker is now included
You can now get rid of the barbed arrow heads in the grib display
When GRIB plugin is active and tide- and/or current-buttons are pressed,
then tide/current calculations are shown at the "GRIB time".
New settings for old and slow computers in
Options-> Display-> Advanced-> Graphics
For details see
https://opencpn.org/OpenCPN/about/ver482.html
Notable changes since 1.12.1:
- Serious optimization of memory copy functions (see new
blosc/fastcopy.c). This benefits the speed of all the codecs, but
specially the BloscLZ one.
- As a result of the above, the BloscLZ codec received a new
adjustment of knobs so that you should expect better compression
ratios with it too.
- Fixed a buffer overrun that happens when compressing small buffers
and len(destination_buffer) < (len(source_buffer) +
BLOSC_MAX_OVERHEAD).
- New split mode that favors forward compatibility. That means that,
from now on, all the buffers created starting with blosc 1.14.0 will
be forward compatible with any previous versions of the library --at
least until 1.3.0, when support for multi-codec was introduced.
3.55.0:
This release includes several improvements to the handling of the :obj:~hypothesis.settings.database setting.
The :obj:~hypothesis.settings.database_file setting was a historical artefact, and you should just use :obj:~hypothesis.settings.database directly.
The :envvar:HYPOTHESIS_DATABASE_FILE environment variable is deprecated, in favor of :meth:~hypothesis.settings.load_profile and the :obj:~hypothesis.settings.database setting.
If you have not configured the example database at all and the default location is not usable (due to e.g. permissions issues), Hypothesis will fall back to an in-memory database. This is not persisted between sessions, but means that the defaults work on read-only filesystems.
3.54.0:
This release improves the :func:~hypotheses.strategies.complex_numbers strategy, which now supports min_magnitude and max_magnitude arguments, along with allow_nan and allow_infinity like for :func:~hypotheses.strategies.floats.
3.53.0:
This release removes support for Django 1.8, which reached end of life on 2018-04-01.
5.2.3:
- Fix hang on close in :class:.ThreadedKernelClient (used in QtConsole)
when using tornado with asyncio
- Fix errors when using deprecated :attr:.KernelManager.kernel_cmd
1.1.0:
This release removes the deprecated functions which were marked as remove in 1.0, but nonetheless remained:
lz4.lz4version()
LZ4FrameCompressor.finalize()
As a side effect, we noo longer have a dependency on the deprecation package.
0.31.0
- Fixed displaying of errors on Python 3
- Fixed single digit versions in wheel files not being properly recognized
- Fixed wrong character encodings being used (instead of UTF-8) to read and
write RECORD (this sometimes crashed bdist_wheel too)
- Enabled Zip64 support in wheels by default
- Metadata-Version is now 2.1
- Dropped DESCRIPTION.rst and metadata.json from the list of generated files
- Dropped support for the non-standard, undocumented provides-extra and
requires-dist keywords in setup.cfg metadata
- Deprecated all wheel signing and signature verification commands
- Removed the (already defunct) tool extras from setup.py
This package explicitly avoids C99-isms and fails to build in C99 mode with
older compilers, even though it works fine with newer compilers that default
to C99 mode. So, we need to explicitly request XPG4_2 if and only if the
compiler does not default to C99, and must not require C99.
Default changes
- socket.max.fails changed to 1 to provide same functionality (fail
request immediately on error) now when retries are working properly
again.
- fetch.max.bytes (new config property) is automatically adjusted to
be >= message.max.bytes, and receive.message.max.bytes is
automatically adjusted to be > fetch.max.bytes.
New features
- Message Headers support
- Java-compatible Murmur2 partitioners
- Add PKCS#12 Keystore support - ssl.keystore.location
Noteworthy fixes
- Formalise and fix Producer retries and retry-ordering
- Ordering is now retained despite retries if max.in.flight=1.
- Behaviour is now documented
- Fix timeouts for retried requests and properly handle retries for
all request types
- Add and use fetch.max.bytes to limit total Fetch response size.
Fixes "Invalid response size" issues.
Enhancements
- Added sasl.mechanism and compression.type configuration property
aliases for conformance with Java client.
- Improved Producer performance
- C++: add c_ptr() to Handle,Topic,Message classes to expose
underlying librdkafka object
- Honour per-message partition in produce_batch() if MSG_F_PARTITION
set
- Added on_request_sent() interceptor
- Added experimental flexible producer queuing.strategy=fifo|lifo
- Broker address DNS record round-robin: try to maintain round-robin
position across resolve calls.
- Set system thread name for internal librdkafka threads
- Added more concise and user-friendly 'consumer' debug context
- Add partitioner (string) topic configuration property to set the
builtin partitioners
- Generate rdkafka-static.pc (pkg-config) for static linking
Fixes
- Fix producer memory leak on <0.11 brokers when compressed messageset
is below copy threshold
- CRC32C - fix unaligned access on ARM
- Fix read after free in buf_write_seek
- Fix broker wake up
- Fix consumer hang when rebalancing during commit
- CMake fixes for Windows
- LeaveGroup was not sent on close when doing final offset commits
- Fix for consumer slowdown/stall on compacted topics where actual
last offset < MsgSet.LastOffset
- Fix global->topic conf fallthru in C++ API
- Fix infinite loop on LeaveGroup failure
- Fix possible crash on OffsetFetch retry
- Incorporate compressed message count when deciding on fetch backoff
- Fix debug-only crash on Solaris (%s NULL)
- Drain broker ops queue on termination to avoid hang
- cmake: Allow build static library
- Don't store invalid offset as next one when pausing
- use #if instead of #ifdef / defined() for atomics
- fixed .lib paths in nuget packaging
- Fixes strerror_r crash on alpine
- Allow arbitrary lengthed (>255) SASL PLAIN user/pass
- Trigger ApiVersionRequest on reconnect if broker.version.fallback
supports it
- Read Fetch MsgAttributes as int8
- Portability: stop using typeof in rdkafka_transport.c
- Portability: replace use of #pragma once with header guards
- mklove: add LIBS in reverse order to maintain dependency order
- Fix build when python is not available #1358
New Feature
- automatic migration of log dirs to new locations
- KIP-145 - Expose Record Headers in Kafka Connect
- Add the AdminClient in Streams' KafkaClientSupplier
- Support dynamic updates of frequently updated broker configs
Improvement
- KafkaConnect should support regular expression for topics
- Move kafka-streams test fixtures into a published package
- SSL support for Connect REST API
- Grow default heap settings for distributed Connect from 256M to 1G
- Enable access to key in ValueTransformer
- Add "getAllKeys" API for querying windowed KTable stores
- Unify StreamsKafkaClient instances
- Revisit Streams DSL JavaDocs
- Extend Consumer Group Reset Offset tool for Stream Applications
- KIP-175: ConsumerGroupCommand no longer shows output for consumer
groups which have not committed offsets
- Add a broker metric specifying the number of consumer group
rebalances in progress
- Use Jackson for serialising to JSON
- KafkaShortnamer should allow for case-insensitive matches
- Improve Util classes
- Gradle 3.0+ is needed on the build
- Adding records deletion operation to the new Admin Client API
- Kafka metrics templates used in document generation should maintain
order of tags
- Provide for custom error handling when Kafka Streams fails to
produce
- Make Repartition Topics Transient
- Connect Schema comparison is slow for large schemas
- Add a Validator for NonNull configurations and remove redundant null
checks on lists
- Have State Stores Restore Before Initializing Toplogy
- Optimize condition in if statement to reduce the number of
comparisons
- Removed unnecessary null check
- Introduce Incremental FetchRequests to Increase Partition
Scalability
- SSLTransportLayer should keep reading from socket until either the
buffer is full or the socket has no more data
- Improve KTable Source state store auto-generated names
- Extend consumer offset reset tool to support deletion (KIP-229)
- Expose Kafka cluster ID in Connect REST API
- Maven artifact for kafka should not depend on log4j
- ConsumerGroupCommand should use the new consumer to query the log
end offsets.
- Change LogSegment.delete to deleteIfExists and harden log recovery
- Make ProducerConfig and ConsumerConfig constructors public
- Improve synchronization in CachingKeyValueStore methods
- Improve Kafka GZip compression performance
- Improve JavaDoc of SourceTask#poll() to discourage indefinite
blocking
- Avoid creating dummy checkpoint files with no state stores
- Change log level from ERROR to WARN for not leader for this
partition exception
- Delay initiating the txn on producers until initializeTopology with
EOS turned on
Bug
- change log4j to slf4j
- Use RollingFileAppender by default in log4j.properties
- Cached zkVersion not equal to that in zookeeper, broker not
recovering.
- FileRecords.read doesn't handle size > sizeInBytes when start is not
zero
- a soft failure in controller may leave a topic partition in an
inconsistent state
- Cannot truncate to a negative offset (-1) exception at broker
startup
- automated leader rebalance causes replication downtime for clusters
with too many partitions
- kafka-run-class has potential to add a leading colon to classpath
- QueryableStateIntegrationTest.concurrentAccess is failing
occasionally in jenkins builds
- FileStreamSource Connector not working for large files (~ 1GB)
- KeyValueIterator returns null values
- KafkaProducer is not joining its IO thread properly
- Kafka connect: error with special characters in connector name
- Replace StreamsKafkaClient with AdminClient in Kafka Streams
- LogCleaner#cleanSegments should not ignore failures to delete files
- Connect Rest API allows creating connectors with an empty name -
KIP-212
- KerberosLogin#login should probably be synchronized
- Support replicas movement between log directories (KIP-113)
- Consumer ListOffsets request can starve group heartbeats
- Struct.put() should include the field name if validation fails
- Clarify handling of connector name in config
- Allow user to specify relative path as log directory
- KafkaConsumer should validate topics/TopicPartitions on
subscribe/assign
- Controller should only update reassignment znode if there is change
in the reassignment data
- records.lag should use tags for topic and partition rather than
using metric name.
- KafkaProducer should not wrap InterruptedException in close() with
KafkaException
- Connect classloader isolation may be broken for JDBC drivers
- JsonConverter generates "Mismatching schema" DataException
- NoSuchElementException in markErrorMeter during
TransactionsBounceTest
- Make KafkaFuture.Function java 8 lambda compatible
- ThreadCache#sizeBytes() should check overflow
- KafkaFuture timeout fails to fire if a narrow race condition is hit
- DeleteRecordsRequest to a non-leader
- ReplicaFetcherThread should close the ReplicaFetcherBlockingSend
earlier on shutdown
- NoSuchMethodError when creating ProducerRecord in upgrade system
tests
- Running tools on Windows fail due to typo in JVM config
- Streams metrics tagged incorrectly
- ducker-ak: add ipaddress and enum34 dependencies to docker image
- Kafka cannot recover after an unclean shutdown on Windows
- Scanning plugin.path needs to support relative symlinks
- Reconnecting to broker does not exponentially backoff
- TaskManager should be type aware
- Major performance issue due to excessive logging during leader
election
- RecordCollectorImpl should not retry sending
- Restore and global consumer should not use auto.offset.reset
- Global Consumer should handle TimeoutException
- Reduce rebalance time by not checking if created topics are
available
- VerifiableConsumer with --max-messages doesn't exit
- Transaction markers are sometimes discarded if txns complete
concurrently
- Simplify StreamsBuilder#addGlobalStore
- JmxReporter can't handle windows style directory paths
- CONSUMER-ID and HOST values are concatenated if the CONSUMER-ID is >
50 chars
- ClientQuotaManager threads prevent shutdown when encountering an
error loading logs
- Streams configuration requires consumer. and producer. in order to
be read
- Timestamp on streams directory contains a colon, which is an illegal
character
- Add methods in Options classes to keep binary compatibility with
0.11
- RecordQueue.clear() does not clear MinTimestampTracker's maintained
list
- Selector memory leak with high likelihood of OOM in case of down
conversion
- GlobalKTable never finishes restoring when consuming transactional
messages
- Server crash while deleting segments
- IllegalArgumentException if 1.0.0 is used for
inter.broker.protocol.version or log.message.format.version
- Using standby replicas with an in memory state store causes Streams
to crash
- Issues with protocol version when applying a rolling upgrade to
1.0.0
- Fix system test dependency issues
- Kafka Connect requires permission to create internal topics even if
they exist
- A metric named 'XX' already exists, can't register another one.
- Improve sink connector topic regex validation
- Flaky Unit test:
KStreamKTableJoinIntegrationTest.shouldCountClicksPerRegionWithNonZeroByteCache
- Make KafkaStreams.cleanup() clean global state directory
- AbstractCoordinator not clearly handles NULL Exception
- Request logging throws exception if acks=0
- GlobalKTable missing #queryableStoreName()
- KTable state restore fails after rebalance
- Make loadClass thread-safe for class loaders of Connect plugins
- System Test failed: ConnectRestApiTest
- Broken symlink interrupts scanning the plugin path
- NetworkClient should not return internal failed api version
responses from poll
- Transient failure in
NetworkClientTest.testConnectionDelayDisconnected
- Line numbers on log messages are incorrect
- Topic can not be recreated after it is deleted
- mBeanName should be removed before returning from
JmxReporter#removeAttribute()
- Kafka Core should have explicit SLF4J API dependency
- StreamsResetter should return non-zero return code on error
- kafka-acls regression for comma characters (and maybe other
characters as well)
- Error deleting log for topic, all log dirs failed.
- punctuate with WALL_CLOCK_TIME triggered immediately
- Exclude node groups belonging to global stores in
InternalTopologyBuilder#makeNodeGroups
- Transient failure in
kafka.api.AdminClientIntegrationTest.testLogStartOffsetCheckpointkafka.api.AdminClientIntegrationTest.testAlterReplicaLogDirs
- NetworkClient.inFlightRequestCount() is not thread safe, causing
ConcurrentModificationExceptions when sensors are read
- ConcurrentModificationException during streams state restoration
- Update KStream JavaDoc with regard to KIP-182
- RocksDB segments not removed when store is closed causes
re-initialization to fail
- auto commit not work since coordinatorUnknown() is always true.
- Fix StateRestoreListener To Use Correct Batch Ending Offset
- NullPointerException on KStream-GlobalKTable leftJoin when
KeyValueMapper returns null
- StreamThread.shutdown doesn't clean up completely when called before
StreamThread.start
- Update ZooKeeper to 3.4.11, Gradle and other minor updates
- output from ensure copartitioning is not used for Cluster metadata,
resulting in partitions without tasks working on them
- Consumer should not block setting initial positions of unavailable
partitions
- Non-aggregation KTable generation operator does not construct value
getter correctly
- AdminClient should handle empty or null topic names better
- When enable trace level log in mirror maker, it will throw null
pointer exception and the mirror maker will shutdown
- Simplify KStreamReduce
- Base64URL encoding under JRE 1.7 is broken due to incorrect padding
assumption
- ChangeLoggingKeyValueBytesStore.all() returns null
- Fetcher.retrieveOffsetsByTimes() should add all the topics to the
metadata refresh topics set.
- LogSemgent.truncateTo() should always resize the index file
- Connect: Plugin scan is very slow
- Connect: Some per-task-metrics not working
- Connect header parser incorrectly parses arrays
- Java Producer: Excessive memory usage with compression enabled
- New Connect header support doesn't define 'converter.type' property
correctly
- ZooKeeperClient holds a lock while waiting for responses, blocking
shutdown
- Transient failure in
DynamicBrokerReconfigurationTest.testThreadPoolResize
- Broker leaks memory and file descriptors after sudden client
disconnects
- Delegation token internals should not impact public interfaces
- Streams quickstart pom.xml is missing versions for a bunch of
plugins
- Deadlock while processing Controller Events
- Broker doesn't reject Produce request with inconsistent state
- LogCleanerManager.doneDeleting() should check the partition state
before deleting the in progress partition
- KafkaController.brokerInfo not updated on dynamic update
- Connect standalone SASL file source and sink test fails without
explanation
- Connect distributed and standalone worker 'main()' methods should
catch and log all exceptions
- Consumer bytes-fetched and records-fetched metrics are not
aggregated correctly
- Coordinator disconnect in heartbeat thread can cause commitSync to
block indefinitely
- Regression in consumer auto-commit backoff behavior
- GroupMetadataManager.loadGroupsAndOffsets decompresses record batch
needlessly
- log segment deletion could cause a disk to be marked offline
incorrectly
- Delayed operations may not be completed when there is lock
contention
- Expression for GlobalKTable is not correct
- System tests do not handle ZK chroot properly with SCRAM
- Fix config initialization in DynamicBrokerConfig
- ReplicaFetcher crashes with "Attempted to complete a transaction
which was not started"
Test
- Add concurrent tests to exercise all paths in group/transaction
managers
- Add unit tests for ClusterConnectionStates
- Only delete reassign_partitions znode after reassignment is complete
- KafkaStreamsTest fails in trunk
- SelectorTest may fail with ConcurrentModificationException
Sub-task
- Add capability to create delegation token
- Add authentication based on delegation token.
- Add capability to renew/expire delegation tokens.
- always leave the last surviving member of the ISR in ZK
- handle ZK session expiration properly when a new session can't be
established
- Streams should not re-throw if suspending/closing tasks fails
- Use async ZookeeperClient in Controller
- Use async ZookeeperClient in SimpleAclAuthorizer
- Use async ZookeeperClient for DynamicConfigManager
- Use async ZookeeperClient for Admin operations
- Trogdor should handle injecting disk faults
- Add process stop faults, round trip workload, partitioned
produce-consume test
- add the notion of max inflight requests to async ZookeeperClient
- Add workload generation capabilities to Trogdor
- Add ZooKeeperRequestLatencyMs to KafkaZkClient
- Use ZookeeperClient in LogManager
- Use ZookeeperClient in GroupCoordinator and TransactionCoordinator
- Use ZookeeperClient in KafkaApis
- Use ZookeeperClient in ReplicaManager and Partition
- Tests for KafkaZkClient
- Transient failure in
kafka.api.SaslScramSslEndToEndAuthorizationTest.testTwoConsumersWithDifferentSaslCredentials
- minimize the number of triggers enqueuing
PreferredReplicaLeaderElection events
- Enable dynamic reconfiguration of SSL keystores
- Enable resizing various broker thread pools
- Enable reconfiguration of metrics reporters and their custom configs
- Enable dynamic reconfiguration of log cleaners
- Enable reconfiguration of default topic configs used by brokers
- Enable reconfiguration of listeners and security configs
- Add ProduceBench to Trogdor
- move ZK metrics in KafkaHealthCheck to ZookeeperClient
- Add documentation for delegation token authentication mechanism
- Document dynamic config update
- Extend ConfigCommand to update broker config using new AdminClient
- Add test to verify markPartitionsForTruncation after fetcher thread
pool resize
3.43.0
Add oauth_access_revocation to WebhookNotifications
Add support for customer_id, disbursement_date and history_event_effective_date in DisputeSearch
Remove sepa_mandate_type and sepa_mandate_acceptance_location params from ClientToken
Add support for VCR compelling evidence dispute representment
New Features
- Add FFI version of gettag().
Improvements
- Add the option to set the AXFR timeout for RPZs.
- IXFR: correct behavior of dealing with DNS Name with multiple
records and speed up IXFR transaction.
- Add RPZ statistics endpoint to the API.
Bug Fixes
- Retry loading RPZ zones from server when they fail initially.
- Fix ECS-based cache entry refresh code.
- Fix ECS-specific NS AAAA not being returned from the cache.
Version 3.8.1:
Use old url_name behavior in route decorators
For list_route and detail_route maintain the old behavior of url_name,
basing it on the url_path instead of the function name.
Version 3.8:
Breaking Change: Alter read_only plus default behaviour.
Correct allow_null behaviour when required=False
Refactor dynamic route generation and improve viewset action introspectibility.
Fix formatting of the 3.7.4 release note
Docs: Update DRF Writable Nested Serializers references
Docs: Fixed typo in auth URLs example.
Improve composite field child errors
Disable HTML inputs for dict/list fields
Fix typo in HostNameVersioning doc
Use rsplit to get module and classname for imports
Formalize URLPatternsTestCase
Add exception translation test
Test staticfiles
Add drf-yasg to documentation and schema 3rd party packages
Remove unused compat._resolve_model()
Drop compat workaround for unsupported Python 3.2
Prefer iter(dict) over iter(dict.keys())
Pass python_requires argument to setuptools
Remove unused links from docs
Prefer https protocol for links in docs when available
Add HStoreField, postgres fields tests
Always fully qualify ValidationError in docs
Remove unreachable code from ManualSchema
Allowed customising API documentation code samples
Updated docs to use pip show
Load 'static' instead of 'staticfiles' in templates
Fixed a typo in fields docs
Refer to "NamespaceVersioning" instead of "NamespacedVersioning" in the documentation
ErrorDetail: add __eq__/__ne__ and __repr__
Replace background-attachment: fixed in docs
Make 404 & 403 responses consistent with exceptions.APIException output
Small fix to API documentation: schemas
Fix schema generation for PrimaryKeyRelatedField
Represent serializer DictField as an Object in schema
Added docs example reimplementing ObtainAuthToken
Add schema to the ObtainAuthToken view
Fix request formdata handling
Fix authtoken views imports
Update pytest, isort
Fixed active timezone handling for non ISO8601 datetimes.
Made TemplateHTMLRenderer render IntegerField inputs when value is 0.
Corrected endpoint in tutorial instructions
Add Django Rest Framework Role Filters to Third party packages
Use single copy of static assets. Update jQuery
Changes ternary conditionals to be PEP308 compliant
Added links to 'A Todo List API with React' and 'Blog API' tutorials
Fix comment typo in ModelSerializer
Add admin to installed apps to avoid test failures.
Fixed schema for UUIDField in SimpleMetadata.
Corrected docs on router include with namespaces.
Test using model objects for dotted source default
Allow traversing nullable related fields
Added: Tutorial: Django REST with React (Django 2.0)
Add LimitOffsetPagination.get_count to allow method override
Don't show hidden fields in metadata
Enable OrderingFilter to handle an empty tuple (or list) for the 'ordering' field.
Added generic 500 and 400 JSON error handlers.
- Fuse Panel support: fixes a few bugs with handling small log files
and with apps that don't output any messages.
- Python app support: fixes a Python 3 compatibility issue w.r.t.
writing data over the socket.
- macOS support: fixes a crash in the `passenger-config
compile-nginx-engine` command which only occurs on macOS >= 10.13.
- Fixes a small memory corruption issue (dangling pointer) in the
ApplicationPool subsystem.
- Improves support for the $TMPDIR environment variable by removing
leftover hardcoded references to /tmp. Closes GH-2052.
- Updated PCRE version to 8.42 (was: 8.41) across the board.