From commits-return-22771-archive-asf-public=cust-asf.ponee.io@pulsar.apache.org Thu Feb 21 06:39:57 2019 Return-Path: X-Original-To: archive-asf-public@cust-asf.ponee.io Delivered-To: archive-asf-public@cust-asf.ponee.io Received: from mail.apache.org (hermes.apache.org [140.211.11.3]) by mx-eu-01.ponee.io (Postfix) with SMTP id 4823718064C for ; Thu, 21 Feb 2019 07:39:53 +0100 (CET) Received: (qmail 19112 invoked by uid 500); 21 Feb 2019 06:39:52 -0000 Mailing-List: contact commits-help@pulsar.apache.org; run by ezmlm Precedence: bulk List-Help: List-Unsubscribe: List-Post: List-Id: Reply-To: dev@pulsar.apache.org Delivered-To: mailing list commits@pulsar.apache.org Received: (qmail 19098 invoked by uid 99); 21 Feb 2019 06:39:52 -0000 Received: from ec2-52-202-80-70.compute-1.amazonaws.com (HELO gitbox.apache.org) (52.202.80.70) by apache.org (qpsmtpd/0.29) with ESMTP; Thu, 21 Feb 2019 06:39:52 +0000 Received: by gitbox.apache.org (ASF Mail Server at gitbox.apache.org, from userid 33) id 675AF851A8; Thu, 21 Feb 2019 06:39:51 +0000 (UTC) Date: Thu, 21 Feb 2019 06:38:38 +0000 To: "commits@pulsar.apache.org" Subject: [pulsar] branch merlimat-patch-4 created (now 1f3d90e) MIME-Version: 1.0 Content-Type: text/plain; charset=utf-8 Content-Transfer-Encoding: 8bit Message-ID: <155073111866.360.3704150263609463331@gitbox.apache.org> From: mmerli@apache.org X-Git-Host: gitbox.apache.org X-Git-Repo: pulsar X-Git-Refname: refs/heads/merlimat-patch-4 X-Git-Reftype: branch X-Git-Oldrev: 0000000000000000000000000000000000000000 X-Git-Newrev: 1f3d90e6f629d47c196fb75b07c7a1323d035c27 X-Git-NotificationType: ref_changed X-Git-Multimail-Version: 1.5.dev Auto-Submitted: auto-generated This is an automated email from the ASF dual-hosted git repository. mmerli pushed a change to branch merlimat-patch-4 in repository https://gitbox.apache.org/repos/asf/pulsar.git. at 1f3d90e Fixed typo on the site build command line args This branch includes the following new commits: new 9f849c3 Initial import new a5f9aba Set version to 1.15-SNAPSHOT new e757999 Added link to announcent blog post in README new d79c33f Configure Travis CI build new 171a993 Fixed concurrent tests intermittently failing new 94b941a Fixed ZookeeperCacheTest timing dependent failures new d876f75 Merge pull request #2 from merlimat/master new d913f71 Explicitly calling out the need to close the client in both the producer and consumer (#4) new 7edf572 Fixed ZookeeperCacheTest failures on Travis build new f09d579 Invalid ZK cache after updating property and cluster metadata new 9f7461c Mocked timeout tests failing on slower build machine new c68e8bc Run ZookeeperCacheTest with MockZK event in same thread to avoid race conditions new d522fbf Made ServerCnxTest.testSubscribeTimeout more resilient new 4f796e4 Merge pull request #3 from merlimat/master new 020a073 Disable Jacoco coverage on every build new 0c4116a Disabled payload corruption test new bd18ebc Made ServerCnx timeout test to execute all steps in same thread new 39b7407 Added better error reporting in PulsarClientToolTest new ddd814a Removed flickering part of getBundles test new 47dbfdb Merge pull request #9 from merlimat/master new 25d65cb Added configuration to upload binaries to maven-central (#6) new 167386b specify require dependencies for python example (#14) new 5771aa4 [#7] Added Geo-Replication documentation (#10) new 47a213c Expose broker URLs in loadbalancer registration node (#11) new b2cbf4e Fixed stats buffer rotation (#17) new d93b233 Replace Collections.sort(list) with list.sort() to support earlier jdk-version than jdk-1.8.0_20 (#24) new de2c7ee Refactoring of DiscoveryService new c2fc29f Fix: unit test cases of Discovery Service new de86ce9 Merge pull request #27 from rdhabalia/discTest new b5d0ebb Fix the cluster setup instructions. (#21) new 001ce01 amend some typographic errors in docs/Architecture.md and docs/Authentication.md (#30) new afc771b Status file path should not be required in configuration (#28) new 4e1bde9 In unit tests, do ZK cache reloads in same thread, to avoid race conditions (#31) new 7d317bd While closing-topic: remove producer from set in separate thread than same set-iterator thread (#32) new 997d8f6 Synchronized producer cleanup during close operation (#34) new 2d75e88 In managed ledger BK test, wait for background ledger roll-over to complete before shutting down (#35) new 8df6b74 Removes bindOnLocalhost=boolean. Adds bindAddress and advertisedAddress. (#26) new d7d5163 Prevent message-replay of already acknowledged messages (#38) new bea1087 Fix msg-acknowledge counter at client-stats (#36) new 728091e Added log4j with info logs for pulsar-broker unit tests (#37) new 2203316 Updated BK version to 4.3.1.41-yahoo new 577596e Fixed logic of test PersistentTopicE2ETest.testMessageRedelivery new 0577fda WebService refactoring (#40) new 26671f6 access individualDeletedMessages with thread-safe while filtering out replay-message (#45) new 554f050 Add circe source code to checksum library (#44) new bfd6b08 Correct an invalid null check (#46) new 16f1561 Revise null check of ServiceConfigureUtils (#47) new adb461c Fix incremental checksum computation for crc (#49) new f526016 Handle concurrent open cursor requests (#50) new bb35716 Accept received-msg-ack from different consumer than received-consumer on shared-subscription (#52) new 0fa6701 Deploy artifacts to OSS sonatype and github release page (#53) new cc7c807 Synchronized 'consumers' in PulsarClientImpl during cleanup (#54) new 95b8239 Add unack-message threshold to restrict consumer for receiving messages without acknowledging-msg up to the threshold (#48) new 7892754 Ensure importing of GPG keys in travis build doesn't get stuck on confirmation prompt (#56) new 309d753 Add crc32c-checksum verification on message header-payload (#43) new e85a1c3 Print current running unit test in pulsar-broker (#57) new 1304d4b Add admin-interface(REST/CLI) to expire messages for topic (#59) new 050ecd1 Use threadsafe formatter (#64) new bd49d69 Include pulsar-checksum in pulsar-client shaded jar (#65) new 3e4e127 Reduce Dispatcher-totalPermits by number of messages delivered in batch (#67) new 5b7b910 Add pending-bloclked-message-permits to dispatcher while redelivery of pending messages (#63) new 1833296 avoid synchronization for method that blocks while fetching zero-queue message (#61) new 1e9fa9f Unack message tracker for pre-fetched messages (#68) new f946a6d Added pulsar logo (#69) new e274a24 Support per message unacknowledged redelivery on RedeliverUnAcknowledgedMessages (#70) new b2805b8 Admin-api-tool doc: Fix REST api url, add expire-messge api doc (#71) new 430eb5e Add numMessagesInQueue and getAvailablePermits for PartitionedConsumerImpl (#72) new 8df2868 fix: flow permits on blocked consumer while redelivery of messages (#74) new 2949490 Pulsar release v1.15 new 36d7fb1 Bump version to 1.16-SNAPSHOT new eb619f3 GPG keys need to imported just once (#75) new 2221aee allow reset of global topic subscription (#79) new b33b2a1 Partitioned numMessagesInQueue should count it's incoming messages (#78) new 4d685b5 Use local broker address as serviceURL when running WebSocket component embedded in broker (#82) new 776042b Increment receive timeout on PerMessageUnAcknowledgedRedeliveryTest to prevent failing tests (#85) new 031271c Added badge image with latest Pulsar version from Maven central (#84) new 979c46d Added pulsar logo in icon format new 1bb5bda Make protoc compiler to use 'pulsar::proto' as C++ namespace (#87) new 1868d2f Async ZooKeeper cache implementation (#76) new e7f08a8 Fix: Reset message-header index while verify checksum-strip at Reconnection (#89) (#90) new 551d42d Fix #91 intermittent test failure PulsarClientToolTest.testInitialzation (#94) new 340dc8d Fix #91 - Intermittent test failure on SimpleProducerConsumerTest.testSharedConsumerAckDifferentConsumer (#92) new 5e55d79 Add redelivery rates to consumer and subscription stats (#95) new 25d4c55 unacked messages should always be changed even if BlockConsumerOnUnackMsgs is disabled (#96) new 5799ffa Updating ning async-http-client to use Netty4 based implementation (#97) new 1f05368 Fix: broken websocket test and proxy-producer error handling (#99) new 15683fd Complete Message replay immediately if there is no entry to replay which will not block reads from other consumer (#103) new afaa63f Async authorization check while creation of producer/consumer (#98) new 004e022 Support Topic lookup using Pulsar binary protocol (#5) new 4e9b051 Avoid setting ReplicatedFrom while init batchMessageMetadata (#107) new f2636e1 Fix typo in pulsar-admin (#108) new ff8318b Issue #80: Use receiveAsync() to aggregate messages into shared queue for partitioned consumer new 72cc677 Issue #80: Use receiveAsync() to aggregate messages into shared queue for partitioned consumer (#106) new 5e9884c Increment permits when redelivering messages from incomingMessages (#101) new f999394 Implement BrokerHostUsage using java (#88) new 536d353 Fix: Discovery-lookup returns correct PartitionMetadataResponse on partition-lookup (#112) new 3c596d4 Fix LinuxBrokerHostUsageImpl scheduled timer (#113) new 4563540 [#114] Process ZK event from background thread to avoid deadlock on ZK sync operations (#115) new 70ae671 Initialize lookup-request variables locally before request-instance recycle (#117) new 610a9fb Remove shading-package-relocation for async-client as it creates conflict while reading property file (#119) new b21e0f3 Upgrade to BK-4.3.1.42-yahoo (#120) new a7e746d Pulsar binary protocol documentation (#111) new 6089dcb Check symbolicLink file type before reading it as SymbolicLink file (#121) new e525da3 Fix: split-package conflict while server startup (#122) new 3cec7e4 Add blockedConsumerOnUnackedMsgs flag in consumer-stats (#124) new 83ff857 exclude: conflicting artifact from async-http-client to avoid split-package conflict (#125) new 5af7d3f Added DbLedgerStorage configuration keys with default values in bookkeeper.conf (#123) new 6ea847c Replaced Json Library (#130) new 4283b1a Fix Error in NodeJS consumer example code (#138) new d04b36f Cleanup pending lookup request on connection close (#131) new 710755f Add support of auth&auth at discovery BinaryProto-lookup (#126) new 6448d36 signSafeMod while getNextBroker index (#141) new caba91c adminApi: add brokerServiceUrl while creating cluster (#140) new 4136b40 Updated to BK-4.3.1.45-yahoo (#127) new e83647a Fix: PartitionedConsumer support queueSize 1 (#149) new 6f1fcd3 Support url/uri encoding of topic-name for http-request (#148) new 9609885 Use binary-proto-lookup url for replication lookup (#128) new 4dbe9d3 Stop consuming messages from consumer-listener if incoming-queue is cleared (#142) new 2e7ecc9 Async reset cursor (#155) new efd21ba recycle OpSendMsg after releasing payload (#157) new e2d8c2e Replicator-producer creation should be idempotent (#161) new 3a5ff46 Validate cursor-readPosition before reading while checkingBacklogCursor (#162) new 3aaff93 Include DataSketches metrics provider for bookie stats (#143) new 12f896e Fair message consumption from all partitions in partitioned-cons… (#153) new a6186b2 Safely stop(close replication-producer) and remove replicator (#152) new 56afa55 Updated to 4.3.1.47-yahoo (#167) new f80a079 Update AdminTools.md new 9266687 Merge pull request #169 from krumo/patch-1 new 8818eea Unload bundle: close topic forcefully and enable bundle on ownership removal failure (#164) new 0569689 Pass brokerServiceUrl to websocket service configuration (#166) new e61acc1 Fix consumer redelivery should not clear availablePermits (#170) new 616d84f Generalize PulsarConfigurationLoader (#168) new 69a68b1 Support online consumer cursor reset (#139) new 7f92ae6 fix file descriptor leak on LinuxBrokerHostUsageImpl (#179) new de2a611 Return correct error code on create-producer/consumer is not complete yet (#177) new 99f7e21 Configure split-bundle task interval different than loadReportGenerationTask-interval (#183) new 39164ce Support custom advertised address in pulsar standalone (#187) new c70601e Pulsar release v1.16 new 9f42936 Bump version to 1.17-SNAPSHOT new 295577c Add client-side lookup throttling (#182) new 77f1ce8 Added pulsar C++ client (#185) new 9833b19 Excluded travis-build.sh from license check (#193) new d278601 Add binary-protocol lookup url in documentation (#129) new d461010 Add Athenz authentication plugin (#178) new 68338c7 Getting the code to run with old boost asio (#197) new fc9b34c Replace usages of Atomic* for Atomic*FieldUpdater (#195) new 60ec362 Ignore already existing required z-nodes in global zk (#202) new 27cc96f Intermittent test failure on DiscoveryServiceTest (#210) new ccde908 Prefer ipv4 in client connections (#209) new d13bc68 Fix #206 - Intermittent test failure in ProxyPublishConsumeTest (#211) new 369e084 Update README to set correct config path to start pulsar-standalone (#213) new 5c82997 Issue #206: Fixed flaky web socket proxy test (#214) new c890005 Directory service should use HTTP temporary redirect (307) (#204) new b1dd7f9 Fixed Discovery Service initialization of global zk cache (#203) new 88e75fe Add tls authentication plugin for cpp client (#200) new fdef79e Using TLSv1 since boost1_41 supports TLS v1.0 new 9f17905 Added the macro to determine tls version new 7284ae8 Fixed race condition on client reconnection logic (#221) new 6fd212a Fix #199: Do not stop to replicate when producer throws exception (#220) new 321d583 Fixed the C++ build to work in mac (#219) new b6f061a Derive direct memory used count from netty counter (#223) new d62cf07 Partitioned topics fix (#226) new 4ac21b4 Add lookup throttling (#225) new 1691778 Merge pull request #218 from jai1/TLSV1 new e2df954 Remove partition-topic redirection as broker sends partition-metadata without redirection (#235) new 1a7b950 Include timezone in datetime printed in stats (#233) new 8c8b72c Set minimum level to DEBUG in log4j.properties new 3186175 Add TLS authentication end to end tests (#224) new e1c3d4b Corrected test case ProxyPublishConsumeTest (#243) new 96f824b Replicator stop retrying to read when cursor is already closed (#239) new 99cf1dc Avoid triggering startReplProducer on newAddProducer as it may flips replicator state wrongly (#232) new a54a1bf Corrected test case ProxyAuthentication, ProxyPublishConsumeTls and ProxyPublishConsumeWithoutZK (#245) new 5dcb440 Travis Build - install xmllint and enforce backward compatibility with gcc4.4 (#242) new 82f9adb On batch-msg dispatching: broker should disconnect consumer which doesn't support batch-message (#215) new cd2d16e Message dispatching based on consumer priority-level (#165) new 9fde15b Fixed compile error in ServerCnxTest after merge (#247) new ae381b4 Get ConsumerStats using Binary Protocol (#216) new d89563c connect dispatcher again on reset cursor complete (#250) new 8ec61b2 fix Intermittent test failures in ProxyPublishConsumeTest.socketTest (#253) new 246a864 Introduce Pulsar Dashboard (#188) new c5200ff Avoid printing unit test info logs by default for pulsar-storm (#259) new f6d2219 Test case for ByteBufCodedOutputStream.writeDouble (#256) new a715c93 Fixed license check mappings and exclusions (#261) new 24c7724 Fix in ConsumerBase.java to return failed future - #249 (#257) new 619ad64 Replaced use of System.out.println() in unit tests (#260) new 0286fa8 Fixed circular dependency in slf4j loggers for pulsar-storm unit tests (#264) new 522aee8 close http-connection on internal server error from broker (#265) new 17630b9 Fix reset on closed cursors (#231) new bb0de8e Added g++-4.4 to travis build (#266) new 5e80344 Resolve compatibility with previous version (#241) new 9d274a1 If there is an error in reading from ZK, DiscoveryService should fail when reading partitions metadata (#272) new 895509d Handle unknown exception on authorization check (#270) new 5c78338 Close HTTP client connection upon server error or per HTTP spec (#273) new 8544200 Fix for Infinite loop in PersistentReplicator.startProducer() (#275) new 92b79d0 Update Broker service configuration dynamically (#186) new 3345d24 Add server-side lookup throttling (#181) new ea85d95 Updated CPP Travis build script to use cached dependencies. (#278) new fbdbddd fix Intermittent test failure in BrokerServiceThrottlingTest (#280) new 83605f6 Persist individually deleted messages (#276) new 75d2273 Rlease ping/pong command buffer (#283) new 1d5ec83 amend some typographic errors in documents (#286) new 1fa4508 reduce collection instances while generating metrics (#284) new 146738c Enable ML binary format from broker configuration (#282) new 6d4bd9d close client connectionon tooManyRequest and internal-server error (#274) new d1cb591 Fixed race condition in cursor.asyncDelete() (#287) new f0fbb4d Extending ZK version wrapper to include ctime and mtime (#288) new 49ac77d add hyperlink for getting-started doc (#293) new bd3fbb2 translate documents into japanese (#285) new dd7de4d Fix typo in docs/Architecture.md (#297) new 8cee846 Fixed CPP Client ABI (backward compatibility) with minimal changes. (#290) new 8dd9ef4 Update BK to 4.3.1.60-yahoo (#302) new a86b6df added c++ sample code to documents (#304) new b7bc381 Add Athenz documentation (#301) new 9c5088f Fix typo in ConsumerHandler (#310) new 181172f Exclude netty individual jars from binary distribution (#311) new 5a28f63 Added more checks in CPP Client URL Tests (#312) new 6710a7b Added REST and CLI tool to expose ManagedLedger metadata (#292) new df0bf9e Atomically Set State when Closing Producer (#313) new 80986d7 Fix for cursor reset after topic reload (#315) new 7dbd596 Add Athenz unit tests (#314) new 2886250 Add topic loading throttling (#306) new 66c091e Start auth service before providing auth data in PulsarAdmin (#321) new 1e02afb Introduce new load manager API (#303) new 9e31e89 Make EntryImpl recyclable to improve gc at broker (#318) new a64be75 Pulsar release v1.17 new d22d656 Bump version to 1.18-SNAPSHOT new a7d476f Fixed CPP Client test cases for BasicEndToEndTests.cc (#323) new b2e676d Avoid extra retain of entry data (#326) new 06ec3bb Add documentation for changing load manager (#325) new 8c270c9 Added api to get list of partitioned topics (#319) new 378217d create dynamic-config znode if not present (#327) new b1df955 Added spark streaming custom receiver for pulsar (#296) new e34b595 Fixed pulsar-spark pom version (#330) new 16d8177 Use historical data from old API in new API (#329) new bea8ff2 HTTP lookups for c++ client lib (#317) new b1469b1 Update cpp client README.md with mention of libjsoncpp (#334) new 8080e88 Fixed BasicEndToEndTest.testResendViaSendCallback (#333) new b38da88 Improve Simulation Tools and Add Documentation (#328) new 4866563 return if serviceNotReady while creating topic (#336) new 911a9b6 deserialize load report based on load-manager (#338) new 2d07cd5 CPP Client - Async call for getting broker side consumer stats new 74c5b6e BrokerConsumerStats - refactored the server side logic to get stats. (#339) new 731e5df Fix Bugs Introduced by New Load Manager (#332) new e224df9 Regenerate OAuth token for github releases upload from travis (#349) new b5fd035 Legacy code expects the AuthData to be initialized to Auth::Disabled (#348) new f572241 Remove orphan ledger when managedCursor fails to switch ledger (#350) new 8bc4235 Fixes to some of the issues reported by fbinfer static code analyzer (#344) new fc10931 Fix bug causing removed brokers to be considered as candidates (#343) new bd5a622 register listener on dynamic-config zpath even if deserialization fail on service startup (#351) new 19399e0 Delete local-policies and invalidate cache when namespace is deleted (#352) new df34ae7 fix import into AdminApiTest and introduce disable-namespaceBundle unit test (#354) new 6099e88 Removed ability to disable connection pool (#337) new b2e3d33 Small fixes in CPP Client (#357) new 9278623 Fix LoadManager shutdown timing issue (#358) new e7622f3 Fixed WebSocket TLS connection bug (#356) new 0992011 Add timeout on zkDataCache dependent task (#362) new d58cc0b Removing Inner structs in cpp client (#360) new 3b99f30 Use binary protocol lookup for connection between WebSocket proxy and broker (#363) new 766e987 Fix for flaky test in testLeakFailedLedgerOfManageCursor (#365) new 5862644 Refactor dispatcher's getting next consumer with consumer priority (#367) new 2620d66 In BinaryProtocol.md use %20 in image links (#368) new 9961d2c add complete list of configuration into websocket.conf template file (#372) new 136fb7b Fixed travis release yaml configuration. Fix for #340 (#373) new 01b5104 Avoid using zk-client thread to process zk-data result (#361) new 26963dc BrokerService should not remove failed topic from map with the same thread which adds in map to prevent deadlock (#375) new 55c49c8 Remove Exceptionally Completed Topic Futures (#374) new f13606e avoid incrementing unack-msg count for non-shared sub and not show it on stats (#376) new 2f1c5fa no call session.close() in onWebSocketError() (#378) new 9765de1 Get messageId in string format (#370) new 7f63ee9 Modifications to create a wrapper for CPP client (#379) new 09b6bb0 handle zkCache failure: invalidate cache and zk-getData failure (#377) new e77fa5b Skip travis local cleanup before uploading releases to github. Fix for #340 (#381) new 947e409 Send replay entries read callback from background thread, to avoid recursive stack calls (#384) new c4d2e8b Shaded AsyncHttpClient in pulsar client (#390) new ce553b7 Pass client library version to broker and show on stats (#387) new fa3cc70 C++ Client - moving all MessageData related code to MessageImpl (#391) new 398bb6a Introduce Interface for Customizing Update Conditions (#347) new 914e428 Add load shedding strategy (#345) new 80bebd5 Change default mark-delete rate limit from 10s to 1s (#393) new de1b35a Upgrade to netty-4.0.46 (#392) new 65da593 NonDurable cursor for managed ledger (#366) new 7badf1a Introduce topic reader in client API (#371) new bd3fa56 Removing blockIfQueueFull option from WebSocket Proxy Server (#396) new 8d92419 Always evenly distribute bundles in the same namespace (#388) new b2e350a Add stats and monitoring for websocket proxy (#341) new 348759c Add options to admin tool (#400) new a2ce536 Dispatcher blocks dispatching once unackMsgs reached max limit (#399) new 1c12849 Fixed websocket proxy stats license headers (#403) new ca5a445 Add ability to filter brokers based on their build version (#397) new 5f64da7 Added missing license header new 6e34115 add ConcurrentLongPairSet and test (#405) new 8bb42f2 close webService on test to close pulsarClient and executors (#409) new 8ce7631 add syntax statement since protoc warns to declare explicitly (#410) new 5de4955 Update documentation for modular load manager impl (#408) new d12eee6 Print hostname and error when we get connection failures (#412) new cdaf228 Fix typo in documentation page for ModularLoadManagerImpl (#413) new 805db3c Fixed ZK configuration instructions (#415) new 920374a Fixed comment typo in broker.conf (#416) new 320dd90 Ignore bin/ directories in submodules (#417) new 0a50fda fix direct-memory usage count (#418) new 08deca1 Remove "experimental" warning for WebSocket API (#421) new 7a7b60b Correct documentation for how to enable ModularLoadManagerImpl (#419) new 5a0d210 Replace messagesToReplay set to ConcurrentLongPairSet to improve gc (#406) new 16cc997 Made log category name configurable in CPP Client (#426) new 77416c6 fix a typo in pulsar binary protocol specification: CHECKSUM size is not 2 bytes, but 4 bytes (#427) new 96b8c20 Include default values uncommented in conf/bookkepeer.conf (#429) new 5ba05cc add api to increase partitions of existing non-global partitioned-topic (#299) new f888d60 Increase ZK timeout in broker-monitor (#432) new d67499a Log broker message rates, weights, and scores during bundle placement (#435) new 6f08d3b Configure to use less memory for short-lived CLI tools (#431) new b47df82 Move websocket performance client and fix bugs (#430) new 293153e Add long-term message rate to the broker monitor (#423) new e93a4c3 Add endpoint to fetch stats for Prometheus (#294) new 19718e4 Enable PulsarAdmin to trust multiple certificates (#440) new e146696 add log and cleanup failed non-durable subscription (#444) new 5a82c79 Remove broker weights for ModularLoadManager (#442) new 2e4475e Recover cursor with correct readPosition and replay unackedMessages (#446) new d990b17 Changed the default value of maxPendingMessages to 30,000 (#445) new 5c6c9c3 Set Block If queue full to false by default (#441) new 049e428 Fix DoubleByteBuf to send large size messages in TLS mode (#447) new 45fcd35 Removed duplicate mentions of authenticationProviders from the websocket.conf. (#449) new 6233356 Fix shared reference between the two load reports (#450) new 54d54c9 pulsar-client should use the log4j.shell.properties conf (#453) new 252b539 Fixed links and a statement related to persistent topic permission in AdminTools.md (#459) new ffc6db7 Topic termination (#433) new 96a4c4f Look at the absolute difference in maximum usage percentage. (#454) new 70abe6d Update ZK version to 3.4.10 (#414) new 0d0c9ed Fix test: testNeedBrokerDataUpdate loadReport considers absolute percentage change only (#464) new 0ddb5fe C++ Client - fix for seeing correct msg rate in broker stats (#462) new 06cdf7a update shaded async-http-client property file with 2.0.31 version (#465) new efb177d Blocking queue (#463) new 11f874e C++ Client - Better handling and logging for curl response. (#461) new 87d8d72 In MockZooKeeper triggers callback without holding mutex (#460) new ec2ea80 Added ZooKeeper instrumentation for enhanced stats (#436) new 019e5f3 C++ Client - Batch Messages - changing group commit time to 10ms (#467) new 10ac6c1 WebSocket proxy should not make a consumer/producer when authorization is failed (#448) new f5ab3b9 Small compilation fixes for GCC 6.3 (#470) new 17e6537 Add Docker images definition and instruction to deploy on Kubernetes (#443) new 121ed54 Internal Producer/Consumer in WebSocketProxy should be closed asynchronously (#473) new 8abafee Correct outdated comments in code about wire protocol format (#477) new 042521a Fixed message rate out with batches to count messages/s (#466) (#474) new 29b2dd1 Allow client(producer/consumer) to check topic stats (#482) new 3750e2e Pulsar Python client library (#468) new c0f8b0d Add debug statement for redelivery message for troubleshoot (#483) new 70b2a35 Remove bundle from the ephemeral preallocated map once it is loaded (#481) new c92abef increment bookkeeper version (#486) new 658243b Pulsar release v1.18 new 3e4a3db Bump version to 1.19-SNAPSHOT new d9c92e7 Shutdown zk cache executor on service shutdown (#487) new 0219829 Fixed race condition with NPE on Producer.closeAsync() (#490) new 07d2daf Shutdown load manager executor on pulsar service close (#489) new b4ad43e Fixed NPE on load manager shutdown (#491) new e1a703f Use maven-3.5.0 in travis builds (#492) new 3c6e29a add timeout for websocket testcase (#495) new cd8a758 Modify Python docstrings to fit the pdoc format (#484) new 120a3c4 Fixed travis build script spaces (#493) new b643bd6 Fix intermittent LoadBalancerTest due to unpredictable host usage (#498) new 5b93f10 add wagon-ssh-external extension (#499) new 0797c4d Fixed tests timeouts for PartitionedProducerConsumerTest (#500) new f4969b4 Refactor HttpLookupService to take ownership of HttpClient (#501) new e87d5f8 Disabled load-dependent test in ModularLoadManagerImplTest (#502) new 02128c6 Add extra wait to avoid intermittent failures in OwnershipCacheTest (#503) new a45ffe2 Add max per-broker unacked message limit (#420) new 3f39a61 Add connectionsPerBroker setting to WebSocket proxy (#497) new fde9b6c Redirect standalone broker logs to file during C++ unit tests (#508) new d746024 Fix testConsumerBlockingWithUnAckedMessagesAndRedelivery : add strategically retry (#510) new c7d982b Add authetication by http header in WebSocket performance tool (#505) new 2ca1a7a fix AdminApi test by creating separate mock-pulsar instances for different broker (#512) new afd64df Only throw Python exception when the current thread is holding the GIL (#513) new c0ba223 Fix testDisconnectClientWithoutClosingConnection (#516) new 0dda904 Updates headers with ASF source files header (#519) new 009d73e Reverting commit d990b1 - changing producer queue size back to 1000 (#517) new 7c0b28f Enable to configure webSocketServiceEnabled on Standalone (#520) new 59a952d Fixed problem in starting ZK server for standalone mode (#521) new 70da31b Renamed Java packages from com.yahoo.pulsar to org.apache.pulsar (#524) new 251594e Renamed java package names in scripts and documentation (#524) new bcb6b57 Updated references of github.com/yahoo/pulsar to github.com/apache/incubator-pulsar (#524) new ac94698 Converted repo urls to apache/incubator-pulsar (#524) new 9bf2a07 Updated maven groupId from com.yahoo.pulsar to org.apache.pulsar (#525) new c3a55b5 Changed version to 1.19-incubating-SNAPSHOT (#527) new 76a73e3 Add managed-ledger admin tool to access ml binary information (#526) new fd3fb1d Reduce default producer queue size from 30K to 1K also for Python (#522) new a9a0afc cleanup yahoo test-url (#531) new 6a84aac Added apache-rat plugin and fixed some license headers (#528) new b3a0f64 C++ Client - Changed compiler to default version (4.8.4) (#529) new 8ccbfae exclude license for athenz-test-conf file (#533) new b3db513 CPP Client - Added Monitoring Stats (#485) new d178710 Validate msg size after compressing the msg while sending msg (#534) new 435a664 C++ unit tests in less than a minute (#539) new 5fa4cb6 Bump up athenz version (#540) new 3d00b31 Fixed license link (#542) new 1994f4f Support wildcard in permitted role name (#530) new b86f7bb Enable TLS Client Authentication on WebSocketProxy and DiscoveryService (#535) new c232df6 Fix: intermittent test failure for BrokerClientIntegrationTest.testCloseBrokerService (#545) new 91d8414 Disabled deployment of SNAPSHOT jars to Sonatype repository (#546) new 09fd5e9 Generate C++ protobuf code during cmake build (#471) new b801eaa Message size validation on post compression (#541) new dcd9b13 Added wildcard matching setting for DiscoveryService (#547) new f5768b0 Fix for Problems in lookup flow in C++ Client (#551) - Issue 1 (#553) new f54dea1 Allow cumulative acknowledgements for Failover subscriptions. (#549) new 9a8098f ZookeeperCache children-cache invalidation on watch-event and LoadManager handling if availableBrokerCache is not updated (#550) new 365230c CPP Client - Accessing connection_ pointer under a lock (#555) new f36b70c PIP-1 - Introduce Pulsar proxy component (#548) new 4be5883 CPP Client - Reducing number of duplicate lookups (#556) new bb0a8fb Add zk-stats instrumentation to get zk-client stats (#507) new 49301ef Upgrdate JNA library to 4.2.0 (#560) new c033484 Removed test log file (#562) new f378551 Fix: CPP release baseCommand after serializing it (#561) new 0470a7e avoid multiple registration of zkClient-aspect in test (#566) new 66ae063 New website and documentation (#557) new 18b47f2 Publish website after commits on master branch (#567) new ae6ca6b disable ZooKeeperClientAspectJTest test (#565) new 3047d1c Add empty check for subscription name (#559) new 524ff06 Fix: register zk-stats listener after broker service started (#573) new 30be621 Simplified the instantiation of Netty EventLoopGroup (#570) new cfc0683 Only deploy releases and website from apache/incubator-pulsar repo (#576) new 7357ae1 Fixes for NOTICE and LICENSE files for src and bin distribution (#563) new 9dae207 Fix #578: Force early load of epoll library to avoid race condition (#580) new 0ee1fad Build and publish docker images (#575) new 72a073b Fixed bin distribution file name from pulsar-x.y-bin.tgz to apache-pulsar... (#583) new 6e8cbc8 Basic website fixes (#582) new 4d4080c make javadoc generation not delete whole /api directory (#585) new f6ebbb2 Add GrowablePriorityLongPairQueue and tests (#425) new ee65abe Upgrade to RocksDB 5.5.5 with Apache License 2.0 (#587) new 2ab766a Updated README by removing broken links and adding instruction on how to build (#589) new 22aee89 clear up pendingReceive queue when consumer close (#588) new 92610d1 Added script to sign release artifacts (#592) new 422a68f Fixed references to Yahoo pages (#591) new aaae221 Enable Apache rat in CI builds (#594) new 87b8944 CPP Client Test for Lookup Issue (#551) (#595) new 52db0e9 Added documents for wildcard matching in authorization (#543) new 298533c CPP Client - removed log statement from ClientImpl Destructor (#590) new 73d50b6 Local-policies cache should copy global-policy data and return combined result (#593) new 3f7d723 Excluded a couple of binary files from src release artifact (#597) new 9d3a450 Documentation changes (#574) new 257363f Added links to the Slack channel in website (#598) new c8dfd41 Added more info on how to setup monitoring (#600) new ca380d8 CPP Client - Use long when calling curl_easy_getinfo in tests (#602) new a6e374a Remove duplicate cluster-info and bump header for properties (#603) new 03ab475 Removed duplicated links (#604) new d7bb707 Add athenz authentication plugin for C++ client (#586) new 380e47e PIP-2: Introduce non-persistent topics (#538) new c02c5df CPP Client - Added -std=c++11 flag (#605) new 875767f Added Jenkins setup for building C++ client (#606) new 85a1c6c add non-persistent topic documentation (#532) new 1305439 Maven artifacts relases into Apache (#607) new b8fd659 Use PrometheusMetricsProvider by default in bookies (#599) new 666e73f Fix variable name in Authentication Class in pulsar.py (#608) new 96ed86c Static link dependency libraries for C++ client lib and Python wrapper (#514) new 88314dd Redirect unit tests logs to file (#610) new a683c19 Bumped version to 1.20.0-incubating-SNAPSHOT (#609) new d305d2e Reduce memory usage in producer and subscriptions maps (#613) new aa56970 Small typo fixes on website (#611) new cd5189d Allow to compile C++ client lib in debug mode (#615) new d8e8813 Fix #612: NonPersistentTopicTest test timeout was too short and sometimes failed (#629) new de31402 Reduce memory settings for LocalBookieEsemble in tests mode (#626) new 10fef7d remove duplicate dynamic-config listener call (#631) new 5b7186d make batch-ack thread-safe (#619) new a0044bc Add subscription-type argument into test (#636) new 052ca00 fix: intermittent test by invalidating cache to read fresh data (#642) new 8ee6ff8 CPP Client - Fixed MAC build errors, due to undefined ZLIB_LIBRARY_PATH (#646) new bef6cad Add instructions on compiling from source (#648) new 177dc66 CPP Client: Fix for sendTimer_ being dereferenced after reset (#649) new b1e28d1 CPP Client: Fix BrokerConsumerStats function returning value instead of void (#650) new 4f22047 Fix #644: BrokerServiceThrottlingTest.testLookupThrottlingForClientByBroker intermittent failures (#645) new 69b3e8c Removed required maven version from pom.xml (#640) new 517885e Ensure the Python client works with Python-3 (#643) new 9f64b8c Docker image to build website in Jenkins (#628) new 2b63573 Build website using the current user rather than root (#652) new d2ab2b5 Add link checker and fix broken links (#647) new ce1131e clarify time + size limits for retention policy (#656) new 7c0bd3b Removed duplicated ASF headers from BookKeeper (#653) new f585598 Do not delete inactive topics if they have retention policy (#654) new ab905fa Use $UID instead of $USER in docker build (#658) new b0ee661 Splitted Admin API reference into multiple pages (#632) new 005aa12 Make athenzConf and athenzPrincipalHeader configurable (#661) new de24aaf support tls in performance tool (#662) new 57314e5 Updated download links to Apache mirrors and prepared for multiple versions docs (#660) new c0d9751 When publishing website, we should not remove files that were not generated in the last build (#663) new b4040c9 Fixed broken links to admin-api/overview (#664) new 12fee6d Use Docker images from apachepulsar hub org (#665) new fdd709e centralize policies znode name (#669) new ad3a900 Fix Python package version (#668) new 34dc24f Don't run Javadoc and Swagger builds on regular mvn package (#670) new 71f1347 Added documentation on how to start the standalone service with Docker (#666) new b037a7a remove topicName-dataProvider from testIncrementPartitionsOfTopic test (#676) new c51eaad Fix #657: Use exceptions instead of assert() to do runtime parameter validations (#673) new 79f8bf0 Removed unnecessary Copyright notices in NOTICE file for bin distribution (#677) new 89a80f6 Fixed Maven test jars warnings (#678) new 80ddad6 Refactored usages of deprecated classes (#679) new f03a8b7 PIP-3 : Introduce message-dispatch rate limiting (#634) new 4ef959e fix list collection import (#688) new 8dd6a5c remove redundant dependencies from modules (#693) new b0bdb25 Fix broker links due to invalid package (#694) new 8440e3d Interrupt the Python consumer when receiving SIGINT (#675) new ff0b4f5 Don't attach pulsar-*-{src,bin}.tar.gz to maven artifacts (#616) new 59bb252 Add narSystemPackage to avoid maven-warning with nar plugin (#695) new d7e9fba Websocket Client - Making ServiceConfiguration extendable (#700) new 583f7fd Fix broken links: downloads link in Kubernetes.md and link in kubernetes/README (#703) new 73c417b Fix broker links for deployment, client (#701) new bcf9f89 Fixed misspelled PrometheusMetricsProvider class name in conf file (#705) new bcfba3a add dispatch rate-limiting for global namespace (#704) new 45ea0bc Create global cluster marker for standalone pulsar (#708) new db85e87 Succeed when unloading namespace bundles not owned by any broker (#709) new bd922bb Fix lookup for non-persistent topic based on correct destination-domain (#711) new 54ad999 add get bundle api for a given topic-name (#710) new 29c705f Add missing lib instrunction for pulsar-ml-admin tool (#706) new 3ddc24d Fix mobile navbar issue (#712) new ccb4d92 added new entrypoint for reader to websocket proxy (#620) new 21a618a Support setting private key content in athenz client plugin (#672) new a64d795 Fix: msg rate acquire permit for msg/bytes (#716) new 1a6ffbf add namespace site section and fix headers (#719) new 3751baf Remove Managed Ledger metadata text format (#394) new df93a42 add msgAck and redelivery debug-logs And add topic-name in debug-logs (#714) new aeeeb56 CPP Client: Small fixes to make the code work with older libraries - no change in code logic (#724) new aa40ebb Validate dynamic-configuration value while updating or init (#725) new f8b051a Handle NPE at load-manager when leader couldn't find available broker (#726) new 070ebc0 Issue 733: Event Time support in java client (#734) new 7b9477b Update `protobuf/README.md` (#737) new 6ca3373 fix code sample (#740) new dec05d8 Managed-ledger admin update zk with the stat-version (#741) new 5f5015b Added reader endpoint description to WebSocket.md (#729) new a9cca05 Include a pre-built protoc in `pulsar-build` docker image (#743) new f740f34 Position Reader on a specific message within a batch (#720) new 9c75f8f Make navbar more mobile friendly (#728) new 8c0d399 Add user-defined properties to cursor position (#744) new 6d2f798 Added links to blog posts (#723) new ee1ba68 Reader API for C++ client (#717) new 3a775cf Add msg ack-hole metrics to internal-stats and broker-stats (#750) new 817898e Add configuration to enable throttling for non-backlog consumers (#754) new bdbb121 Broker side deduplication (#751) new 6e3ba01 Avoid storing ack-msg range while switching-ledger (#756) new c19a1ce Consider cluster-throttling config when namespace-policy throttling is disabled (#748) new 5cf010e Added Python wrapper for C++ reader API (#718) new a8abd98 Updated bookkeper version to 4.3.1.72 (#757) new 0acfe57 Pulsar Clients: Added a mandatory stop to the Backoff logic (#747) new 540b9bc Execute Python client lib unit tests during build (#722) new 2a04683 Parse authParamsString on plugin side (#671) (#721) new 8f15858 Issue #735: Event Time support in c++ client (#736) new dd635ac Admin Tool: Adding support to peek batch Messages (#727) new d4a8c25 Expose control of sequence id in Java producer API (#760) new fed5ae3 Add option to persist unack-msg range to cursor-ledger if range is high (#758) new b5bdd79 End to End Encryption Support - Java client (#731) new e7f1160 Kafka client Java API wrapper (#761) new 1f7712c Use `advertisedAddress` from host IP in Kubernetes deployment (#764) new 824922a Cpp producer sequence id changes (#763) new 272f290 CPP Client: Added client version to User Agent in HTTP Lookup (#765) new fbdec45 [#766] - Disabling IOUtilsTest.test5() for failures (#768) new 549d1bf Fix some documents (#767) new 1e73b31 Don't reuse JVM forks when running tests (#769) new b53a5dc Fixed race condition in ProxyPublishConsumeTest (#770) new 94b1fb9 Fix Intermittent test failure for MessageDispatchThrottlingTest (#771) new b96c50d Fix Intermittent test for dispatcher (#774) new 8bf8eb1 Refactored replicator test with backlog quota interactions (#773) new c8487ef Close topics after creating all subscriptions on increment-partitions (#778) new 79a7790 Fix ClientDeduplicationTest intermittent failure with parallel tests (#777) new 696c4a9 Fixed the jar name for the aspectjweaver (#775) new 577b897 Ensure producer/consumer are creating before upgrading from HTTP to WebSocket (#779) new 7daee93 Added Bouncy Castle Licence files (#783) new 25c8107 Add admin-api to unload a specific topic (#782) new 5f378f6 Fixed Java client documents related to Athenz (#789) new bace0b4 Fix memory leak in WebSocket proxy (#790) new fea1b33 Correctly process the ack for a message that was outstanding on a different consumer (#791) new c5d4f90 Fixed some documents (#794) new a98e818 fix intermittent testBlockBrokerDispatching consume msg async (#787) new c359905 Add persistent-policies validation and dynamic policy update on managed-ledger/cursor (#781) new 350e67a Fix typo in bookkeeper.yaml (#796) new 6010db0 Added encryption key metadata to send additional information about th… (#798) new fe28023 Fix ProxyPublishConsumeTlsTest (#496) new af1bedc Added Crypto notice into README (#799) new e1ffafc Documentation for Kafka/Pulsar client wrapper (#795) new f79fcd3 Added Crypto notice to src distribution README (#800) new a366a2d Allow publish to private registry (#805) new 03c4ce2 Fix test: shutdown executor and intermittent test failure (#804) new d092389 Fix BrokerServiceThrottlingTest using thread-safe list and closing executor (#809) new 4408204 Translated docs into Japanese (#780) new df5be46 Fix testActiveAndInActiveConsumerEntryCacheBehavior (#810) new 482c4c1 Bumped version to 1.21.0-incubating-SNAPSHOT (#815) new 16bf10b Added end user documentation for encryption (#802) new d360b07 Add method to returns bytes type in Python client (#812) new c65207e Added privateKey field to cpp Athenz client plugin's authParams (#803) new 33d1481 Support json format in AuthenticationAthenz's authParams (#793) new 193ea53 Pass originalPrincipal from proxy to broker for auth + Fix tls (#816) new 34ae881 Admin-api to reset cursor by position (#785) new f6ae797 Prevent message duplication when active consumer is changed (#807) new b4694c6 Documentation: Added a few more commands to BinaryProtocol.md (#819) new ccd9ff3 Update _config.yml (#825) new f551c4f Update bundle-cache on split-bundle and avoid disabling main bundle (#822) new 55e04b6 Add athenz role header property (#831) new a26c1e5 CPP Tests - Prevent failure due to namespace creation on rerun (#830) new b7bbe90 Avoid bundle-split with old load-report (#826) new e92c54a When trigger kafka producer callback, don't wrap the exception if it's null (#832) new 9e3f390 Add ASF headers to Markdown documentation files (#823) new 438d083 Fixed missing message key on received batched messages (#837) new 18aec9a Enable replicator to encrypt communication using TLS (#824) new fb92a51 Correct Kafka wrapper producer blocking semantic and passing the producer config object (#833) new 1d9d596 Check data buffer before release() (#835) new f5268ed Specify rsa transform, aes & tag length (#839) new 2c1cbc8 Fixed PulsarClientToolTest.testInitialzation (#843) new 4288839 Add PulsarClientImpl.getNumberOfPartitions() to avoid exposing PartitionedTopicMetadata (#842) new 79ecb72 Modify AuthFactory for C++ Client to enable each plugin to parse authPramsString (#792) new df56dc9 Allow consumer to seek to message id from within Pulsar client (#848) new e981e5a Use "trimStackTrace" option in Maven surefire (#850) new 7ba3675 Change timezone of request log from GMT to local one (#841) new 21e09d6 Enable json format to be used as an authentication params string (#847) new 6625f8e Publish the shaded pulsar-client as the default dependency (#846) new a5b5659 In C++ partitioned consumer, do not append partition index in subscription name (#836) new c85a779 Implement seekToBeginning()/end operations in Kafka consumer wrapper (#849) new aa40f96 Use info log level for message "Reconnecting after timeout" in HandlerBase (#851) new bbc52fe Avoid interrupted exception in PulsarKafkaConsumer when shutting down (#852) new 62e1746 Validate messageRoutingMode and config-enum values in websocket (#862) new d251649 fix: return correct error while splitting bundle which can't be split further (#859) new 16819f0 add query-param for websocket-readme (#860) new 8448198 Allow to configure the default number of bundles for new namespaces (#854) new eb9e5fc Introduce auto bundle split and unloading of split bundle in ModularLoadManager (#857) new 6bd024d Fix: compilation error for NamespaceServiceTest (#863) new 3e965b2 Make spark consumer-listener lambda Serializable (#866) new 8ba2a7c Fix: profobuf interface generation on doc (#864) new e12d0fd Pulsar-testclient should not fetch the shaded pulsar-client dependency (#868) new 5c58367 Add proxy configuration for kubernetes (#856) new c436927 Broker-stats return load-report based on loadmanager + fix: modularLoadManager-loadReport (#869) new 815bd70 Cleanup load-manager configuration and make ModularLoadManager default load-manager (#865) new 9a85134 Recycle MessagePublishContext when publish fails at broker (#871) new 62000d4 Moved some info logs in ClientCnx to debug level (#870) new 3105a46 Fix missing parenthesises in WebSocket sample code (#873) new 5a4dd11 Fix: Non-persistent topic acking sequence for dropped message (#874) new 9f63fa7 Fix ConsumerHandler in WebSocket Proxy (#875) new a0c98eb Namespace-isolation policy should consider secondary brokers (#877) new a1a479b CPP Client - Athens Client header visibile and remove C++11 features (#880) new 7dbb37e Do not used Pooled allocator for stats buffers (#883) new 7c35ce4 Use 127.0.0.1 in standalone and clean the cookie in case of conflicts (#879) new d522c45 Use thread local to allocate temp byte[] instead of allocator (#882) new c86acea Reduce the default per-thread retained objects in netty Recycler (#887) new 9433f36 Separate ports used by global and local zookeeper (#876) new 53f4de7 updating Storm version in Pulsar (#881) new 122cc15d Use fully-qualified name for docker image (#888) new ce289af End-to-end encryption support in Reader (#889) new 163dafa Fixed typo and right sidebar on Encryption.md (#891) new 59931f9 Fix ReaderHandler in WebSocket Proxy (#892) new 29bd6c9 Add debug logs for LoadManager and cleanup unncessary logs (#895) new 6278855 Fix: discovery service logs (#897) new 635b846 Fixed getting the position in PulsarKafkaConsumer when we don't have an offset yet (#900) new c3b1e22 E2e in perf-consumer (#898) new e145c7e Set error-message into RestException (#902) new 35505f3 Cleanup unsused ApiVersionFilter (#885) new f538bec Introduce configuration converter (#901) new 376a0d2 Fail Pulsar storm spout/bolt init on consumer/producer creation failed (#905) new aa9d267 Avoid logging stacktrace for exclusive consumer-busy exception (#906) new 63fe18c Deserialize LoadManagerReport with custom-deserializer + fix broker-discovery (#908) new dd3318e Use Optional to check null gracefully (#907) new bcc7404 Fixed date-time format used in stats (#909) new 153cef3 Fail broker start if broker-znode created by other zk-session (#913) new dddabfc Restrict partitioned-metadata rest-api access for cpp-client older than 1.21 (#884) new f602e68 PIP-8: Introduce peer cluster for global namespace redirection (#903) new 012e274 Fix intermittent test failure for ZookeeperCacheLoaderTest::testZookeeperCacheLoader (#916) new 304d0b0 feat: shaded broker (#914) new 08d4015 Avoid running duplicate ReplicatorTest (#911) new 84e352f add admin-api doc for peer-clusters (#918) new 1366951 Fix status code when partitioned-topic unsubscribe fails (#910) new f0a7dd9 Check whether the property exists at the beginning of `validateAdminAccessOnProperty` (#912) new 4279306 Fix: broker-zookeeper latency-metrics's dimension-name (#919) new 75de0a9 Netty 4.1 (#689) new 2cca6ca Upgrade to bk-4.3.1.83-yahoo to expose journalSyncData option (#923) new cb93f6c Bumped version to 1.22.0-incubating-SNAPSHOT (#925) new d29291e Fixed NOTICE file for binary distribtution (#926) new 935e06d Fixed Apache RAT exclusions (#928) new c8849b2 Fix: failed producer creation leak (#927) new b659409 Re-work bare metal cluster deployment documentation (#921) new c53aeba Avoid dead-lock on broker service when broker failed to load managed-ledger (#934) new d5a47f5 Added more log messages for SLA Namespace acquisition (#932) new 11a6872 Issue #935: Included Kubernetes deployment files in src package (#936) new cc31200 Remove some netty artifacts from bin package since they're already included in netty-all (#940) new 09345ab Handle and log uncaught exception (#938) new c21b61f fix directory structure and update sidebar.yaml (#939) new 93825a1 Start receiving messages after WebSocket session established (#943) new 0b48aba ReaderHandler starts receiving messages after WebSocket session established (#944) new 3cef49b Correct the Kafka Wrapper Functionality matrix as well as maven dep (#945) new 664cfa6 fix types under k8s dir (#948) new 3ad77a4 Remove `apache-rat:check` from travis ci (#947) new d1ba96e Reduce duplicate string allocation for GC improvements (#952) new cc18beb fix image width issue (#956) new db51e28 Exclude tests jar path from classpath.txt (#960) new 08565e4 Adjusted documentation for single cluster deployment to remove need of global ZK (#953) new 12711ea Removed unused client version filter method in WebService (#957) new af20143 Don't create producer/consumer when authentication fails on websocket proxy (#958) new f21cb67 MockZooKeeper watches for non-existing znode (#979) new dd22d11 Fix SHA extension (#964) new 2d7d493 Fix authentication logic in WebSocketWebResource (#949) new 6e7b712 Issue 924: Provide a json file for Marathon app groups to run Pulsar on DCOS (#950) new fdc7b84 Update _config.yml for 1.21.0-incubating (#984) new bffc53d Fix: cursor-ledger leak by deleting cursor-ledger after recovering managed-cursor (#985) new d3ee626 Implement toString in ProducerBase and ConsumerBase (#992) new 55948d6 add signs, hashes, and KEYS to downloads page (#988) new 0ffeb75 Upgrade bk version to 4.3.1.84-yahoo with ledger-creation fix (#998) new ee1a176 Add table listing supported Python versions (#996) new 35d516d Raw Reader for Pulsar Topics (#962) new 73999f2 Retry on failure of ledger-deletion and avoid running callback in executor (#982) new 83b7753 Issue 922: allow run bookie together with broker (#961) new df9d4e5 Partitioned Consumer UnAckedMessageTracker (#963) new 5fa141e Make sure nextTuple emits tuple with non-null values (#1000) new 334afa0 fix remaining instances (#931) new 3e7cd2c Fixed error response for Too many get partition metadata request. (#1004) new fcec34b Edits to DC/OS docs (#1013) new b6f56f0 Make load-balancer shedding dynamic configurable (#1012) new fd36ade Keep strategically-retry logic common for tests (#1019) new 87b9d4a Avoid creating new executor per producer for encryption-key generation (#1018) new 1358200 Fix Incremental long crc32c (#1010) new 757c05e ENH: Add RPC client/server sample in Python (#1021) new 039932a Issue #929: Perform async DNS resolution each time attempting connect… (#930) new 663e8f4 Check message encryption when producer connect and publish (#904) new 3ed91c0 Provide an Ansible playbook for AWS with documentation (#920) new 2eb3e49 Add timeout for bundle unloading (#990) new f5d2a4d Upgrade Jackson dependency to 2.9.3 (#955) new 1fe28e7 refine broker starter command (#1023) new 3d9ae3f Acknowledgement with properties for RawReader (#1006) new 110c105 Add optional key/value metadata to producers. (#1009) new 3e0f275 BUG: Fix ProtocolBuffer output directory (#1027) new 1fd7d98 BUG: Change the search method for boost::python at CMake build (#1030) new 7e7966e Add utility to explode raw batch into individual messages (#993) new 558b0b9 Update downloads page to ensure Apache compliance (WIP) (#999) new 4d94413 Expose sequenceId in message (#1026) new 5263e64 Standardize the unit tests to use TestNG methods only (#1032) new 6bd1138 Add optional key/value metadata to consumers. (#1031) new 002a295 Bookies pods in kubernetes need to use hostPort (#1035) new efd4189 Enable usage of KQueue in MacOS (#1036) new 1fb1938 Issue 1024: Message Router should take `numPartitions` as parameter in choosing partition (#1025) new 67bbda4 Add NoSuchEntryException as not-recoverable error for cursor-recovery (#1040) new 00b5599 Revert "Enable usage of KQueue in MacOS (#1036)" (#1045) new 1458e66 RawReader allows futures to be cancelled (#1043) new d0c70b1 Fix format of Athenz auth parameters written in document (#1055) new d4572b6 fixing imports that mistakenly use jersey.packaged.* (#1057) new 8aa1f6f Populate message properties after building a message (#1054) new 36226c7 Add subscription auth mode by prefix (#899) new e0c04ad Added setting for anonymous user role (#820) new ec1995a Issue 1061: Consumers in failover subscription stops consuming after restart (#1062) new 5795569 ENH: Add C++ code auto-formatting option (#1038) new dd1f64c changes make MessageId Comparable (#1065) new df08414 Serialization and Deserialization for RawMessage (#1039) new 3212fa8 Load-balancer consider max-topic threshold on broker-ownership selection (#1005) new fdf7fa3 Various website updates (#1076) new 3295cfd Move zookeeper/bookkeeper from dependency management and only specify the dependency when they are used (#1052) new de8d09c Fix shading for Kafka wrapper lib (#1079) new a5c123e Support Url Encode in Athenz auth params (#1073) new cccc0bd Implement TopicMetadata for MessageRouter in C++ client (#1033) new 9f775b4 Re-implement DoubleByteBuf as a simple holder of a pair of buffers (#1078) new ee1b24e Force to use Django 1.11 in Pulsar Dashboard (#1083) new b5392be Enforce the validation of Pulsar configuration (#1084) new 0d20924 Fixed some of the warnings in Maven build (#1085) new 5a8103a Upgrade BK version: 4.3.1.85-yahoo with Double bytebuf fix (#1093) new 3396abc Allow topic metrics to be exported to prometheus optionally. (#1064) new be7ba46 Consolidate deployment assets into a single directory (#1098) new a7dadd5 ENH: Apply `make format` into C++ client (#1080) new a6e02bf Include BoringSSL native implementation for faster TLS (#1094) new da4bd4a Support ztsUrl parameter in athenz client plugin (#1099) new f5a2ec7 Introduce config to skip non-recoverable data-ledger (#1046) new 6bb9834 PIP-7 Introduce Failure-domain and Anti-affinity-namespace group (#896) new e1ad269 Fixed race condition between write operation and send timeout (#1108) new f57cd88 Log only first exception in the connection exception handler (#1107) new 574ebde Fix: ignore auth flag for websocket-proxy to broker authentication (#1106) new 72432ce Advertise localhost address for unit test (#1105) new ed488b2 Set loadBalancerEnabled=true in ServiceConfiguration (#1104) new 40d37b1 Fix ByteBufPair encoder to release buffers (#1110) new 1d10e69 Fix: deadlock while closing non-persistent topic (#1113) new d66e427 Increase client setting concurrentLookupRequest default to 50K (#1116) new 53bbf28 update assembly src.xml to reflect new directory structure (#1109) new 4e0812b Add api to get list of non-persistent topics (#1114) new 57e9d39 Reader interface documentation (#1096) new 4e60a98 Remove stack traces from topic lookup errors during unloads (#1121) new b3fe055 Comment in config breaks docker scripts (#1131) new a499850 Compact algo (#1044) new 8a2b2f0 Add timeouts to setup & teardown for ReplicatorTest (#1139) new 059149c Fix race condition in testRedeliveryOnBlockedDistpatcher (#1144) new 8c93ff8 Fix url option on client tool (#1146) new 650a6b8 Publish pulsar-client-admin as a shaded artifact (#1095) new 53619ff Validate expected types in Python code wrapper (#1097) new d6d4fa3 Use Optional for returning least loaded broker (#1122) new 53fa9d0 Add StatefulSet option for BookKeeper on Google Kubernetes Engine (#1047) new 0439a1f Update maven compiler plugin to newest version (#1042) new c86aeed Use Apache dist server with HTTPS to link the release signatures (#1148) new dde5865 Making Pulsar Proxy more secure (#1002) new 60a15f8 Use Optional instead of null checks when reading isolation policies (#1128) new 94bbfda Fix bundler version error (#1155) new 075992f Shade all broker dependencies (#1077) new e783a58 Configure a max producer/consumer queue size enforced across partitions (#1123) new 8d159ef Fix MessageRouter hash inconsistent on C++/Java client (#1029) new 55cb351 Explicitly set zookeeper version in broker (#1132) new 98355ca Added REST handler to create a subscription on a topic (#1151) new 99fb872 In Kafka consumer wrapper, group multiple messages when the app polls (#1115) new 1bca601 Added infinite time retention configuration option (#1135) new e82be83 remove master and slave references from C++ API docs (#1140) new 7e7d0fd Links to archived releases should be using https (#1158) new 3191db4 Pulsar proxy documentation (#1086) new 6154e3c Allow to override the auto-detected NIC speed limit (#1157) new 1569d61 Property name in documentation is incorrect (#1133) new f2073d1 Debump netty version by 1 due to ObjectCleaner bug (#1163) new 69d2b66 Fixed use of static synchronized in LoadManagerShared (#1154) new fb72f72 Remove deprecation warnings related to access of PoolArenaMetric (#1161) new 58d5727 Support Pulsar proxy from C++/Python client library (#1124) new 5257db0 Remove toString() invocation in dispatcher path (#1164) new b8fa8c1 Added missing C++ enum values (#1125) new 034b2b2 Project-wide Checkstyle Config (#1162) new 9a081ad Added end to end encryption in C++ client (#1129) new ddd4de3 Reader interface docs update (#1120) new 71f281a Add basic authentication plugin (#1087) new d482c05 Fixed increment partitions operation (#1153) new 4d220d4 Upgrade BK version: BK-4.3.1.91-yahoo (fix: stats + DoubleByteBuf) (#1170) new 3de54fd Introduce retries for flaky tests (#1166) new 6ed3a49 Some clarifications on Retention documentation (#1141) new 5310f74 Fixed managed ledger missing callback issue when unloading a topic (#1171) new 34c18c0 add dockerfile for pulsar dcos prometheus (#1127) new 1945799 Added some missing configs on websocket producer/consumer (#1173) new d0a4ff3 Update logCtx passed to MessageCrypto, removed unused variable (#1177) new 15e6655 Proxy roles enforcement (#1168) new 03ade5c Throw ProducerBusy when producer with same name is already connected (#1174) new 0ba6ae9 Use double to configure loadBalancerOverrideBrokerNicSpeedGbps (#1180) new 5067209 Avoid printing exceptio stack trace on lookup connection failures (#1179) new 13da935 Remove constexpr from C++ client (#1182) new b68cc80 Read compacted consumer flag (#1136) new d05f94d Performance producer was not using the max producer queue size argument (#1187) new d0bdab8 Upgrade to Netty-4.1.21 (#1189) new 5645229 Fix minor typo in documentation (#1191) new 28ce0ad Validate topic name on broker side (#1178) new 69db894 Fixed storage latency stats with Prometheus (#1185) new 27117f2 Fix for memory leak in Proxy roles enforcement (#1192) new a7df709 Added instructions to verify the release artifacts signatures (#1193) new 3b4d681 Fixed apache rat errors (#1194) new 153b797 Templatize resources page (#1041) new dbbb79c Fix: invalid authprovider value from config (#1196) new 8d88407 Add support for new interface to AuthenticaionTls (#1147) new 71cf49b Update website documentation verbiage (#1197) new 750e1b5 Simplify documentation for getting started (#1198) new 85cce73 Update website documentation verbiage (#1199) new b429931 Proxy forward auth data (#1169) new 11648aa Notify topic of ledger when compaction finishes (#1188) new b7e2e7c Add connection timeout for binary lookup request (#1184) new b538165 Perf producer was overriding the producer max queue size (#1202) new 3615e25 Reduce size of buffer used to assemble batches (#1204) new 552249d Ensure the checksum is not stripped after validation in the broker (#1195) new feb0acc Use duplicates when writing from ByteBuf pair to avoid multiple threads issues (#1203) new 50beaca Fixed missing '"' sign in system metrics for Prometheus (#1209) new f288db5 Cancel keep-alive timer task after the proxy switch to TCP proxy (#1210) new 8d3ab43 Add hostname-verification at client tls connection (#1208) new 16a554b Allow to configure most client/producer/consumer options in Kafka API wrapper (#1207) new 2c0616e Use SecurityUtility class (#1213) new ccbfbf8 Support custom URL scheme handlers (#1212) new a27a1e2 Support hostname verification on proxy to broker connection (#1214) new 71b3b18 Remove org.apache.pulsar.proxy.socket.client.PaddingDecimalFormat (#1217) new 3bfc505 Remove org.apache.pulsar.proxy.authentication.AuthenticationServiceTest (#1220) new 8e5b11a Remove org.apache.pulsar.proxy.socket.client.MockAuthenticationProvider (#1221) new 3fd3ab4 Remove org.apache.pulsar.discovery.service.PulsarServerException (#1222) new d38cf24 Use SecurityUtility (part 2) (#1216) new fb1c61d Add pluggable authorization mechanism (#1200) new fbfd944 Algorithm to find start point of compacted ledger (#1205) new a5a7c79 Checkstyle managed ledger (#1224) new 35e84c3 PIP-10: Removing cluster from topic name (#1150) new 7dd64d0 Regenerated the PulsarApi from proto with latest protoc (#1227) new b990674 Enable specification of TLS Protocol Versions and Cipher Suites (#1225) new 56ebe36 ProxyForwardAuthDataTest shouldn't reuse pulsar client (#1230) new e77faf4 Bumped master to 2.0.0-incubating-SNAPSHOT (#1226) new fbb42e7 Added debug logs in MessageCrypto (#1233) new 7404952 Issue 937: add CommandGetLastMessageId to make reader know the end of topic (#1066) new 4592b76 Force to pull docker build image to regenerate PulsarApi.java generate_protobuf_docker.sh (#1228) new 3c9e281 Add non-persistent topic stats separately in brokers-stat (#1235) new 5613c2b Make max clients per topic/subscription configurable (#1234) new 350d297 add httpcore dep required by httpclient in hostname-verification (#1239) new f2160c0 Introduce ActiveConsumerListener for realizing if a consumer is active in a failover subscription group (#1156) new 32f26ec Created new certs which will expire after ten years (#1244) new d5a4bb0 Add a `internalConfiguration` admin restful endpoint for query internal configuration (#1223) new cb5eb5b PIP-12 Introduce builder for creating Producer Consumer Reader (#1089) new 212d03f Fix broker conf comments (#1247) new 42b9c56 Fix redirect url on proxy to honor TLS (#1243) new 27d87d8 Fix znode path creation for proxies. (#1249) new 3d5d760 Refactor SecurityUtility class (#1245) new 8d04a42 Read from compacted topic ledger if available and enabled (#1231) new 4f1dc52 Fix lookup problem with partions in a non-persistent topics (#1251) new c03943a Add REST api to check host-status for adding/removing from vip (#1241) new de06bd4 Fix bug that consumer which specify incorrect subscription hangs up w… (#1256) new 1061906 Use advertisedAddress for bookies in pulsar standalone (#1254) new 8d9f277 Add JsonIgnore to a few fields in configuration objects (#1260) new eab0db9 Fix in ServerCnx to prevent using recycled commands (#1264) new 3dbfb68 Fixed Lookup redirect logic on Proxy side (#1265) new 6de2652 Compaction CLI tool (#1257) new d073a7c PIP-13-1/3: Provide `TopicsConsumer` to consume from several topics under same namespace (#1103) new 7b07fce Add get-peer clusters admin api (#1268) new 68cd115 Issue #1237: support builder for topicsConsumer (#1269) new f38a003 Broker should not start replicator for root partitioned-topic (#1262) new e581d95 Added ManagedLedger perf tool (#1270) new 21d3307 Upgrade to log4j2 dependency and configuration (#680) new c351026 Separating configuration for client and server trust store (#1246) new adbf818 Change HTTP status code which WebSocket proxy returns to producer whe… (#1242) new 7eb1002 allow superuser to consume without subscription_auth_mode check (#1273) new 2f1ef0b Improve retention and expiry documentation (WIP) (#1172) new a72c912 Pulsar FAQ (#1186) new 1a1a6e3 Refactored ClientConfuguration to use ClientConfigurationData shared with ClientBuilderImpl (#1276) new 5fc4d53 Renamed DestinationName into TopicName (#1280) new 6645341 Renamed destination to 'topic' in C++ code (#1281) new cd6f539 Add namespace policy for max clients (#1255) new c8d0a00 Add prefix setting for Java reader (#1272) new c308bd5 Fixed merge issues with DestinationName renaming (#1282) new 4f1f02b BatchMessageIdImpl can be compared to MessageIdImpl (#1285) new da64d0c Compaction uses GetLastMessageId (#1286) new 9656c06 Mavenize docker images (#1284) new 3739567 Fix Terraform/Ansible docs (#1290) new 8a20499 Upgrade jersey version to 2.25 and powermock to 1.7.3 (#1274) new fa4493b Add a shaded module for pulsar-client-tools (#1294) new fadb667 Update CLI documentation (WIP) (#1296) new 83972e1 Enable multipart feature in pulsar admin and make a few fields protected to allow extension (#1293) new ba58a2a PIP-13-2/3: support regex based subscription (#1279) new af44a88 Use log4j2 as slf4j binding for tests (#1295) new 08b5b85 Add prefix setting for C++/Python reader (#1283) new 98656cf Watch-znode script for docker image (#1289) new 90fb9b2 Make BackoffTest deterministic, fixes #1299 (#1301) new 3e1465a Updated ASF links on index page. (#1305) new 6bd4ccc Switched to BookKeeper-4.7.0-SNAPSHOT + Adjustements (#1292) new 6689c4d Make buildtools dependency in test scope and a few updates in PulsarClientImpl (#1304) new d179bee Replace pulsar-checksum module with circe-checksum from BK (#1306) new 518120d PIP-13-3/3: auto subscribe based on regex pattern topics changing (#1298) new 3a6b0fb Cleanup old compacted topic ledgers when a new one is available (#1302) new 9c54e73 Docker image for integration testing (#1275) new 3e76ba2 Add Type information to Pulsar client interface (#987) new 3b9f3d8 Moved the bk-tests dependency to parent pom (#1308) new d0f8a40 Precreate readonly path and increase disk usage thresholds for pulsar standalone (#1309) new 72aa7d9 Make client configuration protected in PulsarAdminTool (#1312) new 1db47ca Fix the typo in shaded client-tools module (#1313) new ccf1812 Remove deprecated newConnect methods (#1315) new 21ffe2c Schema registry (1/4) (#1232) new a64b383 Converted main part of code to use builder APIs with typed interface (#1311) new 973fa3a Introduce a pulsar log4j2 appender (#1316) new 44e0663 Utilities for arquillian integration tests (#1310) new 72092c4 Create pulsar-functions module (#1) new 9a56774 Added the first cut of the Java interface for Pulsar functions (#2) new a13d5ce Instance (#3) new 468c6e1 Only test pulsar-functions (#5) new 9e7d30c Use TypeResolver to resolve generic types (#7) new 7c871b0 Make RequestHandler a functional interface (#8) new aca6ac5 Introduce Function Config and Functions Cmd (#4) new c1b68ed Run travis ci on linux and osx (#10) new 920277b Introduce `functioncache` and `functioncontainer` (#9) new e30808c Spawner (#11) new 5e76557 Bugcix (#12) new d2b4483 Split functions module into api/runtime/api-examples (#13) new bb6409f Add examples (#14) new da4957b Fix bugs (#15) new e6978ba Integrate CLI with spawner to run functions locally (#16) new 98d208d Add the missing `pulsar-function` script new 5b0ed1b Minor stuff (#17) new 52c9c24 Refactor (#18) new 85e1882 Simplestringserde (#19) new 228e01b Fix broken license headers at pulsar-functions (#20) new 9766676 Opt (#22) new fc1f71c Cleanup (#23) new 5f3b93e Fix tests (#24) new f883f16 Buffer limit (#25) new 5adc066 Relocate packages (#21) new 117f816 System exception (#26) new f026ef8 Refactor cli (#27) new 13bbbf7 Use the thread context classloader for loading functions (#28) new 316f834 relocate SerDe classes to `serde` package and add tests (#29) new 275daf0 Make SerDe interface a generic interface and load the serde class in JavaInstance (#30) new a548bc2 Input and Output Serdes (#31) new 4dd4089 Nomenclature (#32) new 48d4aa4 Added Submit Function capability to the pulsar-functions cli (#33) new 3227065 Cleanup (#34) new da66b2d Fix compilation (#35) new 3f7d304 Make producer and consumer async new 7fbe342 Asyncack (#37) new e90b308 Nonthreadpool (#38) new 5c1e369 Provide a jmh benchmark to benchmark thread container (#39) new 4b4bea7 Reconcile (#40) new a1b1ea5 Made Update a put request (#41) new 27f4c0b Enable batching on producer (#42) new 5077d71 Completecli (#43) new 0444ac4 Introduce FunctionStats to collection function related stats (#44) new 5ea8065 Fileinterface (#45) new 5c4b286 Print (#46) new 570d59c Initial implementation of Pulsar Function Worker (#47) new 103d20d Fix license header (#48) new 8824efb Compose `FunctionState` with FunctionConfig and LimitsConfig (#49) new 84a8040 Load function worker configuration from yaml file (#50) new 0c113d7 Rewrite FunctionStateListener to use receiveAsyc (#51) new 59ec630 Rename functionstate (#52) new 793b1cf Renamed FunctionState stuff to something that reflects their functionality (#53) new d0c231e Refactor to support at-least-once processing (#54) new 7c10a31 Cleanup Cli commands (#55) new eefe67e Invoke spawner upon start/stop of worker (#56) new 58a5392 Removed ExecutionResult since its not longer needed (#57) new 507b938 fixing log functions (#58) new 4f107d3 Use LinkedBlockingQueue#put and ack before processing for at-most-once processing (#59) new 4c973c8 Added atmost once and atleast once semantics (#60) new 38a5987 Make sure it works if the function does not have a sink topic (#61) new 43a09e6 add/fixes the following: (#62) new 9902a32 Moved FunctionStats to fs since it does not belong to api (#64) new ef7657c Organize function packages in hierarchy (#65) new c74e545 Removing ServiceRequest from requestResult (#66) new d14c23a Added FunctionActioner to start/stop functions in seperate thread (#68) new 61650f3 Add unit tests for dlog classes and rest api (#67) new 5fe559d Add the missing script for running pulsar worker (#69) new 8a0cd54 Added more logging. Also changed getFunctions to return 404 when not found (#71) new 4e6adca Add `@RequiredField` annotation to enforce verification on whether a field is set or not. (#73) new 7e14c8f More graceful warning when args are missing (#72) new f1081f8 add client side class validation (#70) new 2dc4a5b Bug fix and add log messages (#75) new b662fe6 Function Logging (#74) new 992e947 Name our threads (#76) new 46d8874 Revert dlog version to stable 0.5.0 (#77) new 638e3c7 Fix spelling (#78) new 6a4592a fixing bugs and adding assignments datastructure (#79) new 8002e3b Use Reader API instead of Consumer API (#81) new 2fc20b5 Upgrade testng and downgrade log4j2 and remove junit (#80) new ee0ba86 Fix upload path issue (#83) new ab3007f Removed FunctionStats interface and added FunctionStatus class (#82) new 5dcf03a If the function is not found, send 404 (#84) new aa19226 Pulsar worker uses routing appender (#85) new d5955d8 adding initialize routine to launch existing assignments (#86) new f4130f8 Added getstatus function (#87) new 5650574 Refactor worker to make sure that FunctionActioner is just an actioner. Also consolidate all info in worker in FunctionRuntimeInfo (#88) new 1b0607a Added ability to propagate user defined configs (#89) new d82a04f Move worker module out of runtime module (#90) new 71997bb Make ThreadFactory as thin as possible (#91) new 493e54a Made use of LimitsConfig in JavaInstanceConfig (#92) new f65c4a4 Move most of the instance logic to JavaInstanceRunnable (#93) new 72a9804 Moved FunctionId/InstanceId to fs package (#94) new 9abeef2 Simplify Container interface (#95) new fe80a6c adding generated code module (#96) new d07897a updating generated code dir (#97) new ce81cb7 fixing generated dir (#98) new 426ab54 Migrating ServiceRequest to proto (#99) new 7b24f68 Removed FunctionId and InstanceId (#100) new 8316228 Refactor functions module structure (#101) new a0e4204 Rename generated module to proto module (#102) new ec46e1a LimitsConfig is always part of WorkerConfig (#103) new d02ae48 Migrating FunctionConfig, FunctionMetaData, and ServiceRequest to proto (#104) new cb74f21 Added ProcessContainerFactory (#105) new 7ea376a Removed FunctionStatus and use protobuf as the central datastructure (#106) new d400a03 Added Metric Interface (#107) new 1c4bbaf Added metrics sinks interface and added file and prometheus interface (#108) new 5bf96a7 Added ability to specify metrics sinks (#109) new 674b2a2 Misc bug fixes to get metrics to work (#110) new 45c807e Added system metrics to the list of metrics collected (#111) new 8d4ff95 Shade `pulsar-client-admin` (#112) new 4cbec31 adding log4j confs for unit tests (#114) new 882d56f Adding snapshot feature to Pulsar Functions worker (#113) new 8fcdd09 Refactor serde classes into JavaInstanceRunnable (#115) new 693ae3b Use `pulsar-client-tools-shaded` jar to avoid inconsistency between shaded jars and avoid shading jackson (#116) new 2cb75ba Fixing response and cli (#117) new ba06963 Added ability for a function to consume multiple input topics (#118) new 2e438b5 Add `join` interface to container to wait for a container (#121) new 28ff628 Use a different location for caching the classpath (#122) new 5dfbb27 Move SerDe to api (#120) new b3a8b21 Added publish interface to the api (#123) new 65f02b3 Moved JavaInstanceConfig to InstanceConfig (#125) new f2d511e Added ability to specify subscription type (#124) new 6c380c4 Added runtime descriptor in functionConfig (#126) new f50a68e adding additional worker tests (#127) new 850c1bd Moved api/examples to api-java and java-examples (#128) new 0e84121 Removed RawRequest interface (#130) new 624afe7 Renamed RequestHandler to PulsarFunction (#131) new 8f571de Added python api (#132) new b590e8b Add plumbing to accept python inside worker/container (#133) new 0863c22 adding user acking and fixing bugs (#134) new fea9805 First cut of Python Instance that just parses the arguments and start… (#135) new 6f853cd First of cut of windowing for Pulsar Functions (#136) new 0ee69b9 renaming to streamlet (#138) new 0667a47 Provide a copy task in runtime package phase to copy all python-instance required files into `target/python-instance` (#137) new d2f32e8 Feature Complete Python Instance. (#139) new a2ed4c2 Kill process upon shutdown (#140) new f1c403c Quit cleanly upon ctrl-c (#141) new bc074c8 Propagate Auto Acking information to the processes (#142) new 937b57d Support explicit acking in the context just like Java interface (#143) new 7af9d02 Moved Stats to java instance since it now only has visibility in java world only (#144) new 331e658 Event time windowing for Pulsar Functions (#145) new 5241991 Remove calculating of quantiles and keep stats simple (#146) new f77cd00 moving windowing code (#147) new 1ebc04d Overhaul stats in both Java and Python instances (#148) new caddfd7 Periodically check the liveness of the function process (#149) new 3682ed0 adding unittest for windowing (#150) new 4b24eb6 Correct spacing (#151) new 907b6e4 changing publish function to accept string for classname (#152) new 27cb857 Added scripts to generate python packages (#153) new 86c8897 correcting header files (#154) new a94e2d8 remove possible race condition (#156) new f0d9e1d Convert user config to json in process builder (#157) new 5f55daa Remove type checking since Serde is now exposed (#159) new 6e8d14e localrun uses broker admin url and remove empty module (#160) new 4a82004 Removed the usage of timer since it doesnt seem to be used (#161) new 21aec14 State - Counter support (#155) new 46fe5d2 Interrupt instance thread when stopping function container (#162) new 3f963d8 Added SimpleSerDe to ser/deser basic types (#163) new 4396db6 Make state storage service url (#164) new 989f59d Improve pulsar functions logging (#165) new 2f6167e Improve the logic for finding java instance location (#166) new efce272 Use Spawner inside Java Instance rather than using JavaInstance directly (#169) new edbae3c Allow two types of input. (#170) new 5f84eb1 Make Output Serde Optional (#171) new 3424041 Infer Missing Arguments (#172) new 0e4a4da Add more logs while starting thread container (#173) new bcecfcc More checks for checking the presence of certain fields (#174) new 06e7d74 Change the log file name to the name of the function. This greatly as… (#175) new 3b7d1f4 Return a valid response upon not being able to get status from spawner (#176) new d498fa9 Move SimpleSerDe to api (#177) new 138da83 Simplify DefaultSerde and make users be able to explicitly set it (#178) new 14b0fe4 Removed Utf8SerDe now that we have its more generic alternative DefaultSerDe (#179) new 75ce665 Python Instance should resort to default serializer if nothing is specified (#180) new 467f6e4 Use the right regexp for extracting class name (#181) new ecf223c Assume a default output topic if none is specified and create one (#182) new aa36dcb Fix python location (#168) new 10e45d6 Added more python examples and fix existing (#183) new a954d96 Since server is already module name, rename the variable (#185) new 3448c10 during startup self.producer will always be null (#186) new 180f01f Implementing distributed worker mode (#184) new dfb333f Added a mechanism to configure user config via cli as well (#187) new 79a3b78 Fixing Function get status (#188) new 555a08b Add more type checks for Java submissions (#189) new 0c7e7b5 Check for void type for output serde (#190) new ef5f986 DefaultSerDe needs to be init specially for user publish (#191) new 37a0b63 Added Java Native Functions capability (#192) new a025bfe Added support for Pure Python Functions (#193) new dd8b4a8 Raise an exception if the module is not found (#194) new dfcfe5f Avoid race condition by making methods synchronized (#195) new ac5ca04 adding check for failures subroutine and fixing worker delete bug (#196) new 922494e Correct the order of checking (#197) new 868d21d Reload class for the function/serde type checking on submitting functions (#199) new 6779f3a synchronizing some methods and add comments (#201) new 8df9d54 checking synchronization and adding comments (#202) new 631f22f Consolidate error handling to Spawner (#203) new a9c2437 Add more information about function in getstatus (#205) new 3af1d48 fixing bug in snapshot manager (#204) new 1832b52 fixing worker namespace initialize race condition (#206) new 4b730b1 GetStatus should return a set of recent exceptions (#207) new f11f192 Since we assuming that user key/value are all strings, explicitly transform result to str (#208) new 911d289 Fix variable name (#210) new c08b392 Always download because the code might have changed (#209) new 0d44440 Fix the way to import pulsarfunction root specific modules (#211) new 6fc757e Add a simpler way to publish (#212) new b64644c Accomodate native functions (#213) new 4b62d14 Don't count first start as a restart (#214) new 2dccc85 fixing bug in scheduler (#215) new 7fd924f Rename FunctionConfig names to make them more consistent (#216) new 43ec19b Added last invocation time to the function status (#217) new 21212a1 Added subscription type to function command (#218) new d21341c Add a cli command to query function state (#200) new 1bb2ccf Avoid creating pulsar admin client for local run (#219) new 0c94f29 Removed LimitsConfig (#222) new d1699b2 Removed timeout since it is no longer tracked (#223) new 4b89453 Allow workers to deploy multiple function instances (#221) new e724141 For FunctionsCommand make use of required fields (#224) new adcdf68 adding checks for parallelism (#225) new 0393713 adding instance id to get status (#226) new fe1bb68 Bump functions to 2.0.0-incubating-SNAPSHOT after rebase new e47af0c Remove zookeeper from dependency management to avoid pulling in a wrong version of zookeeper (#227) new 8f1f022 Log before quitting (#228) new f6b914d Address netty version conflicts causing getFunctionStatus to fail (#229) new f8152c8 Remove zkServers from worker config (#232) new fe6747b Get rid of the leader election trick and use ConsumerEventListener for electing a leader (#231) new 64d2b18 Fix NPE on serializing MembershipManager (#235) new e3403c5 adding worker retry if cannot connect to broker (#237) new 27ad9c7 Use metadata field for worker info (#238) new 8a99e50 Effectively once support (#230) new cb48b09 Move all the components required for running worker (except rest endpoint) to WorkerService (#239) new 587da92 Revert "Move all the components required for running worker (except rest endpoint) to WorkerService (#239)" (#241) new 6b0e087 fixing getting assignments from assignment topic (#240) new 914179c Move all the components required for running worker (except rest endpoint) to WorkerService (#242) new 7da9755 Ignore "javax.ws.*" from PowerMockito (address rebase issue) new f90c4d3 Upgrade state storage client to latest version (#245) new b1306d6 Cleanup WorkerService (#243) new fb5e34b Move function metadata setup logic out of WorkerService (#244) new 753155d Remove snapshotting (#246) new 2e296ee Bump log4j2 to 2.10.0 new d5285e2 Remove hardcoded jackson version (#247) new 86f6cdc Refactored instance related stuff into instance as well as rejiggered utils into its own module (#248) new 2d7a7f8 Refactored all metrics stuff into its own module (#249) new 0497368 Renamed all container stuff to runtime (#250) new ee77f77 Address merge conflicts new 599077a Corrected the name of the java instance main (#252) new 41c9713 Address conflicts after merged new 2412f80 Added more comments to the JavaDoc (#253) new bbc1242 revert zookeeper dependency new b7d3083 Upgrade dlog deps (#254) new 9bc41ab Increase bookkeeper disk usage threshold for pulsar standalone (#255) new ab93a18 Update threshold (#256) new 2fe4a38 Fix NPE for void functions (#258) new 7370fbc Added abiltiy to specify broker on cmdline for localrun (#259) new dc8f39c fix bug in scheduler (#260) new 9114ddc Moved localrun to process based runtime (#261) new e5ed2ed Provide a distribution package for pulsar functions (#263) new e417c57 Support parallelism parameter while running functions locally (#262) new 68e1f3c Fix pulsar-functions on locating java & python instance files (#264) new 981e472 Use `distributedlog-core-shaded` in pulsar worker (#257) new 6652c5a Move the thread construction to start to avoid illegalstate (#266) new 322f3af Fix serviceUrl for functions cli (#267) new c350e1d Improve function package download process (#268) new a68fb0d Organize the function packages in tenant/namespace/function hierarchy (#269) new 82bccd1 Resolve rebase conflicts new ae1ac31 Build classpath using `compile` scope (#272) new 2e49646 Create ProcessBuilder at during start() so that start() can be called… (#273) new 6ec05f9 If no brokerUrl is specified use localhost (#274) new 46bc558 fix scaling up and down as well as updating a function in general (#275) new 03df440 adding SchedulerManager tests (#276) new 433eb8b Better variable safety (#277) new 5245529 Effectively once not yet supported in Python (#278) new 12dac7e - Revert .travis.yml - Remove function-composition new 052814d Refactored all unit tests to use new typed API with builders for configuration (#1320) new 1270bba Introduce pulsar-seed and pulsar-snapshot-release jenkins jobs (#1323) new fb97446 Rename pulsar function api from V1 to V2 (#1325) new 585ea13 Move pulsar functions dependency version to root pom and remove duplicated license headers (#1324) new f38fce7 Upgrade the bookkeeper storage client dependency to the official bookkeeper version (#1328) new b701925 Support running function worker along with broker (#1329) new 81935b5 Added timeout to ZookeeperCacheTest tests (#1339) new 97c2b44 Improved API for producer/consumer stats (#1321) new 0dfe3fa Remove dupliated gson definition in root pom file (#1341) new 1013f04 Ignore log4j coming from bookkeeper-server:tests (#1342) new a6e65eb Use log4j2.xml in buildtools and specify the log4j configuration in surefire plugin (#1344) new 6230ab4 Integrate function cli into pulsar-admin cli (#1331) new 9503274 Fixed ZK cache test exectutor configuration. (#1343) new e9e31c7 Merge pulsar-functions dist package into pulsar binary distribution (#1332) new 557166a Added pulsar-1.22.0-incubating to site configuration (#1330) new 350037a Make default processing guarantee AT_LEAST_ONCE (#1340) new a28c2cf Arquillian topologies for integration testing (#1333) new 2c5ef2d Make it possible to get namespaces owned by broker when TLS is enabled (#1346) new da142eb Cleanup failed connection from background thread (#1345) new e82ff7e adding max retries for assignment write wait (#1348) new 9c6e124 Log phases in two phase compaction (#1335) new e0fb00b Base module for Arquillian integration tests (#1349) new 0ac6b9a Shade pulsar-functions-runtime instead of pulsar-functions-worker (#1351) new a0623d5 Pulsar Functions documentation (#1350) new a8a595d Have the ability to send log messages to a topic in Python (#1353) new dad679a CompactedTopic should seek to position of cursor, not next position (#1336) new 6b24ab9 Log Topic for Functions (#1356) new e5ac5f0 Pulsar Functions documentation follow-up (#1357) new e35087c Fix race in PersistentTopicTest#testClosingReplicationProducerTwice (#1360) new f04eb51 Schema registry (2/N) (#1319) new eb52626 Added slides for Effectively-once semantics in Apache Pulsar (#1364) new e543a77 Allow to configure BK digest type in broker configuration (#1369) new 662ac9b Relocate service files for shading `pulsar-client-admin` module (#1370) new b5068bb Allow to set BacklogQuota when RetentionSizeInMB is set to -1 (#1368) new 4cc20df Fix CID 262329 (#1258) new 9333202 Moved Python Api to a functions module inside pulsar client python module (#1375) new e5aebce Allow override of redirectTestOutput from CLI (#1366) new 55d3ff0 Update log size limit to 1GB (#1374) new 2f6de57 add byte array to default pulsar functions serde (#1372) new e7e340c Fix partitioned topic update for admin v2 api. (#1376) new 381ccc0 Renamed PulsarFunction to plain Function (#1377) new 9251a44 Issue 1118: refine HandlerBase to let only ConsumerImpl and ProducerImpl have client-cnx (#1354) new 80dc0de Schema registry 3/N (#1363) new e0c9e7a Add compactedOut flag for batched messages (#1361) new 5c31b2e remove function package on function delete (#1385) new e118a22 Fix java docs (#1389) new 323f4f1 Improve sync send logic for allowing batching (#1386) new cad2039 Prepare admin client to support v2 api. (#1384) new dc34ab6 Standardize on input/output terminology for Pulsar Functions (#1378) new 9ee682b Make close on RawMessage idempotent (#1390) new fee5667 Precommit integration test gate (#1392) new 7f587cb Fixed BK PrometheusProvider package name (#1379) new 672047c Update to newer version of datasketches (#1393) new 6fbd8c3 Functions metrics prometheus (#1373) new 833539a Improved ManagedLedgerWriter to use multiple threads and configurable digest type (#1396) new 5b01d3b Correlate Output of function with input (#1382) new cdaec9e PulsarClusterMetadataSetup exits with non-zero on bad args (#1398) new 4ac71d4 Copy only needed files for building Python Instance (#1400) new f6a8cb0 Add V2 compatibility for pulsar admin persistent topics. (#1394) new 5e541fc NPE in PersistentReplicator in Debug mode since messageId is not set during MessageImpl.deserialize (#1401) new 440284e Make admin client namepsaces work with v2 rest endpoints. (#1404) new 9e874cb Fix JavaSerDeTest package name (#1406) new bde6598 Build batching-awareness into round-robin message router (#1387) new 4cb4f11 Added trigger Function capability (#1402) new ef87567 Timeout task for batchMessageAndSendTask is not cancelled when close (#1405) new 0068568 Add a page for events (#1403) new e7261b7 Issue 1069: Provide a setting in consumer configuration to specify where to start consuming messages (#1397) new baa9c8b Allow site to be built on debian/ubuntu (#1408) new f5ffbbe Recycle OpAddEntry when ledger-ops fails (#1415) new 9bc5518 Null checks in MockedPulsarServiceBaseTest (#1420) new 6541720 Utility to rebatch a message (#1391) new fdad48b Add pulsar python location to python path so that pdoc can succeed generating docs (#1414) new 38d3b4b Performance consumer end-to-end latency can be negative when running on different machines (#1422) new d11ae4d Add v2 support to the websockets endpoints. (#1429) new 89ca249 change ruby version in Gemfile and update README (#1413) new 561d954 Clarify in docs that admin is separate module (#1407) new a4174a5 Fix Python example class name (#1421) new a5006b0 Publish the distribution to maven artifact (#1430) new 6424b6e move subscriptionInitialPosition from parameter into ConfigurationData (#1434) new 8659252 update Gemfile.lock and Docker build (#1436) new 489099b Increase timeout on ReplicatorTest#testCloseReplicatorStartProducer (#1426) new 5efafc5 Use private impl for MessageId in c++ client (#1322) new 9a62eb8 Fixed count of messages per thread in managed ledger writer (#1438) new 665672d Update user config interface for Java Pulsar Functions SDK (#1437) new 3360b14 Fixed C++ formatting (#1443) new 358bbc2 Revert "Recycle OpAddEntry when ledger-ops fails (#1415)" (#1442) new 02fede7 Added Groovy DSL definition for C++/Java PR builds (#1444) new 01a77aa Avoid allocation of one PositionImpl object in write path (#1439) new dafe123 Enforce timeout on all TestNG tests, thread dump on timeout (#1347) new b1fbd3a Extend Spark Streaming Receiver UT Coverage (#1448) new 4bf44d9 Fix: NPE on http-lookup redirection (#1451) new 86b9546 Send Log statements to log Topic for Java Functions (#1447) new 527731c Check if request is HTTPs before redirecting to TLS URL (#1454) new ea39148 Issue #1117: handle race in concurrent bundle split (#1428) new bb6daa2 Add version warning for latest vs. 2.0 (#1445) new 8ffd011 Update the bookkeeper configuration file (#1441) new f258e6e Handle null redirection url with error-message at broker (#1418) new 5bd13a0 Convert admin client properties to use v2 endpoints. (#1410) new ffd6f21 Add Configuration to set tlsClientAuth (#1297) new 8f6e33d When running standalone broker, force the proxy redirection flag (#1449) new ba855c3 Add batching support to compaction (#1427) new 16b448f Replace cached data key from the map if present already (#1417) new a141f30 Improve batch message acking by removing batch message tracker (#1424) new 29257d0 If cursor update to BK fails, fallback to meta store (#1461) new ba76b71 Fix broker stats to work with v2 namespace format. (#1464) new 7e035b0 Avoid boxing of checksum into a Long (#1467) new 56e0109 Added Throttling mechanism to Pulsar Proxy (#1453) new 7f37914 Provude v2 support for admin non persistent topics. (#1463) new cbdaab1 Add v2 support for broker stats in the admin client. (#1469) new 6d108d8 Add admin v2 support for clusters, brokers, and resources quotas. (#1471) new f4d6c2b Pulsar Proxy - Added Prometheus metrics for throttled connections and lookups. (#1472) new dd29630 Fix topic deletion for V2 topics. (#1470) new 73a214a Added multiple position delete in ManagedLedger (#1450) new a2cf918 Used defaults for Netty allocator used in entry cache (#1465) new 5f1aed2 More Pulsar Functions documentation (#1362) new 3cc89d2 Ruby version reset to address website build errors (#1477) new ce61498 use v1 admin api for anti-affinity cluster endpoint (#1473) new 7fa7202 Avoid creating failure-domain for cluster which doesn't exist (#1474) new 2eda972 Fix race condition in skipEntries that moves readPosition and markDeletePosition incorrectly (#1478) new 1933025 Streamline Ansible setup (#1291) new 0bbcea2 remove --user-install flag (#1483) new f4bb185 Fix Python docs generation script (#1484) new 9a257c2 Issue 1071: add ratelimiter for subscription (#1358) new 444d801 Multi-topic subscription documentation (#1181) new 6ef9a16 Pulsar Functions quickstart trigger example (#1479) new df3f757 Refactored PulsarAdmin to use builder for configuration (#1327) new 46411fe Pulsar Functions overview (#1481) new 19dd2c5 Delayed acks impl (#1462) new d309b2c Refactored to reflect changes in BK for OrderedExecutor (#1489) new b052669 Fixed test_producer_send_async in Python (#1491) new 1dd9c43 Delete PartitionedConsumerImpl, use TopicsConsumerImpl instead (#1365) new ffd94e0 Add MultiTopicsConsumerImpl with leaked commit from partitionedConsumer (#1495) new f6cc450 Load manager should offload multiple bundles when overloaded (#1488) new f52f4ef In Namespace.addClusters and Properties.addRoles changed dataType to Set (#1494) new ea8c477 GC improvement: Reduce string objects from Publisher and Consumer stats (#1480) new 1edf4d9 Fixed InvocationTargetException in pulsar-admin (#1492) new 88a9ba3 Disable AnnotationListener for integration tests (#1496) new ead2a2c Update pulsar-admin functions language (#1497) new 687c1fc Rest endpoint for triggering compaction (#1367) new 683ee95 add Boolean type in DefaultSerDe (#1499) new fb3511d When we try to get information for a topic, we should try to load it if exists instead of return "not found" (#1500) new acc3151 Refactor pulsar function admin api location (#1508) new 013ea05 Integration smoke test for pulsar (#1399) new 6e8b5bf Consolidate Pair implementations (#1515) new 125ca58 Pulsar Functions diagrams (#1502) new b5781a1 Enable Pulsar Functions to access entire user config map (#1498) new ec210cb Message deduplication documentation (#1271) new 9d23892 Enable FQFN specification for the Pulsar Functions CLI (#1504) new c2fb795 Also log bookkeeper (and managed ledger) in tests (#1512) new 6f36aee Rest endpoint to query compaction status (#1501) new 346f831 Compaction allows keyless messages to pass through (#1514) new cc28dd0 Readme for integration tests (#1518) new 1eb8068 Schema registry 4/N (#1381) new 3ae5115 Added test to ensure property name can contain '_' characters. (#1516) new 8ad606b Issue 1510: java.lang.IllegalArgumentException on refreshing stats (#1524) new da1a110 Use signSafeMod in RoundRobinPartitionMessageRouter (#1523) new 951d4d3 Compaction considers messages with empty payload as deleting the key (#1525) new ad90ac6 Removed contention between producers on ManagedLedger addEntry (#1521) new ed8d1a5 Avoid contention in ManagedCursorImpl generated by locking on pendingMarkDeleteOps (#1519) new 99bd812 remove unused proto declaration (#1530) new 027b424 Pulsar Connect (#1520) new dc9a9dc Fix delete topic check and provide better error message. (#1529) new ab67386 Managed ledger uses ReadHandle in read path (#1513) new 9525047 Fix for FQFN flag (#1528) new f4300bd Log warn message if exception occurs while WebSocket proxy is sending/receiving message (#1537) new b22769b Fixed flaky test in managed ledger close path (#1539) new 770ddf0 Compaction sets read compacted flag when reading (#1540) new 4f3ac36 Implement Cassandra Sink (#1534) new 884b1d1 Pulsar Functions triggering overview (#1503) new ede7ffe Fix for cursorPersistenceAsyncMarkDeleteSameThread (#1544) new 22e45e7 Refactor JavaInstanceRunnable (#1533) new e370b97 Added Aerospike Sink (#1545) new 16bfc44 LedgerOffloader interface for ManagedLedger (#1542) new 3516aa4 offloadPrefix interface for ManagedLedger (#1543) new e33795b Fix: handle invalid markDelete position at managed-cursor (#1554) new 3428d49 fixing and standardizing logging in functions (#1556) new 0fd4e84 remove unnecessary proto def in FunctionsConfig (#1531) new aff6c04 Fixed race condition intruduced managed ledger addEntry introduced in #1521 (#1548) new 3fbb4c9 renaming/changing FunctionConfig (#1552) new 1c9c074 Allow proxy to come up before any brokers have (#1559) new 199961e Use `AtomicInteger` in LoggingFunction (#1558) new 2de50a7 Issue #1517: make getLastConfirmedEntry in ManagedLedgerImpl return real LAC (#1550) new fafc963 Documentation for non-persistent topics (#1468) new 9ceedee Utility for integration tests to wait for ZK (#1561) new 1fc4b35 Honor User specified Subscription Types while running functions (#1560) new 61de30d Issue #1536: Introduce Short Topic Name (#1535) new 18ef01a Make client keepAliveInterval configurable in client side (#1547) new 9f62c3a Added RabbitMQ source to Pulsar Connect (#1563) new 616e2a2 Added Kafka Source and Kafka Sink to Pulsar Connect (#1557) new 5d2c038 Increase integration test service wait default timeouts (#1569) new ac2721f Converted to v2 topic names test related to ProducerConsumerBase (#1562) new 5c21b33 Compaction CLI integration test (#1572) new aba0d42 moving function worker service to pulsar service (#1568) new fc67fe2 Introduce admin api to get broker and namespace-isolation policy map (#1565) new 31dae05 Provide unshaded pulsar-kafka-client (#1566) new aa9e306 Fix bug that WebSocket proxy returns empty metrics (#1567) new 2267ed4 Converted and duplicated AdminApiTest to v2 topics (#1574) new 2d4a350 Fixed BatchMessageTest intermittent failures (#1577) new 4226d45 Set admin brokers content type. (#1573) new afd4382 Fix for intermittent test failure in SubscriptionMessageDispatchThrottlingTest (#1576) new 6b20516 Reduce the contention on DispatcherSingleActiveConsumer by using a common thread for frequence operations (#1522) new b37d7b7 Support short topic name in cpp client (#1564) new d8af136 Fix for C++ test BasicEndToEndTest.testStatsLatencies (#1581) new cc9a9d9 Renamed "property" into "tenant" (#1578) new bc0a4b8 Forget to recycle MessageMetadata protobuf object (#1541) new 8fbb926 Update default values for a few publisher settings (#1440) new e626e2a Let Proxy handle ZK session expires without restarting (#1583) new 44ace52 Start function worker service after broker is fully started (#1589) new 9d19a0e Handle NPE for output producer is null for function (#1590) new b421e63 Don't format bookkeeper if /ledgers exist (#1588) new 3121bec Add properties alias for tenants in pulsar-admin (#1592) new b7fe671 When new cluster is setup, public/default namespace should be extended there (#1595) new 39112f4 Fix: deadlock while closing non-shared consumer (#1591) new e548aa2 Reduce un-necessary work when doing bundle lookup for partitioned topic (#1527) new bb3c72f Compaction commands for pulsar-admin (#1596) new f5a28f4 Add rate limit for client lookup requests (#1538) new 978c933 Add metadata to compacted topic ledger on creation (#1570) new b9d4912 Removed duplicated declaration of log4j test in dependenciesManagement (#1597) new 828a8c0 fix name space (#1609) new 974cb78 Fixed intermittent test BrokerServiceThrottlingTest.testLookupThrottl… (#1598) new e2a585a cpp tests should wait for standalone up (#1611) new 732105f Use official bookkeeper release 4.7.0 (#1605) new 488942e Added option to create namespace on CLI passing list of clusters (#1579) new 1334005 On tenants cli tool, default tenant to all clusters if not specified (#1584) new e6d1551 Enhance Pulsar Connect api by attaching more information about the message (#1606) new c6f49f8 Proxy should close connections immediately after exception caught (#1602) new f8c2d25 Fix pulsar broker handling WebApplicationException (#1612) new a86e7be Fixed initial default namespace setup with current cluster setup (#1607) new dc404e0 Compression support for compaction (#1604) new f703926 Added config to deploy pulsar in aws using ebs storage (#1586) new 3bfa9d6 Document 307 redirection on admin restful api (#1619) new d116753 Topic termination should work with no consumers connected to (#1620) new 4f73c54 Introduced Upload/Download interface for uploading and downloading function code. (#1624) new b4658e2 Made upload/download generic so that it doesnt have to be function specific (#1629) new a08d248 pulsar-client-admin should not shade dependency on pulsar-common (#1626) new 7361767 Encryption semi-support for Compaction (#1623) new 584cda2 [pulsar-connect] Add pull source (#1622) new f203644 refactoring java instance to use pull model for message ingress (#1621) new 2d621ae Reverting change in ManagedCursorImpl introduced in #1519 since it causes regression (#1628) new 1011979 adding ack method to Message interface (#1627) new 093d005 Handle unchecked exceptions on cursor to ensure read callback is triggered (#1630) new 2ac2b5c Add a integration test for create subscription CLI command (#1613) new 9947f74 Fixed typo in ConsumerBuilder acknowledgmentGroupTime option (#1608) new dd601b7 Also look for the '_static' suffix when searching for libjsoncpp.a (#1635) new 1fad36b Rename Connect `Message` interface to `Record` (#1636) new 785d2a2 offloadPrefix implementation for managed ledger (#1549) new 0c9822c Proxy admin web requests (#1505) new edf01a8 Offloading prints wrong log on exception (#1643) new 6001c41 Delete offloaded ledger when ledger deleted (#1641) new fc3417f Hide namespace cli commands that are no longer relevant (#1645) new 43d2257 Fix the exception output for admin commands (#1646) new 9746ea4 Fix: remove local-cluster from replication list of global-namespace should clean topics (#1647) new 064ba5a Modified functions producer consumers to use new builder based api (#1580) new 8376726 Fix: handle failure of topic stat update (#1546) new c4a8598 Make upload/download hidden since they are really meant for uploading/downloading generic data (#1653) new eaae9ea Refactored BrokerService to use Optional in topics map (#1652) new 4cfa83a refactoring functions to use source interface (#1649) new c4ae6c5 Using Pulsar as a message queue (cookbook) (#1507) new 61cb7ca Use java.time.Clock in managed ledger (#1642) new dab6695 Enable dispatch-throttling for non backlog consumers by default. (#1654) new 7484664 Pulsar Functions CLI fixes (#1655) new 02eff26 In pulsar admin Java API, unified persistent vs non-persistent into "topics()" (#1634) new 8335d7c Fix: NPE when cursor failed to close empty subscription (#1662) new 17f0246 Removed .gitignore.swp from git (#1665) new 1fc7ac4 Include generate_protobuf.sh in src archive (#1666) new 4202d9f Updated Copyright in NOTICE to 2017-2018 (#1664) new d92f352 Use standard format when generating SHA signatures for release (#1667) new bceca1d Fix python functions (#1663) new 002f34d update preview version (#1658) new 66c8428 Read OffloadedLedger if available (#1640) new f307080 Better Runtime failure mgmt (#1671) new 18dc1c8 Fix: deadlock while closing non-persistent topic (#1660) new db89cd4 Json schema codec (#1551) new fa3be03 Return 404 if no schema found (#1659) new 330a7e8 Cleanup ThreadRuntime Exception Management (#1673) new 8dbee11 Fix var names of context that were changed (#1676) new 03ab0d7 BookKeeper ledgers cleaned up after offload (#1668) new f46d8eb Switch to using ConcurrentHashMap (#1675) new 070a9f6 Clean the local cache of downloaded packages if it already exists (#1674) new 8eb2d21 Optionally expose publisher stats in broker-stats admin rest api. (#1648) new 66fa03f Updated Python examples to work with py-2 and py-3 (#1680) new 21abb34 Provide meaningful error message in "pulsar-admin topics lookup" (#1679) new 75ac2be Support read-compacted on Reader (#1672) new 9044c2f Default schemas (#1585) new 42c2f37 Fix DefaultSchemasTest (#1682) new 1cac0ba Add missing Swagger annotations for Pulsar Functions REST API endpoints (#1661) new 31131c2 Protobuf documentation update (#1686) new 4def373 Update REST API docs (#1684) new d5780ef Add tenant and namespace getters to Python context (#1677) new 3a6e0e2 Fixed NPE and added test for Schema.STRING (#1685) new 0f2f478 Introduced TypedMessageBuilder (#1683) new f0d0907 When preparing pulsar-build Docker image, ensure apt-get update is not cached (#1689) new 240f533 Pulsar Functions for Python docs (#1482) new e9a1b9a additional refactoring to use source interface (#1681) new 1eff40e Renamed Schema.IDENTITY into Schema.BYTES (#1694) new 3c99306 Key the download directory by the instance id (#1691) new 1e0e12a Remove "global" from returned clusters list (#1695) new f5d9502 Fix Golang setup in Dockerfile (#1690) new cbdce09 Make SchemaSerializationException an unchecked exception (#1693) new fb7198a Allow functions to be triggered without specifying topic name (#1696) new 600b55d Check if javaInstance is created in the first place before invocing close (#1688) new fd576ae Use Function class loader to resolve function types (#1699) new 5721892 adding sink spec (#1700) new 2dd158e Fix Trigger functionality for non Java Functions (#1701) new 1c4b1c4 adding function worker initialized check (#1697) new c62b5c0 Issue 1014: Rename "global zookeeper" to "configuration-store"(change in code, conf and cli) (#1059) new 762036c Delete inactive subscriptions automatically (#1352) new 28eb372 Return an error if schema is incompatible (#1692) new 40f3933 Add admin api to delete topic forcefully (#1656) new e4a0a5e Allow to configure TLS hostname verification in PulsarAdmin (#1702) new 6cdc3a9 Pulsar 2.0 docs (#1553) new ab59a41 adding mock sink for future compatibility purposes with connector framework (#1703) new 48787c8 Added documentation on how to configure load manager and bundles (#1704) new b837af8 Added missing license header in terraform.tfvars (#1706) new 5f678e0 Rest API for Ledger Offloading (#1639) new 1404944 PIP-17: the part of index block for offload. (#1593) new b982943 Don't offload empty ledgers (#1687) new 4fff8d6 Add release notes page in website (#1705) new 8056df5 Fix website sidebar (#1717) new c3c8013 Refactor functions to use Sink interface (#1708) new 630e119 Version links in release notes (#1721) new e9f8d9d Fix broken image (#1720) new efc893b Bumped version to 2.1.0-incubating-SNAPSHOT (#1709) new 9348d34 Fixed authentication flow via Pulsar Proxy (#1707) new d1e719c PIP-17: provide DataBlockHeader and implementation (#1669) new ab0d081 PIP-17: provide BlockAwareSegmentInputStream implementation and test (#1678) new ea07ee1 Fixed clusters REST API to omit "global" cluster in response (#1725) new 8054d29 Exclude grpc dependencies in binary distribution (#1724) new e5f2e32 Document default values for Pulsar Functions (#1657) new 7cd7034 Changed property to tenant in various helper messages and tests (#1726) new 6a42419 Make Function port part of InstanceConfig (#1731) new bb98419 Simplify creation of functions namespace (#1735) new e3f235b Move s3 unit tests into correct package (#1728) new ee3e06d Encode zk-path for function-pkg (#1727) new afdf6fb Add `messageId` query param for WS Reader doc (#1732) new 1ab1e28 C API wrapper based on C++ client library (#1736) new c570fb1 Make BlockAwareSegmentInputStream extend InputStream (#1730) new 87440f5 Skeleton code for S3 offload (#1723) new cc77e6c Add Commons Logging bridge to broker (#1740) new 97829ef allow custom sources and sink to run on connector framework (#1733) new 8f705be fix idnex entry offset (#1738) new 2de8548 Include Jackson modules in shaded jar as well (#1729) new a2f8aa8 Move functions to use V2 style namespaces for internal data keeping (#1742) new cb648d2 Print periodic status of instances in localrun (#1734) new 17a7d91 Seperate cmd line connector interface to explicit source and sink (#1745) new f331ff7 Allow padding at end of last BlockAwareSegmentInputStream (#1739) new faa107b remove superfluous usage() call (#1744) new 7056384 Schema registry documentation (#1457) new 17f7415 Pulsar IO rename (#1747) new f1e6eb8 Fixed licenses and notice file (#1748) new 374075e Fix exception in offload index block for consistency (#1754) new f535627 Throw exception of source/sink (#1756) new 114be44 BlockAwareSegmentInputStream should only return unsigned bytes (#1741) new 8b2dfd0 Have the ability to provide source/sink config in cmdline for sources/sinks (#1757) new c7117a3 Inject AmazonS3 into S3ManagedLedgerOffloader (#1755) new e695c82 S3Offload datablock magic word should be negative (#1753) new 778fd74 Base class for S3 testing (#1759) new 40a5aa5 In C API add context pointer to callbacks (#1761) new 14e893a Encode the path for download (#1765) new e2b95f2 Allow ability to specify resources to functions (#1751) new cd97336 Windowing for Pulsar Functions (#1758) new 9fb3dcc Fixed dasboard docker pom.xml version to 2.1.0-SNAPSHOT (#1773) new 553da65 remove unnecessary log message in sink cmd (#1770) new 5d6fee3 check record returned by source is not null (#1767) new 0f84222 Implementing PushSource on top of Source (#1766) new 2c5f5dd Removed multifunction.jar from sources (#1774) new 212eb81 adding checkout for auto ack (#1775) new d6a341f refactor source and sink classname to be pulsar source and sink when not set (#1769) new 75643da setting auto ack to be true for sources and sinks (#1771) new c4edead PIP-17: impl offload() for S3ManagedLedgerOffloader (#1746) new b6f93f0 InputStream to read from S3 (#1768) new d7ab96d Move isConnected method into each interface class (#1780) new 46f3829 Fix NPE in Pulsar Functions CLI (#1776) new bcc0bde Descriptions of the changes in this PR: (#1779) new 5260ba2 Download dependencies over HTTPS instead of HTTP (#1782) new 1478d07 fixing behavior when configs are empty (#1781) new f3b47c0 Remove duplicated dependency (#1786) new b47c059 Ability to disable test retries from commandline (#1789) new f0b1471 ReadHandle implementation backed by S3 (#1790) new 86fb8a3 Fix build with boost >= 1.65 (#1783) new 0045d1b Fix sidebar link (#1785) new b1a7b55 Fixes in CMakeFiles to automate build on macos (#1787) new 971f76b Create shared library that only exports API symbols (#1794) new a6544bd PIP-17: impl deleteOffloaded() for S3ManagedLedgerOffloader (#1784) new 177e88d adding windowing CLI option comments (#1788) new 920ecba Fix C++ MurmurHash3 algorithm (#1795) new 5e4f2bb Modifying sink interface to be generic (#1792) new e22ef77 Log4j2.yaml configures loggers incorrectly (#1801) new 63a6b83 Utilities to update configuration for integration tests (#1802) new f09eb3c Remove old comment (#1803) new 1a0c8dc Added docker files and script to build static client library and Python bindings on Linux (#1793) new e6bcae5 Document Python dependencies (#1763) new 655b7c0 Ensure BookKeeperClientFactory is only instantiated once in PulsarService (#1804) new e800dfb Used shaded version of protobuf-2.4.1 internally, to coexist with components using proto3 (#1719) new d7d6ea7 Used protobuf-3.x and auto-generation for ManagedLedger and schema registry protobuf (#1812) new 481f69e Make the current reference sinks usable (#1814) new 0355b14 Fixed race condition in consumer event listener (#1818) new 7f97bde adding update functionality to sources and sinks (#1813) new 2e4362d Improve logging when we fail to bind on server ports (#1811) new 79b0e28 Store offloaded data object size in index (#1810) new fae2343 Used OrderedScheduler for ledger offload (#1808) new 069efdb Expose offload deletion lag in broker configuration (#1805) new 505677a S3ManagedLedgerOffloader should require region or endpoint (#1798) new 920b778 Build responses when returning from web service (#1823) new 4f076f2 S3 offloader doesn't allow block size < 5MB (#1809) new 81e5f9e Example Pulsar Function configs in binary distribution (#1824) new 3e04726 Support non persistent topics in C++ client (#1819) new 5ce4065 Use exact dependency version in LICENSE file and use check-binary-license to enforce (#1820) new ca9099d BlockAwareSegmentInputStreamImpl shouldn't use LedgerEntry#getLength (#1799) new e98d50a Docker testing init script has wrong service url (#1800) new 48e1131 In S3 offloader, dont use InputStream#available for stream length (#1807) new 6ea9d85 Add Pulsar Functions API docs to site build (#1830) new 26b181e Added option for custom loggers in C++ and C APIs (#1827) new 928ba3d Don't set Pulsar Memory if variable is already set (#1831) new b0b0891 Use our own minimal S3Mock rather than findify S3Mock (#1806) new c6c34f5 adding worker to instance health check (#1833) new 3e09628 Added Homebrew recipe for C++ client library (#1834) new fdb35d4 Integration test for s3offload (#1829) new 9bf943f Change docs versions (#1825) new e8c8c37 Resolve the flaky test ReplicatorTest.testCloseReplicatorStartProducer (#1815) new a2ca79d fixing problem of functions that have an array as input or output (#1837) new 3988ca3 Remove reference to consumers in client map when unsubscribing (#1836) new c4d1ed9 Check if producer is not null before closing (#1839) new 0f970e3 Removed internal shading (#1816) new 4e7748b Minor code cleanup in JavaInstanceRunnable (#1840) new a183d08 Fix flaky test with s3 backend (#1841) new e249493 Make the KakfaSource abstract by allowing users to implement method to extract value (#1842) new 333a75c If left unspecified, function tenants and namespaces should have the same behavior as topics (#1843) new 9e88b4d Update pulsar netty/grpc dependencies (#1844) new b0ad69c Fix grpc version conflicts in pulsar binary distribution (#1846) new 365475b Corrected release name 2.0.0-incubating -> 2.0.0-rc1-incubating (#1847) new 5dcd5c4 Fix message builder examples (#1848) new 1448cd6 Shade jars included in java instance uber jar (#1849) new 087c9a2 Run pulsar-functions as daemon process (#1852) new 9594553 Store data block header length in index and block header (#1854) new df6962e S3 offloader should throw an error on receiving an empty ledger (#1855) new 1a5ef1d fix sample and ns1 references (#1832) new 9b26539 Updated release notes (#1857) new 430e888 Supervisord configurations shouldn't specify stderr logfile (#1867) new f05c73b Fixes to new Java API intro docs (#1860) new 6786a2f Topic compaction documentation (#1466) new 92802e9 Ship git info in jar and print at boot (#1850) new ecec933 improving config validation (#1859) new 2710586 Fix Prometheus metrics provider package name (#1868) new 35858bf Fixed script to build all versions Python wheel files (#1856) new 886022a Pulsar Function localrun failed using http service url (#1870) new a1ffa7f fix for python config validation (#1874) new 6896f8c Disable verbose on git maven plugin (#1877) new 06f9e2d CLI for offload (#1865) new 13ad7a6 Fix REST APIs provided by Pulsar proxy (#1862) new 77d936e When offloading to S3 add version information (#1876) new 866bbec adding CmdFunctions unit tests and clean up (#1869) new 4a5bd6c Make sure that output_bytes are of type bytes (#1878) new ec535b6 If tenant/namespace are not specified, infer public/default (#1879) new fc3c1b3 [functions] Dont shade log4j2 in java runtime instance (#1881) new 995a2ac Made the logging file names uniform accross threaded and process modes (#1884) new 9d1916d Fixed event time metadata on batched messages (#1882) new 89dd66b Upgrade RocksDb to 5.13.1 (#1887) new 588ea6a Upgrade Ansible to install 2.0.0-rc1-incubating (#1873) new 075e872 Make supervisord wait a single command (#1866) new 8376a2a All user supplied arguments have to be properly typed (#1883) new ae096eb removing allowing users set subscription type (#1880) new 3412d9c Fixed the filename of the log files in threaded mode (#1890) new c01c6be S3BackedInputStream seeks within current buffer if possible (#1892) new 7565ece allow users to specify message timeout for functions (#1885) new 577e579 When fetching from kafka, specify to get the earliest of messages (#1896) new 54cc1c3 Simplify PushSource (#1898) new 6be584f improving source and sink validation (#1897) new b2b97f2 Move UUID in S3 object name to start (#1888) new 44cbed3 Encrypted or compressed payloads can be compacted out if empty (#1889) new 9089692 Pulsar Go client library (#1764) new 999ac07 Increase watch-znode.py connection timeout (#1864) new cfdf6fc Estimate the size of a managed ledger suffix from a position (#1901) new dfd4980 Add tiered storage configuration to website reference (#1900) new 7c0fd11 allowing users to specify function jar in yml file (#1899) new 34e8315 Removed link to md5 checksums in download page (#1894) new 54eb8a5 Include functions in pulsar-client Python package (#1893) new d47c3ea fix bug in setting the record sequence in Pulsar source and sink (#1905) new 794d3ad Fixed message routing mode in Py client (#1906) new 6b84809 Cpp client: add seek support in consumer for cpp client (#1863) new 8444046 Support function registration with package-url (#1902) new cf2fdce improving error messages when loading configs (#1853) new e0fbbcc Add compaction threshold policy (#1910) new 59c4a6f Use consistent naming for cluster envvar in integ test (#1909) new 439f084 Fix: GLIBC_2.14 dep issue for protoc-3.5.0-linux-x86_64 (#1914) new 61a0bb0 adding protobuf schema (#1908) new 18abc78 Link internal C++ authentication plugins inside client library (#1913) new 881e274 Added authentication support in Go client lib (#1920) new cd28ebf Monitor thread to check if topics need compaction (#1915) new 91cfd2c Upgrade Lombok to 1.18.0 to work with JDK 10 (#1923) new 5f7e367 fix func pkgUrl validation (#1925) new e30dd35 Add pulsar python client osx vagrant templates (#1919) new 57f463d Support pulsar source to start consumer with topic patterns (#1903) new e5256f1 fix pkg location init (#1927) new d77833a Make Python code work with Pulsar Function localrun (#1930) new 4b37fda Introduce kinesis sink on function (#1904) new 268c73b Only set parameters when things are not null (#1931) new 4beb677 The check should be for null (#1932) new c2e9219 Fix doc build error on broker config (#1937) new bff4f8b Cpp client: fix flaky seek test (#1936) new 1950538 Added a bunch of concrete sources/sinks so that they are usable without having to write code (#1934) new 6e336b4 Add Client auth plugin and tls support for function to connect with broker (#1935) new 7a86673 Instructions to build site on linux without root (#1939) new 51a7c02 Have the ability to specify instance id offset in localrun (#1938) new 8682776 Fix: managedledger factory shutdown stuck when any of ledger future-result is not completed (#1945) new 2bf387d Use broker advertisedAddress + tls url in function worker (#1946) new 2245c37 Rest API, AdminClient and CLI for compaction threshold (#1924) new 3e74aff OffloadIndex should have metadata len immediately before metadata (#1911) new cb4f6ad Pulsar Functions resource docs (#1760) new 3db0643 Fix reference configuration display (#1940) new 6289cbc fix: jackson conflict dependency version (#1947) new 8ab6c34 Cpp client: add readCompacted in consumer config (#1858) new 2dae33d adding avro schema (#1917) new 673db8b Documentation for threshold based compaction (#1948) new 0cd33b8 Added documentation for authn & authz plugins (#1907) new 3b1c6db Fixed Python sample code (#1951) new c715022 Simplified authentication wiht Python client lib (#1921) new 311817f adding protobuf schema check support (#1954) new e45d9e3 Workaround for ZK 3.4->3.5 upgrade (#1955) new dbfe9b7 Fix race in MultiTopicsConsumerImpl#redeliverUnacknowledgedMessages (#1952) new 830eef1 Remove potential deadlock in offloading (#1961) new 5c2b0aa Trigger offload when managed ledger reaches a size threshold (#1960) new 08ffa52 Remove duplication in CLI validation code (#1958) new 08146c2 Update pulsar cpp client docs (#1957) new 0a655c1 Fixed authorization for REST API provided by WebSocket proxy (#1959) new 468242e Typo compaction threshold rest api (#1966) new 77502c8 Allow ML offload immediately after ledger closed (#1965) new e104085 Human readable sizes when triggering offload (#1962) new 31ab19f Issue #1722: Fix copy-paste error in ConsumerBuilder javadoc (#1969) new 44349cc Capture zookeeper journal when integration tests end (#1968) new 7dac7ba Added RPM packaging for C++ pulsar client lib (#1963) new 0b26ce7 Fixed License header for ByteBufCoded{Input,Output}Stream.java (#1971) new 4625667 Added DEB packaging for C++ pulsar client lib (#1970) new 4e99ffe Add CLI commands for schema registry (#1944) new fee34d0 Fixed shading of pulsar-client and pulsar-client-admin (#1974) new f221b26 Improved instruction for getting started with C++ client lib (#1975) new b2a373d Offload threshold policy for namespaces (#1973) new 6e0afee Tiered Storage documentation (#1941) new 7134783 Addind version 1.22.1 to archived_releases (#1976) new ee061e2 Fix typo in bookkeeper.conf (#1979) new 8ba8acd Add documentation and flexible aws-credential plugin to support aws-role (#1972) new 374d2ac Improve message id comparison (#1982) new 4ed4233 Add documentation for schema CLI (#1983) new c293ae3 Enable listener to receive messages even if receiver queue size is zero (#1977) new 70412a9 Added release notes for 2.0.1-incubating release (#1985) new 37ce4fe Remove `--advertised-address` from docker getting-started section (#1984) new 8b8335c add bk dependency to fun-worker for runtime execution (#1989) new 18f44de Fixed message popover def (#1986) new a9a37c4 Fixed libgtest path in document (#1990) new 693ea90 Use builder methods in getting started docs (#1942) new 5ba840a Fixed python extension build (#1992) new 52c77d5 Add function-package-url support in function cli add url support to function cli (#1956) new bd00214 Fix: avoid closing RuntimeFactory when any function stops (#1988) new c69003d Fix spelling typos (#1998) new da48f42 Enable bookkeeper table service in pulsar standalone (#1922) new 97b56cf Functions schema integration (#1845) new 9ad5446 Upgrade to RocksDB-5.13.3 (#1999) new e7cc354 Cpp client: add getLastMessageId and hasMessageAvailable in consmer and reader (#1861) new 233c77f Issue 1967: Non-persistent topic drop too many messages (#1994) new 12864e8 Compaction documentation follow-up (#1871) new 1318c86 Add key/value operations in StateContext (#1587) new 8cc296e Enable CRC32-C by default in BK client (#2002) new edaaafc Improve pulsar-client shading (#2006) new b7e3fdd Downgrade pulsar-client CLI consume warning message (#1485) (#2012) new a545c2e add consumer.seek in python client (#2008) new ef92062 Fix: set visibility,exclude-libs options to CMAKE_CXX_FLAGS (#1997) new 94418bb Pulsar Go client docs (#1838) new 0c1cc54 Enable C++ message listener to receive messages even if receiver queue size is zero (#2010) new 8599151 Issue 1943: remove serializable from builders and add loadData to load configuration from a config map (#2004) new 8284fa1 Removed links to github from download page (#2014) new d02ea01 Add trademark for "Apache Pulsar" on website footer (#2015) new 4c5c3cf Revert "Functions schema integration (#1845)" (#2018) new 471d35b Use single instances for compression codec providers (#2017) new 7b72a97 Added Go client library links to navigation bar (#2016) new bf3ff19 Pulsar proxy configuration docs (#1895) new 7c3a324 Remove pulsar-common dependency from pulsar-io-core module and cleanup pulsar-common dependency references (#2020) new 358b68d add admin-api to update function with url (#1987) new 2028aa2 Closing client when Proxyconnection is disconnected (#1821) new a43a682 Add TLS certs to testing docker image (#2021) new db58036 Cpp client: python client wrapper for reader hasMessageAvaliable (#2011) new ed5a8ba Added REST/CLI tools to manage bookies rack placement config (#2005) new 6eb238b Remove jboss-reflect dependency (#2022) new 7a5072e Update LICENSE & NOTICE for newly introduced or version-upgraded dependencies (#2023) new 8a8bef7 Fixup misleading text in compaction cookbook (#2026) new 172f050 Added message parser to decode raw headers and payload without a Consumer instance (#2019) new f7c5696 adding pulsar io docs (#2001) new b506793 Helm charts for deployment on GKE (#1993) new 8b2929b Bump Pulsar version to 2.2.0-incubating (#2027) new 97d06c9 Fixed C99 variable initialization in cgo header (#2029) new ae90f22 Change MessageProcessor Interface to be public (#2030) new bdf52bc Added integer types casting to avoid compile errors with gcc-4.8 (#2031) new ca93d4a Added custom compiled OpenSSL into docker image for RPM/Deb (#2032) new b0292a1 adding a module that shades managed-ledge (#2034) new 174fd02 Exclude a few files from apache-rat:check (#2035) new c80dfb6 Move AuthenticationFilter to pulsar-broker-common (#2039) new 7c30702 Fix license in binary distribution (#2040) new 4487d04 Add depedency on grpcio and protobuf for Python lib (#2044) new ae596ed Inject AuthenticationService into ProxyService (#2038) new c16dfbe Original principal authorization for admin API (#2028) new 398a0bd Enable authentication and authorization for some admin APIs (#2046) new 583ddee Fixed lookups for v2 topics in C++ client lib with HTTP service URL (#2043) new f1df048 Fixed resetting of producer sequence id counter after receiving SendError before any message was successfully published (#2047) new 99c0ed2 Issue 1416: Docs about garbage collection are inaccurate/lacking (#2049) new 4d1cf20 Introduce testcontainer based cluster integration tests (#2055) new bee124e Add semantic integration tests for non-persistent topics and effectively-once producing (#2059) new f14b9e9 fix bug with specifying jar via config file (#2053) new 7cebe23 Forward user-properties to sink (#2057) new 89c7b65 Pulsar Kinesis-sink upgrade aws-sdk version (#2058) new 9b1cc78 Forward encryption properties with encrypted payload to consumer (#2024) new 60a07e9 Migrate CLI integration test mode to use testcontainers (#2060) new 124dfaf Move integration tests for function upload/download to apache (#2061) new 5766844 fix bug in concerning ContextImpl (#2052) new 4ade1bd Tests Python Wheel packaging in CI build (#2042) new b22e883 Package Pulsar IO connectors into separate tgz in form of nar archives (#2054) new d01cc75 Fix build issue in master (#2062) new 791b596 Add integration tests on pulsar functions on process mode (#2063) new 7a10d93 GCS offload support(1): rename s3offload related classes to be reuse-able (#2064) new 7559632 Improve RedeliverUnacknowledgedMessages binary protocol docs (#2066) new e16f91c Run functions runtime test with thread mode (#2070) new 5e4579d Pass encryption-context to pulsar-sink if source receive encrypted message (#2068) new 5614cc5 Integration test coverage on python functions (#2072) new 5d73bb4 Fix: destination lookup url for v2 (#2075) new 8e95ddc By default PulsarSource consume encrypted message (#2074) new e422a6f fix: configure crypto-action for internal consumer independently cryptoReader (#2073) new 9a8428a shade dependencies in pulsar client and admin (#2069) new 59fc8e2 Dump container & pulsar log before container stops (#2076) new c9d1066 Fix python/CMakeLists.txt (#2084) new ec04dc0 Move Pulsar IO as a top-category section at the sidebar (#2050) new 1893323 change JSONSchema to generate and store an avro schema (#2071) new d62cdd8 Cleanup unused function resource (#2082) new f71f4ba avoid unnecessary reflection to create pulsar source instance (#2083) new 4eee5b1 Added ReadOnlyCursor to ManagedLedger (#2041) new 2f6dc80 Fix Rackaware test (#2094) new 99892d7 Enhance Pulsar cluster with container logs (#2078) new 268161c Move Smoke Test and Cli test to semantic package (#2097) new 0420e59 Fix wget argument (#2085) new 83e3157 Issue 1455: MessageID has always batch index 0 when sending messages in a batch (#2099) new 3e9bac6 Issue 1252: Enable bookie autorecovery daemon by default (#2096) new da8981c Kinesis sink publish full json message (#2079) new 7bfc343 Remove dependencies exclusions for org.apache.httpcomponents:httpclient (#2104) new 1ebe334 Fixed path for Postgres in dashboard docker image (#2088) new 86f0a0d Remove unused test annotation (#2095) new 423a9af Add context to source and sink (#2098) new ffe7b62 Issue 2077: SubscriptionInitialPosition doesn't work with multiple-topic type subscription (#2100) new 027f535 Issue 2090: (#2092) new 5402d21 Move Security related documentation to a top-level category (#2051) new 2bf2568 Load connectors from NAR archives (#2102) new c455e5e Provide API and CLI to access list of connectors supported by system (#2106) new bc6e1e6 Disable empty methods in SequenceIdWithErrorTest (#2093) new d81cd38 Make ack timeout work in asynchronous implementation of C++ consumer (#2087) new 7047146 derive worker-host and id at runtime if not provided (#2113) new cd35677 change ID() to Payload (#2117) new b113e90 Make it possible to set idle WebSocket session timeout period (#2118) new 8b206c3 patching CmdSink and adding extensive unit tests (#2107) new a92ac3d add { in creation of ClientOptions (#2115) new 5c9d077 shading dependencies in pulsar client (#2120) new 914de19 Only exit from watch-znode if we managed to communicate with zk (#2127) new a89fe84 remove | (#2125) new db804e7 Remove popover from security overview page (#2109) new 5632d95 Fix an Argument of Wget in Pulsar Functions Getting Started (#2132) new 6391b84 patching CmdSources and adding unit tests (#2124) new 76fb8dc Fix a few links in security pages (#2134) new 133331c Extract out common code from standalone and build Embedded Pulsar (#2080) new 2147201 Submit and run locally builtin connectors (#2114) new a4e9399 Add pulsar python to gitignore (#2123) new 8631067 Temporarely disable SequenceIdWithErrorTest (#2140) new 15e4d3d fix link in binary protocol (#2131) new bf906d1 Fix a command in Pulsar Function overview Document (#2143) new cc8ec3d Issue 1433: Expose batch flushAsync() and flush() methods in Producer (#2103) new 4843154 Fixed mem leak when receiving unrecoverable fencing errors in managed ledger (#2138) new 960dc3a Fixed RPM/Deb package to include "apache" and "incubating" in name (#2129) new 387f884 Added more Java and Python examples and made the examples match across languages (#2137) new ede2108 Release resources for ZLib inflater/deflater when not used (#2111) new 2f38b89 Minor bug-fixes to examples (#2145) new 14fc5d9 Schedule task to update function stats separately (#2128) new d43bf87 add list-connector rest api at workers (#2146) new 2f47a10 Slow consumer prevents offloaded ledger cleanup (#2126) new 8736582 Add authentication to admin proxy (#2056) new e071ec1 Use container name in logs (#2139) new 2a6d195 add flatbuffer option to serialize kinesis-message in KinesisSink (#2108) new e9d67bc Function: REST and CLI to get list of workers in cluster (#2112) new 1e2b5d7 Add std=c99 to CMAKE_C_FLAGS to avoid compile error with gcc-4.8 (#2086) new 06e26b2 Fix schema initialization (#2148) new 123524d Avoid closing cursor when consumers are disconnected (#2149) new 26a70db Fix: function load correct type-class of connector (#2147) new 3b8faea Fix: file-url sink/source submission with cli (#2150) new ea6eae7 Added optional key in pulsar IO (#2116) new 10f273a Add numFunctionWorkers and externalServices to cluster spec (#2160) new e54c58a fix: conflicting jackson transitive dependency for worker (#2159) new 0ff99e7 Fix: trigger function rest-api (#2162) new ce9b125 git ignore nar extension file (#2161) new 35a121b Add a new docker image to include all pulsar io connectors (#2158) new 54dcee4 bin/bookkeeper doesn't output the result to the console (#2155) new 300f736 Documentation need to be updated for Admin command to apply deduplication at namespace: (#2157) new b2ef2e4 Add pulsar-version comment for future reference (#2163) new 555dd57 FunctionActioner should set the type class name for both source and sink (#2167) new 7af6374 fixing protobuf schema shading issue (#2168) new 5f779b4 Add function metrics with function-stats to get metrics on-demand (#2130) new ba1ea66 Add kinesis-sink user metrics to sinkContext (#2169) new da5b3cd If auth is badly configured in c++, close the connection (#2172) new 5b72eec Issue 2119: TopicPatternSubscription doesn't work through proxy (#2176) new 7b59248 Migrate compaction, s3offload to test containers (#2101) new d5536cc Removed GPL deps on gnu crypto from aerospike connector (#2173) new 918e38c Inherit I/O streams in functions process runtime (#2178) new d6fb900 Add integration test for kafka sink (#2170) new 8de127d Add integration test for kafka source (#2171) new 3dfc217 Don't dirty the tree when building in CI (#2175) new f0024d2 Issue 2121: Improve logging around "Namespace not served by this instance" (#2183) new fd7b32c Issue 1288: Provide documentation for running BookKeeper auto-recovery (#2186) new b3845b2 Moved Record interface as part of functions api (#2184) new 6ef9df9 augmenting protoschema with info for parsing (#2181) new a5c339b Allow construction of c++ builtin auth plugins via factory (#2177) new d8c0f10 V2 doc changes (#2174) new e28ef1b Add support to configure subscription name for sink-function (#2198) new ffe3849 Improved dashboard documentation with warning on advertised address (#2196) new 266834e unshade avro in pulsar-client-schema (#2197) new dc06215 attach shaded artifact while deploying to maven-repo (#2202) new 98eeaf5 function-instance lookup: retrieve function instance owner's workerId (#2201) new 6142a4c Removed the `Context.ack(byte[] messageId)` and expose `Record` instead (#2187) new 3c8d13c GCS offload support(2): replace `s3client` api with `jclouds` related api (#2065) new 7ba5c2d support subscription-type to be passed in sink-function (#2200) new 41792f1 support v2 namespace in cppclient (#2205) new 7d75fd2 Pulsar website using docusaurus (#2206) new 90908e9 Add option to retrieve schema for a topic from pulsar client (#2215) new 977cc00 Exclude helm files from Apache Rat Check. (#2209) new b82f66e Fix License Issue (#2208) new 2543ccf Cpp client: add multiTopicsConsumer (#1996) new ce6fe8b Add authorization support on function apis (#2213) new 6b2ce6b Cleanup Arquillian consolidate projects (#2180) new 725d3af set worker port to be broker service port when running worker with broker (#2218) new de05a9b GCS offload support(3): add configs to support GCS driver (#2151) new 2ad89f4 Make sure schema is initialized before the topic is loaded (#2203) new 3c2e3e2 Fixed ack message tracker cleanup for single message batches (#2224) new a186672 Fix implementation of equals() for MessageId (#2226) new d57f400 dumpContainerDirToTargetCompressed should copy files to a containerName named directory (#2189) new 04e38c7 Rename Netty native libs to reflect shading prefix (#2192) new be1eaac Pull docker images before running integration tests (#2212) new 4d631c0 fix bug in FunctionRuntimeManager involving not cleaning up old invalid assignments (#2223) new 4e217dd C++ should default not allow insecure connections with TLS (#2229) new ebb2822 More detailed documentation to config file for TLS (#2228) new 55c8dc0 Set empty response to complete grpc txn (#2225) new 9273c28 Fix TestS3Offload (#2227) new fbc12b5 Make doc image links work when there is a base path. (#2230) new 2d1b100 Add script and README for publishing `pulsar-build` image (#2222) new 596d681 [integration tests] Return exit code as part of execution result of running a command in testcontainers (#2233) new cca58fc Add search bar to new site. (#2231) new 5b543ca Fix Spelling Mistake in class (#2232) new bf56a8a Cleanup unnecessary casting and creating variables (#2199) new 355199e [website] Expand the includes `admin-api-partitioned-topics.md` (#2238) new 2415d13 Issue 2110: get-retention returns retentionSizeInMB as 0 when set to -1 (#2182) new 20c97a8 [build][docker] Add zip and unzip to pulsar-build docker image (#2239) new 1632708 [website] Fix security page links and includes (#2237) new f98e099 [website] Fix content inconsistency between site and site2 (#2235) new 56affb9 Clean up sidebar menu under `Deployment` (#2185) new 4fcbe5e Docker compose files for setting up pulsar cluster (#1134) new c1c1f90 [website] fix sidebar (#2241) new 8e62a46 [build] Add `yarn.lock` into gitignore file (#2242) new 10ec02e add stats entry for active consumer name and endpoint to get leader of functions cluster (#2234) new 5b9dc23 [website] add a terminology page and replace popovers with hyperlinks (#2243) new 46e6ea8 Fix batching time in perf producer to allow to disable batching (#2244) new 8318977 remove redundant endpoint to get workers in cluster (#2240) new 4544f6e add function-name reference with function failure log (#2246) new d8c171b [website] fix javadoc template (#2245) new fd1b459 [website] Add versions page (#2247) new e2aca36 Throw exception on non-zero command exit in integ tests (#2249) new 9d37897 [website] remove `reference-auth.md` (#2248) new 2416789 [website] Add contribution guide to README.md (#2255) new 6a4d66c Fix: function-cli avoid arg-type check and class-loading for file url (#2257) new 5f30d04 Fix pulsar:version vars in site2 docs. (#2254) new 95e54c2 Use HTTPs for downloads in new website (#2268) new d0350fc Add Test Specific Examples (#2253) new 5ebd4f5 Fix the sample code in Metrics for Pulsar Functions document (#2270) new f7adc3c Open site links in new windows (#2267) new a59f988 Derive source/sink arg-class name from function-class for file-url (#2258) new c7436fe handle subscription-already-exist exception on partitioned-topic for create-sub admin-api (#2269) new 7d8ee04 [website] Enable Translation & Localization (#2251) new b0b3cee Fixed Spelling. (#2263) new 6b77a23 [website] Render Pulsar REST API in ReDoc and Fix endpoint template (#2274) new 595ba81 Namespace level policy for offload deletion lag (#2256) new a57057a [website] fix swagger file url (#2277) new 6b70122 [website] Move `Concepts and Architecture` page into a seperate category (#2276) new 29e2cc9 Destination fix (#2194) new aa80ecd Rework TLS docs to separate concerns (#2220) new cb4e6f8 [website] update client references (#2284) new 410c361 [website] improve pulsar connector documentation (#2275) new 25e98f4 [website] fix `developing-binary-protocol` page (#2288) new b7267e6 [website] Fix website docker build (#2291) new 651d4cd [build] pin protobuf-shaded version (#2279) new a4c6b51 [website] cherry-pick "Rework TLS docs to separate concerns" to new website (#2286) new 4260025 [website] fix anchors in functions documentation pages and add `State` documentation (#2290) new d2f6dd9 kinesis-sink: manage msg ordering for publish callback failure (#2285) new c85dc46 Fix: set subscription-type based on message ordering (#2259) new 8103fd1 add System property config to run real S3 and GCS test for offloader (#2281) new 773045d [release][website] Add release notes for Release 2.1.0 (#2292) new 794b039 rename args in CmdFunctions to be consistent with existing CLI arg naming conventions in pulsar (#2273) new 87fa838 Add tls support to authenticate client to access function admin-api (#2214) new c2539e3 [release][website] Release 2.1.0 documentation (#2300) new 8d91dfb Add some metrics to prometheus. (#2299) new ba3a36e [website] Fix a few broken links (#2303) new 5c2e88c Fixed linking of boost and boost-python for osx build (#2302) new 93e192f Cpp client: add PatternMultiTopicsConsumerImpl to support regex subscribe (#2219) new 04d6234 Add Example functions (#2305) new 28fe0a1 [website] fix css problem on languages menu (#2306) new 41a973b [website] wrap strings with tags (#2310) new 0d97479 [website] update clients page with feature matrix and a list of 3rdparty clients (#2309) new df02c7b fix Test: function-tls test stops server gracefully (#2297) new 3f8944f Issue #1452: remove reachedEndOfTopic in addConsumer (#2301) new 461647a PIP-19: Initial implementation of Pulsar SQL (#2265) new 9213e58 Attempt to fix flakyness of BrokerBkEnsemblesTests.testSkipCorruptDataLedger (#2318) new 6b7a76f Fixed refcounting when processing entries from sql (#2316) new b118f7b [website] generate swagger definitions for schema API and update schema documentation (#2319) new b1b6702 [website] Translation strings are not downloaded correctly (#2322) new 14765b2 Avoid creating output topic on tenant namespace if output-topic not provided (#2261) new 6f6c5c8 Issue 2272: Fix git-commit-id-plugin (#2327) new 15441f8 [website] rename property to tenant (#2326) new 7e16f13 Enable TLS in client if serviceUrl has pulsar+ssl:// or https:// (#2315) new de66d37 [blog] Enable blog in website and add one for 2.1.0 release (#2308) new f11dfda Minor typo fixes (#2332) new 1773576 Minor typos (#2334) new c8e6fce Add python user exception function example (#2333) new 18b168e [website] update downlink used for quickstart (#2325) new 376bc8b Ignore unknown Properties from config file when parsing (#2336) new 20e652b added FRench to website (#2339) new 8cc7498 [website] fix broken links (#2337) new acc26c9 Introduce warmup period in performance producer (#2338) new d81bf6d Fix flaky test PersistentTopicE2ETest.testMessageRedelivery (#2320) new 5e1ee37 GCS offload support(4): add documentations for GCS (#2152) new 0260df0 [documentation] Issue 2252: incorrect flags for bin/pulsar (#2341) new 3b3f541 [documentation] Fix syntax error on tiered storage documentation (#2345) new 20b41de REST and CLI to get function metrics in json for monitoring (#2296) new 850b56d [documentation] Cherrypick #2341 to version 2.1 documentation (#2344) new 270132c Re-added tracking id to new website (#2349) new a850934 Fix NPE when splitting and unloading bundle (#2348) new 6601eda Remove snapshot-topic ref (#2355) new 10c3511 Add worker specific system and jvm metrics (#2352) new b6feac8 C++ HTTP lookup works with TLS (#2314) (#2350) new d248cee [Integration Tests] Improve and fix integration tests (#2356) new 2796431 [conf] add zookeeper admin server settings to the configuration files (#2331) new 8655d53 [documentation] Improve documentation on bare mental deployment (#2335) new cb16f55 Issue 1067: Problems with Partitioned Topics which name contains -partition-N (#2342) new 9be2a65 [documentation] Cherry-pick documentation on bare mental deployment to 2.1.0 (#2358) new c65b701 Fix typo (#2360) new 20caf5f [deploy][documentation] Fix terraform-ansible script and update documentation (#2357) new c0a5072 add encoding for WebTargets parts (#2359) new 777223d [docker] Publish pulsar-all image to docker hub (#2361) new 0d2154e Fix: function with multi-topic not acking on effectively-once (#2347) new cb2f4ee add function package-url into function-get api response (#2354) new 296830a [cpp] receiver queue size config acorss partitions in multi-topics-consumer (#2311) new 82771da Fixed linking of python wrapper to boost-python in MacOS build (#2366) new c9988cf Set correct exception if function runnable fails with Error (#2353) new 7bcd893 Add support to restart function (#2365) new d5c7a9b change 'cd' to 'cp -r' (#2368) new 4810a26 If --customSerdeInputs is specified, please update the right variable (#2369) new 870e459 [tiered storage] move offloader implementation to a separate module (#2371) new 1e9ec0e add more debug logs with function name reference (#2370) new 7680173 [compaction] make topic compaction works with partitioned topic (#2367) new ad5fc83 Kinesis-sink consider topic-name as partition-key if record key empty (#2372) new f352203 [documentation] Cherry-pick tiered storage documentation to new website (#2364) new c6c7def [documentation][deploy] Update deployment instructions for deploying pulsar to minikube (#2362) new 8d8b905 Include Python-3.7 compatible client lib for linux (#2378) new 7416fc0 Increased default brokerShutdownTimeout to 60 seconds (#2377) new 722dac5 Avoid double executor on non-persistent topic send operation (#2351) new 2bc4812 [documentation][deploy] Improve helm deployment script to deploy Pulsar to minikube (#2363) new b0a4018 Simplify argument passing in process runtimes (#2383) new f6cf48d [tiered storage] Pulsar standalone hangs when s3 offloader is enabled (#2374) new 1f67d9f Remove connection state assertion in NonPersistentTopicTest#testMsgDropStat(#2390) new e1238ac [tiered storage] repackage the offloader implementation from `org.apache.pulsar.broker.offload` to `org.apache.bookkeeper.mledger.offload.jcloud` (#2391) new 83d33d4 [tiered storage] Provide LedgerOffloaderFactory for creating offloaders (#2392) new a79fc74 [build] Fix LICENSE.bin.txt (#2395) new 4f43a3f [documentation] Issue 2386: release notes link of old versions broken (#2388) new 544d90a Add HostName appender function example (#2389) new 086cbbb Fixed race condition during expansion of concurrent open hash maps (#2387) new 2d197b0 Issue 2283: Improve error message if authorization is not enabled (#2382) new 30e4098 Fix some spelling typos (#2385) new 90d86c0 [build] Configure os extension plugin at root pom (#2396) new 271c6ee Fixed initialization order of acknowledgmentsGroupingTracker in ConsumerImpl (#2399) new 6f692af Make authentication parameters configurable on the pulsar-client-kafka (#2373) new 0bf3494 add slf4j handler to log web-server log (#2408) new c5c2a50 [functions][integration tests] Ensure function subscription exists before integration tests start producing messages (#2413) new 05f8560 [tiered storage] bump jclouds version to 2.1.1 (#2410) new d804701 Add admin api to support stop function (#2415) new 5980169 [tiered storage] store driver name and driver specific metadata in original ledger metadata (#2398) new 7bff81e Integrate Functions with Schema (#2397) new 3bd1ad9 remove 'to delete' (#2418) new 6ddc2ad Improve the documentation about publish function (#2422) new eb897a8 [client] add properties to consumer for cpp & python client (#2423) new def32dd [documentation] cherry-pick deploy-kubernetes documentation changes (#2419) new 834104b [client] add properties to producer for cpp & python client (#2420) new ef37890 Allow to configure number of IO and managed ledger threads (#2412) new cc60027 Fix: authorization while redirecting function admin call (#2416) new 001445c Fix bug during user publish (#2421) new 4694e6e Fix InputTopic Submission for Creating Sink (#2427) new 31edf5a Support heartbeat function for worker (#2424) new d6a0ce0 Made Twitter FireHose to emit records containing schema information (#2433) new 225eeb7 Make all cli arguments follow consistent - notation instead of camelcase (#2432) new 672a167 Race condition function-runtime-manager read old assignments (#2437) new 024d2e0 leak assign schema in MessageImpl constructor (#2439) new e9fe7e3 allow predicates concerning publish time to push down to pulsar (#2414) new 29104ef improve error message handling (#2435) new 30fee6b Standalone bookie should always advertise 'localhost' when running in docker container (#2425) new 31ebf61 Added missing committers from "team" page (#2443) new d4b214c fix issue with protocol version not being correct (#2444) new f44d367 Added cli commands to get function cluster related information (#2426) new a16b64a Add EventTime interface to Record (#2446) new 9a93789 Issue #2312: add python multi-topics consumer support (#2451) new 8688b67 Issue #2330: change getTopicName in MultiTopicsConsumer (#2346) new 73bc19d Added Reader.HasNext in Go client (#2450) new 8ba8688 Add multi-topic and regex consumer in Go client (#2448) new b234f33 Remove schema validator from annotations since it requires slightly more information (#2445) new 757222d [Schema] Provide a generic record interface for representing a typed message (#2452) new 8da0669 Fixed {{pulsar.version}} into {{pulsar:version}} in few pages (#2455) new 774cafa Fix flake in DiscoveryServiceTest (#1081) (#2406) new ecc34a9 Fixed cpp multi-topic consumer when topics are not partitioned (#2453) new b283ebd Fix: Function assignment can support large number of topics (#2438) new 83a3377 Remove Aerospike Connector (#2456) new 8a85384 Support compaction options in Go client (#2449) new 50caedc Fixed few links in contact and download pages (#2458) new 6c5f2f6 Add backlog quota retention policy to server config. (#2460) new fa11a3c Increase default maxConcurrentLookupRequests to 50k (#2380) new f36f375 Package Presto with Pulsar for SQL integration (#2428) new 6aaf613 Fix pulsar sql cli bug (#2469) new 9c1503b [tiered storage] Use NAR plugin to package offloaders (#2393) new 87fb48f Updated documentation about changed arguments for functions, sources and sinks (#2457) new 03742b7 Added the --custom-schema-inputs cli arg to allow custom schema input to functions (#2486) new ce74b11 Revert "Fix: Function assignment can support large number of topics (#2438)" (#2474) new c12e9ae Added Contributing page on website (#2459) new e71540e Clarified project roles in team page (#2470) new 5fb58d2 Fix: auto-ack flag always set true (#2496) new affbe17 Attach Producer/Consumer property tags so its easier to identify topics being produced/consumed by functions (#2490) new d1134bf Added a no args constructor (#2485) new 1263043 Fix Trigger Functinality (#2501) new 18f0741 Initial SQL documentation and DataGeneratorSource (#2479) new 581acc6 Fix semantics of skip output (#2468) new 630fc0d add sub-name option to function cli (#2492) new 79b88cf Added producer/consumer properties in Go client (#2447) new 34e9fd6 Copy ByteBufPair buffers when using with SSL (#2401) (#2464) new 143979d Fix: avoid continuous acking with invalid msgId for cumulative ack (#2498) new 42b598a [Schema] Introduce Schema.AUTO to detect schema automatically for consumers and readers (#2494) new cfdcdb5 Fixed the issue 2481 by not to take PULSAR_MEM from env. (#2484) new 95f2bf8 Fix sql cli (#2505) new 23afb69 Fix typos (#2507) new 16f3517 Include pulsar python client dependencies in pulsar image (#2491) new 4124de1 [functions] Don't set the state storage url if state is not enabled. (#2488) new 37f266b Fix log4j config to not redirect BK logs into separate file (#2482) new 8f4f371 Allow to configure bookie settings when running in standalone mode (#2480) new ad03a07 Add pulsar flink sink connector (#2434) new 03d1302 Ensure standalone service comes back quickly after ungraceful restarts (#2487) new 8763c74 Don't initialize /managed-ledgers on client creation (#2379) (#2509) new 79ac46a Issue 2313: create a JDBC sink connector (#2440) new 889b1bf Handle /managed-ledgers znode existance on cluster init (#2379) (#2510) new 8453d73 [schema] implement generic schema/record for Schema.JSON (#2497) new 6d58114 Fix Handling of user defined nar sources/sinks (#2502) new 45d1a99 Use SigKill to kill python process as opposed to sigterm which can be caught (#2514) new 10ce8ec Add CLI to get function status of a specific instance (#2518) new 2ae20e2 Log and Return error-message on function-stats failure (#2517) new ec9dfa8 Delete temp file after submitting function (#2519) new 7b2bf19 Misc Cleanups (#2512) new 7a92111 PIP-23: Pulsar Java Client Interceptors. (#2471) new 6fa95fa [documentation] Add instructions for contributing c++/python code changes (#2513) new 90a7448 better way to estimate object size for sql (#2528) new 669196c TopicPatterns are now supported by python functions (#2506) new 2ecd03a Reintroduce Aerospike connector (#2524) new 3ffcf61 [go] Ensure producer/consumer/reader keep a ref of client instance so it won't be finalized (#2527) new 6860a90 Typo in CSR generation docs (#2530) (#2531) new d734738 Downgrading ZK to stable version 3.4.13 (#2473) new 261eab1 Added HDFS Sink (#2409) new e4aea8c Fix validator logic to differentiate between serializer and deserializer (#2523) new 59df98b When WindowConfig is set, automatically default autoAck to false (#2532) new 879c730 fixed zookeeper name references in helm charts. (#2525) new 2023b48 support nested fields in Pulsar presto connector (#2515) new 9f6f5c0 set correct guice version to prevent dependency inject errors in docker container (#2534) new 6451efd Enable C++ AuthFactory to parse Athenz params string (#2540) new cd185d1 Fix status code of REST API to get partitioned topic stats (#2542) new 9ec8a5e [schema] enable Schema.AUTO if functions or connectors are using GenericRecord (#2537) new 1c72ac3 Added cmake install for lib and headers (#2529) new 3e9a445 [documentation] Add section about licensing at contribution guide (#2511) new 2812fef [docker] introduce a pulsar standalone image (#2545) new 928c3e1 Elastic connector (#2546) new fc2d1d3 Fix dashboard to work with python3. (#2552) new 69571f8 Readd MockBookKeeper to Pulsar (#2544) new 24605d3 Fix status code of REST API to get list of subscriptions of partitioned topic (#2550) new e098117 Fixed download links and resource page (#2557) new fc61056 [ecosystem] Flink pulsar source connector (#2555) new 29a8af5 Correcting doc id to be consistent with sidebar (#2558) new bf374fc Fixed website build with missing comma in replace.js (#2562) new 0ce9e1f Removed sha1 from release signing script (#2563) new 71003e2 [documentation][example] Flink Source & Sink Connector (#2561) new 5506b54 Remove property term from dashboard. (#2553) new a45ea9c [build] Fix maven deploy failure (#2565) new 7364563 [io] jdbc connector uses Schema.AUTO (#2538) new e5a7b53 Fix: get function status with auth enable (#2516) new 0964dad Another fix for website build (#2567) new 6ef7aca optimizing throughput in Pulsar Presto connector (#2564) new 95ed9b9 Stop all functions gracefully on closing worker-service (#2548) new 7c62ecf ManagedLedger only closes ledger on error if current ledger (#240) (#2573) new 95fe84c PIP-22: Dead Letter Topic (#2508) new 07d4226 [proxy][functions] Issue #2154: proxy should be able to forward rest requests to function workers cluster (#2560) new ec74355 Issue #2574: Timeout message not get redeliver in TopicsConsumer when use message listener new 858648e Misc fixes (#2579) new d5e88c1 Add ledger op timeout to avoid topics stuck on ledger-creation (#2535) new 844f46f Change repository tag for test image (#2571) new 5a2d75c [schema] add schemas for primtive types (#2500) new a123380 Preserve filename of the original function submission (#2588) new 259275b [tests] Fix the synchronization problem at BrokerClientIntegrationTest.testMaxConcurrentTopicLoading (#2595) new aebfbba [tests] make PersistentQueueE2ETest tolerant failures during deleting topic at cleanup (#2600) new 6c07c81 [tests] Flaky Test ZooKeeperCacheTest#testChildrenCacheZnodeCreatedAfterCache (#2598) new c866279 [java-client] Issue #2384: ConnectionHandler: Log stack trace instead of printing (#2599) new 8d50617 Fix: Compaction with last deleted keys not completing compaction (#2591) new fb396bf [build] Fix docker organization parameter (#2597) new 7530d64 [tests] improve connector related integration tests (#2587) new 49fc5e5 [Function] avoid creating assignment snapshot and publish individual assigment msg (#2549) new 701f3ea fix behavior of JSONSchema for derived classes (#2577) new 3097283 docs for 2.1.1-incubating release (#2601) new 8e14175 add auto ack and timeout configurable (#2503) new 4fdc21a [tests] remove PersistentQueueE2ETest#testConsumersWithDifferentPermits (#2604) new 3f8bd00 fixing/improving logging for function instance (#2586) new ee5afa5 Add ServiceUrlProvider and add method forceCloseConnection in PulsarC… (#2543) new 82aa2b8 Add support for dead letter topics for java functions (#2606) new e357253 Correcting SQL getting started title (#2594) new 99ad32b [Python] Consolidated duplicated subscribe_*() methods into a single one (#2580) new d536d66 Enforce boost-python was found by CMake (#2608) new f076974 Shorten the timeout value of C++ ZTS client (#2572) new ab5834b Fixed the null checking of retryDetails field (#2616) new 40ed8e4 Prepare website for future releases without '-incubating' suffix (#2610) new 0ab2325 Issue #2584: unacked message is not redelivered on time (#2590) new d6d5562 [tests] improve PersistentFailoverE2ETest and add more logging to RawReaderTest (#2596) new 71b5339 Renamed 2.2.0-incubating-SNAPSHOT into 2.2.0-SNAPSHOT in poms (#2625) new c1199d0 [schema] Add ByteBuf schema and fix ByteBuffer schema (#2624) new aff681d Make use of workerconfig defined health check interval (#2626) new 15f4587 [tests] Make BrokerClientIntegrationTest testing behavior deterministic (#2585) new 52ffdc4 [tests] improve BatchMessageTest#testSimpleBatchProducerConsumer (#2629) new adaae57 Debezium: add PulsarDatabaseHistory for debezium (#2614) new 200f97a Add support for running python functions with wheel file (#2593) new 634726d Fix: NPE if messageId not present on create-sub admin-api call (#2636) new 6481a4e fix NPE while setting stats (#2633) new 5b88042 Add sample docker-compose file with pulsar standalone (#2617) new 1f46e75 Fix aggregation process of topic stats (#2619) new a911890 Guard against NaN for double type metrics (#2618) new 1905133 Issue #2638: com.fasterxml.jackson.databind.JsonMappingException: Infinite recursion (#2644) new 1110584 Upgrade kinesis version to fix extract binary in memory (#2621) new 371f1db Handle RejectedExecutionException at closing ManagedLedgerClientFactory (#2646) new 6619679 Fix average size of messages included in partitioned stats (#2637) new 1eb0e67 [tests] improve DispatcherBlockConsumerTest#testBrokerSubscriptionRecovery (#2643) new 6907135 Allow non-pesistent topics to be retrieved along with persistent ones from the "GetTopicsOfNamespace" method (#2025) new 7d81b66 Update Cassandra version (#2649) new 7e8e8bc [tests] disable DeadLetterTopicTest#testDeadLetterTopicWithMultiTopic (#2650) new 6658891 [tests] ignore exceptions during shutting down test cases (#2645) new a4d1624 [tests] Issue 2639: NullPointerException at closing consumer (#2640) new 96c10dc Removed mentions to incubator-pulsar (#2620) new 93000ed Debezium: kafka connect offset store (#2627) new 828af53 Gracefully shutdown function worker service (#2635) new 12e98cd In ZK 3.4.13 the elapsed time is not anymore based on System.currentTimeMillis() (#2628) new c1ecdab clear old function failure exception from stats (#2632) new 3da0c98 Fix: web-thread stuck on function metadata update (#2634) new e809faa Fix Bug of ConsumerInterceptor on method onAcknowledge() (#2656) new cb52d51 Access function state by rest endpoint (#2653) new be5e847 [functions] change instance id from string to int and expose number of instances in context (#2411) new 3f8ad30 Fixed flaky test BatchMessageTest.testBatchAndNonBatchCumulativeAcks (#2661) new fa44e19 Fixed links in download page (#2654) new e15a606 implement topic routing on a per record basis (#2605) new 30f6935 Allow byte[] keys for messages (#1016) (#2612) new edd4bed Python Functions support topic pattern, so removing this check (#2668) new 2c2e0dd Fixed HTTP redirects with proxy handler (#2670) new 464e7d1 Simplify ServiceUrlProvider related APIs (#2671) new f4eaa58 Fixed typo in docs (#2674) new 1d7bb17 Fix sink-record to get topic name (#2675) new 357c5d1 mismatch package for AggregatedNamespaceStatsTest (#2677) new f5d8b9a Add types comment in Prometheus stats (#2679) new ff6de4a Clarify and add tests for schema change scenarios (#2669) new 671c7bc Add support for schema extraction from a jar (#2578) new 29382dc Fix ConsumerBuilder and PulsarClient document (#2681) new f8256e6 Allow user to get topic from consumer message (#2007) (#2135) new e7930f3 Change access to public for method getProducers(). (#2663) new d085806 Enable Pulsar Functions to be deployed on a kubernetes cluster (#1950) new fd76151 [tests] disabled cassandra connector test and python function test (#2683) new b2484d9 Avoid problem that topic becomes unavailable due to failure of cursor recovery (#2673) new ac9fb4c Fixed default value for batchingMaxPublishDelay in javadoc (#2690) new 054a784 [function] Fix expected health check interval (#2684) new 248e329 Process mode covers function_details in quotes. We need to remove that (#2693) new 1bdbad3 Ensumer Mocked BK client triggers the addEntry callbacks in order (#2694) new f7022df Add Presto Sql Test (#2504) new 8191fcf Admission checks (#2692) new 044ba40 Avoid scheduling heartbeat function if owner-worker not available (#2613) new 6b725fe [tests] create consumers before producing for DeadLetterTopicTest (#2648) new 8d075d2 add kafka source connect adaptor for debezium (#2705) new e31c2d8 [functions][metrics] Update function metrics (#2686) new 5e9c35c Do not register each DispatchRateLimiter for policies notifications (#2699) new af85a05 add wagon-ssh plugin to modules not inherit pulsar parent (#2696) new 3bdd6ec Fix: apache-rat validation (#2700) new 25d52eb Have the ability to specify custom labels for k8 jobs (#2702) new 1f37326 [schema] introduce AUTO_PRODUCE schema (#2685) new fe04ce8 Avoid NullPointerException in ZK server stats collection (#2710) new 5fd80a0 Improve Go/macOS C++ client installation documentation (#2711) new 606b4de Fix: Brokers redirect Schema REST requests in a loop when bundle doesn't have a leader (#2712) new 474645f adding metrics to presto pulsar connector (#2631) new 9ccaf2c Function Serverside Validation (#2701) new 12962d0 Fix invalid range error when getting number of entries (#2709) new 3c1ce54 Added missing brokerServiceURL config keys in proxy.conf (#2713) new 24749e1 Allow bk-client to support old bk-protocol (#2718) new bb945d3 Add System Property Option for Athenz (#2707) new 861f155 [tests][integration] Fix errors in integration tests (#2716) new 828e22d Removed organization affiliations from website (#2715) new 90c365c Removed shading relocations for Circe-checksum and lz4 libraries (#2191) new c7b9119 Mock out the settting up k8 client part (#2726) new 79dd772 Fixed intermittent test failures with "bind error" (#2725) new 520f9aa Fix download path in Kubernetes (#2727) new 9b74e9d [functions][stats] NPE in FunctionStatsGenerator when worker service is not ready (#2723) new af58956 local function-worker use localhost broker service url (#2722) new ab02f4f [functions][stats] don't generate function stats at worker service if runtime is k8s (#2724) new 525239b [functions][conf] Update functions_worker yml with all the possible settings (#2721) new ea503da [function][runtime] NPE at RuntimeSpawner (#2728) new da83322 Added ability a download dependencies in Kubernetes (#2729) new d26bea8 [integration tests] add a smoketest for pulsar standalone (#2732) new fc0ef90 [functions][worker] timeout creating producer for worker (#2738) new 77e2e0b The log4j should be prefixed by pulsarRootDir (#2737) new c3c7f0d Collect metrics on number of logs lines printed (#2735) new f8e7dfe Removed client-admin dependency from function-utils (#2739) new 0da4e4a [schema] provide a flag to disable/enable schema validation on broker (#2730) new b2d6a80 [functions][python] support both python 2 and 3 (#2742) new 7e3203d fix: NPE when there are assignments for workers not in membership (#2744) new dd4f71d [clients][kafka] Fix topic name & race condition on kafka wrapper (#2746) new f718128 All grpc calls should have timeouts (#2747) new 90aa408 Fix getstatus logic in kubernetes runtime (#2748) new 83da460 Avoid shading netty in managed-ledger-shaded (#2741) new b22f59c Fixed apache-rat validations (#2753) new 95f67d0 [python] MessageId.serialize() should return bytes instead of str (#2750) new 8d396c3 [c++] Fixed virtual destructors (#2754) new 6d6155e fix: function update and related tests are broken (#2755) new 362f795 change constructor access for ConsumerBuilderImpl (#2759) new 18c26e0 Do not create any producer if the output type of a function is void (#2756) new 6e9b6c2 Issue #2757: Kafka source connector should just transfer bytes (#2761) new 4ed2e33 Fix Topic Pattern functionality for Python functions (#2760) new 591df49 Fix IdentitySerde (#2762) new 6b15a6b Bumped version to 2.3.0-SNAPSHOT (#2765) new 11a6982 Fixed link and spacing for python docs (#2763) new 04bd8bd fix classname flag in python function example (#2766) new a51e6d1 Remove `install_usercode_dependencies` from java instance main (#2768) new fa589ed [website] make sure 2.1.1 documentation reflects to the features in 2.1.1 (#2769) new 60a6a7b Added script to change the project version in 1 command (#2772) new 89ccde0 Metrics Collector Agent for Functions running in Kubernetes (#2773) new ec51612 Enhance publish method to allow properties (#2777) new 412859d Fix the variable name for getting current topic name (#2776) new 592737a For externally managed functions, function worker should not do metrics management (#2775) new 9bf3357 Make Pulsar Docker have very short ttl cache time so that bookie changes etc are reacted to quickly (#2774) new f077f9d Fixed shading of Netty (#2783) new 3a66808 Added ability to specify compression while publishing (#2781) new a1a1abe add initialize routine to FunctionRuntimeManager (#2784) new b6a25f0 fix: unsafe cast of schema to JSONSchema (#2779) new c2977be Java Client - Threads to inherit daemon status from thread creating the client (#2770) new 7d2a012 Refresh ZK cache based on insertion time rather than access (#2785) new 966c054 Automatic schema update can be disabled through admin interface (#2691) new f2f5f83 Uptated example scripts (#2787) new b8423a5 CLI for setting schema update policy (#2788) new 1c4d0fa Fix: deadlock on blocking ml operation (#2745) new 9875866 Updated README to build cpp client. (#2798) new 15fbfee [docs] fix missing code quote on class name for Twitter Firehose source (#2800) new c848860 Document TLS hostname verification option (#2403) (#2794) new a7310ee Function Serverside validation Part 2 (#2752) new 052c3b0 Allow user to configure proxy as reverse HTTP proxy (#2801) new 8d69ad8 Added log statements to debug PulsarFunctionsTest.testJavaExclamationTopicPatternFunction (#2806) new 251e36e [cpp] Removed required version 5.0 for CLang format (#2790) new 3bde91d Include replication when reporting topic stats to Prometheus (#2789) new 1fe6395 Added stats for proxy operations and bytes (#2740) new 4d16522 Export Jetty stats to Prometheus (#2804) new 3d51af1 Ensure proxy and broker stats are reported to Prometheus (with 0) even when no traffic is present (#2805) new 9ae37b2 In stage-release.sh, also include offloaders package (#2803) new 1386e6d Source/Sink Endpoint validations (#2807) new f3a027b Added stop/restart functionality in sources/sinks (#2810) new b73a967 Bump jetty to v9.4.12 (#2811) new 32d1daf Removed Validation Annotations and do manual Validation (#2813) new 75d9fe2 Logs should be output to stdout when running functions in Kubernetes (#2817) new c7c7696 Specify default for cpu/ram/disk (#2820) new f0a81cb Add a simple log4j configuration for PrometheusMetricsServer (#2819) new 0e08b6a Add http output buffer configuration to proxy (#2815) new aad9a00 Moved FunctionConfig/SourceConfig/SinkConfig to a more common location (#2818) new 5b3d50d Remove annoying error message. (#2825) new 3db8b73 Allow the ability to specify which artifactory to download dep from (#2824) new c1dc39b Support admin-api for subscription-name with wildcard char (#2809) new 4a42a60 Python3 strings are not bytes (#2827) new 203c8ee Allow Python functions logging to be more configurable (#2832) new db131d2 '#2823' (#2835) new 0682f1c Site Update for Pulsar 2.2.0 Release (#2837) new 33d89aa Fix the document format in example/flink-consumer-source (#2839) new f0e9bee Adding option to use TLS in broker admin client. (#2831) new 9c43205 Update release-notes.md (#2843) new 6a79a9a Check partitioned topics in namespace when delete the namespace #2822 (#2833) new 30351ed fix python functions context publish (#2844) new 1026edc Handle builtin/functionpkgurl properly in externally managed schedulers (#2840) new a9a7f30 Set function resources properly (#2841) new 3f6612c Fixed a broken link (#2846) new 519cbe9 Add "dashboard" to list of modules so that pom version gets auto updated (#2838) new b797d7b fixing/adding sql docs to correct locations (#2849) new 5bdcdc5 Make proxy advertise protocol version of client to broker (#2845) new 000cc22 Fix: schema init for topic-name with special char (#2836) new b867907 Make IdentitySerde handle bytes as well (#2848) new 138c863 Use the right field to get the filename (#2851) new fa212bc Cleanup Logging for python functions (#2847) new 1a1cf22 adding Python function instance unit test (#2850) new d79499d Fix Websocket Consume Messages in Partitioned Topics (#2829) new 82b267b Secrets Frontend (#2853) new eb747c4 Reduce memory reserved for prometheus (#2857) new 2d208c5 Added ability for the kubernetes to poll a configmap to look out for changes (#2856) new c518247 Fix memory issue in cpp ZTSClient (#2814) new 91dc135 Fixed Typo (#2859) new 5c1b3a7 fix typo in architecture docs (#2862) new 6ef6879 Fixed mail address typo on contact page (#2861) new fc8873c Change java function instance logs to flush immediately (#2864) new d9e7c92 Update WorkerConfig.java (#2870) new dc397b0 class ActiveBroker don't attribute url, use url of class Broker (#2871) new 4c44a8c Removed metrics from getstatus (#2866) new 1aff3c4 Secretprovider interfaces and some default implementations (#2855) new 6a51109 Remove metrics from getstatus in python functions (#2873) new b990e1a Fixed ZLib decompression in C++ client (#2854) new 5fa83b8 Fixing function latency metric arithmetic error (#2868) new d13fe5b Debezium: integrate KafkaConnectSource with MySqlConnectorTask (#2791) new f7a91a1 Fixed python websocket client sample code (#2881) new aad7300 Fix helm lint error for zookeeper-metadata.yaml (#2878) new c7e2197 Upgrade commons-collections for Security Vulnerabilities[CVE-2015-7501] (#2886) new 95f4385 Upgrade jackson version to 2.9.7 (#2884) new 0a7c64b [zookeeper] remove hardcoded zookeeper session timeout (#2889) new 649c6ca Hooked up secrets function api with secret function implementations (#2875) new 2591ccd Add KeyValueSchema to satisfy org.apache.kafka.connect.connector.ConnectRecord (#2885) new e72ed35 Issue #2890: Dependencies for using Pulsar in Storm topologies (#2893) new c1baa74 Use unique test names in PartitionedProducerConsumerTest to avoid individual tests inter-dependencies (#2867) new 3789967 Updating libpulsar Homebrew recipe to 2.2.0 (#2896) new 40e6213 Remove runtime dependency from pulsar-admin (#2892) new 4def78d Move WorkerInfo to commons (#2899) new cd63c84 Changed secretsproviderconfigurator interface to pass v1podspec (#2903) new 42c2b0a Consolidate all inferMissing logic inside ConfigUtils. (#2904) new 08d8e25 Rename id to path for better understanding (#2905) new f36c43f Move all validation/inferring missing args to serverside (#2907) new 35cd182 Added ability to take python zip files that contain all their dependencies (#2915) new 4686724 Removed checked in examples jar and instead added mvn target to copy (#2913) new 4e9971d [state] Initialize bookkeeper table service metadata on initializing pulsar cluster metadata (#2706) new 355ebc5 Add state storage service url as part of internal configuration data (#2908) new 8f294c9 Remove functions-util dependency from pulsar-client-admin (#2917) new 7d1464f Make print statement python3 friendly (#2921) new 080107a Enable Presto Test (#2919) new 6b5f737 Prefer rest path over Function/Source/Sink Config values (#2918) new edf988d Always cover gson generated json with quotes (#2922) new 6583d2c Refactor function metrics to use prometheus (#2914) new 7351b24 Fix typo in consumer code (#2920) new 150f2a0 Allow configuring extra dependencies directory for functions (#2923) new 36f767f fix bugs in python instance metrics (#2925) new 6617b32 Added some basic checks for function/source/sink in cli as well (#2924) new ee22e0a Fix process runtime with extra dependencies and re-enable python integration tests (#2926) new 5de1ef7 change kafkaConnectSource to return KeyValue type record (#2902) new e5d79bf Handle broker shutdown for already deleted load-balancer znode (#2909) new 169534d fix bugs in python metrics (#2928) new 33ab2e0 Rejigger SecretsProviderConfigurator interface to make checking more generic (#2933) new 74b6af2 fix go client demo (#2931) new d1c531a Infer missing arguments before starting localrun (#2937) new bc1d94c When killing process make sure to use the force mode (#2938) new 4fb60ee Add healthcheck HTTP endpoint (#2883) new fab36a1 Fix the conversion process of windowing functions (#2940) new 76b46a5 fix go-client demo code (#2934) new be0fe35 Handle case where function produces some output but no output topic given (#2941) new da0cc00 Made Window Context up to date with Context (#2932) new e0c3430 fix api path (#2948) new 144ee74 Make sure to create client before doing admission check (#2945) new 810b95f Make sure that the returned object is string for conversion purposes (#2946) new 6fd7406 Remove guava usage in pulsar-storm (#2898) new ec170b0 Check for presence of namespace/tenant before creating function (#2947) new 988b55d Make Log a logger instead of Logger Adapter (#2944) new 43da26d Remove conflicting log4j2 policies (#2955) new 7756231 Fix zk latency metrics collector (#2916) new b708b49 Fixed race condition in schema initialization in partitioned topics (#2959) new 900e747 Expose metrics via http port in function instance (#2930) new f9dc3e4 Derive np topic worker threads based on system config (#2956) new 037c153 Add partitioned-topic stats internal admin-api (#2958) new 34ab423 Websocket dead letter topic (PIP22) (#2968) new c704aaa improve python function packaging (#2965) new 91a0488 Fix Get Function Cluster in Master Docs (#2960) new 2abb172 Don't use default values within the config. (#2971) new c1c699f Added pause and resume to Java client Consumer (#2961) new e8cce5c Ignore the current class while going over variables (#2970) new 7c19bd2 move exclamation.zip location (#2974) new 915411b fix NPE for debezium-mysql-source-config.yaml (#2975) new 9ecfb7d Fix NPE caused by the race condition (#2973) new 562cb36 reverting jackson version bump for sql (#2978) new 424034b add triggerFlush to immediately flush batch messages in producer::send (#2980) new 2e49a1a default enable cpp client producer batch (#2949) new 585c55b Introduce `Client.getPartitionsForTopic()` (#2972) new 579e0dc add go client link to document (#2991) new 2c8c288 Handle unknown runtime exception while reading entries (#2993) new aefbaac Add Flink - Pulsar Batch Sink Support (#2979) new efa040f Add connection timeout client configuration option (#2852) new 784044b moving pulsar storm tests under tests (#3000) new 23c5505 cleaning up and improving function metrics (#2994) new 2d1db63 Infer paralellism as well (#2999) new d487371 Use std::call_once instead of pthread_once (#3004) new ab8e268 Enforce timeout on all integration tests (#3011) new a22842e Fix bug for not setting resources (#3005) new c83b5ad moving pulsar-spark tests into its own module (#3002) new dafec7d Removed AspectJ runtime agent loader (#3007) new feb848c fix typo (#3010) new 5e446a6 Use AbstractCASReferenceCounted to ensure entry.retain() is valid (#2995) new d80eee6 Fix creating certificate authority doc (#3001) new 7f49b56 Remove the original zip when update netty lib name (#3008) new dadac4c Fix logic to validate admin calls from proxy (validateOriginalPrincipal) (#2986) new 76d0c71 Publish pulsar-standalone image along with other images (#3016) new 31345de Set version for exec-maven-plugin in pom (#3018) new 5fde6f3 Prevent race condition while calculating unack-msg offset stats (#3015) new b982b5d add producer flush method in cpp client (#3020) new a8023df [proxy] Use ProxyServlet instead of AsyncProxyServlet (#3022) new 4f1b53c [state][standalone] When running with more than one function instance, Function instances will crash because of table service throws INTERNAL_SERVER_ERROR (#3017) new f8594e0 Refactored C++ tests (#3003) new 3008a4b Fix-2876 Limit the client reconnect behavior (#2977) new 7efce98 Ensure broker is fully boostrapped before load manager register itself (#2935) new 1b0589b Update Function Semantics (#2985) new 8e7e335 Enable SSL of LibCurl linked to C++ library (#3024) new fae43a9 Fix C++ tests after merge (#3027) new aaf224b add debezium source documentation (#2976) new 859c914 adding windowed metrics for functions (#3021) new 4e10472 [state] use closeAsync to close state storage client (#3028) new ac97846 Add bookkeeper service and other fixes (#3026) new 0a7e133 Add default ackTimeout(30s) for dead letter policy (#3014) new a77b760 Fixed lookup of boost_python with boost-1.68 (#3041) new 26b91bb Moved broker aspectj to zk-utils (#3023) new 4253de7 Issue #2657: change function cli getstate to use REST endpoint (#2943) new 36f7ac3 Disable ZK & BK fsync calls in integration tests (#3037) new 182ac65 [Pulsar-Flink] Add Batch Csv Sink Support (#3039) new 9dddd64 Use topic unload instead of broker restarts in TestS3Offload (#3036) new 469ce55 Documentation: impove the doc 'Deploying and managing Pulsar Functions' (#3048) new 6671881 [website] Add cdc connector doc to sidebar (#3045) new 396c232 Update dockerfile-maven plugin (#3040) new b4168a7 Typo in Auth TLS docs (#3049) new c942479 Issue #2751: Add check to fix NPE (#3034) new 7bbcc72 Update libcurl version included in docker images (#3035) new 9d2c001 Expose Redelivery Count By Message Properties(issue-3030) (#3033) new 716a6b4 Fixes for Java 11 (#3006) new c2c9f33 support mysql binlog sync to pulsar by canal (#2998) new 2c8f081 [io][docs] introduce annotations for generating connector yaml config files (#2936) new 9f89977 [state] make setting and opening state table more robust (#3029) new 1b421ed Add configs for broker stats update frequency (#3047) new fe2c8ee [Pulsar-Flink] Add Batch Json Sink Support (#3046) new b721ae3 Correcting metrics and adding tests (#3050) new 0b57b3c Move maven-dependency-plugin in distribution/server/pom.xml (#3053) new ff76bd7 Documentation for TLS protocol version and ciphers (#3057) new 5438659 [Pulsar-Flink] Extends Validations (#3063) new 78e8a2a Check for nullness of SchemaInfo (#3064) new 08ef448 [doc] Generate connector yaml files for connectors (#3065) new 7719b8e Make sure to properly count number of processed messages in python (#3060) new 8d24102 prometheus metrics for functions served via brokers or function instances should match (#3066) new b413c19 [Pulsar-Flink] Add Scala Examples (#3071) new e5de682 Delete extraneous punctuation (#3072) new 35f84eb Fixed wordcount example to actually extract words from sentence (#3075) new 65592ad cache StorageClient (#3078) new 4358a98 Extra logging for offloaders (#2733) new f74b939 Disable retry on integration tests (#3081) new 2df5540 Don't overwrite integration tests longs if container restarted (#3080) new a99f733 PIP-25: Token based authentication (#2888) new aaf1996 QueryState now spits out FunctionState (#3076) new 5858df0 Issue #2582: Schema javadoc missing from client api docs (#3086) new 5c2b13e Set not just resource requests but also limits (#3043) new 019ae66 PIP-25: C++ / Python / Go implementation for token authentication (#3067) new f9ea60e PIP-25: Added token authentication docs (#3089) new a2fd124 Removed AspectJ build plugin from pulsar-broker (#3085) new 9195d07 Add pulsar-build:manylinux-cp37-cp37m to pushed docker images (#3091) new d18c07b Fixed C++ CMake dependency and enabled parallel build (#3084) new 0ddaa2f Fix process of calculating msgBacklog included in stats (#3092) new 25958ba Python Client: fix `Consumer.unsubscribe` (#3093) new e235233 Fixed protobuf-shaded/pom.xml with correct version (#3096) new 0871a28 Option to not to use rbac in helm deployment (#3082) new 3b3457e Redeliver messages that can't be decrypted. (#3097) new 015e2e5 Improve and correct status for function, sources, sinks (#3088) new 62ecf4d [website] Fix apache pulsar events calendar (#3099) new a62633b [conf] Clean up ServiceConfiguration to use lombok getter and setter (#3101) new 86abab9 [build] generate connector yaml config only when building a release (#3100) new 7ed15d0 [conf] clean up proxy configuration to use lombok setter and getter (#3103) new c7440f9 add default impl for getKey() (#3105) new d4794bd fixing and refactoring function status (#3102) new dd4e59f revert #2590 (#3110) new 8cd900c report function exceptions via prometheus (#3107) new 5d06b1e Change un-ack messages start tracking behavior (#3079) new 66a68d5 Add pull-mode on Websockets (#3058) new 02df3d2 Allow subscribers to access subscription admin-api (#2981) new 8ea5c14 [conf] Add annotations for documenting proxy configuration settings (#3106) new ded9086 Consolidate timer threads in functions (#3109) new dedeb33 JSONSchema fails to serialise fields on objects that are nested in a collection (#2969) new c60cf47 Exception Handling for Null Pointer Exception in BrokerService (#3108) new 45b6d73 Add log dir creation in ProcessRuntime (#3114) new 032df08 ignore unknown properties in worker config (#3125) new e5a9ec3 Fixed Kubernetes runtime bug (#3123) new 322f2c6 Correct instances of 'availble' found (#3124) new eab17ad Few optimizations for pulsar sql (#3128) new 499ffd7 Ensure that the input topic exists before doing trigger (#3130) new e8fac57 Fix calendar link (#3120) new d76dfe2 Cleanup Exception thrown during error (#3133) new 2c0cf59 Force to load LZ4 JNI wrapper (#3134) new 44f8386 Use BK v2 protocol from Presto connector (#3135) new 736d82d Enhanced Pulsar Message API as well as functions context to get more details about messages (#3136) new 64b1b80 Improve user prompts on get topic reference (#3111) new 65be5c2 Make Source/Sink status Source/Sink specific (#3137) new 77e5809 fix CompressionCodecLZ4 (#3141) new 32d6334 more optimizations for sql (#3139) new 3f0e541 optimizing json deserialization in sql (#3144) new b804de7 Recycle objects when parsing single message metadata (#3143) new 5b6f679 [Message Routing] Set CustomPartition implicitly when messageRouter is set (#3126) new b2ddf7e [Pulsar Broker] CleanUp and Javadocs fix (#3145) new d2ffa79 Update pulsar.properties (#3147) new 49cf5e2 fix rpmVersoin (#3149) new f2f7ba9 [Message Routing] Support default MessageRouter initialization as RoundRobinPartition (#3150) new 20fbb5d In managed ledger ReadOnlyCursor, optimize for when there's a new ledger created (#3148) new 29d4139 add_proxy_daemon_command (#3151) new a60fb3f [website][doc] Update the deployment documentation on how to deploy Pulsar to one node (#3152) new bddfa2a Use raw message when manually parsing messages from topic storage (#3146) new 8c7ff2b Introduce Source and Sink exceptions in Status (#3142) new 1260bf3 a simple debezium integration test (#3154) new b60f9f6 [bookkeeper] bump bookkeeper version to 4.7.3 (#3129) new c029b95 improve avro schema deserialization by reusing binary decoder (#3158) new 7eca99e Use jackson for serialization and deserialization of json since its faster than gson (#3163) new 0bfbfb2 make conf file sync with code (#3169) new 04df219 add eks broker proxy (#3167) new 7bda5b6 Modify producer handler of WebSocket to send ack to client asynchronously (#3172) new e10e096 Use regular ThreadLocal instead of the netty one (#3170) new 9cdb7fc Cleaning up io deps (#3176) new 4f2feb0 Sources/Sinks can be launched using fat jars as well (#3166) new 1c8305d Check if log folder exists (#3165) new c44294d cleaning up pom for pulsar-client-schema (#3175) new bd8eb97 Cleanup Pulsar IO depdencies (#3182) new 24cc4bb Add bookkeeperClientRegionawarePolicyEnabled and bookkeeperClientReor… (#3171) new e0792d6 FIX: EKS load balancer selector should be proxy (#3174) new 6df595a Fix Spellings and Code Cleanup (#3181) new eb3ac3f Enable specifying allowed offset when verifying athenz role token (#3187) new 5e41f70 Share the batch metadata object across all messages in batch (#3156) new 355b754 Always return the backlog quota for a namespace in rest response (#3164) new 018fb04 Allow the option to disable Python wrapper compilation (#3188) new 23a6622 Cleaning up and improving worker endpoints (#3191) new 5dd4b6e remove pulsar-client-schema (#3184) new a3fbd2e [Pulsar-Flink] Add Batch Sink Scala Examples Documentation (#3190) new d6e5c95 Add monitoring.yaml for EKS (#3194) new baca8f0 Upgrade caffiene dependency in pom.xml (#3192) new 60df0a9 [Pulsar-Client] Extends ProducerBuilder Validations (#3193) new 576609b [Pulsar-IO] Add Netty Tcp Source Support (#3179) new 18b2a20 Start Pulsar in TLS Only mode and deprecate tlsEnabled flag. (#2988) new 2ccf7ff Broke Pulsar-IO::HDFS into 3.x and 2.x versions (#2966) new 41e8e66 Error open RocksDB database in docker for windows (#3198) new e2408ef Use direct memory instead of Heap to determine a broker is "overloaded" in memory usage (#3199) new da07af9 Get information_schema for pulsar connector to work (#3195) new 68b5dd5 Fixes to get the travis build running again (#3204) new b6c25ed Error open RocksDB database in docker for windows (#3201) new ee53ab6 improve datagenerator source (#3203) new 5d24067 enable java enums to be queried in sql (#3202) new 1414edd Path prometheus python client due to thread leak (#3206) new 5493e2f [pulsar-flink] Implements a batch program on Pulsar topic by writing Flink DataSet as Avro (#3205) new 6bb459c [Pulsar-Client] Extends ConsumerBuilder Validations (#3200) new 83cf25c optimize java functions stats code (#3209) new 8da04cb fix up pulsar-flink and flink-consumer-source (#3212) new 00ae3cf Provide a flag to ignore Json format error in pulsar flink connector (#3210) new 85b8bea Fix hdfs module dependencies in pulsar-io/docs module (#3215) new 71d5a25 Make pulsar compile on windows (#3221) new 9c3f2a7 [conf] Add annotations for documenting broker configuration settings (#3113) new 8c3eb34 [conf] Add annotations for documenting function worker configuration settings (#3117) new 3490e64 [doc] Improve documentation of running administration dashboard for a Pulsar standalone installation (#3222) new 06d3755 Configure limited number of threads in Jetty executor (#3207) new 6c42737 optimize py function stats usage (#3229) new 867d924 Refactor api commands (#3168) new f493676 support GetLastMessageId api (#3196) new d9691b7 [issues 3232] integrate flink-json to pulsar (#3234) new d7526c8 [Pulsar-Broker-Common] Refactor AuthenticationProviderToken (#3239) new 2607c18 fix bug involving consumer producer deadlock in functions (#3237) new a901a35 add replication_delay to namespace metrics (#2983) new db26946 UnAcked message tracker based on TimePartition (#3118) new 90f6b9e Fix: NPE in pulsar source close (#3246) new 5dc90b4 [Pulsar-Broker-Common] Extend AuthenticationProviderToken UT Coverages (#3244) new f24a0b1 Fix: Empty exception message in java functions can cause an NPE (#3245) new c3a7d6a document co-run zookeeper and bookie on same machine (#3242) new a43ae4d Issue 3247: Build error on linux if userid is an huge number (#3248) new 7a1a148 [pulsar-flink] add streaming connectors as a Pulsar stream that serializes data in Avro format (#3231) new 1e4f769 Clear-out old inbound cnx stats when repl producer disconnects (#3250) new ea6f366 Fix NPE: namespaceService need leaderElection service (#3238) new 94a9423 cli support for get last message id of a topic (#3251) new 7a31352 Document new rest api - getLastMessageId (#3243) new e63b658 add backwards compatiblity to 2.2 for function admin API (#3241) new f15afec Improve service url and service url provider prompt. (#3257) new 209c448 Added Pulsar IO connector for local files (#2869) new a010166 Support multi-topic and pattern-topic for PulsarConsumerSource in pulsar (#3256) new 1fa81ca catch bad version in persistentopic, make its behavior same as namespace (#3260) new 140d375 [Pulsar-Flink] Refactor Flink Batch Sink Examples (#3262) new 742ee7e Provide separate module with Pulsar v1 client API wrapper (#3228) new f7af5c8 [Pulsar-Flink] Rename Flink examples sub-module (#3266) new ab39aeb [flink-consumer-source] fix flink streaming connector examples to be consistent with batch examples (#3265) new 469b177 Release notes and website update for 2.2.1 (#3269) new 5cc4dd8 add sink and source prometheus stats (#3261) new adc6fc0 Relay on CompletableFuture utils (#3270) new bbd736d Optimization of binlog to pulsar use canal (#3268) new 1c7a7a4 Improve documentation for message routing mode (#3263) new 99bd316 Issue #3277: left sidebar missing for 2.2.1 website new e49b8c5 change 'function' prometheus label for sources, sinks, functions (#3284) new 223c0c4 output from 'print' statements should be handled correctly in python functions (#3286) new a514ec7 remove function details from v3 function endpoints (#3271) new 7bac25e Update copyright year in NOTICE files to 2019 (#3283) new 49b5590 Fixed KEYS URL in download page. (#3282) new c0c2dda Pulsar CPP CLient - making log messages more meaningful. (#3285) new 57e1852 Default Templates for Bugs and Features (#3296) new 6b129e0 Issue #3227: Improve deployment guide on enabling tiered storage (#3281) new ffb2250 CPP Client - Turning switch case warnings into errors. (#3297) new 58c8e87 CPP Client - Error out Lookup request after operation timeout. (#3300) new ef82f04 Adding config auto.offset.reset to PulsarKafkaConsumer (#3273) new 1d22571 issue #3276 Pulsar IO connector for udp source (#3295) new 2103792 Add logic in the dashboard to handle cases where Bundle,Topic,Subscription,Consumer already exists new 8ab80bb Fix typo in Go client docs (#3306) new 4a85bb7 After #3228, removed usages of deprecated client API (#3272) new 0b9c99c Use auto resource management to avoid closing resource manually (#3311) new 9e68dda [Pulsar-Client] Add minor Schema fixes (#3313) new b79bb92 Add heartbeat interval for kafka connector (#3308) new 719eab8 Issue 3226: Unclosed consumer after calling closeAsync new e3b03fb Fixed export path (#3318) new 7b239ec Clean up and correct properties to producer and consumers created by Functions/Sinks/Sources (#3315) new 14cd667 s/paralellism/parallelism (#3323) new ccfa389 bump mac pulsar c++ client version to 2.2.1 (#3329) new ad72b7e Fix consumer stats log error. (#3327) new 6ef4733 Some settings of WebSocket proxy are not effective (#3328) new cbd770b timeout stuck producer/consumer operation request (#3240) new baec02c Java Client - Add Bouncy Castle Provider to AuthenticationTls (#3334) new 1013c75 Install python3.7 packages (#3325) new aae3755 add support get getTopicName for CPP/Python clients (#3326) new 918dc68 Separate pulsar client API interfaces in different module (#3309) new 4f9771a Test for namespace delete with TLS authorization (#3340) new fc58d71 Typo in exception message: property -> tenant (#3341) new 06c819e Bump testcontainers version to fix log dumping (#3344) new 99f05b5 add read-timeout option to async managed-ledger read (#3019) new fa45573 Export Message.Topic() in Go wrapper (#3346) new e9a5e61 Propagate specific Schema error to client (#3345) new 46f00fe Docker compose configuration with TLS (#3342) new 69ab1f5 Make scripts run on python2 and python3 (#3356) new 4b8bd04 Add BC Testing sample smoke test (#3355) new ef94cb7 Pass schema info to C++ client (#3354) new aa3fd10 Integration test and documentation for Proxy w/o ZK (#3352) new aa20363 Fix title and content mismatch issue in cookbooks-partitioned.md (#3349) (#3353) new b14aca8 Minor typo (cd instead of cp) (#3301) new 210d828 Added filtering to Twitter Firehose Connector (#3298) new 7ec205a Added HTTP Support (#3336) new 1484711 fix dep to make build compatible with jdk11 (#3357) new 617712e Support TLS authentication and authorization in standalone mode (#3360) new 272725a [client] Issue 3218: Support specifying multiple hosts in pulsar service url and web url (#3249) new 221e5c7 issues #3264 fix partitioned-stats reporting errors not match (#3339) new 13d6c62 fix type warn -> warm (#3366) new c793ad6 Add doc entry for packaging python dependencies. (#3321) new 034f6ba Cleanup consumer subscriptions and fix graceful shutdown for functions/sinks (#3299) new bf2a9c7 Add Windowfunction interface to functions api (#3324) new 63a0491 Enable stats to be recovered by Kubernetes runtime (#3363) new 49a271f Add a consumer example in deploy-bare-metal doc for a new beginner. (#3372) new 4738991 Bug fixes/Improvement for notify pending receive method (#3337) new a704afd Support Add-entry timeout at broker to avoid stuck topics (#3347) new 934d80d Fixed links to RPM/Deb package signature files (#3371) new 8e4b27d Fix bug consumer stop consume(issue-3131) (#3358) new 9e5d9de [dev] PIP 27: Add checklist in github pull request template (#3252) new 757c3f9 Issue #3373: RemotelyClosedException when running SampleProducer new d1b8f94 Java Client - Prevent printing authentication data in INFO logs. (#3377) new 484efa2 [cpp-build] support run specific cpp-test using docker build script (#3386) new 550bccb fix get topic name for input message (#3384) new f669d7d Amend several typos in Kafka Wrapper doc. (#3387) new 9be5996 [cpp-build] add argument to cpp incremental build (#3385) new d94866a Support CLI pulsar-client for concise description. (#3381) new c8b274a create_topic_with_check_namespaces_cluster (#3365) new 547883e Remove global-zookeeper in documentation (#3307) new da232c2 Add acks group time of consumer property in Kafka Wrapper doc. (#3392) new 7460e5a Issue #3375 Websocket example not working (#3393) new b9370c3 Support to set subscriptionTopicsMode via properties. (#3395) new 02cddfd [cpp-client] add support of receiveAsync API (#3389) new 55f9854 Fix race condition: broker not scheduling read for active consumer (#3411) new 358d4e7 Add a running flag for Kafka source connector (#3310) new 0ec897f Issue #3332: fix httplookup issue for get ns/topics in cpp (#3407) new 9a1bd81 Added support for ZSTD compression (#3159) new fdbdb96 Use ConsumerConfig instead of ProducerConfig in PulsarKafkaConsumer (#3394) new 9184c34 Fix: Bug in function triggering (#3406) new 14390da Cancel timeout timer in ClientCnx (#3422) new 3255957 Use topics in public/default namespaces for kafka ProducerExample and ConsumerExample (#3401) new 5657797 refactor AuthorizationProvider interface to allow custom logic for determining super user (#3383) new 6c69edf fix cp: target '/pulsar/generated-site/content' is not a directory (#3433) new 26c1f3d Use equals to check if two strings are equal (#3429) new 8eb4ae2 [pulsar-client-go]add producer.LastSequenceID and message SequenceID in Go client (#3416) new 1914b25 Fix Python packaging docs (#3437) new ca690ad CPP Client - Removing boost dependencies from interface. (#3374) new 762e0ab [Issue #3226][cpp client] Prevent dup consumers on same client cnx (#3403) new 231db03 Prevent dup consumers on same client cnx with shared subscription (#3312) new eda414d CPP Client - initialize flushedPartitions_ correctly and fix make test rerunnable (#3441) new 32e7f33 UncaughtExceptionLogsNOTWork (#3434) new 39e0f32 Update command usage for pulsar-perf cli command (#2895) (#3452) new 0446075 Add set python version script (#3427) new 2391503 Fix incomplete documentation in cookbooks-retention-expiry (#3451) new ee25415 Exposing more methods in Sink/Source Context (#3397) new 95d02d5 Removed remaining import and usages of boost::shared_ptr (#3449) new 3875220 Fix REST API document link (#3444) new 9c6b06e Replaced boost::lexical_cast with std::to_string (#3460) new e8bb6de [pulsar-client] add BooleanSchema (#3415) new b051a5c Added ZStd in Docker images used for building RPM/Deb packages (#3438) new 7e1c804 Keep function-worker web-server thread configurable (#3464) new 8b74640 [go-client] integrated `logrus`, `testify` and `go mod` for pulsar-client-go (#3443) new 252ba22 Some minor fixes in Kafka-IO and Client-Cli. (#3418) new 14d478d [go-client] support produce flush (#3469) new 0fe9e89 Fix thread safety violation on ConsumerImpl (#3467) new bdd6019 Add a component tag for every pulsar function (#3468) new 8d3534c Issue 3457: Do not set HierarchicalLedgerManagerFactory explicitly (#3473) new cc3eb7f Use randomized names for kafka container in integration tests (#3412) new a1826af use iota for go-client (#3474) new 86a9f43 Support defining and validating schema on Python client (#3391) new 1d14680 Replace boost::mutex and boost::thread with std::mutex and std::thread (#3461) new abd482d Document how to change Bookkeeper Zk root config (#3459) new 2f1aae1 [docs] Fix broken link in the dashboard's readme (#3489) new 9917784 [go-client] support consumer seek (#3478) new ebc381b Fixed watch-znode script to work in Py2 (#3470) new 7eed36d Upgrade BouncyCastle to 1.60 (#3495) new 7d9d879 When cursor recovery encounters empty cursor ledger, fallback to latest snapshot (#3487) new 9871200 Issue #3290 Pulsar IO connector for Hbase sink (#3368) new 4151413 Add Connect and Read timeout to pulsar admin (#2957) new 020a1d5 Fixed the behavior of Function start/stop (#3477) new 3791dfe allow users to set the image pull policy for kubernetes runtime (#3496) new 0781cf4 Add host name verification for C/C++ (#2475) new dd5d051 Replaced boost::bind with std::bind (#3484) new 5551f5e Functions of externally managed runtimes shouldn't need to restart when changing assignments (#3502) new d258b1f CPP Client - Adding LOG4CXX_USE_DYNAMIC_LIBS to CMake. (#3503) new 17f2aab Add support for pluggable jvm-metrics (#3428) new 2b03106 Re-enable running Python tests in CI PR validation (#3424) new 30be35a Fix document section reference (#3499) new dba2190 Use try-resource to auto close opened resource (#3492) new a98184c Add BC Testing for client (#3466) new a12b2b9 Replaced boost::array with std::array (#3507) new c070424 allow function state storage url to configurable in standalone deployment (#3508) new ee2a2aa Clean up duplicate section in doc (#3442) new a4359d2 Add document for uploading namespace API (#3445) new 93e9720 Debug log: include ledgerId for dispatched message (#3465) new eadf722 Remove the judgment of the localrun mode (#3447) (#3456) new 8fcc7ca Replaces boost::regex with std::regex (#3512) new e1ed181 Make PulsarStandalone.start() public to be called in Embedded mode (#3516) new 31243ee Update link to Presto website (#3498) new 2cca8ce [pulsar-broker] Avoid creating unnecessary dispatch-rate-limit objects (#3479) new a7f6e8b [pulsar-broker] Fix TLS : loading PKCS8Key key file for replication in pulsar-broker (#3483) new 6c8f4d1 [Issue 3431] Support Kafka-IO to pass extra configs (#3432) new ec923cc Revert "Replaces boost::regex with std::regex (#3512)" (#3534) new dd3e7df fix command name in help (#3530) new d59a6ed Use testDupConsumersOnSharedModeNotThrowsExcOnUnsubscribe to avoid interference with other tests running in parallel (#3521) new c55bd95 fix: RuntimeInfo doesn't get set when transferring ownership of function from another worker to this worker (#3523) new a5b17f5 Removed usages of boost::filesystem (#3527) new b833bce Cleaned up the code to not return Response objects (#3520) new 3a5df1a Issue 3230: auto update topic partitions extend for consumer and producer (#3513) new 1e531e0 Use synchronized when accessing consumers identity map (#3540) new 7ef26dd Upgrade AsyncHTTP client to 2.7.0 (#3509) new 3b1dd8c Build static lib with bundled dependencies (#3488) new 2bc5c5b For integration tests, copy function logs out of container on shutdown for debugging purposes (#3529) new d9e1370 fix: get list connectors return status (#3532) new c448aaa Added suppport for Kafka partitioner and explicit setting of partition on record (#3462) new 4e9505a Modify CmdProduce to avoid closing resource manually. (#3472) new 8c7fe8c fix a couple race conditions (#3547) new b424fad [bookie] enable bookie http server (#3062) new c40bb08 In functions log topic appender, don't set producer name (#3544) new 98a7d6a CPP Client - Only require linking with Boost program_options for CLI tools (#3546) new 9ce635a In Python schema, allow to declare required fields (#3526) new 1943cd0 Improved SimpleProducerConsumerTest to avoid receive timeout (#3517) new 27aa393 Fixed BrokerClientIntegrationTest.testUnsupportedBatchMessageConsumer (#3545) new a1a20a8 Added integration test for Python and Java schema compatibility (#3557) new b9fb91e [pulsar-broker] cursor: safe guard to avoid cursor-znode after cursor is closed (#3556) new 634994e Add minimum amount of resources to run setting for functions (#3536) new 9140e3f [tests] Allow configure integration test suite file using system property (#3558) new 18312da Replace JsonCPP lib with boost::property_tree (#3528) new f22bbea Create SSL context in constructor of ChannelInitializer (#3550) new f11e994 Remove two unused shaded modules (#3559) new 00c71e2 [pulsar-broker][replicator] add remote cluster name in producer name (#3553) new 1b44aaa [bookkeeper] bump bookkeeper version to 4.9.0 (#2906) new 894146a In PulsarKafkaProducer use flush() from pulsar API (#3549) new bfcc7c7 Link to protobuf-lite library in C++ client (#3563) new 21b8c9d [functions][state] Python state support (#2714) new 986ea8b Add a unit test for KafkaAbstractSink. (#3564) new f825b54 Added docs for using schema in Python client lib (#3511) new 4ec98d8 Auto-configure managed ledger cache size based on JVM available mem (#3573) new 37224b3 Add configuration to enabled BK sticky reads (#3569) new ae23906 [pulsar-broker]Fix: Topic loaded by multiple brokers (#3574) new d0a3d5f [cpp-client] add SubscriptionInitialPosition option in ConsumerConfiguration #3494 (#3567) new c000ad4 Support CLI pulsar-admin subcommands for concise description. (#3579) new 285d16e Fixed C++ client hostname verification (#3582) new 3aeafc1 Consolidated all windowing code into its own module (#3583) new 06e911d Add a Pulsar IO MongoDB (#3561) new f0fba94 Use python xml to parse pom for version instead of xmllint (#3562) new 5ca75ef [go client] add validation host name for ClientOptions (#3580) new c7987d5 Fix broken links in spark adaptor documentations (#3587) new 2ed8fea [go client] add SubscriptionInitPos option in ConsumerOptions (#3588) new 4338052 [Issue 3458: Tag Pulsar ledgers in order to distinguish from other leggers in the same Bookkeeper cluster (#3525) new 200d175 Add resource close in CmdBrokerStats and some minor fixes. (#3589) new 14a5962 [pulsar-broker] provide option to disable redelivery-tracker to reduce in memory positionImpl footprint and gc improvement (#3584) new 48e4a0b If no clusters are specified, the namespace should by default use current cluster (#3571) new c79fd72 Improved Javadocs on Java client API (#3592) new cecf8e7 Fixed race condition in C++ test testTlsDetectPulsarSslWithHostNameValidation (#3593) new 01f0d35 Fixed getting message properties map in Python client (#3595) new e395efc Fixed deadlock by triggering asyncCreateFullPathOptimistic() callback in different thread (#3591) new 6fba72c Add several missing subcommands in Pulsar Admin CLI md. (#3596) new 0a6fa4b Distribute Pulsar IO connectors individually (#3601) new cf44525 Fixed CMake lookup of boost Python for Py 3.4, 3.5 and 3.6 (#3599) new 3ea2c77 Fixed RAT check to exclude Avro generated files (#3598) new 53ba1a4 Bumped version to 2.4.0-SNAPSHOT (#3604) new 8a714ad fix: add retry and wait for kubernetes creation/deletion (#3603) new e183aba CPP Client - changing min cmake to 3.4 and adding flag for ccache (#3610) new 924f495 Adding configuration to disable auto-topic creation (#3450) new f25939f adding memory padding to memory limits set in Kubernetes (#3616) new a378ac2 fix bug in kubenetes runtime (#3617) new bca09b0 Added ability to specify consumer queue size for function input topics (#3608) new 384fca3 Define the maven phase for generating protobuf code (#3609) new a0f7661 Refresh Certs every X minutes (#3568) new 57daf4e Fixed C++ batch acks tracker to evict message from sendList array (#3618) new 84c68c3 [Issue 3590] [broker] Support to get broker server runtime configuration (#3606) new 2e1e1ab Use default queue size in function producer (#3619) new 8bd06d2 Minor improvement of CmdNamespaces and add the missing subcommands in Pulsar Admin CLI md (#3620) new 26c4626 Refactored handling of zero-queue consumer into separate subclass (#3615) new 5db6bce Link wwrapper with pytho libs on MacOS (#3626) new ce2d21c0 Remove duplicated `pushd` in stage-release.sh (#3607) new 2fd283e set functions config to me uniform (#3629) new d1fefad Support graceful shutdown Kubernetes (#3628) new 4de22cd Pulsar Startup Script fixes to provide custom conf files for bookie shell and configuration store. (#3627) new 2d3d81a Clarify apt install instructions (#3632) new 1205357 Website for 2.3.0 (#3634) new c31ccd1 Fix stackoverflow issue with java function window context. (#3621) new 6e54f89 Fixed the building of javadoc/doxygen/pydoc on site2 build (#3639) new 5e4283e Added link to get individual connectors on download page (#3635) new 1f3d90e Fixed typo on the site build command line args The 2916 revisions listed above as "new" are entirely new to this repository and will be described in separate emails. The revisions listed as "add" were already present in the repository and have only been added to this reference.