[jira] [Commented] (NIFI-5619) Node can join the cluster with a processor running when cluster state for that processor is stopped

2018-10-01 Thread Jeff Storck (JIRA)


[ 
https://issues.apache.org/jira/browse/NIFI-5619?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=16634770#comment-16634770
 ] 

Jeff Storck commented on NIFI-5619:
---

Tested this today with the WIP PR 3010 for NIFI-5585 a couple different ways.  
With this fix, reconnecting a node with a running GenerateFlowFile processor to 
a cluster where GenerateFlowFile is stopped results in the reconnected node's 
GenerateFlowFile processor being stopped after joining.  State of processors 
looks consistent across the cluster.

> Node can join the cluster with a processor running when cluster state for 
> that processor is stopped
> ---
>
> Key: NIFI-5619
> URL: https://issues.apache.org/jira/browse/NIFI-5619
> Project: Apache NiFi
>  Issue Type: Bug
>Affects Versions: 1.8.0
>Reporter: Jeff Storck
>Assignee: Mark Payne
>Priority: Major
> Attachments: Screen Shot 2018-09-20 at 4.53.44 PM.png, Screen Shot 
> 2018-09-20 at 4.54.07 PM.png, Screen Shot 2018-09-20 at 4.54.15 PM.png
>
>
> When the cluster state for a processor is stopped, it is possible for a node 
> to join the cluster with that particular processor running.  The UI will show 
> the processor as stopped, but going to the cluster summary and viewing the 
> node-specific status of that processor will show it's running on the node 
> that joined.
> To reproduce this:
> # Build the Node Decommissioning [PR 
> 3010|https://github.com/apache/nifi/pull/3010]
> # Create a two-node cluster, does not need to be secure
> # Create a flow with a GenerateFlowFile processor connected to an 
> UpdateAttribute processor
> # Start the GenerateFlowFile processor to let flowfiles queue in the 
> connection to UpdateAttribute
> # Using node 1's UI, disconnect node 2 from the cluster
> # Using node 1's UI, offload node 2
> # Using node 1's UI, delete node 2 from the cluster
> # Using node 1's UI, stop GenerateFlowFile
> # Restart node 2
> # Once node 2 is reconnected, in the UI the GenerateFlowFile processor will 
> look like it is stopped
> # Go to the Cluster Summary UI and click on the View Processor Details icon 
> which will show the processor running on node 2



--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[jira] [Created] (NIFI-5655) Heartbeat monitor keeps restarting zookeeper connection thread after node disconnect

2018-10-01 Thread Jeff Storck (JIRA)
Jeff Storck created NIFI-5655:
-

 Summary: Heartbeat monitor keeps restarting zookeeper connection 
thread after node disconnect
 Key: NIFI-5655
 URL: https://issues.apache.org/jira/browse/NIFI-5655
 Project: Apache NiFi
  Issue Type: Bug
  Components: Core Framework
Affects Versions: 1.7.1
Reporter: Jeff Storck


After disconnecting a node from the cluster, the disconnected node's Heartbeat 
Monitor thread will continue to allow the Curator's ConnectionStateManager to 
repeatedly update ZK. An excerpt from the logs when this occurs:
{code:java}
2018-09-26 15:17:20,181 INFO [Heartbeat Monitor Thread-1] 
o.a.c.f.imps.CuratorFrameworkImpl Starting
2018-09-26 15:17:20,184 INFO [Heartbeat Monitor Thread-1-EventThread] 
o.a.c.f.state.ConnectionStateManager State change: CONNECTED
2018-09-26 15:17:20,186 INFO [Curator-Framework-0] 
o.a.c.f.imps.CuratorFrameworkImpl backgroundOperationsLoop exiting
{code}



--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[jira] [Updated] (NIFI-5619) Node can join the cluster with a processor running when cluster state for that processor is stopped

2018-10-01 Thread Mark Payne (JIRA)


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

Mark Payne updated NIFI-5619:
-
Status: Patch Available  (was: Open)

> Node can join the cluster with a processor running when cluster state for 
> that processor is stopped
> ---
>
> Key: NIFI-5619
> URL: https://issues.apache.org/jira/browse/NIFI-5619
> Project: Apache NiFi
>  Issue Type: Bug
>Affects Versions: 1.8.0
>Reporter: Jeff Storck
>Assignee: Mark Payne
>Priority: Major
> Attachments: Screen Shot 2018-09-20 at 4.53.44 PM.png, Screen Shot 
> 2018-09-20 at 4.54.07 PM.png, Screen Shot 2018-09-20 at 4.54.15 PM.png
>
>
> When the cluster state for a processor is stopped, it is possible for a node 
> to join the cluster with that particular processor running.  The UI will show 
> the processor as stopped, but going to the cluster summary and viewing the 
> node-specific status of that processor will show it's running on the node 
> that joined.
> To reproduce this:
> # Build the Node Decommissioning [PR 
> 3010|https://github.com/apache/nifi/pull/3010]
> # Create a two-node cluster, does not need to be secure
> # Create a flow with a GenerateFlowFile processor connected to an 
> UpdateAttribute processor
> # Start the GenerateFlowFile processor to let flowfiles queue in the 
> connection to UpdateAttribute
> # Using node 1's UI, disconnect node 2 from the cluster
> # Using node 1's UI, offload node 2
> # Using node 1's UI, delete node 2 from the cluster
> # Using node 1's UI, stop GenerateFlowFile
> # Restart node 2
> # Once node 2 is reconnected, in the UI the GenerateFlowFile processor will 
> look like it is stopped
> # Go to the Cluster Summary UI and click on the View Processor Details icon 
> which will show the processor running on node 2



--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[jira] [Assigned] (NIFI-5619) Node can join the cluster with a processor running when cluster state for that processor is stopped

2018-10-01 Thread Mark Payne (JIRA)


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

Mark Payne reassigned NIFI-5619:


Assignee: Mark Payne

> Node can join the cluster with a processor running when cluster state for 
> that processor is stopped
> ---
>
> Key: NIFI-5619
> URL: https://issues.apache.org/jira/browse/NIFI-5619
> Project: Apache NiFi
>  Issue Type: Bug
>Affects Versions: 1.8.0
>Reporter: Jeff Storck
>Assignee: Mark Payne
>Priority: Major
> Attachments: Screen Shot 2018-09-20 at 4.53.44 PM.png, Screen Shot 
> 2018-09-20 at 4.54.07 PM.png, Screen Shot 2018-09-20 at 4.54.15 PM.png
>
>
> When the cluster state for a processor is stopped, it is possible for a node 
> to join the cluster with that particular processor running.  The UI will show 
> the processor as stopped, but going to the cluster summary and viewing the 
> node-specific status of that processor will show it's running on the node 
> that joined.
> To reproduce this:
> # Build the Node Decommissioning [PR 
> 3010|https://github.com/apache/nifi/pull/3010]
> # Create a two-node cluster, does not need to be secure
> # Create a flow with a GenerateFlowFile processor connected to an 
> UpdateAttribute processor
> # Start the GenerateFlowFile processor to let flowfiles queue in the 
> connection to UpdateAttribute
> # Using node 1's UI, disconnect node 2 from the cluster
> # Using node 1's UI, offload node 2
> # Using node 1's UI, delete node 2 from the cluster
> # Using node 1's UI, stop GenerateFlowFile
> # Restart node 2
> # Once node 2 is reconnected, in the UI the GenerateFlowFile processor will 
> look like it is stopped
> # Go to the Cluster Summary UI and click on the View Processor Details icon 
> which will show the processor running on node 2



--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[jira] [Resolved] (NIFI-5651) Provide better support for backpressure on load-balanced connections

2018-10-01 Thread Mark Payne (JIRA)


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

Mark Payne resolved NIFI-5651.
--
Resolution: Not A Problem

This was addressed in NIFI-5516 before being merged so this Jira is not needed.

> Provide better support for backpressure on load-balanced connections
> 
>
> Key: NIFI-5651
> URL: https://issues.apache.org/jira/browse/NIFI-5651
> Project: Apache NiFi
>  Issue Type: Improvement
>Reporter: Mark Payne
>Assignee: Mark Payne
>Priority: Major
>




--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[jira] [Commented] (NIFI-5516) Allow data in a Connection to be Load-Balanced across cluster

2018-10-01 Thread ASF GitHub Bot (JIRA)


[ 
https://issues.apache.org/jira/browse/NIFI-5516?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=16634520#comment-16634520
 ] 

ASF GitHub Bot commented on NIFI-5516:
--

Github user markap14 commented on a diff in the pull request:

https://github.com/apache/nifi/pull/2947#discussion_r221729013
  
--- Diff: 
nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/queue/clustered/server/ConnectionLoadBalanceServer.java
 ---
