[GitHub] [pulsar] tuteng commented on issue #5716: [Issues 5709]remove the namespace checking

2019-12-04 Thread GitBox
tuteng commented on issue #5716: [Issues 5709]remove the namespace checking
URL: https://github.com/apache/pulsar/pull/5716#issuecomment-562004015
 
 
   run java8 tests
   run integration tests


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] jiazhai commented on issue #5776: fix potential NPE and repeated conditional test

2019-12-04 Thread GitBox
jiazhai commented on issue #5776: fix potential NPE and repeated conditional 
test
URL: https://github.com/apache/pulsar/pull/5776#issuecomment-56157
 
 
   run java8 tests
   
   


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] jiazhai commented on issue #5790: [Issue:5687] Add prefix for new keys from Env

2019-12-04 Thread GitBox
jiazhai commented on issue #5790: [Issue:5687] Add prefix for new keys from Env
URL: https://github.com/apache/pulsar/pull/5790#issuecomment-561999673
 
 
   run cpp tests
   run java8 tests


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] zymap commented on issue #5791: [Issue 5638][docs] Add explanation about the v1 REST API

2019-12-04 Thread GitBox
zymap commented on issue #5791: [Issue 5638][docs] Add explanation about the v1 
REST API
URL: https://github.com/apache/pulsar/pull/5791#issuecomment-561981766
 
 
   @Anonymitaet PTAL. Thanks
   


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] Anonymitaet commented on a change in pull request #5794: [release][website] Add release notes for Release 2.4.2

2019-12-04 Thread GitBox
Anonymitaet commented on a change in pull request #5794: [release][website] Add 
release notes for Release 2.4.2
URL: https://github.com/apache/pulsar/pull/5794#discussion_r354120541
 
 

 ##
 File path: site2/website/release-notes.md
 ##
 @@ -1,6 +1,107 @@
 
 ## Apache
 
