You are viewing a plain text version of this content. The canonical link for it is here.
Posted to issues@nifi.apache.org by GitBox <gi...@apache.org> on 2021/09/13 11:11:28 UTC

[GitHub] [nifi-minifi-cpp] aminadinari19 opened a new pull request #1173: MINIFICPP-1458-Register and test hidden InvokeHTTP properties

aminadinari19 opened a new pull request #1173:
URL: https://github.com/apache/nifi-minifi-cpp/pull/1173


   Thank you for submitting a contribution to Apache NiFi - MiNiFi C++.
   
   In order to streamline the review of the contribution we ask you
   to ensure the following steps have been taken:
   
   ### For all changes:
   - [X] Is there a JIRA ticket associated with this PR? Is it referenced
        in the commit message?
   
   - [X] Does your PR title start with MINIFICPP-XXXX where XXXX is the JIRA number you are trying to resolve? Pay particular attention to the hyphen "-" character.
   
   - [X] Has your PR been rebased against the latest commit within the target branch (typically main)?
   
   - [ ] Is your initial contribution a single, squashed commit?
   
   ### For code changes:
   - [ ] If adding new dependencies to the code, are these dependencies licensed in a way that is compatible for inclusion under [ASF 2.0](http://www.apache.org/legal/resolved.html#category-a)?
   - [ ] If applicable, have you updated the LICENSE file?
   - [ ] If applicable, have you updated the NOTICE file?
   
   ### For documentation related changes:
   - [ ] Have you ensured that format looks appropriate for the output in which it is rendered?
   
   ### Note:
   Please ensure that once the PR is submitted, you check GitHub Actions CI results for build issues and submit an update to your PR as soon as possible.
   


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

To unsubscribe, e-mail: issues-unsubscribe@nifi.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [nifi-minifi-cpp] aminadinari19 commented on a change in pull request #1173: MINIFICPP-1458-Register and test hidden InvokeHTTP properties

Posted by GitBox <gi...@apache.org>.
aminadinari19 commented on a change in pull request #1173:
URL: https://github.com/apache/nifi-minifi-cpp/pull/1173#discussion_r709073806



##########
File path: docker/test/integration/features/http.feature
##########
@@ -8,7 +8,6 @@ Feature: Sending data using InvokeHTTP to a receiver using ListenHTTP
 
   Scenario: A MiNiFi instance transfers data to another MiNiFi instance with message body
     Given a GetFile processor with the "Input Directory" property set to "/tmp/input"
-    And the "Keep Source File" property of the GetFile processor is set to "true"

Review comment:
       There was no problem but it seemed unnecessary so the change was made to just keep it simple :)




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

To unsubscribe, e-mail: issues-unsubscribe@nifi.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [nifi-minifi-cpp] szaszm commented on a change in pull request #1173: MINIFICPP-1458-Register and test hidden InvokeHTTP properties

Posted by GitBox <gi...@apache.org>.
szaszm commented on a change in pull request #1173:
URL: https://github.com/apache/nifi-minifi-cpp/pull/1173#discussion_r707243044



##########
File path: extensions/http-curl/tests/unit/InvokeHTTPTests.cpp
##########
@@ -306,3 +291,97 @@ TEST_CASE("HTTPTestsPostNoResourceClaim", "[httptest1]") {
   REQUIRE(true == LogTestController::getInstance().contains("Exiting because method is POST"));
   LogTestController::getInstance().reset();
 }