@@ -0,0 +1,251 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You 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.
+ */
+
+package org.apache.nifi.controller.queue.clustered.server;
+
+import org.apache.nifi.engine.FlowEngine;
+import org.apache.nifi.events.EventReporter;
+import org.apache.nifi.reporting.Severity;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
+
+import javax.net.ssl.SSLContext;
+import javax.net.ssl.SSLServerSocket;
+import java.io.IOException;
+import java.net.InetAddress;
+import java.net.ServerSocket;
+import java.net.Socket;
+import java.net.SocketTimeoutException;
+import java.util.Collections;
+import java.util.HashSet;
+import java.util.Set;
+import java.util.concurrent.BlockingQueue;
+import java.util.concurrent.ExecutorService;
+import java.util.concurrent.LinkedBlockingQueue;
+import java.util.concurrent.TimeUnit;
+
+
+public class ConnectionLoadBalanceServer {
+private static final Logger logger = 
LoggerFactory.getLogger(ConnectionLoadBalanceServer.class);
+
+private final String hostname;
+private final int port;
+private final SSLContext sslContext;
+private final ExecutorService threadPool;
+private final LoadBalanceProtocol loadBalanceProtocol;
+private final int connectionTimeoutMillis;
+private final int numThreads;
+private final EventReporter eventReporter;
+
+private volatile Set communicationActions = 
Collections.emptySet();
+private final BlockingQueue connectionQueue = new 
LinkedBlockingQueue<>();
+
+private volatile AcceptConnection acceptConnection;
+private volatile ServerSocket serverSocket;
+private volatile boolean stopped = true;
+
+public ConnectionLoadBalanceServer(final String hostname, final int 
port, final SSLContext sslContext, final int numThreads, final 
LoadBalanceProtocol loadBalanceProtocol,
+   final EventReporter eventReporter, 
final int connectionTimeoutMillis) {
+this.hostname = hostname;
+this.port = port;
+this.sslContext = sslContext;
+this.loadBalanceProtocol = loadBalanceProtocol;
+this.connectionTimeoutMillis = connectionTimeoutMillis;
+this.numThreads = numThreads;
+this.eventReporter = eventReporter;
+
+threadPool = new FlowEngine(numThreads, "Load Balance Server");
+}
+
+public void start() throws IOException {
+if (!stopped) {
+return;
+}
+
+stopped = false;
+if (serverSocket != null) {
+return;
+}
+
+try {
+serverSocket = createServerSocket();
+} catch (final Exception e) {
+throw new IOException("Could not begin listening for incoming 
connections in order to load balance data across the cluster. Please verify the 
values of the " +
+"'nifi.cluster.load.balance.port' and 
'nifi.cluster.load.balance.host' properties as well as the 'nifi.security.*' 
properties", e);
+}
+
+final Set actions = new HashSet<>(numThreads);
+for (int i=0; i < numThreads; i++) {
+final CommunicateAction action = new 
CommunicateAction(loadBalanceProtocol);
+actions.add(action);
+threadPool.submit(action);
+}
+
+this.communicationActions 

[GitHub] nifi pull request #2947: [WIP] NIFI-5516: Implement Load-Balanced Connection...

2018-10-01 Thread markap14
Github user markap14 commented on a diff in the pull request:

https://github.com/apache/nifi/pull/2947#discussion_r221729013
  
--- Diff: 
nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/queue/clustered/server/ConnectionLoadBalanceServer.java
 ---
@@ -0,0 +1,251 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You 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.
+ */
+
+package org.apache.nifi.controller.queue.clustered.server;
+
+import org.apache.nifi.engine.FlowEngine;
+import org.apache.nifi.events.EventReporter;
+import org.apache.nifi.reporting.Severity;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
+
+import javax.net.ssl.SSLContext;
+import javax.net.ssl.SSLServerSocket;
+import java.io.IOException;
+import java.net.InetAddress;
+import java.net.ServerSocket;
+import java.net.Socket;
+import java.net.SocketTimeoutException;
+import java.util.Collections;
+import java.util.HashSet;
+import java.util.Set;
+import java.util.concurrent.BlockingQueue;
+import java.util.concurrent.ExecutorService;
+import java.util.concurrent.LinkedBlockingQueue;
+import java.util.concurrent.TimeUnit;
+
+
+public class ConnectionLoadBalanceServer {
+private static final Logger logger = 
LoggerFactory.getLogger(ConnectionLoadBalanceServer.class);
+
+private final String hostname;
+private final int port;
+private final SSLContext sslContext;
+private final ExecutorService threadPool;
+private final LoadBalanceProtocol loadBalanceProtocol;
+private final int connectionTimeoutMillis;
+private final int numThreads;
+private final EventReporter eventReporter;
+
+private volatile Set communicationActions = 
Collections.emptySet();
+private final BlockingQueue connectionQueue = new 
LinkedBlockingQueue<>();
+
+private volatile AcceptConnection acceptConnection;
+private volatile ServerSocket serverSocket;
+private volatile boolean stopped = true;
+
+public ConnectionLoadBalanceServer(final String hostname, final int 
port, final SSLContext sslContext, final int numThreads, final 
LoadBalanceProtocol loadBalanceProtocol,
+   final EventReporter eventReporter, 
final int connectionTimeoutMillis) {
+this.hostname = hostname;
+this.port = port;
+this.sslContext = sslContext;
+this.loadBalanceProtocol = loadBalanceProtocol;
+this.connectionTimeoutMillis = connectionTimeoutMillis;
+this.numThreads = numThreads;
+this.eventReporter = eventReporter;
+
+threadPool = new FlowEngine(numThreads, "Load Balance Server");
+}
+
+public void start() throws IOException {
+if (!stopped) {
+return;
+}
+
+stopped = false;
+if (serverSocket != null) {
+return;
+}
+
+try {
+serverSocket = createServerSocket();
+} catch (final Exception e) {
+throw new IOException("Could not begin listening for incoming 
connections in order to load balance data across the cluster. Please verify the 
values of the " +
+"'nifi.cluster.load.balance.port' and 
'nifi.cluster.load.balance.host' properties as well as the 'nifi.security.*' 
properties", e);
+}
+
+final Set actions = new HashSet<>(numThreads);
+for (int i=0; i < numThreads; i++) {
+final CommunicateAction action = new 
CommunicateAction(loadBalanceProtocol);
+actions.add(action);
+threadPool.submit(action);
+}
+
+this.communicationActions = actions;
+
+acceptConnection = new AcceptConnection(serverSocket);
+final Thread receiveConnectionThread = new 
Thread(acceptConnection);
+receiveConnectionThread.setName("Receive Queue 

[jira] [Commented] (NIFI-5537) Create Neo4J cypher execution processor

2018-10-01 Thread ASF GitHub Bot (JIRA)


[ 
https://issues.apache.org/jira/browse/NIFI-5537?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=16634500#comment-16634500
 ] 

ASF GitHub Bot commented on NIFI-5537:
--

Github user MikeThomsen commented on the issue:

https://github.com/apache/nifi/pull/2956
  
> @MikeThomsen - Regarding your graph output questions - It looks correct 
but can you please let me know what are the commands/files that were ingested 
for above output ?

I'll try to find some time to replay and get back to you on that.


> Create Neo4J cypher execution processor
> ---
>
> Key: NIFI-5537
> URL: https://issues.apache.org/jira/browse/NIFI-5537
> Project: Apache NiFi
>  Issue Type: New Feature
>  Components: Extensions
>Affects Versions: 1.7.1
> Environment: All
>Reporter: Mans Singh
>Assignee: Mans Singh
>Priority: Minor
>  Labels: graph, neo4j, node, relationship
> Fix For: 1.8.0
>
>
> Create Nifi Neo4J cypher queries processor



--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[GitHub] nifi issue #2956: NIFI-5537 Create Neo4J cypher execution processor

2018-10-01 Thread MikeThomsen
Github user MikeThomsen commented on the issue:

https://github.com/apache/nifi/pull/2956
  
> @MikeThomsen - Regarding your graph output questions - It looks correct 
but can you please let me know what are the commands/files that were ingested 
for above output ?

I'll try to find some time to replay and get back to you on that.


---


[jira] [Commented] (NIFI-5537) Create Neo4J cypher execution processor

2018-10-01 Thread ASF GitHub Bot (JIRA)


[ 
https://issues.apache.org/jira/browse/NIFI-5537?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=16634499#comment-16634499
 ] 

ASF GitHub Bot commented on NIFI-5537:
--

Github user MikeThomsen commented on a diff in the pull request:

https://github.com/apache/nifi/pull/2956#discussion_r221723913
  
--- Diff: 
nifi-nar-bundles/nifi-neo4j-bundle/nifi-neo4j-processors/src/main/java/org/apache/nifi/processors/neo4j/AbstractNeo4JCypherExecutor.java
 ---
@@ -0,0 +1,281 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You 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.
+ */
+package org.apache.nifi.processors.neo4j;
+
+import java.io.File;
+import java.util.concurrent.TimeUnit;
+
+import org.apache.commons.lang3.StringUtils;
+import org.apache.nifi.annotation.lifecycle.OnScheduled;
+import org.apache.nifi.annotation.lifecycle.OnStopped;
+import org.apache.nifi.components.AllowableValue;
+import org.apache.nifi.components.PropertyDescriptor;
+import org.apache.nifi.components.PropertyValue;
+import org.apache.nifi.expression.ExpressionLanguageScope;
+import org.apache.nifi.processor.AbstractProcessor;
+import org.apache.nifi.processor.ProcessContext;
+import org.apache.nifi.processor.Relationship;
+import org.apache.nifi.processor.exception.ProcessException;
+import org.apache.nifi.processor.util.StandardValidators;
+import org.neo4j.driver.v1.AuthTokens;
+import org.neo4j.driver.v1.Config;
+import org.neo4j.driver.v1.Config.ConfigBuilder;
+import org.neo4j.driver.v1.Config.LoadBalancingStrategy;
+import org.neo4j.driver.v1.Config.TrustStrategy;
+import org.neo4j.driver.v1.Driver;
+import org.neo4j.driver.v1.GraphDatabase;
+
+/**
+ * Abstract base class for Neo4JCypherExecutor processors
+ */
+abstract class AbstractNeo4JCypherExecutor extends AbstractProcessor {
+
+protected static final PropertyDescriptor QUERY = new 
PropertyDescriptor.Builder()
+.name("neo4J-query")
+.displayName("Neo4J Query")
+.description("Specifies the Neo4j Query.")
+.required(true)
+
.expressionLanguageSupported(ExpressionLanguageScope.FLOWFILE_ATTRIBUTES)
+.addValidator(StandardValidators.NON_BLANK_VALIDATOR)
+.build();
+
+public static final PropertyDescriptor CONNECTION_URL = new 
PropertyDescriptor.Builder()
+.name("neo4j-connection-url")
+.displayName("Neo4j Connection URL")
+.description("Neo4J endpoing to connect to.")
+.required(true)
+.defaultValue("bolt://localhost:7687")
+
.expressionLanguageSupported(ExpressionLanguageScope.VARIABLE_REGISTRY)
+.addValidator(StandardValidators.NON_EMPTY_VALIDATOR)
+.build();
+
+public static final PropertyDescriptor USERNAME = new 
PropertyDescriptor.Builder()
+.name("neo4j-username")
+.displayName("Username")
+.description("Username for accessing Neo4J")
+.required(true)
+
.expressionLanguageSupported(ExpressionLanguageScope.VARIABLE_REGISTRY)
+.addValidator(StandardValidators.NON_BLANK_VALIDATOR)
+.build();
+
+public static final PropertyDescriptor PASSWORD = new 
PropertyDescriptor.Builder()
+.name("neo4j-password")
+.displayName("Password")
+.description("Password for Neo4J user")
+.required(true)
+.sensitive(true)
+
.expressionLanguageSupported(ExpressionLanguageScope.VARIABLE_REGISTRY)
+.addValidator(StandardValidators.NON_BLANK_VALIDATOR)
+.build();
+
+public static AllowableValue LOAD_BALANCING_STRATEGY_ROUND_ROBIN = new 
AllowableValue(LoadBalancingStrategy.ROUND_ROBIN.name(), "Round Robin", "Round 
Robin Strategy");
+
+public static AllowableValue 

[GitHub] nifi pull request #2956: NIFI-5537 Create Neo4J cypher execution processor

2018-10-01 Thread MikeThomsen
Github user MikeThomsen commented on a diff in the pull request:

https://github.com/apache/nifi/pull/2956#discussion_r221723913
  
--- Diff: 
nifi-nar-bundles/nifi-neo4j-bundle/nifi-neo4j-processors/src/main/java/org/apache/nifi/processors/neo4j/AbstractNeo4JCypherExecutor.java
 ---
@@ -0,0 +1,281 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You 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.
+ */
+package org.apache.nifi.processors.neo4j;
+
+import java.io.File;
+import java.util.concurrent.TimeUnit;
+
+import org.apache.commons.lang3.StringUtils;
+import org.apache.nifi.annotation.lifecycle.OnScheduled;
+import org.apache.nifi.annotation.lifecycle.OnStopped;
+import org.apache.nifi.components.AllowableValue;
+import org.apache.nifi.components.PropertyDescriptor;
+import org.apache.nifi.components.PropertyValue;
+import org.apache.nifi.expression.ExpressionLanguageScope;
+import org.apache.nifi.processor.AbstractProcessor;
+import org.apache.nifi.processor.ProcessContext;
+import org.apache.nifi.processor.Relationship;
+import org.apache.nifi.processor.exception.ProcessException;
+import org.apache.nifi.processor.util.StandardValidators;
+import org.neo4j.driver.v1.AuthTokens;
+import org.neo4j.driver.v1.Config;
+import org.neo4j.driver.v1.Config.ConfigBuilder;
+import org.neo4j.driver.v1.Config.LoadBalancingStrategy;
+import org.neo4j.driver.v1.Config.TrustStrategy;
+import org.neo4j.driver.v1.Driver;
+import org.neo4j.driver.v1.GraphDatabase;
+
+/**
+ * Abstract base class for Neo4JCypherExecutor processors
+ */
+abstract class AbstractNeo4JCypherExecutor extends AbstractProcessor {
+
+protected static final PropertyDescriptor QUERY = new 
PropertyDescriptor.Builder()
+.name("neo4J-query")
+.displayName("Neo4J Query")
+.description("Specifies the Neo4j Query.")
+.required(true)
+
.expressionLanguageSupported(ExpressionLanguageScope.FLOWFILE_ATTRIBUTES)
+.addValidator(StandardValidators.NON_BLANK_VALIDATOR)
+.build();
+
+public static final PropertyDescriptor CONNECTION_URL = new 
PropertyDescriptor.Builder()
+.name("neo4j-connection-url")
+.displayName("Neo4j Connection URL")
+.description("Neo4J endpoing to connect to.")
+.required(true)
+.defaultValue("bolt://localhost:7687")
+
.expressionLanguageSupported(ExpressionLanguageScope.VARIABLE_REGISTRY)
+.addValidator(StandardValidators.NON_EMPTY_VALIDATOR)
+.build();
+
+public static final PropertyDescriptor USERNAME = new 
PropertyDescriptor.Builder()
+.name("neo4j-username")
+.displayName("Username")
+.description("Username for accessing Neo4J")
+.required(true)
+
.expressionLanguageSupported(ExpressionLanguageScope.VARIABLE_REGISTRY)
+.addValidator(StandardValidators.NON_BLANK_VALIDATOR)
+.build();
+
+public static final PropertyDescriptor PASSWORD = new 
PropertyDescriptor.Builder()
+.name("neo4j-password")
+.displayName("Password")
+.description("Password for Neo4J user")
+.required(true)
+.sensitive(true)
+
.expressionLanguageSupported(ExpressionLanguageScope.VARIABLE_REGISTRY)
+.addValidator(StandardValidators.NON_BLANK_VALIDATOR)
+.build();
+
+public static AllowableValue LOAD_BALANCING_STRATEGY_ROUND_ROBIN = new 
AllowableValue(LoadBalancingStrategy.ROUND_ROBIN.name(), "Round Robin", "Round 
Robin Strategy");
+
+public static AllowableValue LOAD_BALANCING_STRATEGY_LEAST_CONNECTED = 
new AllowableValue(LoadBalancingStrategy.LEAST_CONNECTED.name(), "Least 
Connected", "Least Connected Strategy");
+
+protected static final PropertyDescriptor LOAD_BALANCING_STRATEGY = 
new PropertyDescriptor.Builder()
 

[jira] [Created] (NIFI-5654) NiFi Documentation is shown as insecure in Firefox 62

2018-10-01 Thread Julian Feinauer (JIRA)
Julian Feinauer created NIFI-5654:
-

 Summary: NiFi Documentation is shown as insecure in Firefox 62
 Key: NIFI-5654
 URL: https://issues.apache.org/jira/browse/NIFI-5654
 Project: Apache NiFi
  Issue Type: Bug
  Components: Documentation  Website
Reporter: Julian Feinauer
 Attachments: image-2018-10-01-20-41-16-531.png

While Browsing the documentation I observed that my Browser (Firefox 62) lists 
the Page as insecure when going to https://nifi.apache.org/docs.html and 
Clicking on "User Guide", see Screenshot attached.

 !image-2018-10-01-20-41-16-531.png! 



--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[jira] [Commented] (NIFI-5248) Create new put processors that use the ElasticSearch client service

2018-10-01 Thread ASF GitHub Bot (JIRA)


[ 
https://issues.apache.org/jira/browse/NIFI-5248?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=16634433#comment-16634433
 ] 

ASF GitHub Bot commented on NIFI-5248:
--

Github user MikeThomsen commented on the issue:

https://github.com/apache/nifi/pull/2861
  
One of the lookup integration tests is failing. I need to figure out why.


> Create new put processors that use the ElasticSearch client service
> ---
>
> Key: NIFI-5248
> URL: https://issues.apache.org/jira/browse/NIFI-5248
> Project: Apache NiFi
>  Issue Type: New Feature
>Reporter: Mike Thomsen
>Assignee: Mike Thomsen
>Priority: Major
>
> Two new processors:
>  * PutElasticsearchJson - put raw JSON.
>  * PutElasticsearchRecord - put records.
> Both of them should support the general bulk load API and be able to do 
> things like insert into multiple indexes from one payload.



--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[GitHub] nifi issue #2861: NIFI-5248 Added new Elasticsearch json and record processo...

2018-10-01 Thread MikeThomsen
Github user MikeThomsen commented on the issue:

https://github.com/apache/nifi/pull/2861
  
One of the lookup integration tests is failing. I need to figure out why.


---


[jira] [Commented] (NIFI-5537) Create Neo4J cypher execution processor

2018-10-01 Thread ASF GitHub Bot (JIRA)


[ 
https://issues.apache.org/jira/browse/NIFI-5537?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=16634348#comment-16634348
 ] 

ASF GitHub Bot commented on NIFI-5537:
--

Github user thenatog commented on a diff in the pull request:

https://github.com/apache/nifi/pull/2956#discussion_r221687627
  
--- Diff: nifi-nar-bundles/nifi-neo4j-bundle/nifi-neo4j-processors/pom.xml 
---
@@ -0,0 +1,87 @@
+
+
+http://maven.apache.org/POM/4.0.0; 
xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance; 
xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 
http://maven.apache.org/xsd/maven-4.0.0.xsd;>
+4.0.0
+
+
+org.apache.nifi
+nifi-neo4j-bundle
+1.8.0-SNAPSHOT
+
+
+nifi-neo4j-processors
+jar
+
+
+ 
+ org.neo4j.driver
+ neo4j-java-driver
+ 1.6.2
+ compile
+
+
+org.apache.nifi
+nifi-api
+
+
+org.apache.nifi
+nifi-utils
+1.8.0-SNAPSHOT
+
+
+commons-io
+commons-io
+2.6
+
+
+org.apache.commons
+commons-lang3
+3.7
+
+
+com.google.code.gson
+gson
+2.7
+
+
+org.apache.nifi
+nifi-mock
+1.8.0-SNAPSHOT
+test
+
+
+com.google.guava
+guava
+18.0
--- End diff --

Yes, if possible please use the latest Guava version you're able to. The 
ticket is to upgrade to v26.0-jre


> Create Neo4J cypher execution processor
> ---
>
> Key: NIFI-5537
> URL: https://issues.apache.org/jira/browse/NIFI-5537
> Project: Apache NiFi
>  Issue Type: New Feature
>  Components: Extensions
>Affects Versions: 1.7.1
> Environment: All
>Reporter: Mans Singh
>Assignee: Mans Singh
>Priority: Minor
>  Labels: graph, neo4j, node, relationship
> Fix For: 1.8.0
>
>
> Create Nifi Neo4J cypher queries processor



--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[GitHub] nifi pull request #2956: NIFI-5537 Create Neo4J cypher execution processor

2018-10-01 Thread thenatog
Github user thenatog commented on a diff in the pull request:

https://github.com/apache/nifi/pull/2956#discussion_r221687627
  
--- Diff: nifi-nar-bundles/nifi-neo4j-bundle/nifi-neo4j-processors/pom.xml 
---
@@ -0,0 +1,87 @@
+
+
+http://maven.apache.org/POM/4.0.0; 
xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance; 
xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 
http://maven.apache.org/xsd/maven-4.0.0.xsd;>
+4.0.0
+
+
+org.apache.nifi
+nifi-neo4j-bundle
+1.8.0-SNAPSHOT
+
+
+nifi-neo4j-processors
+jar
+
+
+ 
+ org.neo4j.driver
+ neo4j-java-driver
+ 1.6.2
+ compile
+
+
+org.apache.nifi
+nifi-api
+
+
+org.apache.nifi
+nifi-utils
+1.8.0-SNAPSHOT
+
+
+commons-io
+commons-io
+2.6
+
+
+org.apache.commons
+commons-lang3
+3.7
+
+
+com.google.code.gson
+gson
+2.7
+
+
+org.apache.nifi
+nifi-mock
+1.8.0-SNAPSHOT
+test
+
+
+com.google.guava
+guava
+18.0
--- End diff --

Yes, if possible please use the latest Guava version you're able to. The 
ticket is to upgrade to v26.0-jre


---


[jira] [Commented] (NIFI-5489) Support Attribute Expressions with AMQP Processors

2018-10-01 Thread ASF GitHub Bot (JIRA)


[ 
https://issues.apache.org/jira/browse/NIFI-5489?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=16634320#comment-16634320
 ] 

ASF GitHub Bot commented on NIFI-5489:
--

Github user alopresto commented on the issue:

https://github.com/apache/nifi/pull/2936
  
There are definitely inconsistencies throughout the project as this wasn't 
always a firm policy and there are many different contributors to the project. 
As you noted, we have tried to tighten the reviews and catch this where we can, 
and hopefully with the completion of 
[NIFI-5627](https://issues.apache.org/jira/browse/NIFI-5627), we will have a 
foundation to move forward on enabling EL in passwords for users. 


> Support Attribute Expressions with AMQP Processors
> --
>
> Key: NIFI-5489
> URL: https://issues.apache.org/jira/browse/NIFI-5489
> Project: Apache NiFi
>  Issue Type: Improvement
>Affects Versions: 1.7.1
>Reporter: Daniel
>Priority: Major
> Fix For: 1.8.0
>
>
> Particularly the fields: host, virtualhost and username.



--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[GitHub] nifi issue #2936: NIFI-5489: Add expression language support to AMQP process...

2018-10-01 Thread alopresto
Github user alopresto commented on the issue:

https://github.com/apache/nifi/pull/2936
  
There are definitely inconsistencies throughout the project as this wasn't 
always a firm policy and there are many different contributors to the project. 
As you noted, we have tried to tighten the reviews and catch this where we can, 
and hopefully with the completion of 
[NIFI-5627](https://issues.apache.org/jira/browse/NIFI-5627), we will have a 
foundation to move forward on enabling EL in passwords for users. 


---


[jira] [Commented] (NIFI-5489) Support Attribute Expressions with AMQP Processors

2018-10-01 Thread ASF GitHub Bot (JIRA)


[ 
https://issues.apache.org/jira/browse/NIFI-5489?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=16634316#comment-16634316
 ] 

ASF GitHub Bot commented on NIFI-5489:
--

Github user lukepfarrar commented on the issue:

https://github.com/apache/nifi/pull/2936
  
I wondered if that was the case but it did not seem consistent with the DB 
pooling, which does/did allow EL in the password, althought I notice that the 
scope has been tightened in recent versions.
Thanks :)


> Support Attribute Expressions with AMQP Processors
> --
>
> Key: NIFI-5489
> URL: https://issues.apache.org/jira/browse/NIFI-5489
> Project: Apache NiFi
>  Issue Type: Improvement
>Affects Versions: 1.7.1
>Reporter: Daniel
>Priority: Major
> Fix For: 1.8.0
>
>
> Particularly the fields: host, virtualhost and username.



--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[GitHub] nifi issue #2936: NIFI-5489: Add expression language support to AMQP process...

2018-10-01 Thread lukepfarrar
Github user lukepfarrar commented on the issue:

https://github.com/apache/nifi/pull/2936
  
I wondered if that was the case but it did not seem consistent with the DB 
pooling, which does/did allow EL in the password, althought I notice that the 
scope has been tightened in recent versions.
Thanks :)


---


[jira] [Commented] (NIFI-5489) Support Attribute Expressions with AMQP Processors

2018-10-01 Thread ASF GitHub Bot (JIRA)


[ 
https://issues.apache.org/jira/browse/NIFI-5489?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=16634295#comment-16634295
 ] 

ASF GitHub Bot commented on NIFI-5489:
--

Github user alopresto commented on the issue:

https://github.com/apache/nifi/pull/2936
  
Hi @lukepfarrar , we have a policy of not evaluating EL in password fields. 
Here is [an example of that review 
process](https://github.com/apache/nifi/pull/3020#discussion_r219712821) and 
the reasoning behind it on another PR. 

> Our policy so far has been that passwords do not support expression 
language, for a couple reasons:
> 1. How to evaluate if a password `abc${def}` should be interpreted as 
`abc` + *the value of(`def`)* or the literal string `abc${def}`
> 1. The variable registry is not designed to store sensitive values 
securely, so if a password is stored here, it can be accessed by an 
unauthorized user


> Support Attribute Expressions with AMQP Processors
> --
>
> Key: NIFI-5489
> URL: https://issues.apache.org/jira/browse/NIFI-5489
> Project: Apache NiFi
>  Issue Type: Improvement
>Affects Versions: 1.7.1
>Reporter: Daniel
>Priority: Major
> Fix For: 1.8.0
>
>
> Particularly the fields: host, virtualhost and username.



--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[GitHub] nifi issue #2936: NIFI-5489: Add expression language support to AMQP process...

2018-10-01 Thread alopresto
Github user alopresto commented on the issue:

https://github.com/apache/nifi/pull/2936
  
Hi @lukepfarrar , we have a policy of not evaluating EL in password fields. 
Here is [an example of that review 
process](https://github.com/apache/nifi/pull/3020#discussion_r219712821) and 
the reasoning behind it on another PR. 

> Our policy so far has been that passwords do not support expression 
language, for a couple reasons:
> 1. How to evaluate if a password `abc${def}` should be interpreted as 
`abc` + *the value of(`def`)* or the literal string `abc${def}`
> 1. The variable registry is not designed to store sensitive values 
securely, so if a password is stored here, it can be accessed by an 
unauthorized user


---


[GitHub] nifi issue #2936: NIFI-5489: Add expression language support to AMQP process...

2018-10-01 Thread lukepfarrar
Github user lukepfarrar commented on the issue:

https://github.com/apache/nifi/pull/2936
  
Is there a reason why USER supports el but PASSWORD does not?


---


[jira] [Commented] (NIFI-5489) Support Attribute Expressions with AMQP Processors

2018-10-01 Thread ASF GitHub Bot (JIRA)


[ 
https://issues.apache.org/jira/browse/NIFI-5489?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=16634274#comment-16634274
 ] 

ASF GitHub Bot commented on NIFI-5489:
--

Github user lukepfarrar commented on the issue:

https://github.com/apache/nifi/pull/2936
  
Is there a reason why USER supports el but PASSWORD does not?


> Support Attribute Expressions with AMQP Processors
> --
>
> Key: NIFI-5489
> URL: https://issues.apache.org/jira/browse/NIFI-5489
> Project: Apache NiFi
>  Issue Type: Improvement
>Affects Versions: 1.7.1
>Reporter: Daniel
>Priority: Major
> Fix For: 1.8.0
>
>
> Particularly the fields: host, virtualhost and username.



--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[jira] [Commented] (NIFI-5537) Create Neo4J cypher execution processor

2018-10-01 Thread ASF GitHub Bot (JIRA)


[ 
https://issues.apache.org/jira/browse/NIFI-5537?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=16634271#comment-16634271
 ] 

ASF GitHub Bot commented on NIFI-5537:
--

Github user alopresto commented on a diff in the pull request:

https://github.com/apache/nifi/pull/2956#discussion_r221672221
  
--- Diff: 
nifi-nar-bundles/nifi-neo4j-bundle/nifi-neo4j-processors/src/main/java/org/apache/nifi/processors/neo4j/AbstractNeo4JCypherExecutor.java
 ---
@@ -0,0 +1,281 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You 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.
+ */
+package org.apache.nifi.processors.neo4j;
+
+import java.io.File;
+import java.util.concurrent.TimeUnit;
+
+import org.apache.commons.lang3.StringUtils;
+import org.apache.nifi.annotation.lifecycle.OnScheduled;
+import org.apache.nifi.annotation.lifecycle.OnStopped;
+import org.apache.nifi.components.AllowableValue;
+import org.apache.nifi.components.PropertyDescriptor;
+import org.apache.nifi.components.PropertyValue;
+import org.apache.nifi.expression.ExpressionLanguageScope;
+import org.apache.nifi.processor.AbstractProcessor;
+import org.apache.nifi.processor.ProcessContext;
+import org.apache.nifi.processor.Relationship;
+import org.apache.nifi.processor.exception.ProcessException;
+import org.apache.nifi.processor.util.StandardValidators;
+import org.neo4j.driver.v1.AuthTokens;
+import org.neo4j.driver.v1.Config;
+import org.neo4j.driver.v1.Config.ConfigBuilder;
+import org.neo4j.driver.v1.Config.LoadBalancingStrategy;
+import org.neo4j.driver.v1.Config.TrustStrategy;
+import org.neo4j.driver.v1.Driver;
+import org.neo4j.driver.v1.GraphDatabase;
+
+/**
+ * Abstract base class for Neo4JCypherExecutor processors
+ */
+abstract class AbstractNeo4JCypherExecutor extends AbstractProcessor {
+
+protected static final PropertyDescriptor QUERY = new 
PropertyDescriptor.Builder()
+.name("neo4J-query")
+.displayName("Neo4J Query")
+.description("Specifies the Neo4j Query.")
+.required(true)
+
.expressionLanguageSupported(ExpressionLanguageScope.FLOWFILE_ATTRIBUTES)
+.addValidator(StandardValidators.NON_BLANK_VALIDATOR)
+.build();
+
+public static final PropertyDescriptor CONNECTION_URL = new 
PropertyDescriptor.Builder()
+.name("neo4j-connection-url")
+.displayName("Neo4j Connection URL")
+.description("Neo4J endpoing to connect to.")
+.required(true)
+.defaultValue("bolt://localhost:7687")
+
.expressionLanguageSupported(ExpressionLanguageScope.VARIABLE_REGISTRY)
+.addValidator(StandardValidators.NON_EMPTY_VALIDATOR)
+.build();
+
+public static final PropertyDescriptor USERNAME = new 
PropertyDescriptor.Builder()
+.name("neo4j-username")
+.displayName("Username")
+.description("Username for accessing Neo4J")
+.required(true)
+
.expressionLanguageSupported(ExpressionLanguageScope.VARIABLE_REGISTRY)
+.addValidator(StandardValidators.NON_BLANK_VALIDATOR)
+.build();
+
+public static final PropertyDescriptor PASSWORD = new 
PropertyDescriptor.Builder()
+.name("neo4j-password")
+.displayName("Password")
+.description("Password for Neo4J user")
+.required(true)
+.sensitive(true)
+
.expressionLanguageSupported(ExpressionLanguageScope.VARIABLE_REGISTRY)
+.addValidator(StandardValidators.NON_BLANK_VALIDATOR)
+.build();
+
+public static AllowableValue LOAD_BALANCING_STRATEGY_ROUND_ROBIN = new 
AllowableValue(LoadBalancingStrategy.ROUND_ROBIN.name(), "Round Robin", "Round 
Robin Strategy");
+
+public static AllowableValue LOAD_BALANCING_STRATEGY_LEAST_CONNECTED 

[GitHub] nifi pull request #2956: NIFI-5537 Create Neo4J cypher execution processor

2018-10-01 Thread alopresto
Github user alopresto commented on a diff in the pull request:

https://github.com/apache/nifi/pull/2956#discussion_r221672221
  
--- Diff: 
nifi-nar-bundles/nifi-neo4j-bundle/nifi-neo4j-processors/src/main/java/org/apache/nifi/processors/neo4j/AbstractNeo4JCypherExecutor.java
 ---
@@ -0,0 +1,281 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You 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.
+ */
+package org.apache.nifi.processors.neo4j;
+
+import java.io.File;
+import java.util.concurrent.TimeUnit;
+
+import org.apache.commons.lang3.StringUtils;
+import org.apache.nifi.annotation.lifecycle.OnScheduled;
+import org.apache.nifi.annotation.lifecycle.OnStopped;
+import org.apache.nifi.components.AllowableValue;
+import org.apache.nifi.components.PropertyDescriptor;
+import org.apache.nifi.components.PropertyValue;
+import org.apache.nifi.expression.ExpressionLanguageScope;
+import org.apache.nifi.processor.AbstractProcessor;
+import org.apache.nifi.processor.ProcessContext;
+import org.apache.nifi.processor.Relationship;
+import org.apache.nifi.processor.exception.ProcessException;
+import org.apache.nifi.processor.util.StandardValidators;
+import org.neo4j.driver.v1.AuthTokens;
+import org.neo4j.driver.v1.Config;
+import org.neo4j.driver.v1.Config.ConfigBuilder;
+import org.neo4j.driver.v1.Config.LoadBalancingStrategy;
+import org.neo4j.driver.v1.Config.TrustStrategy;
+import org.neo4j.driver.v1.Driver;
+import org.neo4j.driver.v1.GraphDatabase;
+
+/**
+ * Abstract base class for Neo4JCypherExecutor processors
+ */
+abstract class AbstractNeo4JCypherExecutor extends AbstractProcessor {
+
+protected static final PropertyDescriptor QUERY = new 
PropertyDescriptor.Builder()
+.name("neo4J-query")
+.displayName("Neo4J Query")
+.description("Specifies the Neo4j Query.")
+.required(true)
+
.expressionLanguageSupported(ExpressionLanguageScope.FLOWFILE_ATTRIBUTES)
+.addValidator(StandardValidators.NON_BLANK_VALIDATOR)
+.build();
+
+public static final PropertyDescriptor CONNECTION_URL = new 
PropertyDescriptor.Builder()
+.name("neo4j-connection-url")
+.displayName("Neo4j Connection URL")
+.description("Neo4J endpoing to connect to.")
+.required(true)
+.defaultValue("bolt://localhost:7687")
+
.expressionLanguageSupported(ExpressionLanguageScope.VARIABLE_REGISTRY)
+.addValidator(StandardValidators.NON_EMPTY_VALIDATOR)
+.build();
+
+public static final PropertyDescriptor USERNAME = new 
PropertyDescriptor.Builder()
+.name("neo4j-username")
+.displayName("Username")
+.description("Username for accessing Neo4J")
+.required(true)
+
.expressionLanguageSupported(ExpressionLanguageScope.VARIABLE_REGISTRY)
+.addValidator(StandardValidators.NON_BLANK_VALIDATOR)
+.build();
+
+public static final PropertyDescriptor PASSWORD = new 
PropertyDescriptor.Builder()
+.name("neo4j-password")
+.displayName("Password")
+.description("Password for Neo4J user")
+.required(true)
+.sensitive(true)
+
.expressionLanguageSupported(ExpressionLanguageScope.VARIABLE_REGISTRY)
+.addValidator(StandardValidators.NON_BLANK_VALIDATOR)
+.build();
+
+public static AllowableValue LOAD_BALANCING_STRATEGY_ROUND_ROBIN = new 
AllowableValue(LoadBalancingStrategy.ROUND_ROBIN.name(), "Round Robin", "Round 
Robin Strategy");
+
+public static AllowableValue LOAD_BALANCING_STRATEGY_LEAST_CONNECTED = 
new AllowableValue(LoadBalancingStrategy.LEAST_CONNECTED.name(), "Least 
Connected", "Least Connected Strategy");
+
+protected static final PropertyDescriptor LOAD_BALANCING_STRATEGY = 
new PropertyDescriptor.Builder()
   

[jira] [Created] (NIFI-5653) Add NiFi ports section to the Administration Guide

2018-10-01 Thread Andrew Lim (JIRA)
Andrew Lim created NIFI-5653:


 Summary: Add NiFi ports section to the Administration Guide
 Key: NIFI-5653
 URL: https://issues.apache.org/jira/browse/NIFI-5653
 Project: Apache NiFi
  Issue Type: Improvement
  Components: Documentation  Website
Reporter: Andrew Lim


It would be useful to document/list which ports NiFi opens.  Can display what 
the defaults are as well as how to configure if applicable. 



--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[jira] [Commented] (NIFIREG-182) Add a way to move on from reverted versions

2018-10-01 Thread Randy Thomasson (JIRA)


[ 
https://issues.apache.org/jira/browse/NIFIREG-182?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=16634242#comment-16634242
 ] 

Randy Thomasson commented on NIFIREG-182:
-

To me, this is more than a minor annoyance.

As  a developer, I would expect to be able to exercise the full lifecycle of a 
flow version including:
 * Creating a flow version (currently supported in both the NiFi UI and the 
Registry REST API)
 * Retrieving a flow version (currently supported in both the NiFi UI and the 
Registry REST API)
 * Deleting a flow version (currently not supported)

The current workarounds for dealing with this as outlined by Fredrik in 
original post leave a lot to be desired.

My general expectation would be that any API that allows me to create something 
would make provision for deleting the same.

 

> Add a way to move on from reverted versions
> ---
>
> Key: NIFIREG-182
> URL: https://issues.apache.org/jira/browse/NIFIREG-182
> Project: NiFi Registry
>  Issue Type: New Feature
>Affects Versions: 0.2.0
> Environment: NiFi 1.7.0, NiFi Registry 0.2.0
>Reporter: Fredrik Skolmli
>Priority: Minor
>
> Quote from {{nifi-users thread "Registry - deleting versions of flow}}".
> {quote}I'm not sure if my workflow needs to change using NiFi + NiFi 
> Registry, or if this is a bug or corner-case.
>   
>  I do the following:
>  1) Create a new process group, make the initial flow and start version 
> control (ver 1)
>  2) Modify the workflow and commit (ver 2)
>  3) Realize the most recent change was defective, and reverts (back to ver 1)
>  4) Make some new changes
>   
>  I'm now stuck with NiFi telling me "Local changes have been made and a newer 
> version of the flow is available".
>   
>  There are two options as I see it:
>   
>  1) The need for the ability to delete version 2, enabling me to commit my 
> local changes.
>  2) The ability to commit a new version 3, which is a child of version 1.
>   
>  As of now (running NiFI 1.7 and Registry 0.2), my only options are to either 
> revert my local changes or stop version control. My current workaround is 
> unfortunately to stop version control, delete the entire flow using the 
> Registry UI and start over again.
>  Thoughts?
> {quote}
>  
>  Creating Jira ticket as suggested by [~bende] to track 
> development/ideas/thoughts.
>   



--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[jira] [Commented] (NIFI-5652) LogMessage emits "transfer relationship not specified" error

2018-10-01 Thread Mark Payne (JIRA)


[ 
https://issues.apache.org/jira/browse/NIFI-5652?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=16634231#comment-16634231
 ] 

Mark Payne commented on NIFI-5652:
--

There does seem to be a bug in that processor, if the log level is not enabled. 
So if it logs at INFO and the log level is not enabled for INFO, the bug is 
triggered. It looks like maybe it was intended to be an optimization, by 
pulling a batch and transferring them to success. But in doing so, it ignored 
the original FlowFile that was pulled and only tries to transfer the batch... 
That optimization should be removed, as the logic is also not correct... Since 
the Log Level is determined by Expression Language evaluated against 
Attributes, it should never transfer a chunk of FlowFiles, because one of the 
FlowFiles in that batch may indicate that a lower (or higher) log level is to 
be used...

> LogMessage emits "transfer relationship not specified" error
> 
>
> Key: NIFI-5652
> URL: https://issues.apache.org/jira/browse/NIFI-5652
> Project: Apache NiFi
>  Issue Type: Bug
>  Components: Core Framework
>Affects Versions: 1.7.1
> Environment: 3 nodes cluster of CentOS 7.4 servers; JRE 1.8
>Reporter: Takeshi Koya
>Priority: Minor
>
> Hi, all NiFi developers and users.
> I upgraded our staging cluster from 1.5 to 1.7.1 recently, 
>  but I am in trouble with LogMessage errors.
> The combination of a log level and a bulletin level that is higher than the 
> log level seems to bring about the following "transfer relationship not 
> specified" error.
> {code:java}
> 2018-10-02 00:00:00,442 ERROR [Timer-Driven Process Thread-7] 
> o.a.nifi.processors.standard.LogMessage LogMessage[id=...] LogMessage[id=...] 
> failed to process session due to 
> org.apache.nifi.processor.exception.FlowFileHandlingException: 
> StandardFlowFileRecord[uuid=...,claim=StandardContentClaim 
> [resourceClaim=StandardResourceClaim[id=1538373600261-460, container=default, 
> section=460], offset=7822560, 
> length=8434],offset=0,name=potaufeu_topics_static_ip-172-19-25-78_20181001162829878.tar.gz,size=8434]
>  transfer relationship not specified; Processor Administratively Yielded for 
> 1 sec: org.apache.nifi.processor.exception.FlowFileHandlingException: 
> StandardFlowFileRecord[uuid=...,claim=StandardContentClaim 
> [resourceClaim=StandardResourceClaim[id=1538373600261-460, container=default, 
> section=460], offset=7822560, 
> length=8434],offset=0,name=potaufeu_topics_static_ip-172-19-25-78_20181001162829878.tar.gz,size=8434]
>  transfer relationship not specified
> {code}
> Errors disappear if we make a bulletin level equal to or lower than a log 
> level.



--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[jira] [Created] (NIFI-5652) LogMessage emits "transfer relationship not specified" error

2018-10-01 Thread Takeshi Koya (JIRA)
Takeshi Koya created NIFI-5652:
--

 Summary: LogMessage emits "transfer relationship not specified" 
error
 Key: NIFI-5652
 URL: https://issues.apache.org/jira/browse/NIFI-5652
 Project: Apache NiFi
  Issue Type: Bug
  Components: Core Framework
Affects Versions: 1.7.1
 Environment: 3 nodes cluster of CentOS 7.4 servers; JRE 1.8
Reporter: Takeshi Koya


Hi, all NiFi developers and users.

I upgraded our staging cluster from 1.5 to 1.7.1 recently, 
 but I am in trouble with LogMessage errors.

The combination of a log level and a bulletin level that is higher than the log 
level seems to bring about the following "transfer relationship not specified" 
error.
{code:java}
2018-10-02 00:00:00,442 ERROR [Timer-Driven Process Thread-7] 
o.a.nifi.processors.standard.LogMessage LogMessage[id=...] LogMessage[id=...] 
failed to process session due to 
org.apache.nifi.processor.exception.FlowFileHandlingException: 
StandardFlowFileRecord[uuid=...,claim=StandardContentClaim 
[resourceClaim=StandardResourceClaim[id=1538373600261-460, container=default, 
section=460], offset=7822560, 
length=8434],offset=0,name=potaufeu_topics_static_ip-172-19-25-78_20181001162829878.tar.gz,size=8434]
 transfer relationship not specified; Processor Administratively Yielded for 1 
sec: org.apache.nifi.processor.exception.FlowFileHandlingException: 
StandardFlowFileRecord[uuid=...,claim=StandardContentClaim 
[resourceClaim=StandardResourceClaim[id=1538373600261-460, container=default, 
section=460], offset=7822560, 
length=8434],offset=0,name=potaufeu_topics_static_ip-172-19-25-78_20181001162829878.tar.gz,size=8434]
 transfer relationship not specified
{code}

Errors disappear if we make a bulletin level equal to or lower than a log level.



--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[jira] [Commented] (NIFI-5605) Create Cassandra update/delete processor

2018-10-01 Thread ASF GitHub Bot (JIRA)


[ 
https://issues.apache.org/jira/browse/NIFI-5605?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=16634159#comment-16634159
 ] 

ASF GitHub Bot commented on NIFI-5605:
--

Github user mattyb149 commented on the issue:

https://github.com/apache/nifi/pull/3025
  
Is there a reason we can't have delete/update capabilities in 
PutCassandraQL and/or PutCassandraRecord? Wondering why the need for a separate 
processor. If it does need to be separate, maybe UpdateCassandraRecord instead 
or in addition to?


> Create Cassandra update/delete processor
> 
>
> Key: NIFI-5605
> URL: https://issues.apache.org/jira/browse/NIFI-5605
> Project: Apache NiFi
>  Issue Type: New Feature
>Reporter: Mike Thomsen
>Assignee: Mike Thomsen
>Priority: Major
>
> There should be a processor that can update and delete from Cassandra tables. 
> Where QueryCassandra is geared toward reading data, this should be geared 
> toward data mutations.



--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[GitHub] nifi issue #3025: NIFI-5605 Added UpdateCassandra.

2018-10-01 Thread mattyb149
Github user mattyb149 commented on the issue:

https://github.com/apache/nifi/pull/3025
  
Is there a reason we can't have delete/update capabilities in 
PutCassandraQL and/or PutCassandraRecord? Wondering why the need for a separate 
processor. If it does need to be separate, maybe UpdateCassandraRecord instead 
or in addition to?


---


[jira] [Commented] (NIFI-5650) Add xercesImpl to scripting NAR for Jython 2.7.1

2018-10-01 Thread ASF GitHub Bot (JIRA)


[ 
https://issues.apache.org/jira/browse/NIFI-5650?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=16634156#comment-16634156
 ] 

ASF GitHub Bot commented on NIFI-5650:
--

Github user MikeThomsen commented on the issue:

https://github.com/apache/nifi/pull/3042
  
Merged.


> Add xercesImpl to scripting NAR for Jython 2.7.1
> 
>
> Key: NIFI-5650
> URL: https://issues.apache.org/jira/browse/NIFI-5650
> Project: Apache NiFi
>  Issue Type: Improvement
>  Components: Extensions
>Reporter: Matt Burgess
>Assignee: Matt Burgess
>Priority: Major
> Fix For: 1.8.0
>
>
> NIFI-4301 bumped the version of Jython from Jython 2.7.0 to 2.7.1 in order to 
> get a fix related to the os.getpid() method. However Jython 2.7.1 does not 
> include Xerces (which provides the SAXParser for XML parsing), so although 
> one bug is fixed, a capability has been degraded.
> Recommend explicitly adding Xerces as a dependency to the scripting NAR, and 
> make sure the unit tests and such run for other languages, so as not to 
> introduce a classloading issue if some engine brings their own Xerces shaded 
> into the engine's JAR(s), for example.



--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[GitHub] nifi issue #3042: NIFI-5650: Added Xerces to scripting bundle for Jython 2.7...

2018-10-01 Thread MikeThomsen
Github user MikeThomsen commented on the issue:

https://github.com/apache/nifi/pull/3042
  
Merged.


---


[jira] [Commented] (NIFI-5650) Add xercesImpl to scripting NAR for Jython 2.7.1

2018-10-01 Thread ASF GitHub Bot (JIRA)


[ 
https://issues.apache.org/jira/browse/NIFI-5650?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=16634155#comment-16634155
 ] 

ASF GitHub Bot commented on NIFI-5650:
--

Github user asfgit closed the pull request at:

https://github.com/apache/nifi/pull/3042


> Add xercesImpl to scripting NAR for Jython 2.7.1
> 
>
> Key: NIFI-5650
> URL: https://issues.apache.org/jira/browse/NIFI-5650
> Project: Apache NiFi
>  Issue Type: Improvement
>  Components: Extensions
>Reporter: Matt Burgess
>Assignee: Matt Burgess
>Priority: Major
> Fix For: 1.8.0
>
>
> NIFI-4301 bumped the version of Jython from Jython 2.7.0 to 2.7.1 in order to 
> get a fix related to the os.getpid() method. However Jython 2.7.1 does not 
> include Xerces (which provides the SAXParser for XML parsing), so although 
> one bug is fixed, a capability has been degraded.
> Recommend explicitly adding Xerces as a dependency to the scripting NAR, and 
> make sure the unit tests and such run for other languages, so as not to 
> introduce a classloading issue if some engine brings their own Xerces shaded 
> into the engine's JAR(s), for example.



--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[jira] [Commented] (NIFI-5650) Add xercesImpl to scripting NAR for Jython 2.7.1

2018-10-01 Thread ASF subversion and git services (JIRA)


[ 
https://issues.apache.org/jira/browse/NIFI-5650?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=16634154#comment-16634154
 ] 

ASF subversion and git services commented on NIFI-5650:
---

Commit 813cc1f6a25417c47eafd409089c7d2dec7ac12a in nifi's branch 
refs/heads/master from [~ca9mbu]
[ https://git-wip-us.apache.org/repos/asf?p=nifi.git;h=813cc1f ]

NIFI-5650: Added Xerces to scripting bundle for Jython 2.7.1

This closes #3042

Signed-off-by: Mike Thomsen 


> Add xercesImpl to scripting NAR for Jython 2.7.1
> 
>
> Key: NIFI-5650
> URL: https://issues.apache.org/jira/browse/NIFI-5650
> Project: Apache NiFi
>  Issue Type: Improvement
>  Components: Extensions
>Reporter: Matt Burgess
>Assignee: Matt Burgess
>Priority: Major
> Fix For: 1.8.0
>
>
> NIFI-4301 bumped the version of Jython from Jython 2.7.0 to 2.7.1 in order to 
> get a fix related to the os.getpid() method. However Jython 2.7.1 does not 
> include Xerces (which provides the SAXParser for XML parsing), so although 
> one bug is fixed, a capability has been degraded.
> Recommend explicitly adding Xerces as a dependency to the scripting NAR, and 
> make sure the unit tests and such run for other languages, so as not to 
> introduce a classloading issue if some engine brings their own Xerces shaded 
> into the engine's JAR(s), for example.



--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[jira] [Updated] (NIFI-5650) Add xercesImpl to scripting NAR for Jython 2.7.1

2018-10-01 Thread Mike Thomsen (JIRA)


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

Mike Thomsen updated NIFI-5650:
---
   Resolution: Fixed
Fix Version/s: 1.8.0
   Status: Resolved  (was: Patch Available)

> Add xercesImpl to scripting NAR for Jython 2.7.1
> 
>
> Key: NIFI-5650
> URL: https://issues.apache.org/jira/browse/NIFI-5650
> Project: Apache NiFi
>  Issue Type: Improvement
>  Components: Extensions
>Reporter: Matt Burgess
>Assignee: Matt Burgess
>Priority: Major
> Fix For: 1.8.0
>
>
> NIFI-4301 bumped the version of Jython from Jython 2.7.0 to 2.7.1 in order to 
> get a fix related to the os.getpid() method. However Jython 2.7.1 does not 
> include Xerces (which provides the SAXParser for XML parsing), so although 
> one bug is fixed, a capability has been degraded.
> Recommend explicitly adding Xerces as a dependency to the scripting NAR, and 
> make sure the unit tests and such run for other languages, so as not to 
> introduce a classloading issue if some engine brings their own Xerces shaded 
> into the engine's JAR(s), for example.



--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[GitHub] nifi pull request #3042: NIFI-5650: Added Xerces to scripting bundle for Jyt...

2018-10-01 Thread asfgit
Github user asfgit closed the pull request at:

https://github.com/apache/nifi/pull/3042


---


[jira] [Commented] (NIFI-5516) Allow data in a Connection to be Load-Balanced across cluster

2018-10-01 Thread ASF GitHub Bot (JIRA)


[ 
https://issues.apache.org/jira/browse/NIFI-5516?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=16634151#comment-16634151
 ] 

ASF GitHub Bot commented on NIFI-5516:
--

Github user markap14 commented on the issue:

https://github.com/apache/nifi/pull/2947
  
@jtstorck @ijokarumawak thanks for the time that you guys have put into 
reviewing this! I just pushed a new commit, which I believe addresses the 
feedback above. It also updates the dependency on nifi-registry from 
0.3.0-SNAPSHOT to 0.3.0.


> Allow data in a Connection to be Load-Balanced across cluster
> -
>
> Key: NIFI-5516
> URL: https://issues.apache.org/jira/browse/NIFI-5516
> Project: Apache NiFi
>  Issue Type: New Feature
>  Components: Core Framework
>Reporter: Mark Payne
>Assignee: Mark Payne
>Priority: Major
>
> Allow user to configure a Connection to be load balanced across the cluster. 
> For more information, see Feature Proposal at 
> https://cwiki.apache.org/confluence/display/NIFI/Load-Balanced+Connections



--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[GitHub] nifi issue #2947: [WIP] NIFI-5516: Implement Load-Balanced Connections

2018-10-01 Thread markap14
Github user markap14 commented on the issue:

https://github.com/apache/nifi/pull/2947
  
@jtstorck @ijokarumawak thanks for the time that you guys have put into 
reviewing this! I just pushed a new commit, which I believe addresses the 
feedback above. It also updates the dependency on nifi-registry from 
0.3.0-SNAPSHOT to 0.3.0.


---


[jira] [Created] (NIFI-5651) Provide better support for backpressure on load-balanced connections

2018-10-01 Thread Mark Payne (JIRA)
Mark Payne created NIFI-5651:


 Summary: Provide better support for backpressure on load-balanced 
connections
 Key: NIFI-5651
 URL: https://issues.apache.org/jira/browse/NIFI-5651
 Project: Apache NiFi
  Issue Type: Improvement
Reporter: Mark Payne
Assignee: Mark Payne






--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[jira] [Commented] (NIFI-5516) Allow data in a Connection to be Load-Balanced across cluster

2018-10-01 Thread ASF GitHub Bot (JIRA)


[ 
https://issues.apache.org/jira/browse/NIFI-5516?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=16634150#comment-16634150
 ] 

ASF GitHub Bot commented on NIFI-5516:
--

Github user markap14 commented on a diff in the pull request:

https://github.com/apache/nifi/pull/2947#discussion_r221641452
  
--- Diff: 
nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/queue/clustered/server/ConnectionLoadBalanceServer.java
 ---
@@ -0,0 +1,251 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You 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.
+ */
+
+package org.apache.nifi.controller.queue.clustered.server;
+
+import org.apache.nifi.engine.FlowEngine;
+import org.apache.nifi.events.EventReporter;
+import org.apache.nifi.reporting.Severity;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
+
+import javax.net.ssl.SSLContext;
+import javax.net.ssl.SSLServerSocket;
+import java.io.IOException;
+import java.net.InetAddress;
+import java.net.ServerSocket;
+import java.net.Socket;
+import java.net.SocketTimeoutException;
+import java.util.Collections;
+import java.util.HashSet;
+import java.util.Set;
+import java.util.concurrent.BlockingQueue;
+import java.util.concurrent.ExecutorService;
+import java.util.concurrent.LinkedBlockingQueue;
+import java.util.concurrent.TimeUnit;
+
+
+public class ConnectionLoadBalanceServer {
+private static final Logger logger = 
LoggerFactory.getLogger(ConnectionLoadBalanceServer.class);
+
+private final String hostname;
+private final int port;
+private final SSLContext sslContext;
+private final ExecutorService threadPool;
+private final LoadBalanceProtocol loadBalanceProtocol;
+private final int connectionTimeoutMillis;
+private final int numThreads;
+private final EventReporter eventReporter;
+
+private volatile Set communicationActions = 
Collections.emptySet();
+private final BlockingQueue connectionQueue = new 
LinkedBlockingQueue<>();
+
+private volatile AcceptConnection acceptConnection;
+private volatile ServerSocket serverSocket;
+private volatile boolean stopped = true;
+
+public ConnectionLoadBalanceServer(final String hostname, final int 
port, final SSLContext sslContext, final int numThreads, final 
LoadBalanceProtocol loadBalanceProtocol,
+   final EventReporter eventReporter, 
final int connectionTimeoutMillis) {
+this.hostname = hostname;
+this.port = port;
+this.sslContext = sslContext;
+this.loadBalanceProtocol = loadBalanceProtocol;
+this.connectionTimeoutMillis = connectionTimeoutMillis;
+this.numThreads = numThreads;
+this.eventReporter = eventReporter;
+
+threadPool = new FlowEngine(numThreads, "Load Balance Server");
+}
+
+public void start() throws IOException {
+if (!stopped) {
+return;
+}
+
+stopped = false;
+if (serverSocket != null) {
+return;
+}
+
+try {
+serverSocket = createServerSocket();
+} catch (final Exception e) {
+throw new IOException("Could not begin listening for incoming 
connections in order to load balance data across the cluster. Please verify the 
values of the " +
+"'nifi.cluster.load.balance.port' and 
'nifi.cluster.load.balance.host' properties as well as the 'nifi.security.*' 
properties", e);
+}
+
+final Set actions = new HashSet<>(numThreads);
+for (int i=0; i < numThreads; i++) {
+final CommunicateAction action = new 
CommunicateAction(loadBalanceProtocol);
+actions.add(action);
+threadPool.submit(action);
+}
+
+this.communicationActions 

[jira] [Commented] (NIFI-5254) Upgrade to Groovy 2.5.0

2018-10-01 Thread ASF GitHub Bot (JIRA)


[ 
https://issues.apache.org/jira/browse/NIFI-5254?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=16634149#comment-16634149
 ] 

ASF GitHub Bot commented on NIFI-5254:
--

Github user mattyb149 commented on the issue:

https://github.com/apache/nifi/pull/3015
  
Unfortunately I believe you need to enumerate all the transitive 
dependencies in the L You should have been able to copy that from the Groovy 
NOTICE, but it does not have its own dependencies listed in there (assuming 
some of the dependencies have NOTICEs), so we have to do it here. Their LICENSE 
mentions a couple of dependencies, but I'm not sure it's complete, so you'll 
have to verify both our L include the appropriate entries.


> Upgrade to Groovy 2.5.0
> ---
>
> Key: NIFI-5254
> URL: https://issues.apache.org/jira/browse/NIFI-5254
> Project: Apache NiFi
>  Issue Type: Improvement
>Reporter: Mike Thomsen
>Assignee: Mike Thomsen
>Priority: Major
>
> Groovy 2.5 has been released and support for it should be added.



--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[GitHub] nifi pull request #2947: [WIP] NIFI-5516: Implement Load-Balanced Connection...

2018-10-01 Thread markap14
Github user markap14 commented on a diff in the pull request:

https://github.com/apache/nifi/pull/2947#discussion_r221641452
  
--- Diff: 
nifi-nar-bundles/nifi-framework-bundle/nifi-framework/nifi-framework-core/src/main/java/org/apache/nifi/controller/queue/clustered/server/ConnectionLoadBalanceServer.java
 ---
@@ -0,0 +1,251 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You 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.
+ */
+
+package org.apache.nifi.controller.queue.clustered.server;
+
+import org.apache.nifi.engine.FlowEngine;
+import org.apache.nifi.events.EventReporter;
+import org.apache.nifi.reporting.Severity;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
+
+import javax.net.ssl.SSLContext;
+import javax.net.ssl.SSLServerSocket;
+import java.io.IOException;
+import java.net.InetAddress;
+import java.net.ServerSocket;
+import java.net.Socket;
+import java.net.SocketTimeoutException;
+import java.util.Collections;
+import java.util.HashSet;
+import java.util.Set;
+import java.util.concurrent.BlockingQueue;
+import java.util.concurrent.ExecutorService;
+import java.util.concurrent.LinkedBlockingQueue;
+import java.util.concurrent.TimeUnit;
+
+
+public class ConnectionLoadBalanceServer {
+private static final Logger logger = 
LoggerFactory.getLogger(ConnectionLoadBalanceServer.class);
+
+private final String hostname;
+private final int port;
+private final SSLContext sslContext;
+private final ExecutorService threadPool;
+private final LoadBalanceProtocol loadBalanceProtocol;
+private final int connectionTimeoutMillis;
+private final int numThreads;
+private final EventReporter eventReporter;
+
+private volatile Set communicationActions = 
Collections.emptySet();
+private final BlockingQueue connectionQueue = new 
LinkedBlockingQueue<>();
+
+private volatile AcceptConnection acceptConnection;
+private volatile ServerSocket serverSocket;
+private volatile boolean stopped = true;
+
+public ConnectionLoadBalanceServer(final String hostname, final int 
port, final SSLContext sslContext, final int numThreads, final 
LoadBalanceProtocol loadBalanceProtocol,
+   final EventReporter eventReporter, 
final int connectionTimeoutMillis) {
+this.hostname = hostname;
+this.port = port;
+this.sslContext = sslContext;
+this.loadBalanceProtocol = loadBalanceProtocol;
+this.connectionTimeoutMillis = connectionTimeoutMillis;
+this.numThreads = numThreads;
+this.eventReporter = eventReporter;
+
+threadPool = new FlowEngine(numThreads, "Load Balance Server");
+}
+
+public void start() throws IOException {
+if (!stopped) {
+return;
+}
+
+stopped = false;
+if (serverSocket != null) {
+return;
+}
+
+try {
+serverSocket = createServerSocket();
+} catch (final Exception e) {
+throw new IOException("Could not begin listening for incoming 
connections in order to load balance data across the cluster. Please verify the 
values of the " +
+"'nifi.cluster.load.balance.port' and 
'nifi.cluster.load.balance.host' properties as well as the 'nifi.security.*' 
properties", e);
+}
+
+final Set actions = new HashSet<>(numThreads);
+for (int i=0; i < numThreads; i++) {
+final CommunicateAction action = new 
CommunicateAction(loadBalanceProtocol);
+actions.add(action);
+threadPool.submit(action);
+}
+
+this.communicationActions = actions;
+
+acceptConnection = new AcceptConnection(serverSocket);
+final Thread receiveConnectionThread = new 
Thread(acceptConnection);
+receiveConnectionThread.setName("Receive Queue 

[GitHub] nifi issue #3015: NIFI-5254 [WIP] Updated to Groovy 2.5.2

2018-10-01 Thread mattyb149
Github user mattyb149 commented on the issue:

https://github.com/apache/nifi/pull/3015
  
Unfortunately I believe you need to enumerate all the transitive 
dependencies in the L You should have been able to copy that from the Groovy 
NOTICE, but it does not have its own dependencies listed in there (assuming 
some of the dependencies have NOTICEs), so we have to do it here. Their LICENSE 
mentions a couple of dependencies, but I'm not sure it's complete, so you'll 
have to verify both our L include the appropriate entries.


---


[jira] [Commented] (NIFI-5248) Create new put processors that use the ElasticSearch client service

2018-10-01 Thread ASF GitHub Bot (JIRA)


[ 
https://issues.apache.org/jira/browse/NIFI-5248?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=16634144#comment-16634144
 ] 

ASF GitHub Bot commented on NIFI-5248:
--

Github user mattyb149 commented on the issue:

https://github.com/apache/nifi/pull/2861
  
Mind rebasing this one? I think you were waiting on the ES LookupService PR 
anyway, and now it's in :)


> Create new put processors that use the ElasticSearch client service
> ---
>
> Key: NIFI-5248
> URL: https://issues.apache.org/jira/browse/NIFI-5248
> Project: Apache NiFi
>  Issue Type: New Feature
>Reporter: Mike Thomsen
>Assignee: Mike Thomsen
>Priority: Major
>
> Two new processors:
>  * PutElasticsearchJson - put raw JSON.
>  * PutElasticsearchRecord - put records.
> Both of them should support the general bulk load API and be able to do 
> things like insert into multiple indexes from one payload.



--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[GitHub] nifi issue #2861: NIFI-5248 Added new Elasticsearch json and record processo...

2018-10-01 Thread mattyb149
Github user mattyb149 commented on the issue:

https://github.com/apache/nifi/pull/2861
  
Mind rebasing this one? I think you were waiting on the ES LookupService PR 
anyway, and now it's in :)


---


[jira] [Commented] (NIFI-5051) Create a LookupService that uses ElasticSearch

2018-10-01 Thread ASF GitHub Bot (JIRA)


[ 
https://issues.apache.org/jira/browse/NIFI-5051?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=16634141#comment-16634141
 ] 

ASF GitHub Bot commented on NIFI-5051:
--

Github user asfgit closed the pull request at:

https://github.com/apache/nifi/pull/2615


> Create a LookupService that uses ElasticSearch
> --
>
> Key: NIFI-5051
> URL: https://issues.apache.org/jira/browse/NIFI-5051
> Project: Apache NiFi
>  Issue Type: New Feature
>Reporter: Mike Thomsen
>Assignee: Mike Thomsen
>Priority: Major
> Fix For: 1.8.0
>
>




--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[jira] [Updated] (NIFI-5051) Create a LookupService that uses ElasticSearch

2018-10-01 Thread Matt Burgess (JIRA)


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

Matt Burgess updated NIFI-5051:
---
Fix Version/s: 1.8.0

> Create a LookupService that uses ElasticSearch
> --
>
> Key: NIFI-5051
> URL: https://issues.apache.org/jira/browse/NIFI-5051
> Project: Apache NiFi
>  Issue Type: New Feature
>Reporter: Mike Thomsen
>Assignee: Mike Thomsen
>Priority: Major
> Fix For: 1.8.0
>
>




--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[jira] [Updated] (NIFI-5051) Create a LookupService that uses ElasticSearch

2018-10-01 Thread Matt Burgess (JIRA)


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

Matt Burgess updated NIFI-5051:
---
Resolution: Fixed
Status: Resolved  (was: Patch Available)

> Create a LookupService that uses ElasticSearch
> --
>
> Key: NIFI-5051
> URL: https://issues.apache.org/jira/browse/NIFI-5051
> Project: Apache NiFi
>  Issue Type: New Feature
>Reporter: Mike Thomsen
>Assignee: Mike Thomsen
>Priority: Major
> Fix For: 1.8.0
>
>




--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[jira] [Commented] (NIFI-5650) Add xercesImpl to scripting NAR for Jython 2.7.1

2018-10-01 Thread ASF GitHub Bot (JIRA)


[ 
https://issues.apache.org/jira/browse/NIFI-5650?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=16634142#comment-16634142
 ] 

ASF GitHub Bot commented on NIFI-5650:
--

Github user mattyb149 commented on the issue:

https://github.com/apache/nifi/pull/3042
  
Thanks! Might need to update your master before pushing, I brought in your 
ES Lookup Service PR (finally :P)


> Add xercesImpl to scripting NAR for Jython 2.7.1
> 
>
> Key: NIFI-5650
> URL: https://issues.apache.org/jira/browse/NIFI-5650
> Project: Apache NiFi
>  Issue Type: Improvement
>  Components: Extensions
>Reporter: Matt Burgess
>Assignee: Matt Burgess
>Priority: Major
>
> NIFI-4301 bumped the version of Jython from Jython 2.7.0 to 2.7.1 in order to 
> get a fix related to the os.getpid() method. However Jython 2.7.1 does not 
> include Xerces (which provides the SAXParser for XML parsing), so although 
> one bug is fixed, a capability has been degraded.
> Recommend explicitly adding Xerces as a dependency to the scripting NAR, and 
> make sure the unit tests and such run for other languages, so as not to 
> introduce a classloading issue if some engine brings their own Xerces shaded 
> into the engine's JAR(s), for example.



--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[jira] [Commented] (NIFI-5051) Create a LookupService that uses ElasticSearch

2018-10-01 Thread ASF subversion and git services (JIRA)


[ 
https://issues.apache.org/jira/browse/NIFI-5051?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=16634130#comment-16634130
 ] 

ASF subversion and git services commented on NIFI-5051:
---

Commit b1478cdb195722d7d285cad53d1f89c325868f55 in nifi's branch 
refs/heads/master from [~mike.thomsen]
[ https://git-wip-us.apache.org/repos/asf?p=nifi.git;h=b1478cd ]

NIFI-5051 Created ElasticSearch lookup service.

NIFI-5051 Fixed checkstyle issue.

NIFI-5051 Converted ES lookup service to use a SchemaRegistry.

NIFI-5051 Cleaned up POM and added a simple unit test that uses a mock client 
service.

NIFI-5051 Added change; waiting for feedback.

NIFI-5051 Changed query setup based on code review. Changed tests to Groovy to 
make them easier to read with all of the inline JSON.

NIFI-5051 fixed a checkstyle issue.

NIFI-5051 Rebased to cleanup merge issues

NIFI-5051 Added changes from a code review.

NIFI-5051 Fixed a checkstyle issue.

NIFI-5051 Added coverage generator for tests.

Rebased.

NIFI-5051 Updated service and switched it over to 
JsonInferenceSchemaRegistryService.

NIFI-5051 Removed dead code.

NIFI-5051 Fixed checkstyle errors.

NIFI-5051 Refactored query builder.

NIFI-5051 Added placeholder gitignore to force test compile.

NIFI-5051 Added note explaining why the .gitignore file was needed.

NIFI-5051 Made constructor public.

NIFI-5051 Fixed path issue in client service integration tests.

NIFI-5051 Added additional mapping capabilities to let users massage the result 
set into the fields they want.

Signed-off-by: Matthew Burgess 

This closes #2615


> Create a LookupService that uses ElasticSearch
> --
>
> Key: NIFI-5051
> URL: https://issues.apache.org/jira/browse/NIFI-5051
> Project: Apache NiFi
>  Issue Type: New Feature
>Reporter: Mike Thomsen
>Assignee: Mike Thomsen
>Priority: Major
>




--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[jira] [Commented] (NIFI-5051) Create a LookupService that uses ElasticSearch

2018-10-01 Thread ASF subversion and git services (JIRA)


[ 
https://issues.apache.org/jira/browse/NIFI-5051?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=16634124#comment-16634124
 ] 

ASF subversion and git services commented on NIFI-5051:
---

Commit b1478cdb195722d7d285cad53d1f89c325868f55 in nifi's branch 
refs/heads/master from [~mike.thomsen]
[ https://git-wip-us.apache.org/repos/asf?p=nifi.git;h=b1478cd ]

NIFI-5051 Created ElasticSearch lookup service.

NIFI-5051 Fixed checkstyle issue.

NIFI-5051 Converted ES lookup service to use a SchemaRegistry.

NIFI-5051 Cleaned up POM and added a simple unit test that uses a mock client 
service.

NIFI-5051 Added change; waiting for feedback.

NIFI-5051 Changed query setup based on code review. Changed tests to Groovy to 
make them easier to read with all of the inline JSON.

NIFI-5051 fixed a checkstyle issue.

NIFI-5051 Rebased to cleanup merge issues

NIFI-5051 Added changes from a code review.

NIFI-5051 Fixed a checkstyle issue.

NIFI-5051 Added coverage generator for tests.

Rebased.

NIFI-5051 Updated service and switched it over to 
JsonInferenceSchemaRegistryService.

NIFI-5051 Removed dead code.

NIFI-5051 Fixed checkstyle errors.

NIFI-5051 Refactored query builder.

NIFI-5051 Added placeholder gitignore to force test compile.

NIFI-5051 Added note explaining why the .gitignore file was needed.

NIFI-5051 Made constructor public.

NIFI-5051 Fixed path issue in client service integration tests.

NIFI-5051 Added additional mapping capabilities to let users massage the result 
set into the fields they want.

Signed-off-by: Matthew Burgess 

This closes #2615


> Create a LookupService that uses ElasticSearch
> --
>
> Key: NIFI-5051
> URL: https://issues.apache.org/jira/browse/NIFI-5051
> Project: Apache NiFi
>  Issue Type: New Feature
>Reporter: Mike Thomsen
>Assignee: Mike Thomsen
>Priority: Major
>




--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[jira] [Commented] (NIFI-5051) Create a LookupService that uses ElasticSearch

2018-10-01 Thread ASF subversion and git services (JIRA)


[ 
https://issues.apache.org/jira/browse/NIFI-5051?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=16634139#comment-16634139
 ] 

ASF subversion and git services commented on NIFI-5051:
---

Commit b1478cdb195722d7d285cad53d1f89c325868f55 in nifi's branch 
refs/heads/master from [~mike.thomsen]
[ https://git-wip-us.apache.org/repos/asf?p=nifi.git;h=b1478cd ]

NIFI-5051 Created ElasticSearch lookup service.

NIFI-5051 Fixed checkstyle issue.

NIFI-5051 Converted ES lookup service to use a SchemaRegistry.

NIFI-5051 Cleaned up POM and added a simple unit test that uses a mock client 
service.

NIFI-5051 Added change; waiting for feedback.

NIFI-5051 Changed query setup based on code review. Changed tests to Groovy to 
make them easier to read with all of the inline JSON.

NIFI-5051 fixed a checkstyle issue.

NIFI-5051 Rebased to cleanup merge issues

NIFI-5051 Added changes from a code review.

NIFI-5051 Fixed a checkstyle issue.

NIFI-5051 Added coverage generator for tests.

Rebased.

NIFI-5051 Updated service and switched it over to 
JsonInferenceSchemaRegistryService.

NIFI-5051 Removed dead code.

NIFI-5051 Fixed checkstyle errors.

NIFI-5051 Refactored query builder.

NIFI-5051 Added placeholder gitignore to force test compile.

NIFI-5051 Added note explaining why the .gitignore file was needed.

NIFI-5051 Made constructor public.

NIFI-5051 Fixed path issue in client service integration tests.

NIFI-5051 Added additional mapping capabilities to let users massage the result 
set into the fields they want.

Signed-off-by: Matthew Burgess 

This closes #2615


> Create a LookupService that uses ElasticSearch
> --
>
> Key: NIFI-5051
> URL: https://issues.apache.org/jira/browse/NIFI-5051
> Project: Apache NiFi
>  Issue Type: New Feature
>Reporter: Mike Thomsen
>Assignee: Mike Thomsen
>Priority: Major
>




--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[jira] [Commented] (NIFI-5051) Create a LookupService that uses ElasticSearch

2018-10-01 Thread ASF subversion and git services (JIRA)


[ 
https://issues.apache.org/jira/browse/NIFI-5051?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=16634136#comment-16634136
 ] 

ASF subversion and git services commented on NIFI-5051:
---

Commit b1478cdb195722d7d285cad53d1f89c325868f55 in nifi's branch 
refs/heads/master from [~mike.thomsen]
[ https://git-wip-us.apache.org/repos/asf?p=nifi.git;h=b1478cd ]

NIFI-5051 Created ElasticSearch lookup service.

NIFI-5051 Fixed checkstyle issue.

NIFI-5051 Converted ES lookup service to use a SchemaRegistry.

NIFI-5051 Cleaned up POM and added a simple unit test that uses a mock client 
service.

NIFI-5051 Added change; waiting for feedback.

NIFI-5051 Changed query setup based on code review. Changed tests to Groovy to 
make them easier to read with all of the inline JSON.

NIFI-5051 fixed a checkstyle issue.

NIFI-5051 Rebased to cleanup merge issues

NIFI-5051 Added changes from a code review.

NIFI-5051 Fixed a checkstyle issue.

NIFI-5051 Added coverage generator for tests.

Rebased.

NIFI-5051 Updated service and switched it over to 
JsonInferenceSchemaRegistryService.

NIFI-5051 Removed dead code.

NIFI-5051 Fixed checkstyle errors.

NIFI-5051 Refactored query builder.

NIFI-5051 Added placeholder gitignore to force test compile.

NIFI-5051 Added note explaining why the .gitignore file was needed.

NIFI-5051 Made constructor public.

NIFI-5051 Fixed path issue in client service integration tests.

NIFI-5051 Added additional mapping capabilities to let users massage the result 
set into the fields they want.

Signed-off-by: Matthew Burgess 

This closes #2615


> Create a LookupService that uses ElasticSearch
> --
>
> Key: NIFI-5051
> URL: https://issues.apache.org/jira/browse/NIFI-5051
> Project: Apache NiFi
>  Issue Type: New Feature
>Reporter: Mike Thomsen
>Assignee: Mike Thomsen
>Priority: Major
>




--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[jira] [Commented] (NIFI-5051) Create a LookupService that uses ElasticSearch

2018-10-01 Thread ASF subversion and git services (JIRA)


[ 
https://issues.apache.org/jira/browse/NIFI-5051?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=16634120#comment-16634120
 ] 

ASF subversion and git services commented on NIFI-5051:
---

Commit b1478cdb195722d7d285cad53d1f89c325868f55 in nifi's branch 
refs/heads/master from [~mike.thomsen]
[ https://git-wip-us.apache.org/repos/asf?p=nifi.git;h=b1478cd ]

NIFI-5051 Created ElasticSearch lookup service.

NIFI-5051 Fixed checkstyle issue.

NIFI-5051 Converted ES lookup service to use a SchemaRegistry.

NIFI-5051 Cleaned up POM and added a simple unit test that uses a mock client 
service.

NIFI-5051 Added change; waiting for feedback.

NIFI-5051 Changed query setup based on code review. Changed tests to Groovy to 
make them easier to read with all of the inline JSON.

NIFI-5051 fixed a checkstyle issue.

NIFI-5051 Rebased to cleanup merge issues

NIFI-5051 Added changes from a code review.

NIFI-5051 Fixed a checkstyle issue.

NIFI-5051 Added coverage generator for tests.

Rebased.

NIFI-5051 Updated service and switched it over to 
JsonInferenceSchemaRegistryService.

NIFI-5051 Removed dead code.

NIFI-5051 Fixed checkstyle errors.

NIFI-5051 Refactored query builder.

NIFI-5051 Added placeholder gitignore to force test compile.

NIFI-5051 Added note explaining why the .gitignore file was needed.

NIFI-5051 Made constructor public.

NIFI-5051 Fixed path issue in client service integration tests.

NIFI-5051 Added additional mapping capabilities to let users massage the result 
set into the fields they want.

Signed-off-by: Matthew Burgess 

This closes #2615


> Create a LookupService that uses ElasticSearch
> --
>
> Key: NIFI-5051
> URL: https://issues.apache.org/jira/browse/NIFI-5051
> Project: Apache NiFi
>  Issue Type: New Feature
>Reporter: Mike Thomsen
>Assignee: Mike Thomsen
>Priority: Major
>




--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[jira] [Commented] (NIFI-5051) Create a LookupService that uses ElasticSearch

2018-10-01 Thread ASF subversion and git services (JIRA)


[ 
https://issues.apache.org/jira/browse/NIFI-5051?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=16634127#comment-16634127
 ] 

ASF subversion and git services commented on NIFI-5051:
---

Commit b1478cdb195722d7d285cad53d1f89c325868f55 in nifi's branch 
refs/heads/master from [~mike.thomsen]
[ https://git-wip-us.apache.org/repos/asf?p=nifi.git;h=b1478cd ]

NIFI-5051 Created ElasticSearch lookup service.

NIFI-5051 Fixed checkstyle issue.

NIFI-5051 Converted ES lookup service to use a SchemaRegistry.

NIFI-5051 Cleaned up POM and added a simple unit test that uses a mock client 
service.

NIFI-5051 Added change; waiting for feedback.

NIFI-5051 Changed query setup based on code review. Changed tests to Groovy to 
make them easier to read with all of the inline JSON.

NIFI-5051 fixed a checkstyle issue.

NIFI-5051 Rebased to cleanup merge issues

NIFI-5051 Added changes from a code review.

NIFI-5051 Fixed a checkstyle issue.

NIFI-5051 Added coverage generator for tests.

Rebased.

NIFI-5051 Updated service and switched it over to 
JsonInferenceSchemaRegistryService.

NIFI-5051 Removed dead code.

NIFI-5051 Fixed checkstyle errors.

NIFI-5051 Refactored query builder.

NIFI-5051 Added placeholder gitignore to force test compile.

NIFI-5051 Added note explaining why the .gitignore file was needed.

NIFI-5051 Made constructor public.

NIFI-5051 Fixed path issue in client service integration tests.

NIFI-5051 Added additional mapping capabilities to let users massage the result 
set into the fields they want.

Signed-off-by: Matthew Burgess 

This closes #2615


> Create a LookupService that uses ElasticSearch
> --
>
> Key: NIFI-5051
> URL: https://issues.apache.org/jira/browse/NIFI-5051
> Project: Apache NiFi
>  Issue Type: New Feature
>Reporter: Mike Thomsen
>Assignee: Mike Thomsen
>Priority: Major
>




--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[jira] [Commented] (NIFI-5051) Create a LookupService that uses ElasticSearch

2018-10-01 Thread ASF GitHub Bot (JIRA)


[ 
https://issues.apache.org/jira/browse/NIFI-5051?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=16634118#comment-16634118
 ] 

ASF GitHub Bot commented on NIFI-5051:
--

Github user mattyb149 commented on the issue:

https://github.com/apache/nifi/pull/2615
  
+1 LGTM, ran full build with unit tests, tried the lookup service with a 
nested record and everything worked fine. Thanks for the improvement! Merging 
to master


> Create a LookupService that uses ElasticSearch
> --
>
> Key: NIFI-5051
> URL: https://issues.apache.org/jira/browse/NIFI-5051
> Project: Apache NiFi
>  Issue Type: New Feature
>Reporter: Mike Thomsen
>Assignee: Mike Thomsen
>Priority: Major
>




--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[GitHub] nifi issue #3042: NIFI-5650: Added Xerces to scripting bundle for Jython 2.7...

2018-10-01 Thread mattyb149
Github user mattyb149 commented on the issue:

https://github.com/apache/nifi/pull/3042
  
Thanks! Might need to update your master before pushing, I brought in your 
ES Lookup Service PR (finally :P)


---


[jira] [Commented] (NIFI-5051) Create a LookupService that uses ElasticSearch

2018-10-01 Thread ASF subversion and git services (JIRA)


[ 
https://issues.apache.org/jira/browse/NIFI-5051?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=16634122#comment-16634122
 ] 

ASF subversion and git services commented on NIFI-5051:
---

Commit b1478cdb195722d7d285cad53d1f89c325868f55 in nifi's branch 
refs/heads/master from [~mike.thomsen]
[ https://git-wip-us.apache.org/repos/asf?p=nifi.git;h=b1478cd ]

NIFI-5051 Created ElasticSearch lookup service.

NIFI-5051 Fixed checkstyle issue.

NIFI-5051 Converted ES lookup service to use a SchemaRegistry.

NIFI-5051 Cleaned up POM and added a simple unit test that uses a mock client 
service.

NIFI-5051 Added change; waiting for feedback.

NIFI-5051 Changed query setup based on code review. Changed tests to Groovy to 
make them easier to read with all of the inline JSON.

NIFI-5051 fixed a checkstyle issue.

NIFI-5051 Rebased to cleanup merge issues

NIFI-5051 Added changes from a code review.

NIFI-5051 Fixed a checkstyle issue.

NIFI-5051 Added coverage generator for tests.

Rebased.

NIFI-5051 Updated service and switched it over to 
JsonInferenceSchemaRegistryService.

NIFI-5051 Removed dead code.

NIFI-5051 Fixed checkstyle errors.

NIFI-5051 Refactored query builder.

NIFI-5051 Added placeholder gitignore to force test compile.

NIFI-5051 Added note explaining why the .gitignore file was needed.

NIFI-5051 Made constructor public.

NIFI-5051 Fixed path issue in client service integration tests.

NIFI-5051 Added additional mapping capabilities to let users massage the result 
set into the fields they want.

Signed-off-by: Matthew Burgess 

This closes #2615


> Create a LookupService that uses ElasticSearch
> --
>
> Key: NIFI-5051
> URL: https://issues.apache.org/jira/browse/NIFI-5051
> Project: Apache NiFi
>  Issue Type: New Feature
>Reporter: Mike Thomsen
>Assignee: Mike Thomsen
>Priority: Major
>




--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[jira] [Commented] (NIFI-5051) Create a LookupService that uses ElasticSearch

2018-10-01 Thread ASF subversion and git services (JIRA)


[ 
https://issues.apache.org/jira/browse/NIFI-5051?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=16634121#comment-16634121
 ] 

ASF subversion and git services commented on NIFI-5051:
---

Commit b1478cdb195722d7d285cad53d1f89c325868f55 in nifi's branch 
refs/heads/master from [~mike.thomsen]
[ https://git-wip-us.apache.org/repos/asf?p=nifi.git;h=b1478cd ]

NIFI-5051 Created ElasticSearch lookup service.

NIFI-5051 Fixed checkstyle issue.

NIFI-5051 Converted ES lookup service to use a SchemaRegistry.

NIFI-5051 Cleaned up POM and added a simple unit test that uses a mock client 
service.

NIFI-5051 Added change; waiting for feedback.

NIFI-5051 Changed query setup based on code review. Changed tests to Groovy to 
make them easier to read with all of the inline JSON.

NIFI-5051 fixed a checkstyle issue.

NIFI-5051 Rebased to cleanup merge issues

NIFI-5051 Added changes from a code review.

NIFI-5051 Fixed a checkstyle issue.

NIFI-5051 Added coverage generator for tests.

Rebased.

NIFI-5051 Updated service and switched it over to 
JsonInferenceSchemaRegistryService.

NIFI-5051 Removed dead code.

NIFI-5051 Fixed checkstyle errors.

NIFI-5051 Refactored query builder.

NIFI-5051 Added placeholder gitignore to force test compile.

NIFI-5051 Added note explaining why the .gitignore file was needed.

NIFI-5051 Made constructor public.

NIFI-5051 Fixed path issue in client service integration tests.

NIFI-5051 Added additional mapping capabilities to let users massage the result 
set into the fields they want.

Signed-off-by: Matthew Burgess 

This closes #2615


> Create a LookupService that uses ElasticSearch
> --
>
> Key: NIFI-5051
> URL: https://issues.apache.org/jira/browse/NIFI-5051
> Project: Apache NiFi
>  Issue Type: New Feature
>Reporter: Mike Thomsen
>Assignee: Mike Thomsen
>Priority: Major
>




--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[jira] [Commented] (NIFI-5051) Create a LookupService that uses ElasticSearch

2018-10-01 Thread ASF subversion and git services (JIRA)


[ 
https://issues.apache.org/jira/browse/NIFI-5051?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=16634123#comment-16634123
 ] 

ASF subversion and git services commented on NIFI-5051:
---

Commit b1478cdb195722d7d285cad53d1f89c325868f55 in nifi's branch 
refs/heads/master from [~mike.thomsen]
[ https://git-wip-us.apache.org/repos/asf?p=nifi.git;h=b1478cd ]

NIFI-5051 Created ElasticSearch lookup service.

NIFI-5051 Fixed checkstyle issue.

NIFI-5051 Converted ES lookup service to use a SchemaRegistry.

NIFI-5051 Cleaned up POM and added a simple unit test that uses a mock client 
service.

NIFI-5051 Added change; waiting for feedback.

NIFI-5051 Changed query setup based on code review. Changed tests to Groovy to 
make them easier to read with all of the inline JSON.

NIFI-5051 fixed a checkstyle issue.

NIFI-5051 Rebased to cleanup merge issues

NIFI-5051 Added changes from a code review.

NIFI-5051 Fixed a checkstyle issue.

NIFI-5051 Added coverage generator for tests.

Rebased.

NIFI-5051 Updated service and switched it over to 
JsonInferenceSchemaRegistryService.

NIFI-5051 Removed dead code.

NIFI-5051 Fixed checkstyle errors.

NIFI-5051 Refactored query builder.

NIFI-5051 Added placeholder gitignore to force test compile.

NIFI-5051 Added note explaining why the .gitignore file was needed.

NIFI-5051 Made constructor public.

NIFI-5051 Fixed path issue in client service integration tests.

NIFI-5051 Added additional mapping capabilities to let users massage the result 
set into the fields they want.

Signed-off-by: Matthew Burgess 

This closes #2615


> Create a LookupService that uses ElasticSearch
> --
>
> Key: NIFI-5051
> URL: https://issues.apache.org/jira/browse/NIFI-5051
> Project: Apache NiFi
>  Issue Type: New Feature
>Reporter: Mike Thomsen
>Assignee: Mike Thomsen
>Priority: Major
>




--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[jira] [Commented] (NIFI-5051) Create a LookupService that uses ElasticSearch

2018-10-01 Thread ASF subversion and git services (JIRA)


[ 
https://issues.apache.org/jira/browse/NIFI-5051?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=16634134#comment-16634134
 ] 

ASF subversion and git services commented on NIFI-5051:
---

Commit b1478cdb195722d7d285cad53d1f89c325868f55 in nifi's branch 
refs/heads/master from [~mike.thomsen]
[ https://git-wip-us.apache.org/repos/asf?p=nifi.git;h=b1478cd ]

NIFI-5051 Created ElasticSearch lookup service.

NIFI-5051 Fixed checkstyle issue.

NIFI-5051 Converted ES lookup service to use a SchemaRegistry.

NIFI-5051 Cleaned up POM and added a simple unit test that uses a mock client 
service.

NIFI-5051 Added change; waiting for feedback.

NIFI-5051 Changed query setup based on code review. Changed tests to Groovy to 
make them easier to read with all of the inline JSON.

NIFI-5051 fixed a checkstyle issue.

NIFI-5051 Rebased to cleanup merge issues

NIFI-5051 Added changes from a code review.

NIFI-5051 Fixed a checkstyle issue.

NIFI-5051 Added coverage generator for tests.

Rebased.

NIFI-5051 Updated service and switched it over to 
JsonInferenceSchemaRegistryService.

NIFI-5051 Removed dead code.

NIFI-5051 Fixed checkstyle errors.

NIFI-5051 Refactored query builder.

NIFI-5051 Added placeholder gitignore to force test compile.

NIFI-5051 Added note explaining why the .gitignore file was needed.

NIFI-5051 Made constructor public.

NIFI-5051 Fixed path issue in client service integration tests.

NIFI-5051 Added additional mapping capabilities to let users massage the result 
set into the fields they want.

Signed-off-by: Matthew Burgess 

This closes #2615


> Create a LookupService that uses ElasticSearch
> --
>
> Key: NIFI-5051
> URL: https://issues.apache.org/jira/browse/NIFI-5051
> Project: Apache NiFi
>  Issue Type: New Feature
>Reporter: Mike Thomsen
>Assignee: Mike Thomsen
>Priority: Major
>




--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[jira] [Commented] (NIFI-5051) Create a LookupService that uses ElasticSearch

2018-10-01 Thread ASF subversion and git services (JIRA)


[ 
https://issues.apache.org/jira/browse/NIFI-5051?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=16634132#comment-16634132
 ] 

ASF subversion and git services commented on NIFI-5051:
---

Commit b1478cdb195722d7d285cad53d1f89c325868f55 in nifi's branch 
refs/heads/master from [~mike.thomsen]
[ https://git-wip-us.apache.org/repos/asf?p=nifi.git;h=b1478cd ]

NIFI-5051 Created ElasticSearch lookup service.

NIFI-5051 Fixed checkstyle issue.

NIFI-5051 Converted ES lookup service to use a SchemaRegistry.

NIFI-5051 Cleaned up POM and added a simple unit test that uses a mock client 
service.

NIFI-5051 Added change; waiting for feedback.

NIFI-5051 Changed query setup based on code review. Changed tests to Groovy to 
make them easier to read with all of the inline JSON.

NIFI-5051 fixed a checkstyle issue.

NIFI-5051 Rebased to cleanup merge issues

NIFI-5051 Added changes from a code review.

NIFI-5051 Fixed a checkstyle issue.

NIFI-5051 Added coverage generator for tests.

Rebased.

NIFI-5051 Updated service and switched it over to 
JsonInferenceSchemaRegistryService.

NIFI-5051 Removed dead code.

NIFI-5051 Fixed checkstyle errors.

NIFI-5051 Refactored query builder.

NIFI-5051 Added placeholder gitignore to force test compile.

NIFI-5051 Added note explaining why the .gitignore file was needed.

NIFI-5051 Made constructor public.

NIFI-5051 Fixed path issue in client service integration tests.

NIFI-5051 Added additional mapping capabilities to let users massage the result 
set into the fields they want.

Signed-off-by: Matthew Burgess 

This closes #2615


> Create a LookupService that uses ElasticSearch
> --
>
> Key: NIFI-5051
> URL: https://issues.apache.org/jira/browse/NIFI-5051
> Project: Apache NiFi
>  Issue Type: New Feature
>Reporter: Mike Thomsen
>Assignee: Mike Thomsen
>Priority: Major
>




--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[GitHub] nifi pull request #2615: NIFI-5051 Created ElasticSearch lookup service.

2018-10-01 Thread asfgit
Github user asfgit closed the pull request at:

https://github.com/apache/nifi/pull/2615


---


[jira] [Commented] (NIFI-5051) Create a LookupService that uses ElasticSearch

2018-10-01 Thread ASF subversion and git services (JIRA)


[ 
https://issues.apache.org/jira/browse/NIFI-5051?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=16634135#comment-16634135
 ] 

ASF subversion and git services commented on NIFI-5051:
---

Commit b1478cdb195722d7d285cad53d1f89c325868f55 in nifi's branch 
refs/heads/master from [~mike.thomsen]
[ https://git-wip-us.apache.org/repos/asf?p=nifi.git;h=b1478cd ]

NIFI-5051 Created ElasticSearch lookup service.

NIFI-5051 Fixed checkstyle issue.

NIFI-5051 Converted ES lookup service to use a SchemaRegistry.

NIFI-5051 Cleaned up POM and added a simple unit test that uses a mock client 
service.

NIFI-5051 Added change; waiting for feedback.

NIFI-5051 Changed query setup based on code review. Changed tests to Groovy to 
make them easier to read with all of the inline JSON.

NIFI-5051 fixed a checkstyle issue.

NIFI-5051 Rebased to cleanup merge issues

NIFI-5051 Added changes from a code review.

NIFI-5051 Fixed a checkstyle issue.

NIFI-5051 Added coverage generator for tests.

Rebased.

NIFI-5051 Updated service and switched it over to 
JsonInferenceSchemaRegistryService.

NIFI-5051 Removed dead code.

NIFI-5051 Fixed checkstyle errors.

NIFI-5051 Refactored query builder.

NIFI-5051 Added placeholder gitignore to force test compile.

NIFI-5051 Added note explaining why the .gitignore file was needed.

NIFI-5051 Made constructor public.

NIFI-5051 Fixed path issue in client service integration tests.

NIFI-5051 Added additional mapping capabilities to let users massage the result 
set into the fields they want.

Signed-off-by: Matthew Burgess 

This closes #2615


> Create a LookupService that uses ElasticSearch
> --
>
> Key: NIFI-5051
> URL: https://issues.apache.org/jira/browse/NIFI-5051
> Project: Apache NiFi
>  Issue Type: New Feature
>Reporter: Mike Thomsen
>Assignee: Mike Thomsen
>Priority: Major
>




--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[jira] [Commented] (NIFI-5051) Create a LookupService that uses ElasticSearch

2018-10-01 Thread ASF subversion and git services (JIRA)


[ 
https://issues.apache.org/jira/browse/NIFI-5051?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=16634137#comment-16634137
 ] 

ASF subversion and git services commented on NIFI-5051:
---

Commit b1478cdb195722d7d285cad53d1f89c325868f55 in nifi's branch 
refs/heads/master from [~mike.thomsen]
[ https://git-wip-us.apache.org/repos/asf?p=nifi.git;h=b1478cd ]

NIFI-5051 Created ElasticSearch lookup service.

NIFI-5051 Fixed checkstyle issue.

NIFI-5051 Converted ES lookup service to use a SchemaRegistry.

NIFI-5051 Cleaned up POM and added a simple unit test that uses a mock client 
service.

NIFI-5051 Added change; waiting for feedback.

NIFI-5051 Changed query setup based on code review. Changed tests to Groovy to 
make them easier to read with all of the inline JSON.

NIFI-5051 fixed a checkstyle issue.

NIFI-5051 Rebased to cleanup merge issues

NIFI-5051 Added changes from a code review.

NIFI-5051 Fixed a checkstyle issue.

NIFI-5051 Added coverage generator for tests.

Rebased.

NIFI-5051 Updated service and switched it over to 
JsonInferenceSchemaRegistryService.

NIFI-5051 Removed dead code.

NIFI-5051 Fixed checkstyle errors.

NIFI-5051 Refactored query builder.

NIFI-5051 Added placeholder gitignore to force test compile.

NIFI-5051 Added note explaining why the .gitignore file was needed.

NIFI-5051 Made constructor public.

NIFI-5051 Fixed path issue in client service integration tests.

NIFI-5051 Added additional mapping capabilities to let users massage the result 
set into the fields they want.

Signed-off-by: Matthew Burgess 

This closes #2615


> Create a LookupService that uses ElasticSearch
> --
>
> Key: NIFI-5051
> URL: https://issues.apache.org/jira/browse/NIFI-5051
> Project: Apache NiFi
>  Issue Type: New Feature
>Reporter: Mike Thomsen
>Assignee: Mike Thomsen
>Priority: Major
>




--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[jira] [Commented] (NIFI-5051) Create a LookupService that uses ElasticSearch

2018-10-01 Thread ASF subversion and git services (JIRA)


[ 
https://issues.apache.org/jira/browse/NIFI-5051?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=16634126#comment-16634126
 ] 

ASF subversion and git services commented on NIFI-5051:
---

Commit b1478cdb195722d7d285cad53d1f89c325868f55 in nifi's branch 
refs/heads/master from [~mike.thomsen]
[ https://git-wip-us.apache.org/repos/asf?p=nifi.git;h=b1478cd ]

NIFI-5051 Created ElasticSearch lookup service.

NIFI-5051 Fixed checkstyle issue.

NIFI-5051 Converted ES lookup service to use a SchemaRegistry.

NIFI-5051 Cleaned up POM and added a simple unit test that uses a mock client 
service.

NIFI-5051 Added change; waiting for feedback.

NIFI-5051 Changed query setup based on code review. Changed tests to Groovy to 
make them easier to read with all of the inline JSON.

NIFI-5051 fixed a checkstyle issue.

NIFI-5051 Rebased to cleanup merge issues

NIFI-5051 Added changes from a code review.

NIFI-5051 Fixed a checkstyle issue.

NIFI-5051 Added coverage generator for tests.

Rebased.

NIFI-5051 Updated service and switched it over to 
JsonInferenceSchemaRegistryService.

NIFI-5051 Removed dead code.

NIFI-5051 Fixed checkstyle errors.

NIFI-5051 Refactored query builder.

NIFI-5051 Added placeholder gitignore to force test compile.

NIFI-5051 Added note explaining why the .gitignore file was needed.

NIFI-5051 Made constructor public.

NIFI-5051 Fixed path issue in client service integration tests.

NIFI-5051 Added additional mapping capabilities to let users massage the result 
set into the fields they want.

Signed-off-by: Matthew Burgess 

This closes #2615


> Create a LookupService that uses ElasticSearch
> --
>
> Key: NIFI-5051
> URL: https://issues.apache.org/jira/browse/NIFI-5051
> Project: Apache NiFi
>  Issue Type: New Feature
>Reporter: Mike Thomsen
>Assignee: Mike Thomsen
>Priority: Major
>




--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[jira] [Commented] (NIFI-5051) Create a LookupService that uses ElasticSearch

2018-10-01 Thread ASF subversion and git services (JIRA)


[ 
https://issues.apache.org/jira/browse/NIFI-5051?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=16634119#comment-16634119
 ] 

ASF subversion and git services commented on NIFI-5051:
---

Commit b1478cdb195722d7d285cad53d1f89c325868f55 in nifi's branch 
refs/heads/master from [~mike.thomsen]
[ https://git-wip-us.apache.org/repos/asf?p=nifi.git;h=b1478cd ]

NIFI-5051 Created ElasticSearch lookup service.

NIFI-5051 Fixed checkstyle issue.

NIFI-5051 Converted ES lookup service to use a SchemaRegistry.

NIFI-5051 Cleaned up POM and added a simple unit test that uses a mock client 
service.

NIFI-5051 Added change; waiting for feedback.

NIFI-5051 Changed query setup based on code review. Changed tests to Groovy to 
make them easier to read with all of the inline JSON.

NIFI-5051 fixed a checkstyle issue.

NIFI-5051 Rebased to cleanup merge issues

NIFI-5051 Added changes from a code review.

NIFI-5051 Fixed a checkstyle issue.

NIFI-5051 Added coverage generator for tests.

Rebased.

NIFI-5051 Updated service and switched it over to 
JsonInferenceSchemaRegistryService.

NIFI-5051 Removed dead code.

NIFI-5051 Fixed checkstyle errors.

NIFI-5051 Refactored query builder.

NIFI-5051 Added placeholder gitignore to force test compile.

NIFI-5051 Added note explaining why the .gitignore file was needed.

NIFI-5051 Made constructor public.

NIFI-5051 Fixed path issue in client service integration tests.

NIFI-5051 Added additional mapping capabilities to let users massage the result 
set into the fields they want.

Signed-off-by: Matthew Burgess 

This closes #2615


> Create a LookupService that uses ElasticSearch
> --
>
> Key: NIFI-5051
> URL: https://issues.apache.org/jira/browse/NIFI-5051
> Project: Apache NiFi
>  Issue Type: New Feature
>Reporter: Mike Thomsen
>Assignee: Mike Thomsen
>Priority: Major
>




--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[jira] [Commented] (NIFI-5051) Create a LookupService that uses ElasticSearch

2018-10-01 Thread ASF subversion and git services (JIRA)


[ 
https://issues.apache.org/jira/browse/NIFI-5051?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=16634138#comment-16634138
 ] 

ASF subversion and git services commented on NIFI-5051:
---

Commit b1478cdb195722d7d285cad53d1f89c325868f55 in nifi's branch 
refs/heads/master from [~mike.thomsen]
[ https://git-wip-us.apache.org/repos/asf?p=nifi.git;h=b1478cd ]

NIFI-5051 Created ElasticSearch lookup service.

NIFI-5051 Fixed checkstyle issue.

NIFI-5051 Converted ES lookup service to use a SchemaRegistry.

NIFI-5051 Cleaned up POM and added a simple unit test that uses a mock client 
service.

NIFI-5051 Added change; waiting for feedback.

NIFI-5051 Changed query setup based on code review. Changed tests to Groovy to 
make them easier to read with all of the inline JSON.

NIFI-5051 fixed a checkstyle issue.

NIFI-5051 Rebased to cleanup merge issues

NIFI-5051 Added changes from a code review.

NIFI-5051 Fixed a checkstyle issue.

NIFI-5051 Added coverage generator for tests.

Rebased.

NIFI-5051 Updated service and switched it over to 
JsonInferenceSchemaRegistryService.

NIFI-5051 Removed dead code.

NIFI-5051 Fixed checkstyle errors.

NIFI-5051 Refactored query builder.

NIFI-5051 Added placeholder gitignore to force test compile.

NIFI-5051 Added note explaining why the .gitignore file was needed.

NIFI-5051 Made constructor public.

NIFI-5051 Fixed path issue in client service integration tests.

NIFI-5051 Added additional mapping capabilities to let users massage the result 
set into the fields they want.

Signed-off-by: Matthew Burgess 

This closes #2615


> Create a LookupService that uses ElasticSearch
> --
>
> Key: NIFI-5051
> URL: https://issues.apache.org/jira/browse/NIFI-5051
> Project: Apache NiFi
>  Issue Type: New Feature
>Reporter: Mike Thomsen
>Assignee: Mike Thomsen
>Priority: Major
>




--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[jira] [Commented] (NIFI-5051) Create a LookupService that uses ElasticSearch

2018-10-01 Thread ASF subversion and git services (JIRA)


[ 
https://issues.apache.org/jira/browse/NIFI-5051?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=16634125#comment-16634125
 ] 

ASF subversion and git services commented on NIFI-5051:
---

Commit b1478cdb195722d7d285cad53d1f89c325868f55 in nifi's branch 
refs/heads/master from [~mike.thomsen]
[ https://git-wip-us.apache.org/repos/asf?p=nifi.git;h=b1478cd ]

NIFI-5051 Created ElasticSearch lookup service.

NIFI-5051 Fixed checkstyle issue.

NIFI-5051 Converted ES lookup service to use a SchemaRegistry.

NIFI-5051 Cleaned up POM and added a simple unit test that uses a mock client 
service.

NIFI-5051 Added change; waiting for feedback.

NIFI-5051 Changed query setup based on code review. Changed tests to Groovy to 
make them easier to read with all of the inline JSON.

NIFI-5051 fixed a checkstyle issue.

NIFI-5051 Rebased to cleanup merge issues

NIFI-5051 Added changes from a code review.

NIFI-5051 Fixed a checkstyle issue.

NIFI-5051 Added coverage generator for tests.

Rebased.

NIFI-5051 Updated service and switched it over to 
JsonInferenceSchemaRegistryService.

NIFI-5051 Removed dead code.

NIFI-5051 Fixed checkstyle errors.

NIFI-5051 Refactored query builder.

NIFI-5051 Added placeholder gitignore to force test compile.

NIFI-5051 Added note explaining why the .gitignore file was needed.

NIFI-5051 Made constructor public.

NIFI-5051 Fixed path issue in client service integration tests.

NIFI-5051 Added additional mapping capabilities to let users massage the result 
set into the fields they want.

Signed-off-by: Matthew Burgess 

This closes #2615


> Create a LookupService that uses ElasticSearch
> --
>
> Key: NIFI-5051
> URL: https://issues.apache.org/jira/browse/NIFI-5051
> Project: Apache NiFi
>  Issue Type: New Feature
>Reporter: Mike Thomsen
>Assignee: Mike Thomsen
>Priority: Major
>




--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[jira] [Commented] (NIFI-5051) Create a LookupService that uses ElasticSearch

2018-10-01 Thread ASF subversion and git services (JIRA)


[ 
https://issues.apache.org/jira/browse/NIFI-5051?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=16634129#comment-16634129
 ] 

ASF subversion and git services commented on NIFI-5051:
---

Commit b1478cdb195722d7d285cad53d1f89c325868f55 in nifi's branch 
refs/heads/master from [~mike.thomsen]
[ https://git-wip-us.apache.org/repos/asf?p=nifi.git;h=b1478cd ]

NIFI-5051 Created ElasticSearch lookup service.

NIFI-5051 Fixed checkstyle issue.

NIFI-5051 Converted ES lookup service to use a SchemaRegistry.

NIFI-5051 Cleaned up POM and added a simple unit test that uses a mock client 
service.

NIFI-5051 Added change; waiting for feedback.

NIFI-5051 Changed query setup based on code review. Changed tests to Groovy to 
make them easier to read with all of the inline JSON.

NIFI-5051 fixed a checkstyle issue.

NIFI-5051 Rebased to cleanup merge issues

NIFI-5051 Added changes from a code review.

NIFI-5051 Fixed a checkstyle issue.

NIFI-5051 Added coverage generator for tests.

Rebased.

NIFI-5051 Updated service and switched it over to 
JsonInferenceSchemaRegistryService.

NIFI-5051 Removed dead code.

NIFI-5051 Fixed checkstyle errors.

NIFI-5051 Refactored query builder.

NIFI-5051 Added placeholder gitignore to force test compile.

NIFI-5051 Added note explaining why the .gitignore file was needed.

NIFI-5051 Made constructor public.

NIFI-5051 Fixed path issue in client service integration tests.

NIFI-5051 Added additional mapping capabilities to let users massage the result 
set into the fields they want.

Signed-off-by: Matthew Burgess 

This closes #2615


> Create a LookupService that uses ElasticSearch
> --
>
> Key: NIFI-5051
> URL: https://issues.apache.org/jira/browse/NIFI-5051
> Project: Apache NiFi
>  Issue Type: New Feature
>Reporter: Mike Thomsen
>Assignee: Mike Thomsen
>Priority: Major
>




--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[jira] [Commented] (NIFI-5051) Create a LookupService that uses ElasticSearch

2018-10-01 Thread ASF subversion and git services (JIRA)


[ 
https://issues.apache.org/jira/browse/NIFI-5051?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=16634131#comment-16634131
 ] 

ASF subversion and git services commented on NIFI-5051:
---

Commit b1478cdb195722d7d285cad53d1f89c325868f55 in nifi's branch 
refs/heads/master from [~mike.thomsen]
[ https://git-wip-us.apache.org/repos/asf?p=nifi.git;h=b1478cd ]

NIFI-5051 Created ElasticSearch lookup service.

NIFI-5051 Fixed checkstyle issue.

NIFI-5051 Converted ES lookup service to use a SchemaRegistry.

NIFI-5051 Cleaned up POM and added a simple unit test that uses a mock client 
service.

NIFI-5051 Added change; waiting for feedback.

NIFI-5051 Changed query setup based on code review. Changed tests to Groovy to 
make them easier to read with all of the inline JSON.

NIFI-5051 fixed a checkstyle issue.

NIFI-5051 Rebased to cleanup merge issues

NIFI-5051 Added changes from a code review.

NIFI-5051 Fixed a checkstyle issue.

NIFI-5051 Added coverage generator for tests.

Rebased.

NIFI-5051 Updated service and switched it over to 
JsonInferenceSchemaRegistryService.

NIFI-5051 Removed dead code.

NIFI-5051 Fixed checkstyle errors.

NIFI-5051 Refactored query builder.

NIFI-5051 Added placeholder gitignore to force test compile.

NIFI-5051 Added note explaining why the .gitignore file was needed.

NIFI-5051 Made constructor public.

NIFI-5051 Fixed path issue in client service integration tests.

NIFI-5051 Added additional mapping capabilities to let users massage the result 
set into the fields they want.

Signed-off-by: Matthew Burgess 

This closes #2615


> Create a LookupService that uses ElasticSearch
> --
>
> Key: NIFI-5051
> URL: https://issues.apache.org/jira/browse/NIFI-5051
> Project: Apache NiFi
>  Issue Type: New Feature
>Reporter: Mike Thomsen
>Assignee: Mike Thomsen
>Priority: Major
>




--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[jira] [Commented] (NIFI-5051) Create a LookupService that uses ElasticSearch

2018-10-01 Thread ASF subversion and git services (JIRA)


[ 
https://issues.apache.org/jira/browse/NIFI-5051?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=16634133#comment-16634133
 ] 

ASF subversion and git services commented on NIFI-5051:
---

Commit b1478cdb195722d7d285cad53d1f89c325868f55 in nifi's branch 
refs/heads/master from [~mike.thomsen]
[ https://git-wip-us.apache.org/repos/asf?p=nifi.git;h=b1478cd ]

NIFI-5051 Created ElasticSearch lookup service.

NIFI-5051 Fixed checkstyle issue.

NIFI-5051 Converted ES lookup service to use a SchemaRegistry.

NIFI-5051 Cleaned up POM and added a simple unit test that uses a mock client 
service.

NIFI-5051 Added change; waiting for feedback.

NIFI-5051 Changed query setup based on code review. Changed tests to Groovy to 
make them easier to read with all of the inline JSON.

NIFI-5051 fixed a checkstyle issue.

NIFI-5051 Rebased to cleanup merge issues

NIFI-5051 Added changes from a code review.

NIFI-5051 Fixed a checkstyle issue.

NIFI-5051 Added coverage generator for tests.

Rebased.

NIFI-5051 Updated service and switched it over to 
JsonInferenceSchemaRegistryService.

NIFI-5051 Removed dead code.

NIFI-5051 Fixed checkstyle errors.

NIFI-5051 Refactored query builder.

NIFI-5051 Added placeholder gitignore to force test compile.

NIFI-5051 Added note explaining why the .gitignore file was needed.

NIFI-5051 Made constructor public.

NIFI-5051 Fixed path issue in client service integration tests.

NIFI-5051 Added additional mapping capabilities to let users massage the result 
set into the fields they want.

Signed-off-by: Matthew Burgess 

This closes #2615


> Create a LookupService that uses ElasticSearch
> --
>
> Key: NIFI-5051
> URL: https://issues.apache.org/jira/browse/NIFI-5051
> Project: Apache NiFi
>  Issue Type: New Feature
>Reporter: Mike Thomsen
>Assignee: Mike Thomsen
>Priority: Major
>




--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[GitHub] nifi issue #2615: NIFI-5051 Created ElasticSearch lookup service.

2018-10-01 Thread mattyb149
Github user mattyb149 commented on the issue:

https://github.com/apache/nifi/pull/2615
  
+1 LGTM, ran full build with unit tests, tried the lookup service with a 
nested record and everything worked fine. Thanks for the improvement! Merging 
to master


---


[jira] [Commented] (NIFIREG-203) Apache Nifi Registry with Git Integration

2018-10-01 Thread Joseph Witt (JIRA)


[ 
https://issues.apache.org/jira/browse/NIFIREG-203?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=16634108#comment-16634108
 ] 

Joseph Witt commented on NIFIREG-203:
-

i'm not quite sure if we've done all the work necessary for the nifi registry 
to be deployed/tested well on windows at this point anyway tbh. 

> Apache Nifi Registry with Git Integration
> -
>
> Key: NIFIREG-203
> URL: https://issues.apache.org/jira/browse/NIFIREG-203
> Project: NiFi Registry
>  Issue Type: Bug
>Reporter: Vijay Mathew
>Priority: Major
>
> Please note that the below issue is occurring in the Windows environment.
> From the Nifi V1.7 UI, I am able to commit a test process group to the Git 
> Repository, however, when I try to import the process group from Git, UI 
> throws an exception "The Flow Registry with ID {} reports that no Flow exists 
> with Bucket {}, Flow {}, Version {}".Below is the logs from Registry
> 2018-09-26 19:45:11,543 WARN [NiFi Registry Web Server-19] 
> o.a.n.registry.service.RegistryService The specified bucket id 
> [64df4f73-160d-4c19-b47c-563804263300] does not exist.
> 2018-09-26 19:45:11,544 INFO [NiFi Registry Web Server-19] 
> o.a.n.r.w.m.ResourceNotFoundExceptionMapper 
> org.apache.nifi.registry.exception.ResourceNotFoundException: The specified 
> bucket ID does not exist in this registry.. Returning Not Found response.
> 2018-09-26 19:45:49,325 ERROR [NiFi Registry Web Server-19] 
> o.a.n.r.web.mapper.ThrowableMapper An unexpected error has occurred: 
> java.lang.NullPointerException. Returning Internal Server Error response.
> java.lang.NullPointerException: null
> at org.eclipse.jgit.lib.Repository.resolve(Repository.java:526) 
> ~[org.eclipse.jgit-4.11.0.201803080745-r.jar:4.11.0.201803080745-r]
> at org.eclipse.jgit.lib.Repository.resolve(Repository.java:487) 
> ~[org.eclipse.jgit-4.11.0.201803080745-r.jar:4.11.0.201803080745-r]
> at 
> org.apache.nifi.registry.provider.flow.git.GitFlowMetaData.getContent(GitFlowMetaData.java:422)
>  ~[nifi-registry-framework-0.3.0.jar:0.3.0]
> at 
> org.apache.nifi.registry.provider.flow.git.GitFlowPersistenceProvider.getFlowContent(GitFlowPersistenceProvider.java:180)
>  ~[nifi-registry-framework-0.3.0.jar:0.3.0]
> at org.apache.nifi.registry.service.RegistryService.g



--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[jira] [Commented] (NIFI-5650) Add xercesImpl to scripting NAR for Jython 2.7.1

2018-10-01 Thread ASF GitHub Bot (JIRA)


[ 
https://issues.apache.org/jira/browse/NIFI-5650?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=16634103#comment-16634103
 ] 

ASF GitHub Bot commented on NIFI-5650:
--

Github user MikeThomsen commented on the issue:

https://github.com/apache/nifi/pull/3042
  
@mattyb149 I'll merge when Travis is done and at least one build passes.


> Add xercesImpl to scripting NAR for Jython 2.7.1
> 
>
> Key: NIFI-5650
> URL: https://issues.apache.org/jira/browse/NIFI-5650
> Project: Apache NiFi
>  Issue Type: Improvement
>  Components: Extensions
>Reporter: Matt Burgess
>Assignee: Matt Burgess
>Priority: Major
>
> NIFI-4301 bumped the version of Jython from Jython 2.7.0 to 2.7.1 in order to 
> get a fix related to the os.getpid() method. However Jython 2.7.1 does not 
> include Xerces (which provides the SAXParser for XML parsing), so although 
> one bug is fixed, a capability has been degraded.
> Recommend explicitly adding Xerces as a dependency to the scripting NAR, and 
> make sure the unit tests and such run for other languages, so as not to 
> introduce a classloading issue if some engine brings their own Xerces shaded 
> into the engine's JAR(s), for example.



--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[GitHub] nifi issue #3042: NIFI-5650: Added Xerces to scripting bundle for Jython 2.7...

2018-10-01 Thread MikeThomsen
Github user MikeThomsen commented on the issue:

https://github.com/apache/nifi/pull/3042
  
@mattyb149 I'll merge when Travis is done and at least one build passes.


---


[GitHub] nifi pull request #3042: NIFI-5650: Added Xerces to scripting bundle for Jyt...

2018-10-01 Thread MikeThomsen
Github user MikeThomsen commented on a diff in the pull request:

https://github.com/apache/nifi/pull/3042#discussion_r221630928
  
--- Diff: 
nifi-nar-bundles/nifi-scripting-bundle/nifi-scripting-nar/src/main/resources/META-INF/NOTICE
 ---
@@ -73,6 +73,20 @@ The following binary components are provided under the 
Apache Software License v
  The original software and related information is available
  at http://www.jcraft.com/jsch/.
 
+  (ASLv2) Apache Xerces Java
--- End diff --

L looks good.


---


[jira] [Commented] (NIFI-5650) Add xercesImpl to scripting NAR for Jython 2.7.1

2018-10-01 Thread ASF GitHub Bot (JIRA)


[ 
https://issues.apache.org/jira/browse/NIFI-5650?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=16634100#comment-16634100
 ] 

ASF GitHub Bot commented on NIFI-5650:
--

Github user MikeThomsen commented on a diff in the pull request:

https://github.com/apache/nifi/pull/3042#discussion_r221630928
  
--- Diff: 
nifi-nar-bundles/nifi-scripting-bundle/nifi-scripting-nar/src/main/resources/META-INF/NOTICE
 ---
@@ -73,6 +73,20 @@ The following binary components are provided under the 
Apache Software License v
  The original software and related information is available
  at http://www.jcraft.com/jsch/.
 
+  (ASLv2) Apache Xerces Java
--- End diff --

L looks good.


> Add xercesImpl to scripting NAR for Jython 2.7.1
> 
>
> Key: NIFI-5650
> URL: https://issues.apache.org/jira/browse/NIFI-5650
> Project: Apache NiFi
>  Issue Type: Improvement
>  Components: Extensions
>Reporter: Matt Burgess
>Assignee: Matt Burgess
>Priority: Major
>
> NIFI-4301 bumped the version of Jython from Jython 2.7.0 to 2.7.1 in order to 
> get a fix related to the os.getpid() method. However Jython 2.7.1 does not 
> include Xerces (which provides the SAXParser for XML parsing), so although 
> one bug is fixed, a capability has been degraded.
> Recommend explicitly adding Xerces as a dependency to the scripting NAR, and 
> make sure the unit tests and such run for other languages, so as not to 
> introduce a classloading issue if some engine brings their own Xerces shaded 
> into the engine's JAR(s), for example.



--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[jira] [Commented] (NIFI-5650) Add xercesImpl to scripting NAR for Jython 2.7.1

2018-10-01 Thread ASF GitHub Bot (JIRA)


[ 
https://issues.apache.org/jira/browse/NIFI-5650?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=16634091#comment-16634091
 ] 

ASF GitHub Bot commented on NIFI-5650:
--

GitHub user mattyb149 opened a pull request:

https://github.com/apache/nifi/pull/3042

NIFI-5650: Added Xerces to scripting bundle for Jython 2.7.1

Thank you for submitting a contribution to Apache NiFi.

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 NIFI- where  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 master)?

- [x] Is your initial contribution a single, squashed commit?

### For code changes:
- [x] Have you ensured that the full suite of tests is executed via mvn 
-Pcontrib-check clean install at the root nifi folder?
- [ ] Have you written or updated unit tests to verify your changes?
- [x] 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, including the main 
LICENSE file under nifi-assembly?
- [x] If applicable, have you updated the NOTICE file, including the main 
NOTICE file found under nifi-assembly?
- [ ] If adding new Properties, have you added .displayName in addition to 
.name (programmatic access) for each of the new properties?

### 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 travis-ci for build 
issues and submit an update to your PR as soon as possible.


You can merge this pull request into a Git repository by running:

$ git pull https://github.com/mattyb149/nifi NIFI-5650

Alternatively you can review and apply these changes as the patch at:

https://github.com/apache/nifi/pull/3042.patch

To close this pull request, make a commit to your master/trunk branch
with (at least) the following in the commit message:

This closes #3042


commit 857b76f4af082c364e18bc21a8b24d42c9a278ab
Author: Matthew Burgess 
Date:   2018-10-01T14:23:44Z

NIFI-5650: Added Xerces to scripting bundle for Jython 2.7.1




> Add xercesImpl to scripting NAR for Jython 2.7.1
> 
>
> Key: NIFI-5650
> URL: https://issues.apache.org/jira/browse/NIFI-5650
> Project: Apache NiFi
>  Issue Type: Improvement
>  Components: Extensions
>Reporter: Matt Burgess
>Assignee: Matt Burgess
>Priority: Major
>
> NIFI-4301 bumped the version of Jython from Jython 2.7.0 to 2.7.1 in order to 
> get a fix related to the os.getpid() method. However Jython 2.7.1 does not 
> include Xerces (which provides the SAXParser for XML parsing), so although 
> one bug is fixed, a capability has been degraded.
> Recommend explicitly adding Xerces as a dependency to the scripting NAR, and 
> make sure the unit tests and such run for other languages, so as not to 
> introduce a classloading issue if some engine brings their own Xerces shaded 
> into the engine's JAR(s), for example.



--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[jira] [Updated] (NIFI-5650) Add xercesImpl to scripting NAR for Jython 2.7.1

2018-10-01 Thread Matt Burgess (JIRA)


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

Matt Burgess updated NIFI-5650:
---
Status: Patch Available  (was: In Progress)

> Add xercesImpl to scripting NAR for Jython 2.7.1
> 
>
> Key: NIFI-5650
> URL: https://issues.apache.org/jira/browse/NIFI-5650
> Project: Apache NiFi
>  Issue Type: Improvement
>  Components: Extensions
>Reporter: Matt Burgess
>Assignee: Matt Burgess
>Priority: Major
>
> NIFI-4301 bumped the version of Jython from Jython 2.7.0 to 2.7.1 in order to 
> get a fix related to the os.getpid() method. However Jython 2.7.1 does not 
> include Xerces (which provides the SAXParser for XML parsing), so although 
> one bug is fixed, a capability has been degraded.
> Recommend explicitly adding Xerces as a dependency to the scripting NAR, and 
> make sure the unit tests and such run for other languages, so as not to 
> introduce a classloading issue if some engine brings their own Xerces shaded 
> into the engine's JAR(s), for example.



--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[GitHub] nifi pull request #3042: NIFI-5650: Added Xerces to scripting bundle for Jyt...

2018-10-01 Thread mattyb149
GitHub user mattyb149 opened a pull request:

https://github.com/apache/nifi/pull/3042

NIFI-5650: Added Xerces to scripting bundle for Jython 2.7.1

Thank you for submitting a contribution to Apache NiFi.

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 NIFI- where  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 master)?

- [x] Is your initial contribution a single, squashed commit?

### For code changes:
- [x] Have you ensured that the full suite of tests is executed via mvn 
-Pcontrib-check clean install at the root nifi folder?
- [ ] Have you written or updated unit tests to verify your changes?
- [x] 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, including the main 
LICENSE file under nifi-assembly?
- [x] If applicable, have you updated the NOTICE file, including the main 
NOTICE file found under nifi-assembly?
- [ ] If adding new Properties, have you added .displayName in addition to 
.name (programmatic access) for each of the new properties?

### 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 travis-ci for build 
issues and submit an update to your PR as soon as possible.


You can merge this pull request into a Git repository by running:

$ git pull https://github.com/mattyb149/nifi NIFI-5650

Alternatively you can review and apply these changes as the patch at:

https://github.com/apache/nifi/pull/3042.patch

To close this pull request, make a commit to your master/trunk branch
with (at least) the following in the commit message:

This closes #3042


commit 857b76f4af082c364e18bc21a8b24d42c9a278ab
Author: Matthew Burgess 
Date:   2018-10-01T14:23:44Z

NIFI-5650: Added Xerces to scripting bundle for Jython 2.7.1




---


[jira] [Commented] (NIFI-5224) Add SolrClientService

2018-10-01 Thread ASF GitHub Bot (JIRA)


[ 
https://issues.apache.org/jira/browse/NIFI-5224?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=16634086#comment-16634086
 ] 

ASF GitHub Bot commented on NIFI-5224:
--

GitHub user MikeThomsen opened a pull request:

https://github.com/apache/nifi/pull/3041

NIFI-5224 Added SolrClientService.

Thank you for submitting a contribution to Apache NiFi.

In order to streamline the review of the contribution we ask you
to ensure the following steps have been taken:

### For all changes:
- [ ] Is there a JIRA ticket associated with this PR? Is it referenced 
 in the commit message?

- [ ] Does your PR title start with NIFI- where  is the JIRA number 
you are trying to resolve? Pay particular attention to the hyphen "-" character.

- [ ] Has your PR been rebased against the latest commit within the target 
branch (typically master)?

- [ ] Is your initial contribution a single, squashed commit?

### For code changes:
- [ ] Have you ensured that the full suite of tests is executed via mvn 
-Pcontrib-check clean install at the root nifi folder?
- [ ] Have you written or updated unit tests to verify your 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, including the main 
LICENSE file under nifi-assembly?
- [ ] If applicable, have you updated the NOTICE file, including the main 
NOTICE file found under nifi-assembly?
- [ ] If adding new Properties, have you added .displayName in addition to 
.name (programmatic access) for each of the new properties?

### 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 travis-ci for build 
issues and submit an update to your PR as soon as possible.


You can merge this pull request into a Git repository by running:

$ git pull https://github.com/MikeThomsen/nifi NIFI-5224

Alternatively you can review and apply these changes as the patch at:

https://github.com/apache/nifi/pull/3041.patch

To close this pull request, make a commit to your master/trunk branch
with (at least) the following in the commit message:

This closes #3041


commit ca5c881b1d2ceee82bb7d6700191eb209612adbc
Author: Mike Thomsen 
Date:   2018-10-01T13:53:16Z

NIFI-5224 Added SolrClientService.




> Add SolrClientService
> -
>
> Key: NIFI-5224
> URL: https://issues.apache.org/jira/browse/NIFI-5224
> Project: Apache NiFi
>  Issue Type: Improvement
>Reporter: Johannes Peter
>Assignee: Mike Thomsen
>Priority: Major
>
> The Solr CRUD functions that are currently included in SolrUtils should be 
> moved to a controller service. 



--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[GitHub] nifi pull request #3041: NIFI-5224 Added SolrClientService.

2018-10-01 Thread MikeThomsen
GitHub user MikeThomsen opened a pull request:

https://github.com/apache/nifi/pull/3041

NIFI-5224 Added SolrClientService.

Thank you for submitting a contribution to Apache NiFi.

In order to streamline the review of the contribution we ask you
to ensure the following steps have been taken:

### For all changes:
- [ ] Is there a JIRA ticket associated with this PR? Is it referenced 
 in the commit message?

- [ ] Does your PR title start with NIFI- where  is the JIRA number 
you are trying to resolve? Pay particular attention to the hyphen "-" character.

- [ ] Has your PR been rebased against the latest commit within the target 
branch (typically master)?

- [ ] Is your initial contribution a single, squashed commit?

### For code changes:
- [ ] Have you ensured that the full suite of tests is executed via mvn 
-Pcontrib-check clean install at the root nifi folder?
- [ ] Have you written or updated unit tests to verify your 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, including the main 
LICENSE file under nifi-assembly?
- [ ] If applicable, have you updated the NOTICE file, including the main 
NOTICE file found under nifi-assembly?
- [ ] If adding new Properties, have you added .displayName in addition to 
.name (programmatic access) for each of the new properties?

### 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 travis-ci for build 
issues and submit an update to your PR as soon as possible.


You can merge this pull request into a Git repository by running:

$ git pull https://github.com/MikeThomsen/nifi NIFI-5224

Alternatively you can review and apply these changes as the patch at:

https://github.com/apache/nifi/pull/3041.patch

To close this pull request, make a commit to your master/trunk branch
with (at least) the following in the commit message:

This closes #3041


commit ca5c881b1d2ceee82bb7d6700191eb209612adbc
Author: Mike Thomsen 
Date:   2018-10-01T13:53:16Z

NIFI-5224 Added SolrClientService.




---


[jira] [Assigned] (NIFI-5650) Add xercesImpl to scripting NAR for Jython 2.7.1

2018-10-01 Thread Matt Burgess (JIRA)


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

Matt Burgess reassigned NIFI-5650:
--

Assignee: Matt Burgess

> Add xercesImpl to scripting NAR for Jython 2.7.1
> 
>
> Key: NIFI-5650
> URL: https://issues.apache.org/jira/browse/NIFI-5650
> Project: Apache NiFi
>  Issue Type: Improvement
>  Components: Extensions
>Reporter: Matt Burgess
>Assignee: Matt Burgess
>Priority: Major
>
> NIFI-4301 bumped the version of Jython from Jython 2.7.0 to 2.7.1 in order to 
> get a fix related to the os.getpid() method. However Jython 2.7.1 does not 
> include Xerces (which provides the SAXParser for XML parsing), so although 
> one bug is fixed, a capability has been degraded.
> Recommend explicitly adding Xerces as a dependency to the scripting NAR, and 
> make sure the unit tests and such run for other languages, so as not to 
> introduce a classloading issue if some engine brings their own Xerces shaded 
> into the engine's JAR(s), for example.



--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[jira] [Created] (NIFI-5650) Add xercesImpl to scripting NAR for Jython 2.7.1

2018-10-01 Thread Matt Burgess (JIRA)
Matt Burgess created NIFI-5650:
--

 Summary: Add xercesImpl to scripting NAR for Jython 2.7.1
 Key: NIFI-5650
 URL: https://issues.apache.org/jira/browse/NIFI-5650
 Project: Apache NiFi
  Issue Type: Improvement
  Components: Extensions
Reporter: Matt Burgess


NIFI-4301 bumped the version of Jython from Jython 2.7.0 to 2.7.1 in order to 
get a fix related to the os.getpid() method. However Jython 2.7.1 does not 
include Xerces (which provides the SAXParser for XML parsing), so although one 
bug is fixed, a capability has been degraded.

Recommend explicitly adding Xerces as a dependency to the scripting NAR, and 
make sure the unit tests and such run for other languages, so as not to 
introduce a classloading issue if some engine brings their own Xerces shaded 
into the engine's JAR(s), for example.



--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[jira] [Commented] (NIFIREG-203) Apache Nifi Registry with Git Integration

2018-10-01 Thread Vijay Mathew (JIRA)


[ 
https://issues.apache.org/jira/browse/NIFIREG-203?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=16634057#comment-16634057
 ] 

Vijay Mathew commented on NIFIREG-203:
--

Reducing the priority of the ticket since the functionality works fine in Linux.

> Apache Nifi Registry with Git Integration
> -
>
> Key: NIFIREG-203
> URL: https://issues.apache.org/jira/browse/NIFIREG-203
> Project: NiFi Registry
>  Issue Type: Bug
>Reporter: Vijay Mathew
>Priority: Major
>
> Please note that the below issue is occurring in the Windows environment.
> From the Nifi V1.7 UI, I am able to commit a test process group to the Git 
> Repository, however, when I try to import the process group from Git, UI 
> throws an exception "The Flow Registry with ID {} reports that no Flow exists 
> with Bucket {}, Flow {}, Version {}".Below is the logs from Registry
> 2018-09-26 19:45:11,543 WARN [NiFi Registry Web Server-19] 
> o.a.n.registry.service.RegistryService The specified bucket id 
> [64df4f73-160d-4c19-b47c-563804263300] does not exist.
> 2018-09-26 19:45:11,544 INFO [NiFi Registry Web Server-19] 
> o.a.n.r.w.m.ResourceNotFoundExceptionMapper 
> org.apache.nifi.registry.exception.ResourceNotFoundException: The specified 
> bucket ID does not exist in this registry.. Returning Not Found response.
> 2018-09-26 19:45:49,325 ERROR [NiFi Registry Web Server-19] 
> o.a.n.r.web.mapper.ThrowableMapper An unexpected error has occurred: 
> java.lang.NullPointerException. Returning Internal Server Error response.
> java.lang.NullPointerException: null
> at org.eclipse.jgit.lib.Repository.resolve(Repository.java:526) 
> ~[org.eclipse.jgit-4.11.0.201803080745-r.jar:4.11.0.201803080745-r]
> at org.eclipse.jgit.lib.Repository.resolve(Repository.java:487) 
> ~[org.eclipse.jgit-4.11.0.201803080745-r.jar:4.11.0.201803080745-r]
> at 
> org.apache.nifi.registry.provider.flow.git.GitFlowMetaData.getContent(GitFlowMetaData.java:422)
>  ~[nifi-registry-framework-0.3.0.jar:0.3.0]
> at 
> org.apache.nifi.registry.provider.flow.git.GitFlowPersistenceProvider.getFlowContent(GitFlowPersistenceProvider.java:180)
>  ~[nifi-registry-framework-0.3.0.jar:0.3.0]
> at org.apache.nifi.registry.service.RegistryService.g



--
This message was sent by Atlassian JIRA
(v7.6.3#76005)


[jira] [Updated] (NIFIREG-203) Apache Nifi Registry with Git Integration

2018-10-01 Thread Vijay Mathew (JIRA)


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

Vijay Mathew updated NIFIREG-203:
-
Priority: Major  (was: Critical)

> Apache Nifi Registry with Git Integration
> -
>
> Key: NIFIREG-203
> URL: https://issues.apache.org/jira/browse/NIFIREG-203
> Project: NiFi Registry
>  Issue Type: Bug
>Reporter: Vijay Mathew
>Priority: Major
>
> Please note that the below issue is occurring in the Windows environment.
> From the Nifi V1.7 UI, I am able to commit a test process group to the Git 
> Repository, however, when I try to import the process group from Git, UI 
> throws an exception "The Flow Registry with ID {} reports that no Flow exists 
> with Bucket {}, Flow {}, Version {}".Below is the logs from Registry
> 2018-09-26 19:45:11,543 WARN [NiFi Registry Web Server-19] 
> o.a.n.registry.service.RegistryService The specified bucket id 
> [64df4f73-160d-4c19-b47c-563804263300] does not exist.
> 2018-09-26 19:45:11,544 INFO [NiFi Registry Web Server-19] 
> o.a.n.r.w.m.ResourceNotFoundExceptionMapper 
> org.apache.nifi.registry.exception.ResourceNotFoundException: The specified 
> bucket ID does not exist in this registry.. Returning Not Found response.
> 2018-09-26 19:45:49,325 ERROR [NiFi Registry Web Server-19] 
> o.a.n.r.web.mapper.ThrowableMapper An unexpected error has occurred: 
> java.lang.NullPointerException. Returning Internal Server Error response.
> java.lang.NullPointerException: null
> at org.eclipse.jgit.lib.Repository.resolve(Repository.java:526) 
> ~[org.eclipse.jgit-4.11.0.201803080745-r.jar:4.11.0.201803080745-r]
> at org.eclipse.jgit.lib.Repository.resolve(Repository.java:487) 
> ~[org.eclipse.jgit-4.11.0.201803080745-r.jar:4.11.0.201803080745-r]
> at 
> org.apache.nifi.registry.provider.flow.git.GitFlowMetaData.getContent(GitFlowMetaData.java:422)
>  ~[nifi-registry-framework-0.3.0.jar:0.3.0]
> at 
> org.apache.nifi.registry.provider.flow.git.GitFlowPersistenceProvider.getFlowContent(GitFlowPersistenceProvider.java:180)
>  ~[nifi-registry-framework-0.3.0.jar:0.3.0]
> at org.apache.nifi.registry.service.RegistryService.g



--
This message was sent by Atlassian JIRA
(v7.6.3#76005)