You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ratis.apache.org by lj...@apache.org on 2019/09/06 17:55:26 UTC

[incubator-ratis] branch ratis-ozone updated (2337318 -> 78e95b9)

This is an automated email from the ASF dual-hosted git repository.

ljain pushed a change to branch ratis-ozone
in repository https://gitbox.apache.org/repos/asf/incubator-ratis.git.


    from 2337318  RATIS-604. OrderedRequestStreamObserver does not cleanup when responding error.  Contributed by Lokesh Jain
     add 87557f7  RATIS-465. Add docker support for running filestore example. Contributed by Mukul Kumar Singh.
     add b5b0ff2  RATIS-600. Better logging for installSnapshot.
     add eb3feb5  RATIS-605. Change RaftServerImpl and proto to use RaftGroupMemberId.
     add 0d11cd4  RATIS-594 RATIS-593 RATIS-551 Add HadoopMetrics2Adaptor for dropwizard metrics and Graphite container for log service
     add 74da307  RATIS-541 Add option to verify correctness of batch and mix of batch and single updates data from LogService in VerficiationTool(Rajeshbabu)
     add c2a6a24  RATIS-588 LogStream StateMachine export
     add 0ddf4ba  RATIS-611. Add a test for InstallSnapshotNotification with follower restart.
     add 2f12607  RATIS-625. LogSegment#append leaks entryCache when the entries are loaded on a restart.  Contributed by Mukul Kumar Singh
     add d4f5c9d  RATIS-626. Add missing license in TestArchiveHdfsLogReaderAndWriter.  Contributed by Ankit Singhal
     add 7c7cd28  RATIS-596. Rename raft.server.leader.election.timeout.
     add d0edef3  RATIS-621. Metrics subproject is not included in the release tar. Contributed by Marton Elek. (#27)
     add 96351eb  RATIS-628. Simplify the code in LogSegment. Contributed by Tsz Wo Nicholas Sze.
     add 08aa862  RATIS-606. GrpcService should use SO_REUSEADDR flag. Contributed by Mukul Kumar Singh.
     add 5dc4e71  RATIS-642. Bump the copyright year of the NOTICE.txt. Contributed by Mukul Kumar Singh.
     add 81644cc  RATIS-643. Allow Ratis to take a configurable snapshot retention policy. Contributed by Aravindan Vijayan.
     add 499f1d8  RATIS-578. Illegal State transition in LeaderElection.
     add 7ef5115  RATIS-642. Bump the copyright year of the NOTICE.txt. Contributed by Mukul Kumar Singh.
     add 4c11031  RATIS-609. Change RaftLog to use RaftGroupMemberId.
     add 2739b4e  RATIS-654. Fix generation LICENSE and NOTICE for third-party dependencies.  Contributed by Ankit Singhal
     add f401c7a  RATIS-658. ratis-assembly does not include ratis-resource-bundle. Contributed by Mukul Kumar Singh.
     add 021165f  RATIS-629. Vagrant loadgen does not run
     add 30bafb7  RATIS-651. Add metrics related to leaderElection and HeartBeat. Contributed by  Aravindan Vijayan.
     add 2386b1a  RATIS-669. Allow Ratis gRPCTlsConfig to take Java Key/Cert Object in addition to File. Contributed by Xiaoyu Yao. (#33)
     add 0793e9b  RATIS-661. Add call in state machine to handle group removal.  Contributed by Lokesh Jain
     add 48239a7  RATIS-659. StateMachineUpdater#stopAndJoin might not take snapshot due to race condition.  Contributed by Lokesh Jain
     add 78e95b9  RATIS-485. TimeoutScheduler is leaked by gRPC client implementation.  Contributed by Tsz Wo Nicholas Sze and Josh Elser

No new revisions were added by this update.

Summary of changes:
 LICENSE                                            |   23 +
 NOTICE                                             |   24 +-
 dev-support/vagrant/bin/start_ratis_load_gen.sh    |    4 +-
 dev-support/vagrant/bin/start_ratis_server.sh      |    2 +-
 pom.xml                                            |   95 +-
 ratis-assembly/pom.xml                             |   66 +-
 ratis-assembly/src/main/assembly/bin.xml           |   28 +-
 .../main/assembly/{bin.xml => examples-bin.xml}    |   34 +-
 ratis-assembly/src/main/assembly/src.xml           |    2 +
 ratis-assembly/src/main/resources/NOTICE           |   26 +-
 .../apache/ratis/client/RaftClientConfigKeys.java  |   10 -
 .../apache/ratis/client/impl/ClientProtoUtils.java |   29 +-
 .../apache/ratis/client/impl/RaftClientImpl.java   |    8 +-
 .../ratis/client/impl/RaftClientTestUtil.java      |    4 -
 .../ratis/protocol/LeaderNotReadyException.java    |   14 +-
 .../apache/ratis/protocol/NotLeaderException.java  |    5 +-
 .../org/apache/ratis/protocol/RaftClientReply.java |    7 +
 .../apache/ratis/protocol/RaftGroupMemberId.java   |   71 +
 .../ratis/protocol/StateMachineException.java      |    4 +-
 .../java/org/apache/ratis/util/PeerProxyMap.java   |    5 +-
 .../java/org/apache/ratis/util/ProtoUtils.java     |   16 +
 .../org/apache/ratis/util/TimeoutScheduler.java    |   80 +-
 ratis-examples/src/main/docker/Dockerfile          |   39 +
 ratis-examples/src/main/docker/docker-compose.yaml |   63 +
 .../ratis/examples/filestore/cli/Client.java       |    1 -
 .../java/org/apache/ratis/grpc/GrpcTlsConfig.java  |   52 +-
 .../grpc/client/GrpcClientProtocolClient.java      |   19 +-
 .../apache/ratis/grpc/server/GrpcLogAppender.java  |   66 +-
 .../grpc/server/GrpcServerProtocolClient.java      |   13 +-
 .../grpc/server/GrpcServerProtocolService.java     |  164 +-
 .../org/apache/ratis/grpc/server/GrpcService.java  |   15 +-
 ratis-logservice/docker-compose.yml                |   12 +
 ratis-logservice/pom.xml                           |   39 +
 ratis-logservice/src/assembly/assembly.xml         |    1 +
 .../ratis/logservice/api/ArchiveLogReader.java     |   12 +-
 .../api/{LogMessage.java => ArchiveLogWriter.java} |   28 +-
 .../org/apache/ratis/logservice/api/LogReader.java |    4 +-
 .../org/apache/ratis/logservice/api/LogStream.java |   24 +-
 .../ratis/logservice/client/LogServiceClient.java  |  120 +-
 .../apache/ratis/logservice/common/Constants.java  |    1 +
 .../logservice/impl/ArchiveHdfsLogReader.java      |  215 ++
 .../logservice/impl/ArchiveHdfsLogWriter.java      |  112 +
 .../logservice/impl/ArchivedLogStreamImpl.java     |  138 +
 .../logservice/impl/ExportedLogStreamImpl.java     |   20 +-
 .../ratis/logservice/impl/LogStreamImpl.java       |   12 +-
 .../metrics/LogServiceMetricsRegistry.java         |   49 +-
 .../ratis/logservice/server/ArchivalInfo.java      |   95 +
 .../apache/ratis/logservice/server/LogServer.java  |    6 +-
 .../logservice/server/LogServiceRaftLogReader.java |   14 +-
 .../ratis/logservice/server/LogStateMachine.java   |  375 ++-
 .../ratis/logservice/server/MetaStateMachine.java  |   22 +-
 .../ratis/logservice/server/RaftLogReader.java     |   53 +-
 .../ratis/logservice/shell/CommandFactory.java     |    4 +
 ...eleteLogCommand.java => ArchiveLogCommand.java} |   16 +-
 ...CreateLogCommand.java => ExportLogCommand.java} |   18 +-
 .../ratis/logservice/tool/VerificationTool.java    |  126 +-
 .../ratis/logservice/util/LogServiceProtoUtil.java |   61 +-
 .../ratis/logservice/util/LogServiceUtils.java     |   20 +
 .../logservice/util/MetaServiceProtoUtil.java      |    9 -
 ratis-logservice/src/main/proto/LogService.proto   |   44 +-
 ratis-logservice/src/main/proto/MetaService.proto  |    8 -
 .../ratis/logservice/LogServiceReadWriteBase.java  |   13 +-
 .../impl/TestArchiveHdfsLogReaderAndWriter.java    |  170 ++
 .../ratis/logservice/server/TestMetaServer.java    |  119 +-
 .../logservice/util/TestLogServiceProtoUtil.java   |    7 +-
 .../src/test/resources/hadoop-metrics2.properties  |   56 +
 .../src/test/resources/logservice.xml              |   20 +-
 ratis-metrics/pom.xml                              |   18 +
 .../java/org/apache/ratis/metrics/JVMMetrics.java  |   46 +
 .../org/apache/ratis/metrics/MetricRegistries.java |    3 -
 .../ratis/metrics/MetricRegistryFactory.java       |    3 -
 .../apache/ratis/metrics/MetricRegistryInfo.java   |   45 +-
 .../org/apache/ratis/metrics/MetricsReporting.java |  109 +
 .../apache/ratis/metrics/RatisMetricRegistry.java  |   61 +
 .../ratis/metrics/impl/MetricRegistriesImpl.java   |    2 +-
 .../metrics/impl/MetricRegistryFactoryImpl.java    |    4 +-
 ...cRegistry.java => RatisMetricRegistryImpl.java} |   48 +-
 .../ratis/metrics/TestHadoop2MetricsAdaptor.java   |   75 +
 .../ratis/metrics/TestHadoop2MetricsSink.java      |   33 +-
 .../src/test/resources/hadoop-metrics2.properties  |   44 +
 ratis-proto/src/main/proto/Raft.proto              |    7 +-
 ratis-resource-bundle/pom.xml                      |   69 +
 .../src/main/resources/META-INF/LICENSE.vm         | 2608 +++++++++++++++++
 .../src/main/resources/META-INF/NOTICE.vm          |  372 +++
 .../src/main/resources/supplemental-models.xml     | 3095 ++++++++++++++++++++
 .../apache/ratis/server/RaftServerConfigKeys.java  |   38 +-
 .../org/apache/ratis/server/impl/FollowerInfo.java |    7 +-
 .../apache/ratis/server/impl/FollowerState.java    |    1 +
 .../apache/ratis/server/impl/LeaderElection.java   |   13 +-
 .../org/apache/ratis/server/impl/LeaderState.java  |   25 +-
 .../org/apache/ratis/server/impl/LogAppender.java  |   40 +-
 .../apache/ratis/server/impl/RaftServerImpl.java   |  249 +-
 .../apache/ratis/server/impl/RaftServerProxy.java  |    1 +
 .../org/apache/ratis/server/impl/RoleInfo.java     |    2 +-
 .../apache/ratis/server/impl/ServerProtoUtils.java |   88 +-
 .../org/apache/ratis/server/impl/ServerState.java  |   72 +-
 .../ratis/server/impl/StateMachineUpdater.java     |   42 +-
 .../apache/ratis/server/impl/WatchRequests.java    |    2 +-
 .../ratis/server/metrics/HeartbeatMetrics.java     |   63 +
 .../server/metrics/LeaderElectionMetrics.java      |   58 +
 .../ratis/server/metrics/RatisMetricNames.java     |   22 +-
 .../apache/ratis/server/metrics/RatisMetrics.java  |   45 +-
 .../ratis/server/protocol/RaftServerProtocol.java  |    3 +-
 .../org/apache/ratis/server/raftlog/RaftLog.java   |   38 +-
 .../ratis/server/raftlog/memory/MemoryRaftLog.java |    8 +-
 .../ratis/server/raftlog/segmented/LogSegment.java |  113 +-
 .../server/raftlog/segmented/SegmentedRaftLog.java |  124 +-
 .../raftlog/segmented/SegmentedRaftLogCache.java   |   10 +-
 .../raftlog/segmented/SegmentedRaftLogWorker.java  |   10 +-
 .../apache/ratis/statemachine/StateMachine.java    |    8 +
 .../ratis/statemachine/StateMachineStorage.java    |    2 +
 .../ratis/statemachine/impl/BaseStateMachine.java  |    8 +-
 .../impl/SimpleStateMachineStorage.java            |   49 +-
 ...pshotInfo.java => SnapshotRetentionPolicy.java} |   28 +-
 .../ratis/InstallSnapshotNotificationTests.java    |  130 +-
 .../java/org/apache/ratis/LogAppenderTests.java    |   51 +
 .../java/org/apache/ratis/MiniRaftCluster.java     |   12 +-
 .../test/java/org/apache/ratis/RaftAsyncTests.java |    5 -
 .../apache/ratis/server/ServerRestartTests.java    |    2 +-
 .../ratis/server/impl/LeaderElectionTests.java     |   31 +
 .../impl/RaftStateMachineExceptionTests.java       |   55 +-
 .../server/metrics/TestLeaderElectionMetrics.java  |   89 +
 .../ratis/server/storage/RaftStorageTestUtils.java |    3 +-
 .../ratis/statemachine/RaftSnapshotBaseTest.java   |    2 +-
 ...out.java => TestRaftServerNoLeaderTimeout.java} |   22 +-
 .../ratis/TestRaftServerSlownessDetection.java     |   21 +-
 ...> TestInstallSnapshotNotificationWithGrpc.java} |    6 +-
 .../grpc/TestRaftReconfigurationWithGrpc.java      |    8 +-
 .../ratis/server/raftlog/TestRaftLogMetrics.java   |    2 +-
 .../raftlog/segmented/TestCacheEviction.java       |    9 +-
 .../server/raftlog/segmented/TestLogSegment.java   |   30 +-
 .../raftlog/segmented/TestSegmentedRaftLog.java    |   54 +-
 .../segmented/TestSegmentedRaftLogCache.java       |    7 +-
 .../ratis/server/storage/TestRaftStorage.java      |   75 +
 .../apache/ratis/util/TestTimeoutScheduler.java    |   33 +-
 135 files changed, 10353 insertions(+), 1137 deletions(-)
 copy ratis-assembly/src/main/assembly/{bin.xml => examples-bin.xml} (74%)
 create mode 100644 ratis-common/src/main/java/org/apache/ratis/protocol/RaftGroupMemberId.java
 create mode 100644 ratis-examples/src/main/docker/Dockerfile
 create mode 100644 ratis-examples/src/main/docker/docker-compose.yaml
 copy ratis-common/src/main/java/org/apache/ratis/protocol/ServerNotReadyException.java => ratis-logservice/src/main/java/org/apache/ratis/logservice/api/ArchiveLogReader.java (77%)
 copy ratis-logservice/src/main/java/org/apache/ratis/logservice/api/{LogMessage.java => ArchiveLogWriter.java} (58%)
 create mode 100644 ratis-logservice/src/main/java/org/apache/ratis/logservice/impl/ArchiveHdfsLogReader.java
 create mode 100644 ratis-logservice/src/main/java/org/apache/ratis/logservice/impl/ArchiveHdfsLogWriter.java
 create mode 100644 ratis-logservice/src/main/java/org/apache/ratis/logservice/impl/ArchivedLogStreamImpl.java
 copy ratis-test/src/test/java/org/apache/ratis/netty/TestRaftSnapshotWithNetty.java => ratis-logservice/src/main/java/org/apache/ratis/logservice/impl/ExportedLogStreamImpl.java (64%)
 create mode 100644 ratis-logservice/src/main/java/org/apache/ratis/logservice/server/ArchivalInfo.java
 copy ratis-common/src/main/java/org/apache/ratis/protocol/ClientId.java => ratis-logservice/src/main/java/org/apache/ratis/logservice/server/RaftLogReader.java (50%)
 copy ratis-logservice/src/main/java/org/apache/ratis/logservice/shell/commands/{DeleteLogCommand.java => ArchiveLogCommand.java} (76%)
 copy ratis-logservice/src/main/java/org/apache/ratis/logservice/shell/commands/{CreateLogCommand.java => ExportLogCommand.java} (71%)
 create mode 100644 ratis-logservice/src/test/java/org/apache/ratis/logservice/impl/TestArchiveHdfsLogReaderAndWriter.java
 create mode 100644 ratis-logservice/src/test/resources/hadoop-metrics2.properties
 copy ratis-common/src/main/java/org/apache/ratis/protocol/RaftClientProtocol.java => ratis-logservice/src/test/resources/logservice.xml (72%)
 create mode 100644 ratis-metrics/src/main/java/org/apache/ratis/metrics/JVMMetrics.java
 create mode 100644 ratis-metrics/src/main/java/org/apache/ratis/metrics/MetricsReporting.java
 create mode 100644 ratis-metrics/src/main/java/org/apache/ratis/metrics/RatisMetricRegistry.java
 rename ratis-metrics/src/main/java/org/apache/ratis/metrics/impl/{RatisMetricRegistry.java => RatisMetricRegistryImpl.java} (61%)
 create mode 100644 ratis-metrics/src/test/java/org/apache/ratis/metrics/TestHadoop2MetricsAdaptor.java
 copy ratis-common/src/main/java/org/apache/ratis/protocol/GroupListReply.java => ratis-metrics/src/test/java/org/apache/ratis/metrics/TestHadoop2MetricsSink.java (52%)
 create mode 100644 ratis-metrics/src/test/resources/hadoop-metrics2.properties
 create mode 100644 ratis-resource-bundle/pom.xml
 create mode 100644 ratis-resource-bundle/src/main/resources/META-INF/LICENSE.vm
 create mode 100644 ratis-resource-bundle/src/main/resources/META-INF/NOTICE.vm
 create mode 100644 ratis-resource-bundle/src/main/resources/supplemental-models.xml
 create mode 100644 ratis-server/src/main/java/org/apache/ratis/server/metrics/HeartbeatMetrics.java
 create mode 100644 ratis-server/src/main/java/org/apache/ratis/server/metrics/LeaderElectionMetrics.java
 copy ratis-logservice/src/main/java/org/apache/ratis/logservice/shell/commands/ExitCommand.java => ratis-server/src/main/java/org/apache/ratis/server/metrics/RatisMetricNames.java (58%)
 copy ratis-server/src/main/java/org/apache/ratis/statemachine/impl/{SingleFileSnapshotInfo.java => SnapshotRetentionPolicy.java} (64%)
 rename ratis-test/src/test/java/org/apache/ratis/grpc/TestInstallSnapshotWithGrpc.java => ratis-server/src/test/java/org/apache/ratis/InstallSnapshotNotificationTests.java (58%)
 create mode 100644 ratis-server/src/test/java/org/apache/ratis/server/metrics/TestLeaderElectionMetrics.java
 rename ratis-test/src/test/java/org/apache/ratis/{TestRaftServerLeaderElectionTimeout.java => TestRaftServerNoLeaderTimeout.java} (83%)
 copy ratis-test/src/test/java/org/apache/ratis/grpc/{TestLogAppenderWithGrpc.java => TestInstallSnapshotNotificationWithGrpc.java} (83%)