+### 2.4.2  2019-12-04 
+
+ Fixes
+
+* Fixed don't set interrupt flag again after catching interrupt exception in 
Pulsar Client [#5643](https://github.com/apache/pulsar/pull/5643)
+* Fixed data is not deleted after expiration due to connected readers 
[#5621](https://github.com/apache/pulsar/pull/5621)
+* Fixed typo in BrokersBase file 
[#5596](https://github.com/apache/pulsar/pull/5596)
+* Fixed the go client docs missing in website 
[#5595](https://github.com/apache/pulsar/pull/5595)
+* Fixed schema def build error with protobuf schema 
[#5569](https://github.com/apache/pulsar/pull/5569)
+* Fixed docs about reset cursor 
[#5551](https://github.com/apache/pulsar/pull/5551)
+* Fixed repeated initialization of connectorsManager 
[#5545](https://github.com/apache/pulsar/pull/5545)
+* Fixed Functions unnecessarily restart during FunctionRuntimeManager init 
phase [#5527](https://github.com/apache/pulsar/pull/5527)
+* Fixed list non-persistent topics shows the persistent topics 
[#5502](https://github.com/apache/pulsar/pull/5502)
+* Return after triggering callback with empty result 
[#5500](https://github.com/apache/pulsar/pull/5500)
+* Fixed dispatcher skipping delivery of a batch during concurrent replays 
[#5499](https://github.com/apache/pulsar/pull/5499)
+* Fixed reader_listener option for Python API 
[#5487](https://github.com/apache/pulsar/pull/5487)
+* Fixed wrongly report "3600 messages have timed-out" 
[#5477](https://github.com/apache/pulsar/pull/5477)
+* Fixed broken custom auth-provider that uses authenticationData 
[#5462](https://github.com/apache/pulsar/pull/5462)
+* Fixed negative ack tracker constructor sequence 
[#5453](https://github.com/apache/pulsar/pull/5453)
+* Fixed StringSchema static initialization  
[#5445](https://github.com/apache/pulsar/pull/5445)
+* Fixed message corruption on OOM for batch messages 
[#5443](https://github.com/apache/pulsar/pull/5443)
+* Fixed couple functions related integration tests 
[#5434](https://github.com/apache/pulsar/pull/5434)
+* Fixed bug that namespace policies does not take effect due to NPE 
[#5408](https://github.com/apache/pulsar/pull/5408)
+* Fixed race condition : Failed to read-more entries on dispatcher 
[#5391](https://github.com/apache/pulsar/pull/5391)
+* Fixed potential deadlock that can occur in addConsumer 
[#5371](https://github.com/apache/pulsar/pull/5371)
+* Fixed proxy to be able to re-send request body 
[#5361](https://github.com/apache/pulsar/pull/5361)
+* Fixed pulsar can't load the customized SerDe 
[#5357](https://github.com/apache/pulsar/pull/5357)
+* Fixed instability in Pulsar Function window integration test 
[#5337](https://github.com/apache/pulsar/pull/5337)
+* Fixed bk write failure part 2 
[#5322](https://github.com/apache/pulsar/pull/5322)
+* Fixed bad_weak_ptr error when closing producer 
[#5315](https://github.com/apache/pulsar/pull/5315)
+* Fixed typo in prometheus metrics 
[#5299](https://github.com/apache/pulsar/pull/5299)
+* Fixed invalidate cache on zk-cache timeout 
[#5298](https://github.com/apache/pulsar/pull/5298)
+* Don't attempt to append on read-only cursor ledger 
[#5297](https://github.com/apache/pulsar/pull/5297)
+* Fixed memory leak caused by not being executed ClientConnection destructor 
[#5286](https://github.com/apache/pulsar/pull/5286)
+* Fixed producer blocked after send an over size message while batch enabled 
[#5282](https://github.com/apache/pulsar/pull/5282)
+* Fixed race condition while triggering message redelivery after an 
ack-timeout event [#5276](https://github.com/apache/pulsar/pull/5276)
+* Fixed behavior when getting a key from functions state that doesn't exist 
[#5272](https://github.com/apache/pulsar/pull/5272)
+* Fixed Cmake to build _pulsar for osx #5263
+* Fixed client backoff #5261
+* Fixed memory leak caused by deadline_timer holding object reference 
[#5246](https://github.com/apache/pulsar/pull/5246)
+* Fixed in Message Deduplication that may cause incorrect client/broker 
interaction [#5243](https://github.com/apache/pulsar/pull/5243)
+* Fixed bug that fails to search namespace bundle due to NPE 
[#5191](https://github.com/apache/pulsar/pull/5191)
+* Fixed bug that message delivery stops after resetting cursor for failover 
subscription [#5185](https://github.com/apache/pulsar/pull/5185)
+* Fixed exception type check order bug 
[#5174](https://github.com/apache/pulsar/pull/5174)
+* Fixed spark receiver to account for all the consumer config options 
[#5152](https://github.com/apache/pulsar/pull/5152)
+* Fixed broker fails to start with function worker enabled and broker client 
using TLS [#5151](https://github.com/apache/pulsar/pull/5151)
+* Fixed deadlock when resetting cursor 

[GitHub] [pulsar] laxpio commented on issue #5669: Pulsar Broker restart fail owing to create functions/assignments topic fail

2019-12-04 Thread GitBox
laxpio commented on issue #5669: Pulsar Broker restart fail owing to create 
functions/assignments topic fail
URL: https://github.com/apache/pulsar/issues/5669#issuecomment-561978582
 
 
i modify the code,deal NUll return,and now can not reproduce it.
   original code:
   org/apache/bookkeeper/mledger/impl/ManagedLedgerImpl.java
   ```
   PositionImpl startReadOperationOnLedger(PositionImpl position) {
   long ledgerId = ledgers.ceilingKey(position.getLedgerId()); // 
ceilingKey return will null
   if (ledgerId != position.getLedgerId()) {
   // The ledger pointed by this position does not exist anymore. 
It was deleted because it was empty. We need
   // to skip on the next available ledger
   position = new PositionImpl(ledgerId, 0);
   }
   
   return position;
   }
   ```


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] devinbost commented on issue #4721: Flink pulsar sink NotSerializableException

2019-12-04 Thread GitBox
devinbost commented on issue #4721: Flink pulsar sink NotSerializableException
URL: https://github.com/apache/pulsar/issues/4721#issuecomment-561965357
 
 
   Does anyone know of a workaround? I'm stuck on this exact issue. 
   
   You should be able to reproduce it with this example:
   
   
   ```
   import org.apache.flink.api.common.functions.AggregateFunction;
   import org.apache.flink.api.common.functions.FoldFunction;
   import org.apache.flink.api.common.functions.MapFunction;
   import org.apache.flink.api.common.serialization.SimpleStringSchema;
   import org.apache.flink.api.common.typeinfo.TypeHint;
   import org.apache.flink.api.common.typeinfo.TypeInformation;
   import org.apache.flink.api.java.tuple.Tuple2;
   import org.apache.flink.streaming.api.datastream.DataStream;
   import org.apache.flink.streaming.api.environment.StreamExecutionEnvironment;
   import org.apache.flink.streaming.api.functions.source.SourceFunction;
   import 
org.apache.flink.streaming.api.windowing.assigners.EventTimeSessionWindows;
   import org.apache.flink.streaming.api.windowing.time.Time;
   import org.apache.flink.streaming.connectors.pulsar.FlinkPulsarProducer;
   import org.apache.flink.streaming.connectors.pulsar.PulsarSourceBuilder;
   import org.apache.pulsar.client.impl.auth.AuthenticationDisabled;
   import org.json.simple.JSONObject;
   import org.json.simple.parser.JSONParser;
   import org.json.simple.parser.ParseException;
   
   import static java.nio.charset.StandardCharsets.UTF_8;
   
   public class StreamingJob {
   
public static Tuple2 mapToTuple(String incomingMessage) 
throws ParseException {
JSONObject incomingObj = (JSONObject) new 
JSONParser().parse(incomingMessage);
JSONObject correlationIdJson = (JSONObject) 
incomingObj.get("correlationId");
String correlationId = "";
if(correlationIdJson != null){
correlationId = correlationIdJson.toString();
} // Put in try/catch to throw exception if correlationIdJson 
== null
Tuple2 msgEnvelope = new Tuple2(correlationId, 
incomingObj.toString());
return msgEnvelope;
}
private static class JsonConcatenator
implements AggregateFunction, 
Tuple2, String> {
@Override
public Tuple2 createAccumulator() {
return new Tuple2("","");
}
   
@Override
public Tuple2 add(Tuple2 value, 
Tuple2 accumulator) {
return new Tuple2<>(value.f0, accumulator.f1 + ", " + 
value.f1);
}
   
@Override
public String getResult(Tuple2 accumulator) {
return "[" + accumulator.f1 + "]";
}
   
@Override
public Tuple2 merge(Tuple2 a, 
Tuple2 b) {
return new Tuple2<>(a.f0, a.f1 + ", " + b.f1);
}
}
   
public static void main(String[] args) throws Exception {
// set up the streaming execution environment
final StreamExecutionEnvironment env = 
StreamExecutionEnvironment.getExecutionEnvironment();
   
String SERVICE_URL = "pulsar://localhost:6650";
String INPUT_TOPIC = 
"persistent://public/default/test-flink-jaeger-spanner-input";
String SUBSCRIPTION_NAME = "test-jaeger-spanner";
String OUTPUT_TOPIC = 
"persistent://public/default/test-flink-jaeger-spanner-output";
   
PulsarSourceBuilder builder = PulsarSourceBuilder
.builder(new SimpleStringSchema())
.serviceUrl(SERVICE_URL)
.topic(INPUT_TOPIC)
.subscriptionName(SUBSCRIPTION_NAME);
SourceFunction src = builder.build();
DataStream dataStream = env.addSource(src);
   
DataStream combinedEnvelopes = dataStream
.map(new MapFunction>() {
@Override
public Tuple2 map(String 
incomingMessage) throws Exception {
return 
mapToTuple(incomingMessage);
}
})
.keyBy(0)

.window(EventTimeSessionWindows.withGap(Time.seconds(20)))
.aggregate(new JsonConcatenator())
.returns(String.class);
   
combinedEnvelopes.addSink(new FlinkPulsarProducer<>(
SERVICE_URL,
OUTPUT_TOPIC,
new AuthenticationDisabled(), // probably need 
to 

[pulsar.wiki] branch master updated: Updated Release process (markdown)

2019-12-04 Thread hjf
This is an automated email from the ASF dual-hosted git repository.

hjf pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/pulsar.wiki.git


The following commit(s) were added to refs/heads/master by this push:
 new 0341350  Updated Release process (markdown)
0341350 is described below

commit 034135059708a1e0f1db868f975cc233f8140ded
Author: Jennifer Huang <47805623+jennifer88hu...@users.noreply.github.com>
AuthorDate: Thu Dec 5 12:36:19 2019 +0800

Updated Release process (markdown)
---
 Release-process.md | 12 +---
 1 file changed, 5 insertions(+), 7 deletions(-)

diff --git a/Release-process.md b/Release-process.md
index 44ab0c7..eef9ab4 100644
--- a/Release-process.md
+++ b/Release-process.md
@@ -2,11 +2,11 @@
 This page contains instructions for Pulsar committers on
 how to perform a release.
 
-If you haven't already did it. Create and publish the GPG
+If you haven't already done it, create and publish the GPG
 key with which you'll be signing the release artifacts.
 Instructions are at [Create GPG keys to sign release 
artifacts](https://github.com/apache/pulsar/wiki/Create-GPG-keys-to-sign-release-artifacts).
 
-## Making the release
+## Release workflow
 
 The steps for releasing are as follows:
 1. Create release branch
@@ -36,12 +36,10 @@ applied as part of the maintenance for the release.
 The branch needs only to be created when creating major releases,
 and not for patch releases.
 
-Eg: When creating `v2.3.0` release, will be creating
-the branch `branch-2.3`, but for for `v2.3.1` we
-would keep using the old `branch-2.3`.
+Eg: When creating `v2.3.0` release, the branch `branch-2.3` will be created; 
but for `v2.3.1`, we
+keep using the old `branch-2.3`.
 
-In these instructions, I'm referring to an fictitious release `2.X.0`. Change 
the release version in the examples
-accordingly with the real version.
+In these instructions, I'm referring to an fictitious release `2.X.0`. Change 
the release version in the examples accordingly with the real version.
 
 It is recommended to create a fresh clone of the repository to avoid any local 
files to interfere
 in the process:



[GitHub] [pulsar] fangpengcheng95 commented on a change in pull request #5789: [Issue 5708][docs] correct some wrong info about persistent topics

2019-12-04 Thread GitBox
fangpengcheng95 commented on a change in pull request #5789: [Issue 5708][docs] 
correct some wrong info about persistent topics
URL: https://github.com/apache/pulsar/pull/5789#discussion_r354099611
 
 

 ##
 File path: site2/docs/admin-api-persistent-topics.md
 ##
 @@ -191,47 +192,77 @@ It shows current statistics of a given non-partitioned 
topic.
 
   -   **averageMsgSize**: The average size in bytes of messages published 
within the last interval
 
-  -   **storageSize**: The sum of the ledgers' storage size for this topic. See
+  -   **storageSize**: The sum of the ledgers' storage size for this topic. 
Space used to store the messages for the topic
 
   -   **publishers**: The list of all local publishers into the topic. There 
can be zero or thousands
 
-  -   **averageMsgSize**: Average message size in bytes from this publisher 
within the last interval
+  -   **msgRateIn**: Total rate of messages published by this publisher in 
messages per second 
+
+  -   **msgThroughputIn**: Total throughput of the messages published by 
this publisher in bytes per second
+
+  -   **averageMsgSize**: Average message size in bytes from this 
publisher within the last interval
 
-  -   **producerId**: Internal identifier for this producer on this topic
+  -   **producerId**: Id of this publisher. Internal identifier for this 
producer on this topic
 
-  -   **producerName**: Internal identifier for this producer, generated by 
the client library
+  -   **producerName**: Publisher name which is generated by the client 
library
 
-  -   **address**: IP address and source port for the connection of this 
producer
+  -   **address**: IP address and source port for the connection of this 
producer
 
-  -   **connectedSince**: Timestamp this producer was created or last 
reconnected
+  -   **connectedSince**: Timestamp this producer was created or last 
reconnected
 
   -   **subscriptions**: The list of all local subscriptions to the topic
 
-  -   **my-subscription**: The name of this subscription (client defined)
+  -   **my-subscription**: The name of this subscription (client defined)
+
+  -   **msgRateOut**: Total rate of messages delivered on this 
subscription (msg/s)
+
+  -   **msgThroughputOut**: Total throughput delivered on this 
subscription (bytes/s)
 
-  -   **msgBacklog**: The count of messages in backlog for this subscription
+  -   **msgBacklog**: Number of messages in the subscription backlog
 
-  -   **type**: This subscription type
+  -   **type**: This subscription's type
 
-  -   **msgRateExpired**: The rate at which messages were discarded instead of 
dispatched from this subscription due to TTL
+  -   **msgRateExpired**: The rate at which messages were discarded 
instead of dispatched from this subscription due to TTL
 
-  -   **consumers**: The list of connected consumers for this subscription
+  -   **consumers**: The list of connected consumers for this 
subscription
 
-  -   **consumerName**: Internal identifier for this consumer, generated by 
the client library
+-   **msgRateOut**: Total rate of messages delivered to the 
consumer (msg/s)
 
-  -   **availablePermits**: The number of messages this consumer has space for 
in the client library's listen queue. A value of 0 means the client library's 
queue is full and receive() isn't being called. A nonzero value means this 
consumer is ready to be dispatched messages.
+-   **msgThroughputOut**: Total throughput delivered to the 
consumer (bytes/s)
+
+-   **consumerName**: Internal identifier for this consumer, 
generated by the client library
+
+-   **availablePermits**: The number of messages this consumer 
has space for in the client library's listen queue. A value of 0 means the 
client library's queue is full and receive() isn't being called. A nonzero 
value means this consumer is ready to be dispatched messages.
+
+-   **unackedMessages**: Number of unacknowledged messages for 
the consumer
+
+-   **blockedConsumerOnUnackedMsgs**: Flag to verify if 
consumer is blocked due to reaching threshold of unacked messages
 
   -   **replication**: This section gives the stats for cross-colo replication 
of this topic
 
-  -   **replicationBacklog**: The outbound replication backlog in messages
+  -   **msgRateIn**: Total rate of messages received from the remote 
cluster (msg/s)
+
+  -   **msgThroughputIn**: Total throughput received from the remote 
cluster (bytes/s)
 
-  -   **connected**: Whether the outbound replicator is connected
+  -   **msgRateOut**: Total rate of messages delivered to the 
replication-subscriber (msg/s)
 
-  -   **replicationDelayInSeconds**: How long the oldest message has been 
waiting to be sent through the connection, if connected is true
+  -   **msgThroughputOut**: Total through delivered to the 

[GitHub] [pulsar] codelipenghui commented on issue #5794: [release][website] Add release notes for Release 2.4.2

2019-12-04 Thread GitBox
codelipenghui commented on issue #5794: [release][website] Add release notes 
for Release 2.4.2
URL: https://github.com/apache/pulsar/pull/5794#issuecomment-561953636
 
 
   @Anonymitaet Please help review the 2.4.2 release note


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] codelipenghui commented on a change in pull request #5794: [release][website] Add release notes for Release 2.4.2

2019-12-04 Thread GitBox
codelipenghui commented on a change in pull request #5794: [release][website] 
Add release notes for Release 2.4.2
URL: https://github.com/apache/pulsar/pull/5794#discussion_r354095953
 
 

 ##
 File path: site2/website/release-notes.md
 ##
 @@ -1,6 +1,107 @@
 
 ## Apache
 
+### 2.4.2  2019-12-04 
+
+ Fixes
+
+* Fixed don't set interrupt flag again after catching interrupt exception in 
Pulsar Client [#5643](https://github.com/apache/pulsar/pull/5643)
+* Fixed data is not deleted after expiration due to connected readers 
[#5621](https://github.com/apache/pulsar/pull/5621)
+* Fixed typo in BrokersBase file 
[#5596](https://github.com/apache/pulsar/pull/5596)
+* Fixed the go client docs missing in website 
[#5595](https://github.com/apache/pulsar/pull/5595)
+* Fixed schema def build error with protobuf schema 
[#5569](https://github.com/apache/pulsar/pull/5569)
+* Fixed docs about reset cursor 
[#5551](https://github.com/apache/pulsar/pull/5551)
+* Fixed repeated initialization of connectorsManager 
[#5545](https://github.com/apache/pulsar/pull/5545)
+* Fixed Functions unnecessarily restart during FunctionRuntimeManager init 
phase [#5527](https://github.com/apache/pulsar/pull/5527)
+* Fixed list non-persistent topics shows the persistent topics 
[#5502](https://github.com/apache/pulsar/pull/5502)
+* Return after triggering callback with empty result 
[#5500](https://github.com/apache/pulsar/pull/5500)
+* Fixed dispatcher skipping delivery of a batch during concurrent replays 
[#5499](https://github.com/apache/pulsar/pull/5499)
+* Fixed reader_listener option for Python API 
[#5487](https://github.com/apache/pulsar/pull/5487)
+* Fixed wrongly report "3600 messages have timed-out" 
[#5477](https://github.com/apache/pulsar/pull/5477)
+* Fixed broken custom auth-provider that uses authenticationData 
[#5462](https://github.com/apache/pulsar/pull/5462)
+* Fixed negative ack tracker constructor sequence 
[#5453](https://github.com/apache/pulsar/pull/5453)
+* Fixed StringSchema static initialization  
[#5445](https://github.com/apache/pulsar/pull/5445)
+* Fixed message corruption on OOM for batch messages 
[#5443](https://github.com/apache/pulsar/pull/5443)
+* Fixed couple functions related integration tests 
[#5434](https://github.com/apache/pulsar/pull/5434)
+* Fixed bug that namespace policies does not take effect due to NPE 
[#5408](https://github.com/apache/pulsar/pull/5408)
+* Fixed race condition : Failed to read-more entries on dispatcher 
[#5391](https://github.com/apache/pulsar/pull/5391)
+* Fixed potential deadlock that can occur in addConsumer 
[#5371](https://github.com/apache/pulsar/pull/5371)
+* Fixed proxy to be able to re-send request body 
[#5361](https://github.com/apache/pulsar/pull/5361)
+* Fixed pulsar can't load the customized SerDe 
[#5357](https://github.com/apache/pulsar/pull/5357)
+* Fixed instability in Pulsar Function window integration test 
[#5337](https://github.com/apache/pulsar/pull/5337)
+* Fixed bk write failure part 2 
[#5322](https://github.com/apache/pulsar/pull/5322)
+* Fixed bad_weak_ptr error when closing producer 
[#5315](https://github.com/apache/pulsar/pull/5315)
+* Fixed typo in prometheus metrics 
[#5299](https://github.com/apache/pulsar/pull/5299)
+* Fixed invalidate cache on zk-cache timeout 
[#5298](https://github.com/apache/pulsar/pull/5298)
+* Don't attempt to append on read-only cursor ledger 
[#5297](https://github.com/apache/pulsar/pull/5297)
+* Fixed memory leak caused by not being executed ClientConnection destructor 
[#5286](https://github.com/apache/pulsar/pull/5286)
+* Fixed producer blocked after send an over size message while batch enabled 
[#5282](https://github.com/apache/pulsar/pull/5282)
+* Fixed race condition while triggering message redelivery after an 
ack-timeout event [#5276](https://github.com/apache/pulsar/pull/5276)
+* Fixed behavior when getting a key from functions state that doesn't exist 
[#5272](https://github.com/apache/pulsar/pull/5272)
+* Fixed Cmake to build _pulsar for osx #5263
+* Fixed client backoff #5261
 
 Review comment:
   Need  a clear briefly description here


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] codelipenghui commented on a change in pull request #5794: [release][website] Add release notes for Release 2.4.2

2019-12-04 Thread GitBox
codelipenghui commented on a change in pull request #5794: [release][website] 
Add release notes for Release 2.4.2
URL: https://github.com/apache/pulsar/pull/5794#discussion_r354094188
 
 

 ##
 File path: site2/website/release-notes.md
 ##
 @@ -1,6 +1,107 @@
 
 ## Apache
 
+### 2.4.2  2019-12-04 
+
+ Fixes
+
+* Fixed don't set interrupt flag again after catching interrupt exception in 
Pulsar Client [#5643](https://github.com/apache/pulsar/pull/5643)
+* Fixed data is not deleted after expiration due to connected readers 
[#5621](https://github.com/apache/pulsar/pull/5621)
+* Fixed typo in BrokersBase file 
[#5596](https://github.com/apache/pulsar/pull/5596)
+* Fixed the go client docs missing in website 
[#5595](https://github.com/apache/pulsar/pull/5595)
+* Fixed schema def build error with protobuf schema 
[#5569](https://github.com/apache/pulsar/pull/5569)
+* Fixed docs about reset cursor 
[#5551](https://github.com/apache/pulsar/pull/5551)
+* Fixed repeated initialization of connectorsManager 
[#5545](https://github.com/apache/pulsar/pull/5545)
+* Fixed Functions unnecessarily restart during FunctionRuntimeManager init 
phase [#5527](https://github.com/apache/pulsar/pull/5527)
+* Fixed list non-persistent topics shows the persistent topics 
[#5502](https://github.com/apache/pulsar/pull/5502)
+* Return after triggering callback with empty result 
[#5500](https://github.com/apache/pulsar/pull/5500)
+* Fixed dispatcher skipping delivery of a batch during concurrent replays 
[#5499](https://github.com/apache/pulsar/pull/5499)
+* Fixed reader_listener option for Python API 
[#5487](https://github.com/apache/pulsar/pull/5487)
+* Fixed wrongly report "3600 messages have timed-out" 
[#5477](https://github.com/apache/pulsar/pull/5477)
+* Fixed broken custom auth-provider that uses authenticationData 
[#5462](https://github.com/apache/pulsar/pull/5462)
+* Fixed negative ack tracker constructor sequence 
[#5453](https://github.com/apache/pulsar/pull/5453)
+* Fixed StringSchema static initialization  
[#5445](https://github.com/apache/pulsar/pull/5445)
+* Fixed message corruption on OOM for batch messages 
[#5443](https://github.com/apache/pulsar/pull/5443)
+* Fixed couple functions related integration tests 
[#5434](https://github.com/apache/pulsar/pull/5434)
+* Fixed bug that namespace policies does not take effect due to NPE 
[#5408](https://github.com/apache/pulsar/pull/5408)
+* Fixed race condition : Failed to read-more entries on dispatcher 
[#5391](https://github.com/apache/pulsar/pull/5391)
+* Fixed potential deadlock that can occur in addConsumer 
[#5371](https://github.com/apache/pulsar/pull/5371)
+* Fixed proxy to be able to re-send request body 
[#5361](https://github.com/apache/pulsar/pull/5361)
+* Fixed pulsar can't load the customized SerDe 
[#5357](https://github.com/apache/pulsar/pull/5357)
+* Fixed instability in Pulsar Function window integration test 
[#5337](https://github.com/apache/pulsar/pull/5337)
+* Fixed bk write failure part 2 
[#5322](https://github.com/apache/pulsar/pull/5322)
 
 Review comment:
   We'd better have a briefly description for the failure


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] codelipenghui commented on a change in pull request #5794: [release][website] Add release notes for Release 2.4.2

2019-12-04 Thread GitBox
codelipenghui commented on a change in pull request #5794: [release][website] 
Add release notes for Release 2.4.2
URL: https://github.com/apache/pulsar/pull/5794#discussion_r354093972
 
 

 ##
 File path: site2/website/release-notes.md
 ##
 @@ -1,6 +1,107 @@
 
 ## Apache
 
+### 2.4.2  2019-12-04 
+
+ Fixes
+
+* Fixed don't set interrupt flag again after catching interrupt exception in 
Pulsar Client [#5643](https://github.com/apache/pulsar/pull/5643)
 
 Review comment:
   It's not a clear briefly description for this PR, i think you'd better to 
check the PR


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] codelipenghui commented on a change in pull request #5794: [release][website] Add release notes for Release 2.4.2

2019-12-04 Thread GitBox
codelipenghui commented on a change in pull request #5794: [release][website] 
Add release notes for Release 2.4.2
URL: https://github.com/apache/pulsar/pull/5794#discussion_r354094343
 
 

 ##
 File path: site2/website/release-notes.md
 ##
 @@ -1,6 +1,107 @@
 
 ## Apache
 
+### 2.4.2  2019-12-04 
+
+ Fixes
+
+* Fixed don't set interrupt flag again after catching interrupt exception in 
Pulsar Client [#5643](https://github.com/apache/pulsar/pull/5643)
+* Fixed data is not deleted after expiration due to connected readers 
[#5621](https://github.com/apache/pulsar/pull/5621)
+* Fixed typo in BrokersBase file 
[#5596](https://github.com/apache/pulsar/pull/5596)
+* Fixed the go client docs missing in website 
[#5595](https://github.com/apache/pulsar/pull/5595)
+* Fixed schema def build error with protobuf schema 
[#5569](https://github.com/apache/pulsar/pull/5569)
+* Fixed docs about reset cursor 
[#5551](https://github.com/apache/pulsar/pull/5551)
+* Fixed repeated initialization of connectorsManager 
[#5545](https://github.com/apache/pulsar/pull/5545)
+* Fixed Functions unnecessarily restart during FunctionRuntimeManager init 
phase [#5527](https://github.com/apache/pulsar/pull/5527)
+* Fixed list non-persistent topics shows the persistent topics 
[#5502](https://github.com/apache/pulsar/pull/5502)
+* Return after triggering callback with empty result 
[#5500](https://github.com/apache/pulsar/pull/5500)
+* Fixed dispatcher skipping delivery of a batch during concurrent replays 
[#5499](https://github.com/apache/pulsar/pull/5499)
+* Fixed reader_listener option for Python API 
[#5487](https://github.com/apache/pulsar/pull/5487)
+* Fixed wrongly report "3600 messages have timed-out" 
[#5477](https://github.com/apache/pulsar/pull/5477)
+* Fixed broken custom auth-provider that uses authenticationData 
[#5462](https://github.com/apache/pulsar/pull/5462)
+* Fixed negative ack tracker constructor sequence 
[#5453](https://github.com/apache/pulsar/pull/5453)
+* Fixed StringSchema static initialization  
[#5445](https://github.com/apache/pulsar/pull/5445)
+* Fixed message corruption on OOM for batch messages 
[#5443](https://github.com/apache/pulsar/pull/5443)
+* Fixed couple functions related integration tests 
[#5434](https://github.com/apache/pulsar/pull/5434)
+* Fixed bug that namespace policies does not take effect due to NPE 
[#5408](https://github.com/apache/pulsar/pull/5408)
+* Fixed race condition : Failed to read-more entries on dispatcher 
[#5391](https://github.com/apache/pulsar/pull/5391)
+* Fixed potential deadlock that can occur in addConsumer 
[#5371](https://github.com/apache/pulsar/pull/5371)
+* Fixed proxy to be able to re-send request body 
[#5361](https://github.com/apache/pulsar/pull/5361)
+* Fixed pulsar can't load the customized SerDe 
[#5357](https://github.com/apache/pulsar/pull/5357)
+* Fixed instability in Pulsar Function window integration test 
[#5337](https://github.com/apache/pulsar/pull/5337)
+* Fixed bk write failure part 2 
[#5322](https://github.com/apache/pulsar/pull/5322)
+* Fixed bad_weak_ptr error when closing producer 
[#5315](https://github.com/apache/pulsar/pull/5315)
+* Fixed typo in prometheus metrics 
[#5299](https://github.com/apache/pulsar/pull/5299)
 
 Review comment:
   Is also a typo


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] codelipenghui commented on a change in pull request #5794: [release][website] Add release notes for Release 2.4.2

2019-12-04 Thread GitBox
codelipenghui commented on a change in pull request #5794: [release][website] 
Add release notes for Release 2.4.2
URL: https://github.com/apache/pulsar/pull/5794#discussion_r354095710
 
 

 ##
 File path: site2/website/release-notes.md
 ##
 @@ -1,6 +1,107 @@
 
 ## Apache
 
+### 2.4.2  2019-12-04 
+
+ Fixes
+
+* Fixed don't set interrupt flag again after catching interrupt exception in 
Pulsar Client [#5643](https://github.com/apache/pulsar/pull/5643)
+* Fixed data is not deleted after expiration due to connected readers 
[#5621](https://github.com/apache/pulsar/pull/5621)
+* Fixed typo in BrokersBase file 
[#5596](https://github.com/apache/pulsar/pull/5596)
+* Fixed the go client docs missing in website 
[#5595](https://github.com/apache/pulsar/pull/5595)
+* Fixed schema def build error with protobuf schema 
[#5569](https://github.com/apache/pulsar/pull/5569)
+* Fixed docs about reset cursor 
[#5551](https://github.com/apache/pulsar/pull/5551)
+* Fixed repeated initialization of connectorsManager 
[#5545](https://github.com/apache/pulsar/pull/5545)
+* Fixed Functions unnecessarily restart during FunctionRuntimeManager init 
phase [#5527](https://github.com/apache/pulsar/pull/5527)
+* Fixed list non-persistent topics shows the persistent topics 
[#5502](https://github.com/apache/pulsar/pull/5502)
+* Return after triggering callback with empty result 
[#5500](https://github.com/apache/pulsar/pull/5500)
+* Fixed dispatcher skipping delivery of a batch during concurrent replays 
[#5499](https://github.com/apache/pulsar/pull/5499)
+* Fixed reader_listener option for Python API 
[#5487](https://github.com/apache/pulsar/pull/5487)
+* Fixed wrongly report "3600 messages have timed-out" 
[#5477](https://github.com/apache/pulsar/pull/5477)
+* Fixed broken custom auth-provider that uses authenticationData 
[#5462](https://github.com/apache/pulsar/pull/5462)
+* Fixed negative ack tracker constructor sequence 
[#5453](https://github.com/apache/pulsar/pull/5453)
+* Fixed StringSchema static initialization  
[#5445](https://github.com/apache/pulsar/pull/5445)
+* Fixed message corruption on OOM for batch messages 
[#5443](https://github.com/apache/pulsar/pull/5443)
+* Fixed couple functions related integration tests 
[#5434](https://github.com/apache/pulsar/pull/5434)
+* Fixed bug that namespace policies does not take effect due to NPE 
[#5408](https://github.com/apache/pulsar/pull/5408)
+* Fixed race condition : Failed to read-more entries on dispatcher 
[#5391](https://github.com/apache/pulsar/pull/5391)
+* Fixed potential deadlock that can occur in addConsumer 
[#5371](https://github.com/apache/pulsar/pull/5371)
+* Fixed proxy to be able to re-send request body 
[#5361](https://github.com/apache/pulsar/pull/5361)
+* Fixed pulsar can't load the customized SerDe 
[#5357](https://github.com/apache/pulsar/pull/5357)
+* Fixed instability in Pulsar Function window integration test 
[#5337](https://github.com/apache/pulsar/pull/5337)
+* Fixed bk write failure part 2 
[#5322](https://github.com/apache/pulsar/pull/5322)
+* Fixed bad_weak_ptr error when closing producer 
[#5315](https://github.com/apache/pulsar/pull/5315)
+* Fixed typo in prometheus metrics 
[#5299](https://github.com/apache/pulsar/pull/5299)
+* Fixed invalidate cache on zk-cache timeout 
[#5298](https://github.com/apache/pulsar/pull/5298)
+* Don't attempt to append on read-only cursor ledger 
[#5297](https://github.com/apache/pulsar/pull/5297)
 
 Review comment:
   I think this PR is a enhancement,  Avoid persistent Unack Ranges while 
cursor recovering


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] codelipenghui commented on a change in pull request #5794: [release][website] Add release notes for Release 2.4.2

2019-12-04 Thread GitBox
codelipenghui commented on a change in pull request #5794: [release][website] 
Add release notes for Release 2.4.2
URL: https://github.com/apache/pulsar/pull/5794#discussion_r354093181
 
 

 ##
 File path: site2/website/release-notes.md
 ##
 @@ -1,6 +1,107 @@
 
 ## Apache
 
+### 2.4.2  2019-12-04 
+
+ Fixes
+
+* Fixed don't set interrupt flag again after catching interrupt exception in 
Pulsar Client [#5643](https://github.com/apache/pulsar/pull/5643)
+* Fixed data is not deleted after expiration due to connected readers 
[#5621](https://github.com/apache/pulsar/pull/5621)
+* Fixed typo in BrokersBase file 
[#5596](https://github.com/apache/pulsar/pull/5596)
 
 Review comment:
   No need to add the typo fix in to release note, right?


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] codelipenghui commented on a change in pull request #5794: [release][website] Add release notes for Release 2.4.2

2019-12-04 Thread GitBox
codelipenghui commented on a change in pull request #5794: [release][website] 
Add release notes for Release 2.4.2
URL: https://github.com/apache/pulsar/pull/5794#discussion_r354092046
 
 

 ##
 File path: site2/website/release-notes.md
 ##
 @@ -1,6 +1,107 @@
 
 ## Apache
 
+### 2.4.2  2019-12-04 
+
+ Fixes
+
+* Fixed don't set interrupt flag again after catching interrupt exception in 
Pulsar Client [#5643](https://github.com/apache/pulsar/pull/5643)
+* Fixed data is not deleted after expiration due to connected readers 
[#5621](https://github.com/apache/pulsar/pull/5621)
+* Fixed typo in BrokersBase file 
[#5596](https://github.com/apache/pulsar/pull/5596)
+* Fixed the go client docs missing in website 
[#5595](https://github.com/apache/pulsar/pull/5595)
+* Fixed schema def build error with protobuf schema 
[#5569](https://github.com/apache/pulsar/pull/5569)
+* Fixed docs about reset cursor 
[#5551](https://github.com/apache/pulsar/pull/5551)
+* Fixed repeated initialization of connectorsManager 
[#5545](https://github.com/apache/pulsar/pull/5545)
+* Fixed Functions unnecessarily restart during FunctionRuntimeManager init 
phase [#5527](https://github.com/apache/pulsar/pull/5527)
+* Fixed list non-persistent topics shows the persistent topics 
[#5502](https://github.com/apache/pulsar/pull/5502)
+* Return after triggering callback with empty result 
[#5500](https://github.com/apache/pulsar/pull/5500)
+* Fixed dispatcher skipping delivery of a batch during concurrent replays 
[#5499](https://github.com/apache/pulsar/pull/5499)
+* Fixed reader_listener option for Python API 
[#5487](https://github.com/apache/pulsar/pull/5487)
+* Fixed wrongly report "3600 messages have timed-out" 
[#5477](https://github.com/apache/pulsar/pull/5477)
+* Fixed broken custom auth-provider that uses authenticationData 
[#5462](https://github.com/apache/pulsar/pull/5462)
+* Fixed negative ack tracker constructor sequence 
[#5453](https://github.com/apache/pulsar/pull/5453)
+* Fixed StringSchema static initialization  
[#5445](https://github.com/apache/pulsar/pull/5445)
+* Fixed message corruption on OOM for batch messages 
[#5443](https://github.com/apache/pulsar/pull/5443)
+* Fixed couple functions related integration tests 
[#5434](https://github.com/apache/pulsar/pull/5434)
+* Fixed bug that namespace policies does not take effect due to NPE 
[#5408](https://github.com/apache/pulsar/pull/5408)
+* Fixed race condition : Failed to read-more entries on dispatcher 
[#5391](https://github.com/apache/pulsar/pull/5391)
+* Fixed potential deadlock that can occur in addConsumer 
[#5371](https://github.com/apache/pulsar/pull/5371)
+* Fixed proxy to be able to re-send request body 
[#5361](https://github.com/apache/pulsar/pull/5361)
+* Fixed pulsar can't load the customized SerDe 
[#5357](https://github.com/apache/pulsar/pull/5357)
+* Fixed instability in Pulsar Function window integration test 
[#5337](https://github.com/apache/pulsar/pull/5337)
+* Fixed bk write failure part 2 
[#5322](https://github.com/apache/pulsar/pull/5322)
+* Fixed bad_weak_ptr error when closing producer 
[#5315](https://github.com/apache/pulsar/pull/5315)
+* Fixed typo in prometheus metrics 
[#5299](https://github.com/apache/pulsar/pull/5299)
+* Fixed invalidate cache on zk-cache timeout 
[#5298](https://github.com/apache/pulsar/pull/5298)
+* Don't attempt to append on read-only cursor ledger 
[#5297](https://github.com/apache/pulsar/pull/5297)
+* Fixed memory leak caused by not being executed ClientConnection destructor 
[#5286](https://github.com/apache/pulsar/pull/5286)
+* Fixed producer blocked after send an over size message while batch enabled 
[#5282](https://github.com/apache/pulsar/pull/5282)
+* Fixed race condition while triggering message redelivery after an 
ack-timeout event [#5276](https://github.com/apache/pulsar/pull/5276)
+* Fixed behavior when getting a key from functions state that doesn't exist 
[#5272](https://github.com/apache/pulsar/pull/5272)
+* Fixed Cmake to build _pulsar for osx #5263
+* Fixed client backoff #5261
+* Fixed memory leak caused by deadline_timer holding object reference 
[#5246](https://github.com/apache/pulsar/pull/5246)
+* Fixed in Message Deduplication that may cause incorrect client/broker 
interaction [#5243](https://github.com/apache/pulsar/pull/5243)
+* Fixed bug that fails to search namespace bundle due to NPE 
[#5191](https://github.com/apache/pulsar/pull/5191)
+* Fixed bug that message delivery stops after resetting cursor for failover 
subscription [#5185](https://github.com/apache/pulsar/pull/5185)
+* Fixed exception type check order bug 
[#5174](https://github.com/apache/pulsar/pull/5174)
+* Fixed spark receiver to account for all the consumer config options 
[#5152](https://github.com/apache/pulsar/pull/5152)
+* Fixed broker fails to start with function worker enabled and broker client 
using TLS [#5151](https://github.com/apache/pulsar/pull/5151)
+* Fixed deadlock when resetting cursor 

[GitHub] [pulsar] Anonymitaet commented on issue #5795: Update website for 2.4.2 release

2019-12-04 Thread GitBox
Anonymitaet commented on issue #5795: Update website for 2.4.2 release
URL: https://github.com/apache/pulsar/pull/5795#issuecomment-561952647
 
 
   @wolfstudy 
   
   - I have double checked with @congbobo184, the contents of [this 
PR](https://github.com/apache/pulsar/pull/5762) are only for  2.5.0, but they 
are shown in 2.4.2
   
   - For schema guide, I see only the schema-understand.md is in this PR, do we 
need to include other schema chapters (.md files) in 2.4.2? 


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] tuteng commented on issue #5795: Update website for 2.4.2 release

2019-12-04 Thread GitBox
tuteng commented on issue #5795: Update website for 2.4.2 release
URL: https://github.com/apache/pulsar/pull/5795#issuecomment-561949831
 
 
   Our goal is that the pages of the new version of the website can be 
generated correctly and included correctly by the search engine a few days 
later. In order to prevent the search from being unavailable before the pages 
are included, we continue to use version 2.4.1 as the default document for a 
period of time. When the new version search is available, we will set version 
2.4.2 as the default document again.
   
   After testing, we need to change the 
https://github.com/apache/pulsar/blob/fbdfc6d3ea93a4fe994323be26e6bfa97d5c7aab/site2/website/versions.json
 file to generate the page correctly, and the default version is 2.4.1. @sijie 
@wolfstudy 


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] wolfstudy commented on issue #5795: Update website for 2.4.2 release

2019-12-04 Thread GitBox
wolfstudy commented on issue #5795: Update website for 2.4.2 release
URL: https://github.com/apache/pulsar/pull/5795#issuecomment-561947372
 
 
   > make sure you build the website locally and no broken links.
   
   Yes, `yarn build` successful.
   
   > I would recommend remove 2.4.2 release from releases.json so we can 
publish the documentation of 2.4.2 release but not promote it as the default 
release. wait until algolia indexes 2.4.2 release and then add 2.4.2 release to 
the releases.json. This would ensure the search box work as expected. @tuteng 
dealt with Algolia index issue before.
   
   @tuteng verified done.


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] Anonymitaet commented on a change in pull request #5789: [Issue 5708][docs] correct some wrong info about persistent topics

2019-12-04 Thread GitBox
Anonymitaet commented on a change in pull request #5789: [Issue 5708][docs] 
correct some wrong info about persistent topics
URL: https://github.com/apache/pulsar/pull/5789#discussion_r354089862
 
 

 ##
 File path: site2/docs/admin-api-persistent-topics.md
 ##
 @@ -191,47 +192,77 @@ It shows current statistics of a given non-partitioned 
topic.
 
   -   **averageMsgSize**: The average size in bytes of messages published 
within the last interval
 
-  -   **storageSize**: The sum of the ledgers' storage size for this topic. See
+  -   **storageSize**: The sum of the ledgers' storage size for this topic. 
Space used to store the messages for the topic
 
   -   **publishers**: The list of all local publishers into the topic. There 
can be zero or thousands
 
-  -   **averageMsgSize**: Average message size in bytes from this publisher 
within the last interval
+  -   **msgRateIn**: Total rate of messages published by this publisher in 
messages per second 
+
+  -   **msgThroughputIn**: Total throughput of the messages published by 
this publisher in bytes per second
+
+  -   **averageMsgSize**: Average message size in bytes from this 
publisher within the last interval
 
-  -   **producerId**: Internal identifier for this producer on this topic
+  -   **producerId**: Id of this publisher. Internal identifier for this 
producer on this topic
 
-  -   **producerName**: Internal identifier for this producer, generated by 
the client library
+  -   **producerName**: Publisher name which is generated by the client 
library
 
-  -   **address**: IP address and source port for the connection of this 
producer
+  -   **address**: IP address and source port for the connection of this 
producer
 
-  -   **connectedSince**: Timestamp this producer was created or last 
reconnected
+  -   **connectedSince**: Timestamp this producer was created or last 
reconnected
 
   -   **subscriptions**: The list of all local subscriptions to the topic
 
-  -   **my-subscription**: The name of this subscription (client defined)
+  -   **my-subscription**: The name of this subscription (client defined)
+
+  -   **msgRateOut**: Total rate of messages delivered on this 
subscription (msg/s)
+
+  -   **msgThroughputOut**: Total throughput delivered on this 
subscription (bytes/s)
 
-  -   **msgBacklog**: The count of messages in backlog for this subscription
+  -   **msgBacklog**: Number of messages in the subscription backlog
 
-  -   **type**: This subscription type
+  -   **type**: This subscription's type
 
-  -   **msgRateExpired**: The rate at which messages were discarded instead of 
dispatched from this subscription due to TTL
+  -   **msgRateExpired**: The rate at which messages were discarded 
instead of dispatched from this subscription due to TTL
 
-  -   **consumers**: The list of connected consumers for this subscription
+  -   **consumers**: The list of connected consumers for this 
subscription
 
-  -   **consumerName**: Internal identifier for this consumer, generated by 
the client library
+-   **msgRateOut**: Total rate of messages delivered to the 
consumer (msg/s)
 
-  -   **availablePermits**: The number of messages this consumer has space for 
in the client library's listen queue. A value of 0 means the client library's 
queue is full and receive() isn't being called. A nonzero value means this 
consumer is ready to be dispatched messages.
+-   **msgThroughputOut**: Total throughput delivered to the 
consumer (bytes/s)
+
+-   **consumerName**: Internal identifier for this consumer, 
generated by the client library
+
+-   **availablePermits**: The number of messages this consumer 
has space for in the client library's listen queue. A value of 0 means the 
client library's queue is full and receive() isn't being called. A nonzero 
value means this consumer is ready to be dispatched messages.
+
+-   **unackedMessages**: Number of unacknowledged messages for 
the consumer
+
+-   **blockedConsumerOnUnackedMsgs**: Flag to verify if 
consumer is blocked due to reaching threshold of unacked messages
 
   -   **replication**: This section gives the stats for cross-colo replication 
of this topic
 
-  -   **replicationBacklog**: The outbound replication backlog in messages
+  -   **msgRateIn**: Total rate of messages received from the remote 
cluster (msg/s)
+
+  -   **msgThroughputIn**: Total throughput received from the remote 
cluster (bytes/s)
 
-  -   **connected**: Whether the outbound replicator is connected
+  -   **msgRateOut**: Total rate of messages delivered to the 
replication-subscriber (msg/s)
 
-  -   **replicationDelayInSeconds**: How long the oldest message has been 
waiting to be sent through the connection, if connected is true
+  -   **msgThroughputOut**: Total through delivered to the 

[GitHub] [pulsar] Anonymitaet commented on a change in pull request #5789: [Issue 5708][docs] correct some wrong info about persistent topics

2019-12-04 Thread GitBox
Anonymitaet commented on a change in pull request #5789: [Issue 5708][docs] 
correct some wrong info about persistent topics
URL: https://github.com/apache/pulsar/pull/5789#discussion_r354087313
 
 

 ##
 File path: site2/docs/admin-api-persistent-topics.md
 ##
 @@ -191,47 +192,77 @@ It shows current statistics of a given non-partitioned 
topic.
 
   -   **averageMsgSize**: The average size in bytes of messages published 
within the last interval
 
-  -   **storageSize**: The sum of the ledgers' storage size for this topic. See
+  -   **storageSize**: The sum of the ledgers' storage size for this topic. 
Space used to store the messages for the topic
 
   -   **publishers**: The list of all local publishers into the topic. There 
can be zero or thousands
 
-  -   **averageMsgSize**: Average message size in bytes from this publisher 
within the last interval
+  -   **msgRateIn**: Total rate of messages published by this publisher in 
messages per second 
+
+  -   **msgThroughputIn**: Total throughput of the messages published by 
this publisher in bytes per second
+
+  -   **averageMsgSize**: Average message size in bytes from this 
publisher within the last interval
 
-  -   **producerId**: Internal identifier for this producer on this topic
+  -   **producerId**: Id of this publisher. Internal identifier for this 
producer on this topic
 
-  -   **producerName**: Internal identifier for this producer, generated by 
the client library
+  -   **producerName**: Publisher name which is generated by the client 
library
 
-  -   **address**: IP address and source port for the connection of this 
producer
+  -   **address**: IP address and source port for the connection of this 
producer
 
-  -   **connectedSince**: Timestamp this producer was created or last 
reconnected
+  -   **connectedSince**: Timestamp this producer was created or last 
reconnected
 
   -   **subscriptions**: The list of all local subscriptions to the topic
 
-  -   **my-subscription**: The name of this subscription (client defined)
+  -   **my-subscription**: The name of this subscription (client defined)
+
+  -   **msgRateOut**: Total rate of messages delivered on this 
subscription (msg/s)
+
+  -   **msgThroughputOut**: Total throughput delivered on this 
subscription (bytes/s)
 
-  -   **msgBacklog**: The count of messages in backlog for this subscription
+  -   **msgBacklog**: Number of messages in the subscription backlog
 
-  -   **type**: This subscription type
+  -   **type**: This subscription's type
 
 Review comment:
   ```suggestion
 -   **type**: This subscription type
   ```


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] Anonymitaet commented on a change in pull request #5789: [Issue 5708][docs] correct some wrong info about persistent topics

2019-12-04 Thread GitBox
Anonymitaet commented on a change in pull request #5789: [Issue 5708][docs] 
correct some wrong info about persistent topics
URL: https://github.com/apache/pulsar/pull/5789#discussion_r354090452
 
 

 ##
 File path: site2/docs/admin-api-persistent-topics.md
 ##
 @@ -314,27 +345,35 @@ It shows detailed statistics of a topic.
 
   -   **ledgers**: The ordered list of all ledgers for this topic holding its 
messages
 
+  -   **ledgerId**: Id of this ledger
+
+  -   **entries**: Total number of entries which this ledger has
+
+  -   **size**: Size in bytes of messages written to this ledger
 
 Review comment:
   ```suggestion
 -   **size**: Size of messages written to this ledger (in bytes)
   ```


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] Anonymitaet commented on a change in pull request #5789: [Issue 5708][docs] correct some wrong info about persistent topics

2019-12-04 Thread GitBox
Anonymitaet commented on a change in pull request #5789: [Issue 5708][docs] 
correct some wrong info about persistent topics
URL: https://github.com/apache/pulsar/pull/5789#discussion_r354091117
 
 

 ##
 File path: site2/docs/admin-api-persistent-topics.md
 ##
 @@ -314,27 +345,35 @@ It shows detailed statistics of a topic.
 
   -   **ledgers**: The ordered list of all ledgers for this topic holding its 
messages
 
+  -   **ledgerId**: Id of this ledger
+
+  -   **entries**: Total number of entries which this ledger has
+
+  -   **size**: Size in bytes of messages written to this ledger
+
+  -   **offloaded**: Whether this ledger is offloaded
+
   -   **cursors**: The list of all cursors on this topic. There will be one 
for every subscription you saw in the topic stats.
 
-  -   **markDeletePosition**: The ack position: the last message the 
subscriber acknowledged receiving
+  -   **markDeletePosition**: The ack position: the last message the 
subscriber acknowledged receiving
 
 Review comment:
   do you mean the following?
   
   ```suggestion
 -   **markDeletePosition**: The ack position where the subscriber 
acknowledges receiving the last message
   ```


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] Anonymitaet commented on a change in pull request #5789: [Issue 5708][docs] correct some wrong info about persistent topics

2019-12-04 Thread GitBox
Anonymitaet commented on a change in pull request #5789: [Issue 5708][docs] 
correct some wrong info about persistent topics
URL: https://github.com/apache/pulsar/pull/5789#discussion_r354089540
 
 

 ##
 File path: site2/docs/admin-api-persistent-topics.md
 ##
 @@ -191,47 +192,77 @@ It shows current statistics of a given non-partitioned 
topic.
 
   -   **averageMsgSize**: The average size in bytes of messages published 
within the last interval
 
-  -   **storageSize**: The sum of the ledgers' storage size for this topic. See
+  -   **storageSize**: The sum of the ledgers' storage size for this topic. 
Space used to store the messages for the topic
 
   -   **publishers**: The list of all local publishers into the topic. There 
can be zero or thousands
 
-  -   **averageMsgSize**: Average message size in bytes from this publisher 
within the last interval
+  -   **msgRateIn**: Total rate of messages published by this publisher in 
messages per second 
+
+  -   **msgThroughputIn**: Total throughput of the messages published by 
this publisher in bytes per second
+
+  -   **averageMsgSize**: Average message size in bytes from this 
publisher within the last interval
 
-  -   **producerId**: Internal identifier for this producer on this topic
+  -   **producerId**: Id of this publisher. Internal identifier for this 
producer on this topic
 
-  -   **producerName**: Internal identifier for this producer, generated by 
the client library
+  -   **producerName**: Publisher name which is generated by the client 
library
 
-  -   **address**: IP address and source port for the connection of this 
producer
+  -   **address**: IP address and source port for the connection of this 
producer
 
-  -   **connectedSince**: Timestamp this producer was created or last 
reconnected
+  -   **connectedSince**: Timestamp this producer was created or last 
reconnected
 
   -   **subscriptions**: The list of all local subscriptions to the topic
 
-  -   **my-subscription**: The name of this subscription (client defined)
+  -   **my-subscription**: The name of this subscription (client defined)
+
+  -   **msgRateOut**: Total rate of messages delivered on this 
subscription (msg/s)
+
+  -   **msgThroughputOut**: Total throughput delivered on this 
subscription (bytes/s)
 
-  -   **msgBacklog**: The count of messages in backlog for this subscription
+  -   **msgBacklog**: Number of messages in the subscription backlog
 
-  -   **type**: This subscription type
+  -   **type**: This subscription's type
 
-  -   **msgRateExpired**: The rate at which messages were discarded instead of 
dispatched from this subscription due to TTL
+  -   **msgRateExpired**: The rate at which messages were discarded 
instead of dispatched from this subscription due to TTL
 
-  -   **consumers**: The list of connected consumers for this subscription
+  -   **consumers**: The list of connected consumers for this 
subscription
 
-  -   **consumerName**: Internal identifier for this consumer, generated by 
the client library
+-   **msgRateOut**: Total rate of messages delivered to the 
consumer (msg/s)
 
-  -   **availablePermits**: The number of messages this consumer has space for 
in the client library's listen queue. A value of 0 means the client library's 
queue is full and receive() isn't being called. A nonzero value means this 
consumer is ready to be dispatched messages.
+-   **msgThroughputOut**: Total throughput delivered to the 
consumer (bytes/s)
+
+-   **consumerName**: Internal identifier for this consumer, 
generated by the client library
+
+-   **availablePermits**: The number of messages this consumer 
has space for in the client library's listen queue. A value of 0 means the 
client library's queue is full and receive() isn't being called. A nonzero 
value means this consumer is ready to be dispatched messages.
+
+-   **unackedMessages**: Number of unacknowledged messages for 
the consumer
+
+-   **blockedConsumerOnUnackedMsgs**: Flag to verify if 
consumer is blocked due to reaching threshold of unacked messages
 
   -   **replication**: This section gives the stats for cross-colo replication 
of this topic
 
-  -   **replicationBacklog**: The outbound replication backlog in messages
+  -   **msgRateIn**: Total rate of messages received from the remote 
cluster (msg/s)
+
+  -   **msgThroughputIn**: Total throughput received from the remote 
cluster (bytes/s)
 
-  -   **connected**: Whether the outbound replicator is connected
+  -   **msgRateOut**: Total rate of messages delivered to the 
replication-subscriber (msg/s)
 
-  -   **replicationDelayInSeconds**: How long the oldest message has been 
waiting to be sent through the connection, if connected is true
+  -   **msgThroughputOut**: Total through delivered to the 

[GitHub] [pulsar] Anonymitaet commented on a change in pull request #5789: [Issue 5708][docs] correct some wrong info about persistent topics

2019-12-04 Thread GitBox
Anonymitaet commented on a change in pull request #5789: [Issue 5708][docs] 
correct some wrong info about persistent topics
URL: https://github.com/apache/pulsar/pull/5789#discussion_r354090290
 
 

 ##
 File path: site2/docs/admin-api-persistent-topics.md
 ##
 @@ -314,27 +345,35 @@ It shows detailed statistics of a topic.
 
   -   **ledgers**: The ordered list of all ledgers for this topic holding its 
messages
 
+  -   **ledgerId**: Id of this ledger
+
+  -   **entries**: Total number of entries which this ledger has
 
 Review comment:
   ```suggestion
 -   **entries**: Total number of entries belong to this ledger
   ```


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] Anonymitaet commented on a change in pull request #5789: [Issue 5708][docs] correct some wrong info about persistent topics

2019-12-04 Thread GitBox
Anonymitaet commented on a change in pull request #5789: [Issue 5708][docs] 
correct some wrong info about persistent topics
URL: https://github.com/apache/pulsar/pull/5789#discussion_r354089202
 
 

 ##
 File path: site2/docs/admin-api-persistent-topics.md
 ##
 @@ -191,47 +192,77 @@ It shows current statistics of a given non-partitioned 
topic.
 
   -   **averageMsgSize**: The average size in bytes of messages published 
within the last interval
 
-  -   **storageSize**: The sum of the ledgers' storage size for this topic. See
+  -   **storageSize**: The sum of the ledgers' storage size for this topic. 
Space used to store the messages for the topic
 
   -   **publishers**: The list of all local publishers into the topic. There 
can be zero or thousands
 
-  -   **averageMsgSize**: Average message size in bytes from this publisher 
within the last interval
+  -   **msgRateIn**: Total rate of messages published by this publisher in 
messages per second 
+
+  -   **msgThroughputIn**: Total throughput of the messages published by 
this publisher in bytes per second
+
+  -   **averageMsgSize**: Average message size in bytes from this 
publisher within the last interval
 
-  -   **producerId**: Internal identifier for this producer on this topic
+  -   **producerId**: Id of this publisher. Internal identifier for this 
producer on this topic
 
-  -   **producerName**: Internal identifier for this producer, generated by 
the client library
+  -   **producerName**: Publisher name which is generated by the client 
library
 
-  -   **address**: IP address and source port for the connection of this 
producer
+  -   **address**: IP address and source port for the connection of this 
producer
 
-  -   **connectedSince**: Timestamp this producer was created or last 
reconnected
+  -   **connectedSince**: Timestamp this producer was created or last 
reconnected
 
   -   **subscriptions**: The list of all local subscriptions to the topic
 
-  -   **my-subscription**: The name of this subscription (client defined)
+  -   **my-subscription**: The name of this subscription (client defined)
+
+  -   **msgRateOut**: Total rate of messages delivered on this 
subscription (msg/s)
+
+  -   **msgThroughputOut**: Total throughput delivered on this 
subscription (bytes/s)
 
-  -   **msgBacklog**: The count of messages in backlog for this subscription
+  -   **msgBacklog**: Number of messages in the subscription backlog
 
-  -   **type**: This subscription type
+  -   **type**: This subscription's type
 
-  -   **msgRateExpired**: The rate at which messages were discarded instead of 
dispatched from this subscription due to TTL
+  -   **msgRateExpired**: The rate at which messages were discarded 
instead of dispatched from this subscription due to TTL
 
-  -   **consumers**: The list of connected consumers for this subscription
+  -   **consumers**: The list of connected consumers for this 
subscription
 
-  -   **consumerName**: Internal identifier for this consumer, generated by 
the client library
+-   **msgRateOut**: Total rate of messages delivered to the 
consumer (msg/s)
 
-  -   **availablePermits**: The number of messages this consumer has space for 
in the client library's listen queue. A value of 0 means the client library's 
queue is full and receive() isn't being called. A nonzero value means this 
consumer is ready to be dispatched messages.
+-   **msgThroughputOut**: Total throughput delivered to the 
consumer (bytes/s)
+
+-   **consumerName**: Internal identifier for this consumer, 
generated by the client library
+
+-   **availablePermits**: The number of messages this consumer 
has space for in the client library's listen queue. A value of 0 means the 
client library's queue is full and receive() isn't being called. A nonzero 
value means this consumer is ready to be dispatched messages.
+
+-   **unackedMessages**: Number of unacknowledged messages for 
the consumer
+
+-   **blockedConsumerOnUnackedMsgs**: Flag to verify if 
consumer is blocked due to reaching threshold of unacked messages
 
 Review comment:
   ```suggestion
   -   **blockedConsumerOnUnackedMsgs**: Flag to verify if the 
consumer is blocked due to reaching threshold of unacked messages
   ```


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] congbobo184 commented on issue #5570: Transaction log implemention

2019-12-04 Thread GitBox
congbobo184 commented on issue #5570: Transaction log implemention
URL: https://github.com/apache/pulsar/pull/5570#issuecomment-561941336
 
 
   run cpp tests


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] zymap commented on issue #5714: Add more info in the error messages

2019-12-04 Thread GitBox
zymap commented on issue #5714: Add more info in the error messages
URL: https://github.com/apache/pulsar/pull/5714#issuecomment-561937849
 
 
   @sijie PTAL. Thanks


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] zymap commented on issue #5714: Add more info in the error messages

2019-12-04 Thread GitBox
zymap commented on issue #5714: Add more info in the error messages
URL: https://github.com/apache/pulsar/pull/5714#issuecomment-561937689
 
 
   run java8 tests
   run integration tests
   run cpp tests


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] wolfstudy commented on issue #5794: [release][website] Add release notes for Release 2.4.2

2019-12-04 Thread GitBox
wolfstudy commented on issue #5794: [release][website] Add release notes for 
Release 2.4.2
URL: https://github.com/apache/pulsar/pull/5794#issuecomment-561936732
 
 
   @codelipenghui fixed done, PTAL again, thanks.


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] congbobo184 commented on issue #4847: Pulsar sql avro support schema version

2019-12-04 Thread GitBox
congbobo184 commented on issue #4847: Pulsar sql avro support schema version
URL: https://github.com/apache/pulsar/pull/4847#issuecomment-561933195
 
 
   run java8 tests


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] congbobo184 commented on issue #5570: Transaction log implemention

2019-12-04 Thread GitBox
congbobo184 commented on issue #5570: Transaction log implemention
URL: https://github.com/apache/pulsar/pull/5570#issuecomment-561932816
 
 
   run java8 tests


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] congbobo184 commented on issue #5570: Transaction log implemention

2019-12-04 Thread GitBox
congbobo184 commented on issue #5570: Transaction log implemention
URL: https://github.com/apache/pulsar/pull/5570#issuecomment-561932838
 
 
   run cpp tests


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] codelipenghui commented on issue #5680: [transaction-coordinator] Implementation of transaction coordinator client.

2019-12-04 Thread GitBox
codelipenghui commented on issue #5680: [transaction-coordinator] 
Implementation of transaction coordinator client.
URL: https://github.com/apache/pulsar/pull/5680#issuecomment-561932525
 
 
   rerun cpp tests


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] codelipenghui commented on issue #5782: Modify the logical in producer carry a schema to connect broker with isAllowAutoUpdateSchema.

2019-12-04 Thread GitBox
codelipenghui commented on issue #5782: Modify the logical in producer carry a 
schema to connect broker with isAllowAutoUpdateSchema. 
URL: https://github.com/apache/pulsar/pull/5782#issuecomment-561931803
 
 
   run integration tests


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] codelipenghui commented on issue #5786: Fix ArrayIndexOutOfBoundsException in PerformanceProducer.

2019-12-04 Thread GitBox
codelipenghui commented on issue #5786: Fix ArrayIndexOutOfBoundsException in 
PerformanceProducer.
URL: https://github.com/apache/pulsar/pull/5786#issuecomment-561932058
 
 
   run java8 tests


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] codelipenghui commented on issue #5782: Modify the logical in producer carry a schema to connect broker with isAllowAutoUpdateSchema.

2019-12-04 Thread GitBox
codelipenghui commented on issue #5782: Modify the logical in producer carry a 
schema to connect broker with isAllowAutoUpdateSchema. 
URL: https://github.com/apache/pulsar/pull/5782#issuecomment-561931894
 
 
   @sijie please help take a look this PR.


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] jiazhai commented on issue #5798: s3 offloading generates huge zk txn logs in some conditions

2019-12-04 Thread GitBox
jiazhai commented on issue #5798: s3 offloading generates huge zk txn logs in 
some conditions
URL: https://github.com/apache/pulsar/issues/5798#issuecomment-561930910
 
 
   Thanks @vicaya for reporting this, we will try to reproduce and fix this 
issue.


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[pulsar-manager] branch master updated: Fix typos in comments and names of some methods (#227)

2019-12-04 Thread guangning
This is an automated email from the ASF dual-hosted git repository.

guangning pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/pulsar-manager.git


The following commit(s) were added to refs/heads/master by this push:
 new 0f5900c  Fix typos in comments and names of some methods (#227)
0f5900c is described below

commit 0f5900c8b203ed332dd5626a90498a70b75aac55
Author: Sergii Zhevzhyk 
AuthorDate: Thu Dec 5 02:36:20 2019 +0100

Fix typos in comments and names of some methods (#227)
---
 README.md|  2 +-
 .../pulsar/manager/controller/BrokerStatsController.java |  4 ++--
 .../pulsar/manager/controller/BrokerTokensController.java|  2 +-
 .../apache/pulsar/manager/controller/ClustersController.java |  2 +-
 .../pulsar/manager/controller/EnvironmentsController.java|  2 +-
 .../pulsar/manager/controller/NamespacesController.java  |  2 +-
 .../apache/pulsar/manager/service/BrokerStatsService.java|  2 +-
 .../pulsar/manager/service/impl/BrokerStatsServiceImpl.java  |  2 +-
 .../pulsar/manager/service/impl/TopicsServiceImpl.java   | 12 ++--
 .../apache/pulsar/manager/service/TopicsServiceImplTest.java |  2 +-
 10 files changed, 16 insertions(+), 16 deletions(-)

diff --git a/README.md b/README.md
index e7a8bc3..837abaf 100644
--- a/README.md
+++ b/README.md
@@ -151,7 +151,7 @@ The pulsar-manager can monitor topics and subscriptions.
  Introduction
 
 Pulsar Manager bundles JDBC Drivers for 
[HerdDB](https://github.com/diennea/herddb).
-The default confguration starts and embedded in-memory only HerdDB database.
+The default configuration starts and embedded in-memory only HerdDB database.
 
 HerdDB can be used in production, you just have to use the  correct JDBC URL.
 Follow the instructions in 
[application.properties](https://github.com/apache/pulsar-manager/blob/master/src/main/resources/application.properties)
 to switch the connection to a standalone HerdDB service or cluster.
diff --git 
a/src/main/java/org/apache/pulsar/manager/controller/BrokerStatsController.java 
b/src/main/java/org/apache/pulsar/manager/controller/BrokerStatsController.java
index 4fea44b..0f75bf3 100644
--- 
a/src/main/java/org/apache/pulsar/manager/controller/BrokerStatsController.java
+++ 
b/src/main/java/org/apache/pulsar/manager/controller/BrokerStatsController.java
@@ -30,7 +30,7 @@ import org.springframework.web.bind.annotation.RestController;
 import javax.servlet.http.HttpServletRequest;
 
 /**
- * Broker Stats route foward
+ * Broker Stats route forward.
  */
 @RequestMapping(value = "/pulsar-manager/admin/v2")
 @Api(description = "Support more flexible queries to brokerStats.")
@@ -56,7 +56,7 @@ public class BrokerStatsController {
 public ResponseEntity getBrokerStatsMetrics(
 @RequestParam() String broker) {
 String requestHost = environmentCacheService.getServiceUrl(request);
-String result = brokerStatsService.forwarBrokerStatsMetrics(broker, 
requestHost);
+String result = brokerStatsService.forwardBrokerStatsMetrics(broker, 
requestHost);
 return ResponseEntity.ok(result);
 }
 
diff --git 
a/src/main/java/org/apache/pulsar/manager/controller/BrokerTokensController.java
 
b/src/main/java/org/apache/pulsar/manager/controller/BrokerTokensController.java
index a3a758b..ab3296d 100644
--- 
a/src/main/java/org/apache/pulsar/manager/controller/BrokerTokensController.java
+++ 
b/src/main/java/org/apache/pulsar/manager/controller/BrokerTokensController.java
@@ -81,7 +81,7 @@ public class BrokerTokensController {
 }
 String token = 
jwtService.createBrokerToken(brokerTokenEntity.getRole(), null);
 if (token == null) {
-result.put("error", "Token gennerate failed");
+result.put("error", "Token generate failed");
 return ResponseEntity.ok(result);
 }
 brokerTokenEntity.setToken(token);
diff --git 
a/src/main/java/org/apache/pulsar/manager/controller/ClustersController.java 
b/src/main/java/org/apache/pulsar/manager/controller/ClustersController.java
index c8fc738..446ba13 100644
--- a/src/main/java/org/apache/pulsar/manager/controller/ClustersController.java
+++ b/src/main/java/org/apache/pulsar/manager/controller/ClustersController.java
@@ -34,7 +34,7 @@ import javax.validation.constraints.Min;
 import java.util.Map;
 
 /**
- * Cluster rest api
+ * Cluster rest api.
  */
 @RestController
 @RequestMapping(value = "/pulsar-manager/admin/v2")
diff --git 
a/src/main/java/org/apache/pulsar/manager/controller/EnvironmentsController.java
 
b/src/main/java/org/apache/pulsar/manager/controller/EnvironmentsController.java
index 587eadf..56d56aa 100644
--- 
a/src/main/java/org/apache/pulsar/manager/controller/EnvironmentsController.java
+++ 
b/src/main/java/org/apache/pulsar/manager/controller/EnvironmentsController.java
@@ -41,7 +41,7 @@ import java.util.Map;
 import java.util.Optional;

[GitHub] [pulsar] Jennifer88huang commented on issue #5796: Add Yu to team list.

2019-12-04 Thread GitBox
Jennifer88huang commented on issue #5796: Add Yu to team list.
URL: https://github.com/apache/pulsar/pull/5796#issuecomment-561920270
 
 
   run cpp tests
   run integration tests
   run java8 tests


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] vicaya opened a new issue #5798: s3 offloading generates huge zk txn logs in some conditions

2019-12-04 Thread GitBox
vicaya opened a new issue #5798: s3 offloading generates huge zk txn logs in 
some conditions
URL: https://github.com/apache/pulsar/issues/5798
 
 
   **Describe the bug**
   When s3 offloading is turned on but credentials is incorrect the zookeeper 
/managed-ledger znode entries grow to be fairly large (1MB), causing zk txn log 
to be in the range of multiple GBs, which could easily run out of the space on 
the zk log device under default log purging configuration.
   
   An example of the content of such a znode:
   ```
   k: localhost:2181(CONNECTED) 0] get /managed-ledgers/
   ?  ?-*???2?*
   s34
   bucket*
   region  us-west-2.
   endpoint"https://s3.us-west-2.amazonaws.com4
   bucket*
   region  us-west-2.
   endpoint"https://s3.us-west-2.amazonaws.com4
   bucket*
   region  us-west-2.
   ```
   where the bucket, endpoint, and region info appears to be duplicated many 
times. The entry size also grows under normal offloading operation conditions 
but slower.
   
   **To Reproduce**
   See above. We reproduced the problem with fake topics
   
   **Expected behavior**
   znode entry size should be bounded. There appears no reason to duplicate 
offloading metadata.
   


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] rdhabalia opened a new pull request #5797: PIP-52: [pulsar-sever] Add support of dispatch throttling relative to publish-rate

2019-12-04 Thread GitBox
rdhabalia opened a new pull request #5797: PIP-52: [pulsar-sever] Add support 
of dispatch throttling relative to publish-rate
URL: https://github.com/apache/pulsar/pull/5797
 
 
   ### Motivation
   With 
[PIP-3](https://github.com/apache/pulsar/wiki/PIP-3:-Message-dispatch-throttling)
 , Pulsar broker already supports to configure dispatch rate-limiting for a 
given topic. Dispatch-throttling feature allows user to configure absolute 
dispatch rate based on current publish-rate for a given topic or subscriber, 
and broker will make sure to dispatch only configured number of messages to the 
consumers regardless current publish-rate or backlog on that topic.
   
   Current dispatch-rate limiting doesn't consider change in publish-rate so, 
increasing publish-rate on the topic might be larger than configured 
dispatch-rate which will cause backlog on the topic and consumers will never be 
able to catch up the backlog unless user again reconfigured the dispatch-rate 
based on current publish-rate. Reconfiguring dispatch-rate based on 
publish-rate requires human interaction and monitoring. Therefore, we need a 
mechanism to configure dispatch rate relative to the current publish-rate on 
the topic.
   
   ### Modification
   `set-dispatch-rate` cli have a flag `--relative-to-publish-rate` to enable 
relative dispatch throttling.
   
   ```
   pulsar-admin namespaces  set-dispatch-rate 
--msg-dispatch-rate 1000 --relative-to-publish-rate
   ```


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[pulsar.wiki] branch master updated: Created PIP 52: Message dispatch throttling relative to publish rate (markdown)

2019-12-04 Thread rdhabalia
This is an automated email from the ASF dual-hosted git repository.

rdhabalia pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/pulsar.wiki.git


The following commit(s) were added to refs/heads/master by this push:
 new 29afde4  Created PIP 52: Message dispatch throttling relative to 
publish rate (markdown)
29afde4 is described below

commit 29afde44263fd5a881a26d5698b903850d8078d0
Author: Rajan Dhabalia 
AuthorDate: Wed Dec 4 15:14:22 2019 -0800

Created PIP 52: Message dispatch throttling relative to publish rate 
(markdown)
---
 ...dispatch-throttling-relative-to-publish-rate.md | 40 ++
 1 file changed, 40 insertions(+)

diff --git a/PIP-52:-Message-dispatch-throttling-relative-to-publish-rate.md 
b/PIP-52:-Message-dispatch-throttling-relative-to-publish-rate.md
new file mode 100644
index 000..92ff6ba
--- /dev/null
+++ b/PIP-52:-Message-dispatch-throttling-relative-to-publish-rate.md
@@ -0,0 +1,40 @@
+## Motivation
+Producers and consumers can interact with broker on high volumes of data. This 
can monopolize broker resources and cause network saturation, which can have 
adverse effects on other topics owned by that broker. Throttling based on 
resource consumption can protect against these issues and it can play an 
important role for large multi-tenant clusters where a small set of clients 
using high volumes of data can easily degrade performance of other clients. 
+
+With 
[PIP-3](https://github.com/apache/pulsar/wiki/PIP-3:-Message-dispatch-throttling),
 Pulsar broker already supports to configure dispatch rate-limiting for a given 
topic. Dispatch-throttling feature allows user to configure absolute dispatch 
rate based on current publish-rate for a given topic or subscriber, and broker 
will make sure to dispatch only configured number of messages to the consumers 
regardless current publish-rate or backlog on that topic. 
+
+Current dispatch-rate limiting doesn't consider change in publish-rate so, 
increasing publish-rate on the topic might be larger than configured 
dispatch-rate which will cause backlog on the topic and consumers will never be 
able to catch up the backlog unless user again reconfigured the dispatch-rate 
based on current publish-rate. Reconfiguring dispatch-rate based on 
publish-rate requires human interaction and monitoring. Therefore, we need a 
mechanism to configure dispatch rate relative [...]
+
+## Dispatch rate-limiting relative to publish rate
+
+Dispatch rate-limiting relative to current publish-rate allows broker to 
adjust dispatch-rate dynamically based on current publish-rate which still 
throttles dispatch but additionally it gives an opportunity to consumers to 
catch up with backlog.
+
+User should be able to configure relative dispatch rate-limiting using the 
same distpatch-rate-limit admin-api but by passing additional 
relative-throttling flag in input. If user always wants to dispatch 200 
messages more than current publish rate then user will set dispatch-rate as 200 
messages with additional flag for relative throttling. Relative throttling will 
make sure that broker will always dispatch 200 messages more than current 
published rate. For example: if current published [...]
+
+### Broker changes
+In order to support, relative dispatch rate-limiting, broker needs to know the 
latest publish rate on the topic and periodically adjust permits for 
dispatcher’s rate-limiter accordingly. Broker will reuse existing dispatch 
rate-limiting framework and will add relative dispatch throttling enhancement 
on top of it.
+
+ 
+ Namespace throttling configuration
+(a) With below configuration, broker will try to dispatch 1000 messages more 
than current publish-rate for each topic under the given namespace.
+```
+pulsar-admin namespaces  set-dispatch-rate 
--msg-dispatch-rate 1000 --relative-to-publish-rate
+```
+
+And with below configuration, broker will try to dispatch 1000 messages more 
than current publish-rate for each subscriber of topic under the given namespace
+```
+pulsar-admin namespaces  
set-subscription-dispatch-rate --msg-dispatch-rate 1000 
--relative-to-publish-rate
+```
+
+(b) With below configuration, broker will try to dispatch 1000 bytes more than 
current publish-rate for each topic under the given namespace.
+```
+pulsar-admin namespaces  set-dispatch-rate 
--byte-dispatch-rate 1000 --relative-to-publish-rate
+```
+
+And with below configuration, broker will try to dispatch 1000 bytes more than 
current publish-rate for each subscriber of topic under the given namespace
+```
+pulsar-admin namespaces  
set-subscription-dispatch-rate --byte-dispatch-rate 1000 
--relative-to-publish-rate
+```
+
+By default, relative throttling will be disabled for dispatch rate-limiting 
and it can be enabled by passing `relative-to-publish-rate` flag in api.
+



[GitHub] [pulsar] sijie commented on issue #5784: Create load balance znode of broker when znode missed.

2019-12-04 Thread GitBox
sijie commented on issue #5784: Create load balance znode of broker when znode 
missed.
URL: https://github.com/apache/pulsar/pull/5784#issuecomment-561856030
 
 
   run java8 tests


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] sijie commented on issue #5279: Support for python native logging from python wrapper

2019-12-04 Thread GitBox
sijie commented on issue #5279: Support for python native logging from python 
wrapper
URL: https://github.com/apache/pulsar/pull/5279#issuecomment-561847249
 
 
   @BlackJohnny the community is currently deploying a time based release 
schedule. so I move the issue to 2.6.0 since I wasn't sure when this pull 
request will be taken care of as this pull request was made of your master 
branch and I can't change it.


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] Lanayx commented on issue #4931: Cumulative acknowledgement on batched acknowledgements produce unexpected behavior

2019-12-04 Thread GitBox
Lanayx commented on issue #4931: Cumulative acknowledgement on batched 
acknowledgements produce unexpected behavior
URL: https://github.com/apache/pulsar/issues/4931#issuecomment-561810922
 
 
   I want to add a similar behaviour:
   Let's say we have 10 messages in a batch sent by some producer, also we have 
MaxRedeliverCount is 1. Consumer acked 9 messages and 1 nacked. 
   **Current behaviour**
   All 10 messages will be redelivered which will lead to double processing of 
9 messages. 
   **Expected behavior**
   Only 1 message should be redelivered
   


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[pulsar-manager] branch master updated: Support third party login for example GitHub (#222)

2019-12-04 Thread sijie
This is an automated email from the ASF dual-hosted git repository.

sijie pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/pulsar-manager.git


The following commit(s) were added to refs/heads/master by this push:
 new 7138028  Support third party login for example GitHub (#222)
7138028 is described below

commit 713802827eb00214f295195de16f1c82351d0499
Author: tuteng 
AuthorDate: Thu Dec 5 03:04:26 2019 +0800

Support third party login for example GitHub (#222)

Fix #14

### Motivation
This pr is used to support Github authentication. Next, I will add support 
for user authorization.

### Modifications

* Support authentication by Github
* Add user table
* Add a third-party login page

### Verifying this change

 Add unit test
---
 build.gradle   |   1 +
 front-end/src/api/socialsignin.js  |  23 
 front-end/src/icons/svg/github.svg |   1 +
 front-end/src/views/login/index.vue|  19 ++-
 front-end/src/views/login/socialsignin.vue |  44 ---
 src/README.md  |  25 
 .../ThirdPartyLoginCallbackController.java | 113 ++
 .../pulsar/manager/dao/UsersRepositoryImpl.java|  62 ++
 .../pulsar/manager/entity/GithubAuthEntity.java|  36 ++
 .../manager/entity/GithubUserInfoEntity.java   | 108 +
 .../pulsar/manager/entity/UserInfoEntity.java  |  38 ++
 .../pulsar/manager/entity/UsersRepository.java |  58 +
 .../manager/interceptor/WebAppConfigurer.java  |   4 +-
 .../apache/pulsar/manager/mapper/UsersMapper.java  |  54 +
 .../manager/service/ThirdPartyLoginService.java|  37 ++
 .../service/impl/GithubLoginServiceImpl.java   | 112 ++
 .../org/apache/pulsar/manager/utils/HttpUtil.java  |  19 ++-
 src/main/resources/META-INF/sql/herddb-schema.sql  |  12 ++
 src/main/resources/META-INF/sql/mysql-schema.sql   |  13 +++
 .../resources/META-INF/sql/postgresql-schema.sql   |  13 +++
 src/main/resources/META-INF/sql/sqlite-schema.sql  |  12 ++
 src/main/resources/application.properties  |  24 +++-
 src/main/resources/templates/index.html|  40 +++
 .../manager/dao/UsersRepositoryImplTest.java   | 100 
 .../service/GithubLoginServiceImplTest.java| 129 +
 25 files changed, 1069 insertions(+), 28 deletions(-)

diff --git a/build.gradle b/build.gradle
index 8c6803e..960354d 100644
--- a/build.gradle
+++ b/build.gradle
@@ -97,6 +97,7 @@ dependencies {
 compile group: 'org.springframework.boot', name: 'spring-boot-devtools', 
version: springBootVersion
 compile group: 'org.springframework.cloud', name: 
'spring-cloud-starter-netflix-zuul', version: springBootVersion
 compile group: 'org.mybatis.spring.boot', name: 
'mybatis-spring-boot-starter', version: springMybatisVersion
+compile group: 'org.springframework.boot', name: 
'spring-boot-starter-thymeleaf', version: springBootVersion
 compile group: 'org.postgresql', name: 'postgresql', version: 
postgresqlVersion
 compile group: 'org.herddb', name: 'herddb-jdbc', version: herddbVersion
 compile group: 'javax.validation', name: 'validation-api', version: 
javaxValidationVersion
diff --git a/front-end/src/api/socialsignin.js 
b/front-end/src/api/socialsignin.js
new file mode 100644
index 000..fee4336
--- /dev/null
+++ b/front-end/src/api/socialsignin.js
@@ -0,0 +1,23 @@
+/*
+ * Licensed under the Apache License, Version 2.0 (the "License");
+ * you may not use this file except in compliance with the License.
+ * You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+import request from '@/utils/request'
+
+const BASE_URL = '/pulsar-manager/third-party-login'
+
+export function getGithubLoginHost() {
+  return request({
+url: BASE_URL + `/github/login`,
+method: 'get'
+  })
+}
diff --git a/front-end/src/icons/svg/github.svg 
b/front-end/src/icons/svg/github.svg
new file mode 100644
index 000..3899712
--- /dev/null
+++ b/front-end/src/icons/svg/github.svg
@@ -0,0 +1 @@
+http://www.w3.org/2000/svg;>GitHub icon{{ 
$t('login.logIn') }}
+  
+Or connect with
+  
 
 
 
@@ -119,6 +122,9 @@ export default {
   destroyed() {
 // window.removeEventListener('hashchange', this.afterQRScan)
   },
+  mounted() {
+window.addEventListener('message', this.handleMessage)
+  },
   methods: {
 showPwd() {
   if 

[GitHub] [pulsar] codelipenghui opened a new pull request #5796: Add Yu to team list.

2019-12-04 Thread GitBox
codelipenghui opened a new pull request #5796: Add Yu to team list.
URL: https://github.com/apache/pulsar/pull/5796
 
 
   ### Motivation
   
   Add Yu Liu to team.js.


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] wmccarley commented on issue #5792: Extend autoSkipNonRecoverableData to apply to missing Schemas in Bookkeeper

2019-12-04 Thread GitBox
wmccarley commented on issue #5792: Extend autoSkipNonRecoverableData to apply 
to missing Schemas in Bookkeeper
URL: https://github.com/apache/pulsar/issues/5792#issuecomment-561682410
 
 
   Yes I will work on a fix


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] yjshen commented on issue #5788: [pulsar-java-client] Decouple partition switch frequency with maxPublishDelay in producer configuration

2019-12-04 Thread GitBox
yjshen commented on issue #5788: [pulsar-java-client] Decouple partition switch 
frequency with maxPublishDelay in producer configuration
URL: https://github.com/apache/pulsar/pull/5788#issuecomment-561669895
 
 
   > The change looks good me, is it possible implement in 
`RoundRobinPartitionMessageRouterImpl`? Looks the batching partition switch 
frequency only works in RoundRobin mode. Please considering whether this 
configuration should in ProducerBuilder.
   
   I think we are exposing the capability of changing partition switch 
frequency to users? If so, the user conf in 
`RoundRobinPartitionMessageRouterImpl` should be fetched from 
`ProducerConfigurationData`?


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] congbobo184 removed a comment on issue #5570: Transaction log implemention

2019-12-04 Thread GitBox
congbobo184 removed a comment on issue #5570: Transaction log implemention
URL: https://github.com/apache/pulsar/pull/5570#issuecomment-561625564
 
 
   run java8 tests


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] congbobo184 removed a comment on issue #5570: Transaction log implemention

2019-12-04 Thread GitBox
congbobo184 removed a comment on issue #5570: Transaction log implemention
URL: https://github.com/apache/pulsar/pull/5570#issuecomment-561625219
 
 
   run cpp tests


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] congbobo184 removed a comment on issue #5570: Transaction log implemention

2019-12-04 Thread GitBox
congbobo184 removed a comment on issue #5570: Transaction log implemention
URL: https://github.com/apache/pulsar/pull/5570#issuecomment-561597473
 
 
   run cpp tests


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] congbobo184 removed a comment on issue #5570: Transaction log implemention

2019-12-04 Thread GitBox
congbobo184 removed a comment on issue #5570: Transaction log implemention
URL: https://github.com/apache/pulsar/pull/5570#issuecomment-561597344
 
 
   run java8 tests


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] congbobo184 commented on issue #5570: Transaction log implemention

2019-12-04 Thread GitBox
congbobo184 commented on issue #5570: Transaction log implemention
URL: https://github.com/apache/pulsar/pull/5570#issuecomment-561625564
 
 
   run java8 tests


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] congbobo184 removed a comment on issue #5570: Transaction log implemention

2019-12-04 Thread GitBox
congbobo184 removed a comment on issue #5570: Transaction log implemention
URL: https://github.com/apache/pulsar/pull/5570#issuecomment-561625200
 
 
   run cpp tests


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] congbobo184 removed a comment on issue #5570: Transaction log implemention

2019-12-04 Thread GitBox
congbobo184 removed a comment on issue #5570: Transaction log implemention
URL: https://github.com/apache/pulsar/pull/5570#issuecomment-561602545
 
 
   run Integration Tests


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] congbobo184 commented on issue #5570: Transaction log implemention

2019-12-04 Thread GitBox
congbobo184 commented on issue #5570: Transaction log implemention
URL: https://github.com/apache/pulsar/pull/5570#issuecomment-561625219
 
 
   run cpp tests


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] congbobo184 commented on issue #5570: Transaction log implemention

2019-12-04 Thread GitBox
congbobo184 commented on issue #5570: Transaction log implemention
URL: https://github.com/apache/pulsar/pull/5570#issuecomment-561625200
 
 
   run cpp tests


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] congbobo184 commented on issue #5680: [transaction-coordinator] Implementation of transaction coordinator client.

2019-12-04 Thread GitBox
congbobo184 commented on issue #5680: [transaction-coordinator] Implementation 
of transaction coordinator client.
URL: https://github.com/apache/pulsar/pull/5680#issuecomment-561605558
 
 
   run cpp tests


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] Jennifer88huang commented on issue #5789: [docs] Fix persistent topics

2019-12-04 Thread GitBox
Jennifer88huang commented on issue #5789: [docs] Fix persistent topics
URL: https://github.com/apache/pulsar/pull/5789#issuecomment-561605741
 
 
   @fangpengcheng95 thank you very much for your contribution.
   Could you please update the PR title and description according to our PR 
template? (Fixes #, and keep only useful info).


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] congbobo184 commented on issue #5570: Transaction log implemention

2019-12-04 Thread GitBox
congbobo184 commented on issue #5570: Transaction log implemention
URL: https://github.com/apache/pulsar/pull/5570#issuecomment-561602545
 
 
   run Integration Tests


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] congbobo184 commented on issue #5570: Transaction log implemention

2019-12-04 Thread GitBox
congbobo184 commented on issue #5570: Transaction log implemention
URL: https://github.com/apache/pulsar/pull/5570#issuecomment-561597473
 
 
   run cpp tests


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] congbobo184 commented on issue #5570: Transaction log implemention

2019-12-04 Thread GitBox
congbobo184 commented on issue #5570: Transaction log implemention
URL: https://github.com/apache/pulsar/pull/5570#issuecomment-561597344
 
 
   run java8 tests


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] Anonymitaet commented on a change in pull request #5791: [Issue 5638][docs] Add explanation about the v1 REST API

2019-12-04 Thread GitBox
Anonymitaet commented on a change in pull request #5791: [Issue 5638][docs] Add 
explanation about the v1 REST API
URL: https://github.com/apache/pulsar/pull/5791#discussion_r353660411
 
 

 ##
 File path: site2/docs/admin-api-overview.md
 ##
 @@ -30,6 +30,14 @@ In this document, examples from each of the three available 
interfaces will be s
 
 Each of Pulsar's three admin interfaces---the 
[`pulsar-admin`](reference-pulsar-admin.md) CLI tool, the [Java admin 
API](/api/admin), and the {@inject: rest:REST:/} API ---requires some special 
setup if you have 
[authentication](security-overview.md#authentication-providers) enabled in your 
Pulsar [instance](reference-terminology.md#instance).
 
+> If you are using an old version of a namespace, you need to use `v1` to 
replace `v2` in the request URL
+if you are requesting the HTTP service directly. If you are using the 
pulsar-admin to request the v1
+service, you will encounter an exception with HTTP code 405 that shows you are 
requesting a not supported
+method in the v1 version. About the supported method in the v1, please refer 
to the
+[v1 Admin 
API](https://github.com/apache/pulsar/tree/master/pulsar-broker/src/main/java/org/apache/pulsar/broker/admin/v1).
+About the old version of a namespace, please refer to the
+[namespace name 
changes](https://github.com/apache/pulsar/wiki/PIP-10:-Remove-cluster-for-namespace-and-topic-names).
 
 Review comment:
   Delete and Move contents


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] Anonymitaet commented on a change in pull request #5791: [Issue 5638][docs] Add explanation about the v1 REST API

2019-12-04 Thread GitBox
Anonymitaet commented on a change in pull request #5791: [Issue 5638][docs] Add 
explanation about the v1 REST API
URL: https://github.com/apache/pulsar/pull/5791#discussion_r353658684
 
 

 ##
 File path: site2/docs/admin-api-overview.md
 ##
 @@ -30,6 +30,14 @@ In this document, examples from each of the three available 
interfaces will be s
 
 Each of Pulsar's three admin interfaces---the 
[`pulsar-admin`](reference-pulsar-admin.md) CLI tool, the [Java admin 
API](/api/admin), and the {@inject: rest:REST:/} API ---requires some special 
setup if you have 
[authentication](security-overview.md#authentication-providers) enabled in your 
Pulsar [instance](reference-terminology.md#instance).
 
+> If you are using an old version of a namespace, you need to use `v1` to 
replace `v2` in the request URL
+if you are requesting the HTTP service directly. If you are using the 
pulsar-admin to request the v1
+service, you will encounter an exception with HTTP code 405 that shows you are 
requesting a not supported
+method in the v1 version. About the supported method in the v1, please refer 
to the
+[v1 Admin 
API](https://github.com/apache/pulsar/tree/master/pulsar-broker/src/main/java/org/apache/pulsar/broker/admin/v1).
+About the old version of a namespace, please refer to the
+[namespace name 
changes](https://github.com/apache/pulsar/wiki/PIP-10:-Remove-cluster-for-namespace-and-topic-names).
+
 
 Review comment:
   I've made some changes based on our discussed before:
   
   1. Add the following note for `REST API` section
   
   ```
   Note: if you are using an old version of a namespace and requesting the HTTP 
service directly, you need to use `v1` to replace `v2` in the request URL.
   For more information about the old version of a namespace, see [namespace 
name 
changes](https://github.com/apache/pulsar/wiki/PIP-10:-Remove-cluster-for-namespace-and-topic-names).
   ```
   
   2. Add the following tip for `pulsar-admin` section
   ```
   Tip: if you are using the pulsar-admin to request `v1`
   service, you will encounter an exception with HTTP code 405 showing that the 
method you are requesting is not supported in `v1`. 
   For more information about the **supported method in `v1`**, see
   [v1 Admin 
API](https://github.com/apache/pulsar/tree/master/pulsar-broker/src/main/java/org/apache/pulsar/broker/admin/v1).
   ```


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] tuteng commented on issue #5716: [Issues 5709]remove the namespace checking

2019-12-04 Thread GitBox
tuteng commented on issue #5716: [Issues 5709]remove the namespace checking
URL: https://github.com/apache/pulsar/pull/5716#issuecomment-561563902
 
 
   run java8 tests


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] jiazhai commented on issue #5716: [Issues 5709]remove the namespace checking

2019-12-04 Thread GitBox
jiazhai commented on issue #5716: [Issues 5709]remove the namespace checking
URL: https://github.com/apache/pulsar/pull/5716#issuecomment-561547330
 
 
   retest this please


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] congbobo184 commented on issue #5782: Modify the logical in producer carry a schema to connect broker with isAllowAutoUpdateSchema.

2019-12-04 Thread GitBox
congbobo184 commented on issue #5782: Modify the logical in producer carry a 
schema to connect broker with isAllowAutoUpdateSchema. 
URL: https://github.com/apache/pulsar/pull/5782#issuecomment-561543810
 
 
   run Integration Tests


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] congbobo184 removed a comment on issue #5782: Modify the logical in producer carry a schema to connect broker with isAllowAutoUpdateSchema.

2019-12-04 Thread GitBox
congbobo184 removed a comment on issue #5782: Modify the logical in producer 
carry a schema to connect broker with isAllowAutoUpdateSchema. 
URL: https://github.com/apache/pulsar/pull/5782#issuecomment-561543810
 
 
   run Integration Tests


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] congbobo184 removed a comment on issue #5782: Modify the logical in producer carry a schema to connect broker with isAllowAutoUpdateSchema.

2019-12-04 Thread GitBox
congbobo184 removed a comment on issue #5782: Modify the logical in producer 
carry a schema to connect broker with isAllowAutoUpdateSchema. 
URL: https://github.com/apache/pulsar/pull/5782#issuecomment-561492611
 
 
   run java8 tests


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] congbobo184 removed a comment on issue #5782: Modify the logical in producer carry a schema to connect broker with isAllowAutoUpdateSchema.

2019-12-04 Thread GitBox
congbobo184 removed a comment on issue #5782: Modify the logical in producer 
carry a schema to connect broker with isAllowAutoUpdateSchema. 
URL: https://github.com/apache/pulsar/pull/5782#issuecomment-561543701
 
 
   run  Integration Tests 


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] congbobo184 commented on issue #5782: Modify the logical in producer carry a schema to connect broker with isAllowAutoUpdateSchema.

2019-12-04 Thread GitBox
congbobo184 commented on issue #5782: Modify the logical in producer carry a 
schema to connect broker with isAllowAutoUpdateSchema. 
URL: https://github.com/apache/pulsar/pull/5782#issuecomment-561543701
 
 
   run  Integration Tests 


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] BlackJohnny commented on issue #5279: Support for python native logging from python wrapper

2019-12-04 Thread GitBox
BlackJohnny commented on issue #5279: Support for python native logging from 
python wrapper
URL: https://github.com/apache/pulsar/pull/5279#issuecomment-561536275
 
 
   > @BlackJohnny do you mind rebasing this pull request to latest master to 
include some of the test fixes? I can't do it since you are creating a pull 
request based on the master of your fork.
   
   Done. Is it moved to 2.6 because of my late reaction?


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services


[GitHub] [pulsar] zymap commented on issue #5791: [Issue: #5638] Add explanation about the v1 REST API

2019-12-04 Thread GitBox
zymap commented on issue #5791: [Issue: #5638] Add explanation about the v1 
REST API
URL: https://github.com/apache/pulsar/pull/5791#issuecomment-561530018
 
 
   @jiazhai @sijie @Jennifer88huang @codelipenghui PTAL. Thanks


This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services