[jira] [Resolved] (KAFKA-12524) Remove deprecated WindowBytesStoreSupplier#segments

2021-03-27 Thread Guozhang Wang (Jira)


 [ 
https://issues.apache.org/jira/browse/KAFKA-12524?page=com.atlassian.jira.plugin.system.issuetabpanels:all-tabpanel
 ]

Guozhang Wang resolved KAFKA-12524.
---
Resolution: Fixed

> Remove deprecated WindowBytesStoreSupplier#segments
> ---
>
> Key: KAFKA-12524
> URL: https://issues.apache.org/jira/browse/KAFKA-12524
> Project: Kafka
>  Issue Type: Sub-task
>  Components: streams
>Reporter: Guozhang Wang
>Assignee: Guozhang Wang
>Priority: Major
>




--
This message was sent by Atlassian Jira
(v8.3.4#803005)


[jira] [Created] (KAFKA-12568) Remove deprecated "KStream#groupBy/join", "Joined#named" overloads

2021-03-27 Thread Guozhang Wang (Jira)
Guozhang Wang created KAFKA-12568:
-

 Summary: Remove deprecated "KStream#groupBy/join", "Joined#named" 
overloads
 Key: KAFKA-12568
 URL: https://issues.apache.org/jira/browse/KAFKA-12568
 Project: Kafka
  Issue Type: Sub-task
Reporter: Guozhang Wang






--
This message was sent by Atlassian Jira
(v8.3.4#803005)


[GitHub] [kafka-site] Ambuj8105 edited a comment on pull request #342:  Please add Knoldus Inc. (https://www.knoldus.com/) to the list of the "Powered By ❤️".

2021-03-27 Thread GitBox


Ambuj8105 edited a comment on pull request #342:
URL: https://github.com/apache/kafka-site/pull/342#issuecomment-808821955


   Hi @hachikuji can please review this pr  and help me adding Knoldus Inc to 
powered-by page .


-- 
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




[GitHub] [kafka-site] Ambuj8105 edited a comment on pull request #342:  Please add Knoldus Inc. (https://www.knoldus.com/) to the list of the "Powered By ❤️".

2021-03-27 Thread GitBox


Ambuj8105 edited a comment on pull request #342:
URL: https://github.com/apache/kafka-site/pull/342#issuecomment-808821955


   Hi @hachikuji can please review this pr  and help me adding Knoldus Inc to 
powered-by page. 


-- 
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




[GitHub] [kafka-site] Ambuj8105 edited a comment on pull request #342:  Please add Knoldus Inc. (https://www.knoldus.com/) to the list of the "Powered By ❤️".

2021-03-27 Thread GitBox


Ambuj8105 edited a comment on pull request #342:
URL: https://github.com/apache/kafka-site/pull/342#issuecomment-808821955


   Hi @hachikuji can please review this pr  and help me adding Knoldus Inc to 
powered-by page. 


-- 
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




[GitHub] [kafka-site] Ambuj8105 commented on pull request #342:  Please add Knoldus Inc. (https://www.knoldus.com/) to the list of the "Powered By ❤️".

2021-03-27 Thread GitBox


Ambuj8105 commented on pull request #342:
URL: https://github.com/apache/kafka-site/pull/342#issuecomment-808821955


   Hi @hachikuji can please review this or or and help me adding Knoldus Inc to 
powered-by page. 


-- 
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




[GitHub] [kafka-site] Ambuj8105 edited a comment on pull request #342:  Please add Knoldus Inc. (https://www.knoldus.com/) to the list of the "Powered By ❤️".

2021-03-27 Thread GitBox


Ambuj8105 edited a comment on pull request #342:
URL: https://github.com/apache/kafka-site/pull/342#issuecomment-808821955


   Hi @hachikuji can please review this pr or and help me adding Knoldus Inc to 
powered-by page. 


-- 
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




[jira] [Resolved] (KAFKA-12564) KTable#filter-method called twice after aggregation

2021-03-27 Thread Matthias J. Sax (Jira)


 [ 
https://issues.apache.org/jira/browse/KAFKA-12564?page=com.atlassian.jira.plugin.system.issuetabpanels:all-tabpanel
 ]

Matthias J. Sax resolved KAFKA-12564.
-
Resolution: Not A Bug

> KTable#filter-method called twice after aggregation
> ---
>
> Key: KAFKA-12564
> URL: https://issues.apache.org/jira/browse/KAFKA-12564
> Project: Kafka
>  Issue Type: Bug
>  Components: streams
>Affects Versions: 2.7.0
>Reporter: Jessica Johann
>Priority: Major
>
> Libraries from build.sbt:
> {{"org.apache.kafka" % "kafka_2.13" % "2.7.0",}}
> {{"org.apache.kafka" % "kafka-streams" % "2.7.0",}}
> {{"org.apache.kafka" % "kafka-clients" % "2.7.0",}}
> {{"org.apache.kafka" % "kafka-streams-scala_2.13" % "2.7.0",}}
> h4.  
> h4. Feed the Stream "issue_stream" with:
> {{(1->"A")}}
>  {{(1->"B")}}
> h4.  
> h4. Topology:
> {{// #1}}
>  {{val issueStream:KStream[Int,String] = 
> builder.stream[Int,String]("issue_stream")}}
>  
> {{// #2}}
>  {{val aggTable:KTable[Int,String] =}}
>  {{issueStream}}
>  {{.groupBy((k,v)=>k)}}
>  {{.aggregate[String]("EMPTY")((k,v,agg)=>s"$agg+$v")}}
>  
> {{// #3}}
>  {{aggTable}}
>  {{.toStream}}
>  {{.print(Printed.toSysOut)}}
>  
> {{// #4}}
>  {{aggTable.filter((k,v)=> {}}
>  {{  println(s"filter($k, $v) at ${System.nanoTime()}")}}
>  {{  true}}
>  {{})}}
>  {{.toStream}}
>  {{.print(Printed.toSysOut)}}
> h4.  
> h4. First Tuple: (1->"A")
> #3 Output as expected, the aggregated tuple ("EMPTY"+"+A")
> {{[KTABLE-TOSTREAM-44]: 1, EMPTY+A}}
>  
> #4 The filter-method is called twice.
>  First call with the expected tuple.
> {{filter(1, EMPTY+A) at 211379567071847}}
> The second call with the empty initialized aggregate.
> {{filter(1, EMPTY) at 211379567120375}}
> Output contains the correct tuple
> {{[KTABLE-TOSTREAM-47]: 1, EMPTY+A}}
> h4.  
> h4. Second Tuple: (1->"B")
> #3 Output as expected the aggregated tuple ("EMPTY"+"+A"+"+B")
> {{[KTABLE-TOSTREAM-44]: 1, EMPTY+A+B}}
> #4 Again a second unexpected call to filter(...) with the previous tuple 
> before aggregation
>  First call:
> {{filter(1, EMPTY+A+B) at 211379567498482}}
> Second call:
> {{filter(1, EMPTY+A) at 211379567524475}}
> But the output contains only one tuple as expected
> {{[KTABLE-TOSTREAM-47]: 1, EMPTY+A+B}}



--
This message was sent by Atlassian Jira
(v8.3.4#803005)


[jira] [Created] (KAFKA-12567) Flaky Test TransactionsTest.testFencingOnCommit

2021-03-27 Thread Matthias J. Sax (Jira)
Matthias J. Sax created KAFKA-12567:
---

 Summary: Flaky Test TransactionsTest.testFencingOnCommit
 Key: KAFKA-12567
 URL: https://issues.apache.org/jira/browse/KAFKA-12567
 Project: Kafka
  Issue Type: Test
  Components: core, unit tests
Reporter: Matthias J. Sax


{quote}org.opentest4j.AssertionFailedError: Consumed 0 records before timeout 
instead of the expected 2 records at 
org.junit.jupiter.api.AssertionUtils.fail(AssertionUtils.java:39) at 
org.junit.jupiter.api.Assertions.fail(Assertions.java:117) at 
kafka.utils.TestUtils$.pollUntilAtLeastNumRecords(TestUtils.scala:852) at 
kafka.utils.TestUtils$.consumeRecords(TestUtils.scala:1476) at 
kafka.api.TransactionsTest.testFencingOnCommit(TransactionsTest.scala:331){quote}
STDOUT (all of those line appear multiple times throwout the test)
{quote}[2021-03-24 18:29:44,013] ERROR [ZooKeeperClient] Auth failed. 
(kafka.zookeeper.ZooKeeperClient:74)

...

[2021-03-24 18:29:46,251] WARN [ReplicaFetcher replicaId=2, leaderId=0, 
fetcherId=0] Received UNKNOWN_TOPIC_OR_PARTITION from the leader for partition 
topic2-0. This error may be returned transiently when the partition is being 
created or deleted, but it is not expected to persist. 
(kafka.server.ReplicaFetcherThread:70)

...

[2021-03-24 18:29:46,326] WARN Error registering AppInfo mbean 
(org.apache.kafka.common.utils.AppInfoParser:68) 
javax.management.InstanceAlreadyExistsException: 
kafka.producer:type=app-info,id=producer-transactional-producer at 
com.sun.jmx.mbeanserver.Repository.addMBean(Repository.java:437) at 
com.sun.jmx.interceptor.DefaultMBeanServerInterceptor.registerWithRepository(DefaultMBeanServerInterceptor.java:1898)
 at 
com.sun.jmx.interceptor.DefaultMBeanServerInterceptor.registerDynamicMBean(DefaultMBeanServerInterceptor.java:966)
 at 
com.sun.jmx.interceptor.DefaultMBeanServerInterceptor.registerObject(DefaultMBeanServerInterceptor.java:900)
 at 
com.sun.jmx.interceptor.DefaultMBeanServerInterceptor.registerMBean(DefaultMBeanServerInterceptor.java:324)
 at 
com.sun.jmx.mbeanserver.JmxMBeanServer.registerMBean(JmxMBeanServer.java:522) 
at 
org.apache.kafka.common.utils.AppInfoParser.registerAppInfo(AppInfoParser.java:64)
 at 
org.apache.kafka.clients.producer.KafkaProducer.(KafkaProducer.java:434) 
at 
org.apache.kafka.clients.producer.KafkaProducer.(KafkaProducer.java:291) 
at 
org.apache.kafka.clients.producer.KafkaProducer.(KafkaProducer.java:318) 
at kafka.utils.TestUtils$.createTransactionalProducer(TestUtils.scala:1518) at 
kafka.api.TransactionsTest.createTransactionalProducer(TransactionsTest.scala:775)
 at kafka.api.TransactionsTest.$anonfun$setUp$1(TransactionsTest.scala:69) at 
kafka.api.TransactionsTest.$anonfun$setUp$1$adapted(TransactionsTest.scala:68) 
at scala.collection.immutable.Range.foreach(Range.scala:190) at 
kafka.api.TransactionsTest.setUp(TransactionsTest.scala:68)

...

[2021-03-24 18:29:46,810] WARN [ReplicaFetcher replicaId=1, leaderId=0, 
fetcherId=0] Error in response for fetch request (type=FetchRequest, 
replicaId=1, maxWait=500, minBytes=1, maxBytes=10485760, 
fetchData=\{topic2-3=PartitionData(fetchOffset=0, logStartOffset=0, 
maxBytes=1048576, currentLeaderEpoch=Optional[0], 
lastFetchedEpoch=Optional.empty), topic2-0=PartitionData(fetchOffset=0, 
logStartOffset=0, maxBytes=1048576, currentLeaderEpoch=Optional[0], 
lastFetchedEpoch=Optional.empty), 
__transaction_state-1=PartitionData(fetchOffset=0, logStartOffset=0, 
maxBytes=1048576, currentLeaderEpoch=Optional[0], 
lastFetchedEpoch=Optional.empty)}, isolationLevel=READ_UNCOMMITTED, toForget=, 
metadata=(sessionId=1510423728, epoch=1), rackId=) 
(kafka.server.ReplicaFetcherThread:72) java.io.IOException: Connection to 0 was 
disconnected before the response was read at 
org.apache.kafka.clients.NetworkClientUtils.sendAndReceive(NetworkClientUtils.java:100)
 at 
kafka.server.ReplicaFetcherBlockingSend.sendRequest(ReplicaFetcherBlockingSend.scala:110)
 at 
kafka.server.ReplicaFetcherThread.fetchFromLeader(ReplicaFetcherThread.scala:217)
 at 
kafka.server.AbstractFetcherThread.processFetchRequest(AbstractFetcherThread.scala:313)
 at 
kafka.server.AbstractFetcherThread.$anonfun$maybeFetch$3(AbstractFetcherThread.scala:137)
 at 
kafka.server.AbstractFetcherThread.$anonfun$maybeFetch$3$adapted(AbstractFetcherThread.scala:136)
 at scala.Option.foreach(Option.scala:437) at 
kafka.server.AbstractFetcherThread.maybeFetch(AbstractFetcherThread.scala:136) 
at kafka.server.AbstractFetcherThread.doWork(AbstractFetcherThread.scala:119) 
at kafka.utils.ShutdownableThread.run(ShutdownableThread.scala:96){quote}



--
This message was sent by Atlassian Jira
(v8.3.4#803005)


[jira] [Created] (KAFKA-12566) Flaky Test MirrorConnectorsIntegrationSSLTest#testReplication

2021-03-27 Thread Matthias J. Sax (Jira)
Matthias J. Sax created KAFKA-12566:
---

 Summary: Flaky Test 
MirrorConnectorsIntegrationSSLTest#testReplication
 Key: KAFKA-12566
 URL: https://issues.apache.org/jira/browse/KAFKA-12566
 Project: Kafka
  Issue Type: Test
  Components: mirrormaker, unit tests
Reporter: Matthias J. Sax


 
{code:java}
org.opentest4j.AssertionFailedError: Condition not met within timeout 2. 
Offsets not translated downstream to primary cluster. ==> expected:  but 
was:  at 
org.junit.jupiter.api.AssertionUtils.fail(AssertionUtils.java:55) at 
org.junit.jupiter.api.AssertTrue.assertTrue(AssertTrue.java:40) at 
org.junit.jupiter.api.Assertions.assertTrue(Assertions.java:193) at 
org.apache.kafka.test.TestUtils.lambda$waitForCondition$3(TestUtils.java:303) 
at 
org.apache.kafka.test.TestUtils.retryOnExceptionWithTimeout(TestUtils.java:351) 
at 
org.apache.kafka.test.TestUtils.retryOnExceptionWithTimeout(TestUtils.java:319) 
at org.apache.kafka.test.TestUtils.waitForCondition(TestUtils.java:300) at 
org.apache.kafka.test.TestUtils.waitForCondition(TestUtils.java:290) at 
org.apache.kafka.connect.mirror.integration.MirrorConnectorsIntegrationBaseTest.testReplication(MirrorConnectorsIntegrationBaseTest.java:289)
{code}
{{LOGs}}
{quote}[2021-03-26 03:28:06,157] ERROR Could not check connector state info. 
(org.apache.kafka.connect.util.clusters.EmbeddedConnectClusterAssertions:420) 
org.apache.kafka.connect.runtime.rest.errors.ConnectRestException: Could not 
read connector state. Error response: \{"error_code":404,"message":"No status 
found for connector MirrorSourceConnector"} at 
org.apache.kafka.connect.util.clusters.EmbeddedConnectCluster.connectorStatus(EmbeddedConnectCluster.java:479)
 at 
org.apache.kafka.connect.util.clusters.EmbeddedConnectClusterAssertions.checkConnectorState(EmbeddedConnectClusterAssertions.java:413)
 at 
org.apache.kafka.connect.util.clusters.EmbeddedConnectClusterAssertions.lambda$assertConnectorAndAtLeastNumTasksAreRunning$16(EmbeddedConnectClusterAssertions.java:286)
 at 
org.apache.kafka.test.TestUtils.lambda$waitForCondition$3(TestUtils.java:303) 
at 
org.apache.kafka.test.TestUtils.retryOnExceptionWithTimeout(TestUtils.java:351) 
at 
org.apache.kafka.test.TestUtils.retryOnExceptionWithTimeout(TestUtils.java:319) 
at org.apache.kafka.test.TestUtils.waitForCondition(TestUtils.java:300) at 
org.apache.kafka.test.TestUtils.waitForCondition(TestUtils.java:290) at 
org.apache.kafka.connect.util.clusters.EmbeddedConnectClusterAssertions.assertConnectorAndAtLeastNumTasksAreRunning(EmbeddedConnectClusterAssertions.java:285)
 at 
org.apache.kafka.connect.mirror.integration.MirrorConnectorsIntegrationBaseTest.waitUntilMirrorMakerIsRunning(MirrorConnectorsIntegrationBaseTest.java:470)
 at 
org.apache.kafka.connect.mirror.integration.MirrorConnectorsIntegrationBaseTest.testReplication(MirrorConnectorsIntegrationBaseTest.java:227){quote}
and
{quote}[2021-03-26 03:30:41,524] ERROR [MirrorHeartbeatConnector|task-0] 
Graceful stop of task MirrorHeartbeatConnector-0 failed. 
(org.apache.kafka.connect.runtime.Worker:866) [2021-03-26 03:30:41,527] ERROR 
[MirrorHeartbeatConnector|task-0] 
WorkerSourceTask\{id=MirrorHeartbeatConnector-0} failed to send record to 
heartbeats: (org.apache.kafka.connect.runtime.WorkerSourceTask:372) 
org.apache.kafka.common.KafkaException: Producer is closed forcefully. at 
org.apache.kafka.clients.producer.internals.RecordAccumulator.abortBatches(RecordAccumulator.java:750)
 at 
org.apache.kafka.clients.producer.internals.RecordAccumulator.abortIncompleteBatches(RecordAccumulator.java:737)
 at org.apache.kafka.clients.producer.internals.Sender.run(Sender.java:282) at 
java.lang.Thread.run(Thread.java:748) [2021-03-26 03:30:42,248] ERROR 
[MirrorHeartbeatConnector|task-0] 
WorkerSourceTask\{id=MirrorHeartbeatConnector-0} Failed to flush, timed out 
while waiting for producer to flush outstanding 1 messages 
(org.apache.kafka.connect.runtime.WorkerSourceTask:512){quote}
 



--
This message was sent by Atlassian Jira
(v8.3.4#803005)


[DISCUSS] KIP-727 Add --under-preferred-replica-partitions option to describe topics command

2021-03-27 Thread wenbing shen
Hi everyone,

I'd like to discuss the following proposal to add 
--under-preferred-replica-partitions option to describe topics command.

https://cwiki.apache.org/confluence/display/KAFKA/KIP-727%3A+Add+--under-preferred-replica-partitions+option+to+describe+topics+command

Many thanks,

Wenbing


Build failed in Jenkins: Kafka » kafka-2.8-jdk8 #82

2021-03-27 Thread Apache Jenkins Server
See 


Changes:

[A. Sophie Blee-Goldman] KAFKA-12537: fix application shutdown corner case with 
only one thread (#10387)


--
[...truncated 7.24 MB...]

SimpleAclAuthorizerTest > testNoAclFound() STARTED

SimpleAclAuthorizerTest > testNoAclFound() PASSED

SimpleAclAuthorizerTest > testAclInheritance() STARTED

SimpleAclAuthorizerTest > testAclInheritance() PASSED

SimpleAclAuthorizerTest > testDistributedConcurrentModificationOfResourceAcls() 
STARTED

SimpleAclAuthorizerTest > testDistributedConcurrentModificationOfResourceAcls() 
PASSED

SimpleAclAuthorizerTest > testAddAclsOnWildcardResource() STARTED

SimpleAclAuthorizerTest > testAddAclsOnWildcardResource() PASSED

SimpleAclAuthorizerTest > 
testWritesExtendedAclChangeEventWhenInterBrokerProtocolAtLeastKafkaV2() STARTED

SimpleAclAuthorizerTest > 
testWritesExtendedAclChangeEventWhenInterBrokerProtocolAtLeastKafkaV2() PASSED

SimpleAclAuthorizerTest > testAclManagementAPIs() STARTED

SimpleAclAuthorizerTest > testAclManagementAPIs() PASSED

SimpleAclAuthorizerTest > testWildCardAcls() STARTED

SimpleAclAuthorizerTest > testWildCardAcls() PASSED

SimpleAclAuthorizerTest > 
testWritesLiteralAclChangeEventWhenInterBrokerProtocolIsKafkaV2() STARTED

SimpleAclAuthorizerTest > 
testWritesLiteralAclChangeEventWhenInterBrokerProtocolIsKafkaV2() PASSED

SimpleAclAuthorizerTest > testTopicAcl() STARTED

SimpleAclAuthorizerTest > testTopicAcl() PASSED

SimpleAclAuthorizerTest > testSuperUserHasAccess() STARTED

SimpleAclAuthorizerTest > testSuperUserHasAccess() PASSED

SimpleAclAuthorizerTest > testDeleteAclOnPrefixedResource() STARTED

SimpleAclAuthorizerTest > testDeleteAclOnPrefixedResource() PASSED

SimpleAclAuthorizerTest > testDenyTakesPrecedence() STARTED

SimpleAclAuthorizerTest > testDenyTakesPrecedence() PASSED

SimpleAclAuthorizerTest > testSingleCharacterResourceAcls() STARTED

SimpleAclAuthorizerTest > testSingleCharacterResourceAcls() PASSED

SimpleAclAuthorizerTest > testNoAclFoundOverride() STARTED

SimpleAclAuthorizerTest > testNoAclFoundOverride() PASSED

SimpleAclAuthorizerTest > testEmptyAclThrowsException() STARTED

SimpleAclAuthorizerTest > testEmptyAclThrowsException() PASSED

SimpleAclAuthorizerTest > testSuperUserWithCustomPrincipalHasAccess() STARTED

SimpleAclAuthorizerTest > testSuperUserWithCustomPrincipalHasAccess() PASSED

SimpleAclAuthorizerTest > testAllowAccessWithCustomPrincipal() STARTED

SimpleAclAuthorizerTest > testAllowAccessWithCustomPrincipal() PASSED

SimpleAclAuthorizerTest > testDeleteAclOnWildcardResource() STARTED

SimpleAclAuthorizerTest > testDeleteAclOnWildcardResource() PASSED

SimpleAclAuthorizerTest > 
testWritesLiteralWritesLiteralAclChangeEventWhenInterBrokerProtocolLessThanKafkaV2eralAclChangesForOlderProtocolVersions()
 STARTED

SimpleAclAuthorizerTest > 
testWritesLiteralWritesLiteralAclChangeEventWhenInterBrokerProtocolLessThanKafkaV2eralAclChangesForOlderProtocolVersions()
 PASSED

SimpleAclAuthorizerTest > 
testThrowsOnAddPrefixedAclIfInterBrokerProtocolVersionTooLow() STARTED

SimpleAclAuthorizerTest > 
testThrowsOnAddPrefixedAclIfInterBrokerProtocolVersionTooLow() PASSED

SimpleAclAuthorizerTest > testAccessAllowedIfAllowAclExistsOnPrefixedResource() 
STARTED

SimpleAclAuthorizerTest > testAccessAllowedIfAllowAclExistsOnPrefixedResource() 
PASSED

SimpleAclAuthorizerTest > testHighConcurrencyModificationOfResourceAcls() 
STARTED

SimpleAclAuthorizerTest > testHighConcurrencyModificationOfResourceAcls() PASSED

SimpleAclAuthorizerTest > testAuthorizeWithEmptyResourceName() STARTED

SimpleAclAuthorizerTest > testAuthorizeWithEmptyResourceName() PASSED

SimpleAclAuthorizerTest > testAuthorizeThrowsOnNonLiteralResource() STARTED

SimpleAclAuthorizerTest > testAuthorizeThrowsOnNonLiteralResource() PASSED

SimpleAclAuthorizerTest > testDeleteAllAclOnPrefixedResource() STARTED

SimpleAclAuthorizerTest > testDeleteAllAclOnPrefixedResource() PASSED

SimpleAclAuthorizerTest > testAddAclsOnLiteralResource() STARTED

SimpleAclAuthorizerTest > testAddAclsOnLiteralResource() PASSED

SimpleAclAuthorizerTest > testGetAclsPrincipal() STARTED

SimpleAclAuthorizerTest > testGetAclsPrincipal() PASSED

SimpleAclAuthorizerTest > testAddAclsOnPrefiexedResource() STARTED

SimpleAclAuthorizerTest > testAddAclsOnPrefiexedResource() PASSED

SimpleAclAuthorizerTest > 
testWritesExtendedAclChangeEventIfInterBrokerProtocolNotSet() STARTED

SimpleAclAuthorizerTest > 
testWritesExtendedAclChangeEventIfInterBrokerProtocolNotSet() PASSED

SimpleAclAuthorizerTest > testAccessAllowedIfAllowAclExistsOnWildcardResource() 
STARTED

SimpleAclAuthorizerTest > testAccessAllowedIfAllowAclExistsOnWildcardResource() 
PASSED

SimpleAclAuthorizerTest > testLoadCache() STARTED

SimpleAclAuthorizerTest > testLoadCache() PASSED

OperationTest > testJavaConversions() STARTED

OperationTest > testJavaConversions() 

Jenkins build is back to normal : Kafka » kafka-trunk-jdk8 #611

2021-03-27 Thread Apache Jenkins Server
See