You are viewing a plain text version of this content. The canonical link for it is here.
Posted to issues@nifi.apache.org by mattyb149 <gi...@git.apache.org> on 2017/12/12 00:52:37 UTC

[GitHub] nifi pull request #2295: NIFI-4479 Added DeleteMongo processor.

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

    https://github.com/apache/nifi/pull/2295#discussion_r156243670
  
    --- Diff: nifi-nar-bundles/nifi-mongodb-bundle/nifi-mongodb-processors/src/main/java/org/apache/nifi/processors/mongodb/DeleteMongo.java ---
    @@ -0,0 +1,151 @@
    +/*
    + * 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.mongodb;
    +
    +import com.mongodb.WriteConcern;
    +import com.mongodb.client.MongoCollection;
    +import com.mongodb.client.result.DeleteResult;
    +import org.apache.nifi.annotation.behavior.EventDriven;
    +import org.apache.nifi.annotation.documentation.CapabilityDescription;
    +import org.apache.nifi.annotation.documentation.Tags;
    +import org.apache.nifi.components.AllowableValue;
    +import org.apache.nifi.components.PropertyDescriptor;
    +import org.apache.nifi.components.Validator;
    +import org.apache.nifi.flowfile.FlowFile;
    +import org.apache.nifi.processor.ProcessContext;
    +import org.apache.nifi.processor.ProcessSession;
    +import org.apache.nifi.processor.Relationship;
    +import org.apache.nifi.processor.exception.ProcessException;
    +import org.bson.Document;
    +
    +import java.io.ByteArrayOutputStream;
    +import java.util.ArrayList;
    +import java.util.Collections;
    +import java.util.HashSet;
    +import java.util.List;
    +import java.util.Set;
    +
    +@EventDriven
    +@Tags({ "delete", "mongo", "mongodb" })
    +@CapabilityDescription(
    +        "Executes a delete query against a MongoDB collection. The query is provided in the body of the flowfile " +
    +        "and the user can select whether it will delete one or many documents that match it."
    +)
    +public class DeleteMongo extends AbstractMongoProcessor {
    +
    +    private final static Set<Relationship> relationships;
    +    private final static List<PropertyDescriptor> propertyDescriptors;
    +
    +    static final AllowableValue DELETE_ONE = new AllowableValue("one", "Delete One", "Delete only the first document that matches the query.");
    +    static final AllowableValue DELETE_MANY = new AllowableValue("many", "Delete Many", "Delete every document that matches the query.");
    +
    +    static final AllowableValue YES_FAIL = new AllowableValue("true", "True", "Fail when no documents are deleted.");
    +    static final AllowableValue NO_FAIL  = new AllowableValue("false", "False", "Do not fail when nothing is deleted.");
    +
    +    static final PropertyDescriptor DELETE_MODE = new PropertyDescriptor.Builder()
    +            .name("delete-mongo-delete-mode")
    +            .displayName("Delete Mode")
    +            .description("Choose between deleting one document by query or many documents by query.")
    +            .allowableValues(DELETE_ONE, DELETE_MANY)
    +            .defaultValue("one")
    +            .addValidator(Validator.VALID)
    +            .build();
    +
    +    static final PropertyDescriptor FAIL_ON_NO_DELETE = new PropertyDescriptor.Builder()
    +            .name("delete-mongo-fail-on-no-delete")
    +            .displayName("Fail When Nothing Is Deleted")
    +            .description("Determines whether to send the flowfile to the success or failure relationship if nothing is successfully deleted.")
    +            .allowableValues(YES_FAIL, NO_FAIL)
    +            .defaultValue("true")
    +            .addValidator(Validator.VALID)
    +            .build();
    +
    +    static final Relationship REL_SUCCESS = new Relationship.Builder().name("success")
    +            .description("All FlowFiles that are written to MongoDB are routed to this relationship").build();
    +    static final Relationship REL_FAILURE = new Relationship.Builder().name("failure")
    +            .description("All FlowFiles that cannot be written to MongoDB are routed to this relationship").build();
    +
    +    static {
    +        List<PropertyDescriptor> _propertyDescriptors = new ArrayList<>();
    +        _propertyDescriptors.addAll(descriptors);
    +        _propertyDescriptors.add(DELETE_MODE);
    +        _propertyDescriptors.add(FAIL_ON_NO_DELETE);
    +        _propertyDescriptors.add(WRITE_CONCERN);
    +        propertyDescriptors = Collections.unmodifiableList(_propertyDescriptors);
    +
    +        final Set<Relationship> _relationships = new HashSet<>();
    +        _relationships.add(REL_SUCCESS);
    +        _relationships.add(REL_FAILURE);
    +        relationships = Collections.unmodifiableSet(_relationships);
    +    }
    +
    +    @Override
    +    public Set<Relationship> getRelationships() {
    +        return relationships;
    +    }
    +
    +    @Override
    +    public List<PropertyDescriptor> getSupportedPropertyDescriptors() {
    +        return propertyDescriptors;
    +    }
    +
    +    @Override
    +    public void onTrigger(ProcessContext context, ProcessSession session) throws ProcessException {
    +        FlowFile flowFile = session.get();
    +        if (flowFile == null) {
    +            return;
    +        }
    +
    +        final WriteConcern writeConcern = getWriteConcern(context);
    +        final MongoCollection<Document> collection = getCollection(context).withWriteConcern(writeConcern);
    +        final String deleteMode = context.getProperty(DELETE_MODE).getValue();
    +        final Boolean failMode  = context.getProperty(FAIL_ON_NO_DELETE).asBoolean();
    +
    +        DeleteResult result;
    +
    +        try {
    +            ByteArrayOutputStream bos = new ByteArrayOutputStream();
    +            session.exportTo(flowFile, bos);
    +            bos.close();
    +
    +            String json = new String(bos.toByteArray());
    +            Document query = Document.parse(json);
    +
    +            getLogger().info("Test\n\n\n\n\n\n");
    --- End diff --
    
    This can be removed (or replaced with a debug/info message to inform what's going on


---