+
+TEST_CASE("HTTPTestsPenalizeNoRetry", "[httptest1]") {
+  TestController testController;
+  using processors::InvokeHTTP;
+
+  std::shared_ptr<core::ContentRepository>
+  content_repo = std::make_shared<core::repository::VolatileContentRepository>();

Review comment:
       This is a single statement. It should be on one line in this case, but in general it can be separated with a new line + continuation indentation (+4 spaces or aligned) if it's too long.

##########
File path: extensions/http-curl/processors/InvokeHTTP.cpp
##########
@@ -443,6 +447,7 @@ void InvokeHTTP::route(const std::shared_ptr<core::FlowFile> &request, const std
   } else {
     if (request != nullptr) {
       if (penalize_no_retry_) {
+        logger_->log_debug("Flowfile has been penalized");
         session->penalize(request);
       }

Review comment:
       ProcessSession::penalize already produces a log message, so I think this is unnecessary.

##########
File path: extensions/http-curl/tests/unit/InvokeHTTPTests.cpp
##########
@@ -306,3 +291,97 @@ TEST_CASE("HTTPTestsPostNoResourceClaim", "[httptest1]") {
   REQUIRE(true == LogTestController::getInstance().contains("Exiting because method is POST"));
   LogTestController::getInstance().reset();
 }
+
+TEST_CASE("HTTPTestsPenalizeNoRetry", "[httptest1]") {
+  TestController testController;
+  using processors::InvokeHTTP;
+
+  std::shared_ptr<core::ContentRepository>
+  content_repo = std::make_shared<core::repository::VolatileContentRepository>();
+  std::shared_ptr<TestRepository> repo = std::make_shared<TestRepository>();
+
+  LogTestController::getInstance().setTrace<org::apache::nifi::minifi::processors::GenerateFlowFile>();
+  LogTestController::getInstance().setTrace<org::apache::nifi::minifi::processors::ListenHTTP>();
+  LogTestController::getInstance().setTrace<org::apache::nifi::minifi::processors::InvokeHTTP>();
+  LogTestController::getInstance().setTrace<minifi::core::ProcessSession>();
+
+  std::shared_ptr<core::Processor>
+  listenhttp = std::make_shared<org::apache::nifi::minifi::processors::ListenHTTP>("listenhttp");

Review comment:
       Same here

##########
File path: docker/test/integration/features/http.feature
##########
@@ -8,7 +8,6 @@ Feature: Sending data using InvokeHTTP to a receiver using ListenHTTP
 
   Scenario: A MiNiFi instance transfers data to another MiNiFi instance with message body
     Given a GetFile processor with the "Input Directory" property set to "/tmp/input"
-    And the "Keep Source File" property of the GetFile processor is set to "true"

Review comment:
       Are these removed because the input files are not used anymore and just to keep things simple? Or was there an actual problem due to processing the same file multiple time? Or what is the reason for this change?

##########
File path: extensions/http-curl/tests/unit/InvokeHTTPTests.cpp
##########
@@ -306,3 +291,97 @@ TEST_CASE("HTTPTestsPostNoResourceClaim", "[httptest1]") {
   REQUIRE(true == LogTestController::getInstance().contains("Exiting because method is POST"));
   LogTestController::getInstance().reset();
 }
+
+TEST_CASE("HTTPTestsPenalizeNoRetry", "[httptest1]") {
+  TestController testController;
+  using processors::InvokeHTTP;
+
+  std::shared_ptr<core::ContentRepository>
+  content_repo = std::make_shared<core::repository::VolatileContentRepository>();
+  std::shared_ptr<TestRepository> repo = std::make_shared<TestRepository>();
+
+  LogTestController::getInstance().setTrace<org::apache::nifi::minifi::processors::GenerateFlowFile>();
+  LogTestController::getInstance().setTrace<org::apache::nifi::minifi::processors::ListenHTTP>();
+  LogTestController::getInstance().setTrace<org::apache::nifi::minifi::processors::InvokeHTTP>();
+  LogTestController::getInstance().setTrace<minifi::core::ProcessSession>();
+
+  std::shared_ptr<core::Processor>
+  listenhttp = std::make_shared<org::apache::nifi::minifi::processors::ListenHTTP>("listenhttp");
+  listenhttp->initialize();
+  std::shared_ptr<core::ProcessorNode> node = std::make_shared<core::ProcessorNode>(listenhttp);
+  std::shared_ptr<core::ProcessContext> context = std::make_shared<core::ProcessContext>(node, nullptr, repo, repo, content_repo);
+  context->setProperty(org::apache::nifi::minifi::processors::ListenHTTP::BasePath, "/testytesttest");
+  context->setProperty(org::apache::nifi::minifi::processors::ListenHTTP::Port, "8681");
+  auto session = std::make_shared<core::ProcessSession>(context);
+  std::shared_ptr<core::ProcessSessionFactory> factory = std::make_shared<core::ProcessSessionFactory>(context);
+  listenhttp->setScheduledState(core::ScheduledState::RUNNING);
+  listenhttp->onSchedule(context, factory);
+  listenhttp->onTrigger(context, session);
+
+  std::shared_ptr<TestPlan> plan = testController.createPlan();
+  std::shared_ptr<core::Processor> genfile = plan->addProcessor("GenerateFlowFile", "genfile");
+  std::shared_ptr<core::Processor> invokehttp = plan->addProcessor("InvokeHTTP", "invokehttp", core::Relationship("success", "description"), true);
+
+  plan->setProperty(invokehttp, org::apache::nifi::minifi::processors::InvokeHTTP::Method.getName(), "GET");
+  plan->setProperty(invokehttp, org::apache::nifi::minifi::processors::InvokeHTTP::URL.getName(), "http://localhost:8681/testytesttest");
+
+  SECTION("with penalize on no retry set to true") {
+    plan->setProperty(invokehttp,
+                      org::apache::nifi::minifi::processors::InvokeHTTP::PenalizeOnNoRetry.getName(),
+                      "true");
+    invokehttp->setAutoTerminatedRelationships({InvokeHTTP::RelFailure, InvokeHTTP::RelNoRetry, InvokeHTTP::RelResponse,
+                                                InvokeHTTP::RelRetry});
+    testController.runSession(plan, true);
+
+    REQUIRE(LogTestController::getInstance().contains("Flowfile has been penalized"));
+  } SECTION("with penalize on no retry set to false") {
+    plan->setProperty(invokehttp,
+                      org::apache::nifi::minifi::processors::InvokeHTTP::PenalizeOnNoRetry.getName(),
+                      "false");
+    invokehttp->setAutoTerminatedRelationships({InvokeHTTP::RelFailure, InvokeHTTP::RelNoRetry, InvokeHTTP::RelResponse,
+                                                InvokeHTTP::RelRetry});
+    testController.runSession(plan, true);
+
+    REQUIRE_FALSE(LogTestController::getInstance().contains("Flowfile has been penalized"));
+  }
+}
+
+TEST_CASE("HTTPTestsPutResponseBodyinAttribute", "[httptest1]") {
+  TestController testController;
+  using processors::InvokeHTTP;
+  std::string url = "http://localhost:8681/testytesttest";
+
+  std::shared_ptr<core::ContentRepository>
+  content_repo = std::make_shared<core::repository::VolatileContentRepository>();
+  std::shared_ptr<TestRepository> repo = std::make_shared<TestRepository>();
+
+  LogTestController::getInstance().setTrace<org::apache::nifi::minifi::processors::GenerateFlowFile>();
+  LogTestController::getInstance().setTrace<org::apache::nifi::minifi::processors::ListenHTTP>();
+  LogTestController::getInstance().setTrace<org::apache::nifi::minifi::processors::InvokeHTTP>();
+  LogTestController::getInstance().setTrace<minifi::core::ProcessSession>();
+
+  std::shared_ptr<core::Processor>
+  listenhttp = std::make_shared<org::apache::nifi::minifi::processors::ListenHTTP> ("listenhttp");

Review comment:
       same here

##########
File path: extensions/http-curl/tests/unit/InvokeHTTPTests.cpp
##########
@@ -306,3 +291,97 @@ TEST_CASE("HTTPTestsPostNoResourceClaim", "[httptest1]") {
   REQUIRE(true == LogTestController::getInstance().contains("Exiting because method is POST"));
   LogTestController::getInstance().reset();
 }
+
+TEST_CASE("HTTPTestsPenalizeNoRetry", "[httptest1]") {
+  TestController testController;
+  using processors::InvokeHTTP;
+
+  std::shared_ptr<core::ContentRepository>
+  content_repo = std::make_shared<core::repository::VolatileContentRepository>();
+  std::shared_ptr<TestRepository> repo = std::make_shared<TestRepository>();
+
+  LogTestController::getInstance().setTrace<org::apache::nifi::minifi::processors::GenerateFlowFile>();
+  LogTestController::getInstance().setTrace<org::apache::nifi::minifi::processors::ListenHTTP>();
+  LogTestController::getInstance().setTrace<org::apache::nifi::minifi::processors::InvokeHTTP>();
+  LogTestController::getInstance().setTrace<minifi::core::ProcessSession>();
+
+  std::shared_ptr<core::Processor>
+  listenhttp = std::make_shared<org::apache::nifi::minifi::processors::ListenHTTP>("listenhttp");
+  listenhttp->initialize();
+  std::shared_ptr<core::ProcessorNode> node = std::make_shared<core::ProcessorNode>(listenhttp);
+  std::shared_ptr<core::ProcessContext> context = std::make_shared<core::ProcessContext>(node, nullptr, repo, repo, content_repo);
+  context->setProperty(org::apache::nifi::minifi::processors::ListenHTTP::BasePath, "/testytesttest");
+  context->setProperty(org::apache::nifi::minifi::processors::ListenHTTP::Port, "8681");
+  auto session = std::make_shared<core::ProcessSession>(context);
+  std::shared_ptr<core::ProcessSessionFactory> factory = std::make_shared<core::ProcessSessionFactory>(context);
+  listenhttp->setScheduledState(core::ScheduledState::RUNNING);
+  listenhttp->onSchedule(context, factory);
+  listenhttp->onTrigger(context, session);
+
+  std::shared_ptr<TestPlan> plan = testController.createPlan();
+  std::shared_ptr<core::Processor> genfile = plan->addProcessor("GenerateFlowFile", "genfile");
+  std::shared_ptr<core::Processor> invokehttp = plan->addProcessor("InvokeHTTP", "invokehttp", core::Relationship("success", "description"), true);
+
+  plan->setProperty(invokehttp, org::apache::nifi::minifi::processors::InvokeHTTP::Method.getName(), "GET");
+  plan->setProperty(invokehttp, org::apache::nifi::minifi::processors::InvokeHTTP::URL.getName(), "http://localhost:8681/testytesttest");
+
+  SECTION("with penalize on no retry set to true") {
+    plan->setProperty(invokehttp,
+                      org::apache::nifi::minifi::processors::InvokeHTTP::PenalizeOnNoRetry.getName(),
+                      "true");
+    invokehttp->setAutoTerminatedRelationships({InvokeHTTP::RelFailure, InvokeHTTP::RelNoRetry, InvokeHTTP::RelResponse,
+                                                InvokeHTTP::RelRetry});
+    testController.runSession(plan, true);
+
+    REQUIRE(LogTestController::getInstance().contains("Flowfile has been penalized"));
+  } SECTION("with penalize on no retry set to false") {
+    plan->setProperty(invokehttp,
+                      org::apache::nifi::minifi::processors::InvokeHTTP::PenalizeOnNoRetry.getName(),
+                      "false");
+    invokehttp->setAutoTerminatedRelationships({InvokeHTTP::RelFailure, InvokeHTTP::RelNoRetry, InvokeHTTP::RelResponse,
+                                                InvokeHTTP::RelRetry});
+    testController.runSession(plan, true);
+
+    REQUIRE_FALSE(LogTestController::getInstance().contains("Flowfile has been penalized"));
+  }
+}
+
+TEST_CASE("HTTPTestsPutResponseBodyinAttribute", "[httptest1]") {
+  TestController testController;
+  using processors::InvokeHTTP;
+  std::string url = "http://localhost:8681/testytesttest";
+
+  std::shared_ptr<core::ContentRepository>
+  content_repo = std::make_shared<core::repository::VolatileContentRepository>();

Review comment:
       same 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.

To unsubscribe, e-mail: issues-unsubscribe@nifi.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [nifi-minifi-cpp] lordgamez commented on a change in pull request #1173: MINIFICPP-1458-Register and test hidden InvokeHTTP properties

Posted by GitBox <gi...@apache.org>.
lordgamez commented on a change in pull request #1173:
URL: https://github.com/apache/nifi-minifi-cpp/pull/1173#discussion_r710976061



##########
File path: docker/test/integration/features/http.feature
##########
@@ -23,7 +22,6 @@ Feature: Sending data using InvokeHTTP to a receiver using ListenHTTP
 
   Scenario: A MiNiFi instance sends data through a HTTP proxy and another one listens
     Given a GetFile processor with the "Input Directory" property set to "/tmp/input"
-    And the "Keep Source File" property of the GetFile processor is set to "true"

Review comment:
       As far as I remember these were kept here to avoid flakiness. It could happen that the due to some environment issues the first HTTP request times out or fails in that case after the next GetFile invocation can still succeed and the test case succeeds. If this is removed the GetFile only runs once.




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

To unsubscribe, e-mail: issues-unsubscribe@nifi.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [nifi-minifi-cpp] szaszm commented on a change in pull request #1173: MINIFICPP-1458-Register and test hidden InvokeHTTP properties

Posted by GitBox <gi...@apache.org>.
szaszm commented on a change in pull request #1173:
URL: https://github.com/apache/nifi-minifi-cpp/pull/1173#discussion_r709086900



##########
File path: extensions/http-curl/tests/unit/InvokeHTTPTests.cpp
##########
@@ -306,3 +291,97 @@ TEST_CASE("HTTPTestsPostNoResourceClaim", "[httptest1]") {
   REQUIRE(true == LogTestController::getInstance().contains("Exiting because method is POST"));
   LogTestController::getInstance().reset();
 }
+
+TEST_CASE("HTTPTestsPenalizeNoRetry", "[httptest1]") {
+  TestController testController;
+  using processors::InvokeHTTP;
+
+  std::shared_ptr<core::ContentRepository>
+  content_repo = std::make_shared<core::repository::VolatileContentRepository>();

Review comment:
       Maybe your editor/IDE is enforcing some line length requirements? In CLion, it's under Settings/Editor/Code Style/{Hard Wrap At,Wrap on typing}.




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

To unsubscribe, e-mail: issues-unsubscribe@nifi.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [nifi-minifi-cpp] lordgamez commented on a change in pull request #1173: MINIFICPP-1458-Register and test hidden InvokeHTTP properties

Posted by GitBox <gi...@apache.org>.
lordgamez commented on a change in pull request #1173:
URL: https://github.com/apache/nifi-minifi-cpp/pull/1173#discussion_r725943165



##########
File path: extensions/http-curl/tests/unit/InvokeHTTPTests.cpp
##########
@@ -306,3 +291,93 @@ TEST_CASE("HTTPTestsPostNoResourceClaim", "[httptest1]") {
   REQUIRE(true == LogTestController::getInstance().contains("Exiting because method is POST"));
   LogTestController::getInstance().reset();
 }
+
+TEST_CASE("HTTPTestsPenalizeNoRetry", "[httptest1]") {
+  TestController testController;
+  using processors::InvokeHTTP;
+
+  std::shared_ptr<core::ContentRepository> content_repo = std::make_shared<core::repository::VolatileContentRepository>();
+  std::shared_ptr<TestRepository> repo = std::make_shared<TestRepository>();
+
+  LogTestController::getInstance().setTrace<org::apache::nifi::minifi::processors::GenerateFlowFile>();
+  LogTestController::getInstance().setTrace<org::apache::nifi::minifi::processors::ListenHTTP>();
+  LogTestController::getInstance().setTrace<org::apache::nifi::minifi::processors::InvokeHTTP>();
+  LogTestController::getInstance().setTrace<minifi::core::ProcessSession>();
+
+  std::shared_ptr<core::Processor> listenhttp = std::make_shared<org::apache::nifi::minifi::processors::ListenHTTP>("listenhttp");
+  listenhttp->initialize();
+  std::shared_ptr<core::ProcessorNode> node = std::make_shared<core::ProcessorNode>(listenhttp);
+  std::shared_ptr<core::ProcessContext> context = std::make_shared<core::ProcessContext>(node, nullptr, repo, repo, content_repo);
+  context->setProperty(org::apache::nifi::minifi::processors::ListenHTTP::BasePath, "/testytesttest");
+  context->setProperty(org::apache::nifi::minifi::processors::ListenHTTP::Port, "8681");
+  auto session = std::make_shared<core::ProcessSession>(context);
+  std::shared_ptr<core::ProcessSessionFactory> factory = std::make_shared<core::ProcessSessionFactory>(context);
+  listenhttp->setScheduledState(core::ScheduledState::RUNNING);
+  listenhttp->onSchedule(context, factory);
+  listenhttp->onTrigger(context, session);
+
+  std::shared_ptr<TestPlan> plan = testController.createPlan();
+  std::shared_ptr<core::Processor> genfile = plan->addProcessor("GenerateFlowFile", "genfile");
+  std::shared_ptr<core::Processor> invokehttp = plan->addProcessor("InvokeHTTP", "invokehttp", core::Relationship("success", "description"), true);
+
+  plan->setProperty(invokehttp, org::apache::nifi::minifi::processors::InvokeHTTP::Method.getName(), "GET");
+  plan->setProperty(invokehttp, org::apache::nifi::minifi::processors::InvokeHTTP::URL.getName(), "http://localhost:8681/testytesttest");
+
+  SECTION("with penalize on no retry set to true") {
+    plan->setProperty(invokehttp,
+                      org::apache::nifi::minifi::processors::InvokeHTTP::PenalizeOnNoRetry.getName(),
+                      "true");
+    invokehttp->setAutoTerminatedRelationships({InvokeHTTP::RelFailure, InvokeHTTP::RelNoRetry, InvokeHTTP::RelResponse,
+                                                InvokeHTTP::RelRetry});
+    testController.runSession(plan, true);
+
+    REQUIRE(LogTestController::getInstance().contains("Flowfile has been penalized"));
+  } SECTION("with penalize on no retry set to false") {

Review comment:
       The second section should start on a new line




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

To unsubscribe, e-mail: issues-unsubscribe@nifi.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [nifi-minifi-cpp] aminadinari19 commented on a change in pull request #1173: MINIFICPP-1458-Register and test hidden InvokeHTTP properties

Posted by GitBox <gi...@apache.org>.
aminadinari19 commented on a change in pull request #1173:
URL: https://github.com/apache/nifi-minifi-cpp/pull/1173#discussion_r709076342



##########
File path: extensions/http-curl/processors/InvokeHTTP.cpp
##########
@@ -443,6 +447,7 @@ void InvokeHTTP::route(const std::shared_ptr<core::FlowFile> &request, const std
   } else {
     if (request != nullptr) {
       if (penalize_no_retry_) {
+        logger_->log_debug("Flowfile has been penalized");
         session->penalize(request);
       }

Review comment:
       This was added to check whether the flowfile is being penalized in case of no retry relationship. Maybe the wording of the log message could be improved as it is used to test for PenalizeOnNoRetry property?




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

To unsubscribe, e-mail: issues-unsubscribe@nifi.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [nifi-minifi-cpp] szaszm commented on a change in pull request #1173: MINIFICPP-1458-Register and test hidden InvokeHTTP properties

Posted by GitBox <gi...@apache.org>.
szaszm commented on a change in pull request #1173:
URL: https://github.com/apache/nifi-minifi-cpp/pull/1173#discussion_r710922448



##########
File path: extensions/http-curl/processors/InvokeHTTP.cpp
##########
@@ -443,6 +447,7 @@ void InvokeHTTP::route(const std::shared_ptr<core::FlowFile> &request, const std
   } else {
     if (request != nullptr) {
       if (penalize_no_retry_) {
+        logger_->log_debug("Flowfile has been penalized");
         session->penalize(request);
       }

Review comment:
       You could check for that log message instead. This is how it's produced: (ProcessSession.cpp:202)
   ```
     logging::LOG_INFO(logger_) << "Penalizing " << flow->getUUIDStr() << " for " << penalization_period.count() << "ms at " << process_context_->getProcessorNode()->getName();
   ```
   
   Try using `LogTestController::matchesRegex` to match this message. Something like this (untested) regex might work: `"Penalizing ([0-9a-f]+-)+[0-9a-f]+ for [0-9]+ms at invokehttp"`




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

To unsubscribe, e-mail: issues-unsubscribe@nifi.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [nifi-minifi-cpp] fgerlits commented on pull request #1173: MINIFICPP-1458-Register and test hidden InvokeHTTP properties

Posted by GitBox <gi...@apache.org>.
fgerlits commented on pull request #1173:
URL: https://github.com/apache/nifi-minifi-cpp/pull/1173#issuecomment-940808970


   Closing this in favor of #1200.


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

To unsubscribe, e-mail: issues-unsubscribe@nifi.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [nifi-minifi-cpp] aminadinari19 commented on a change in pull request #1173: MINIFICPP-1458-Register and test hidden InvokeHTTP properties

Posted by GitBox <gi...@apache.org>.
aminadinari19 commented on a change in pull request #1173:
URL: https://github.com/apache/nifi-minifi-cpp/pull/1173#discussion_r709070296



##########
File path: extensions/http-curl/tests/unit/InvokeHTTPTests.cpp
##########
@@ -306,3 +291,97 @@ TEST_CASE("HTTPTestsPostNoResourceClaim", "[httptest1]") {
   REQUIRE(true == LogTestController::getInstance().contains("Exiting because method is POST"));
   LogTestController::getInstance().reset();
 }
+
+TEST_CASE("HTTPTestsPenalizeNoRetry", "[httptest1]") {
+  TestController testController;
+  using processors::InvokeHTTP;
+
+  std::shared_ptr<core::ContentRepository>
+  content_repo = std::make_shared<core::repository::VolatileContentRepository>();

Review comment:
       Okay I will change it. For some reason, it keeps happening on its own. Is there any way to make sure it doesn't happen anymore?
   




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

To unsubscribe, e-mail: issues-unsubscribe@nifi.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [nifi-minifi-cpp] aminadinari19 commented on a change in pull request #1173: MINIFICPP-1458-Register and test hidden InvokeHTTP properties

Posted by GitBox <gi...@apache.org>.
aminadinari19 commented on a change in pull request #1173:
URL: https://github.com/apache/nifi-minifi-cpp/pull/1173#discussion_r725094570



##########
File path: docker/test/integration/features/http.feature
##########
@@ -23,7 +22,6 @@ Feature: Sending data using InvokeHTTP to a receiver using ListenHTTP
 
   Scenario: A MiNiFi instance sends data through a HTTP proxy and another one listens
     Given a GetFile processor with the "Input Directory" property set to "/tmp/input"
-    And the "Keep Source File" property of the GetFile processor is set to "true"

Review comment:
       Oh okat that makes sense. I have added the property back :)




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

To unsubscribe, e-mail: issues-unsubscribe@nifi.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [nifi-minifi-cpp] fgerlits closed pull request #1173: MINIFICPP-1458-Register and test hidden InvokeHTTP properties

Posted by GitBox <gi...@apache.org>.
fgerlits closed pull request #1173:
URL: https://github.com/apache/nifi-minifi-cpp/pull/1173


   


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

To unsubscribe, e-mail: issues-unsubscribe@nifi.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org