Skip navigation links
A B C D E F G H I J K L M N O P Q R S T U V W X Y Z 

N

NaiveRevisionManager - Class in org.apache.nifi.web.revision
This class implements a naive approach for Revision Management.
NaiveRevisionManager() - Constructor for class org.apache.nifi.web.revision.NaiveRevisionManager
 
NaiveSearchRingBuffer - Class in org.apache.nifi.util
A RingBuffer that can be used to scan byte sequences for subsequences.
NaiveSearchRingBuffer(byte[]) - Constructor for class org.apache.nifi.util.NaiveSearchRingBuffer
 
NakedProcessor - Class in org.apache.nifi.documentation.example
 
NakedProcessor() - Constructor for class org.apache.nifi.documentation.example.NakedProcessor
 
name(String) - Method in class org.apache.nifi.authorization.Group.Builder
Sets the name of the builder.
name(String) - Method in class org.apache.nifi.components.PropertyDescriptor.Builder
Sets the property name.
name(String) - Method in class org.apache.nifi.connectable.StandardConnection.Builder
 
name(String) - Method in class org.apache.nifi.processor.Relationship.Builder
 
name - Variable in class org.apache.nifi.provenance.TestPersistentProvenanceRepository
 
name(String) - Method in class org.apache.nifi.web.ComponentDescriptor.Builder
 
name(String) - Method in class org.apache.nifi.web.ComponentDetails.Builder
 
name(String) - Method in class org.apache.nifi.web.ConfigurationAction.Builder
 
NamedProfileCredentialsStrategy - Class in org.apache.nifi.processors.aws.credentials.provider.factory.strategies
Supports AWS Credentials using a named profile configured in the credentials file (typically ~/.aws/credentials).
NamedProfileCredentialsStrategy() - Constructor for class org.apache.nifi.processors.aws.credentials.provider.factory.strategies.NamedProfileCredentialsStrategy
 
NamedSearchableField - Class in org.apache.nifi.provenance
 
NamedThreadFactory - Class in org.apache.nifi.provenance.util
 
NamedThreadFactory(String) - Constructor for class org.apache.nifi.provenance.util.NamedThreadFactory
 
NamedThreadFactory(String, boolean) - Constructor for class org.apache.nifi.provenance.util.NamedThreadFactory
 
NamedValue - Class in org.apache.nifi.repository.schema
 
NamedValue(String, Object) - Constructor for class org.apache.nifi.repository.schema.NamedValue
 
NamedVariableImpact - Class in org.apache.nifi.attribute.expression.language
 
NamedVariableImpact(Set<String>) - Constructor for class org.apache.nifi.attribute.expression.language.NamedVariableImpact
 
nameMatches(String) - Method in class org.apache.nifi.reporting.BulletinQuery.Builder
 
NAMES - Static variable in class org.apache.nifi.processors.script.engine.ClojureScriptEngineFactory
 
NAMESPACE - Static variable in class org.apache.nifi.processors.aws.cloudwatch.PutCloudWatchMetric
 
NAMESPACE_DELIMITER - Static variable in class org.apache.nifi.processors.standard.AbstractDatabaseFetchProcessor
 
NameStringNode - Class in org.apache.nifi.processors.evtx.parser.bxml
The strings are stored separately to conserve space
NameStringNode(BinaryReader, ChunkHeader) - Constructor for class org.apache.nifi.processors.evtx.parser.bxml.NameStringNode
 
NameStringNodeTest - Class in org.apache.nifi.processors.evtx.parser.bxml
 
NameStringNodeTest() - Constructor for class org.apache.nifi.processors.evtx.parser.bxml.NameStringNodeTest
 
NAR_LIBRARY_DIRECTORY - Static variable in class org.apache.nifi.util.NiFiProperties
 
NAR_LIBRARY_DIRECTORY_PREFIX - Static variable in class org.apache.nifi.util.NiFiProperties
 
NAR_WORKING_DIRECTORY - Static variable in class org.apache.nifi.util.NiFiProperties
 
NarBundleUtil - Class in org.apache.nifi.nar
 
NarBundleUtil() - Constructor for class org.apache.nifi.nar.NarBundleUtil
 
NarBundleUtilTest - Class in org.apache.nifi.nar
 
NarBundleUtilTest() - Constructor for class org.apache.nifi.nar.NarBundleUtilTest
 
NarClassLoader - Class in org.apache.nifi.nar
A ClassLoader for loading NARs (NiFi archives).
NarClassLoader(File) - Constructor for class org.apache.nifi.nar.NarClassLoader
Construct a nar class loader.
NarClassLoader(File, ClassLoader) - Constructor for class org.apache.nifi.nar.NarClassLoader
Construct a nar class loader with the specific parent.
NarClassLoaders - Class in org.apache.nifi.nar
A singleton class used to initialize the extension and framework classloaders.
NarCloseable - Class in org.apache.nifi.nar
 
NarManifestEntry - Enum in org.apache.nifi.nar
Enumeration of entries that will be in a NAR MANIFEST file.
NarThreadContextClassLoader - Class in org.apache.nifi.nar
THREAD SAFE
NarThreadContextClassLoaderTest - Class in org.apache.nifi.nar
 
NarThreadContextClassLoaderTest() - Constructor for class org.apache.nifi.nar.NarThreadContextClassLoaderTest
 
NarThreadContextClassLoaderTest.WithDefaultConstructor - Class in org.apache.nifi.nar
 
NarThreadContextClassLoaderTest.WithPropertiesConstructor - Class in org.apache.nifi.nar
 
NarUnpacker - Class in org.apache.nifi.nar
 
NarUnpackerTest - Class in org.apache.nifi.nar
 
NarUnpackerTest() - Constructor for class org.apache.nifi.nar.NarUnpackerTest
 
NATIVE_CANONICAL_NAME - Static variable in class org.apache.nifi.processors.windows.event.log.JNAOverridingJUnitRunner
 
NEED_CLIENT_AUTH - Static variable in class org.apache.nifi.processors.grpc.TestGRPCServer
 
NEED_CLIENT_AUTH - Static variable in class org.apache.nifi.processors.slack.TestServer
 
NEED_CLIENT_AUTH - Static variable in class org.apache.nifi.processors.standard.TestServer
 
NEED_CLIENT_AUTH_OPTION - Static variable in class org.apache.nifi.toolkit.s2s.SiteToSiteCliMain
 
negotiateCodec(Peer) - Method in interface org.apache.nifi.remote.protocol.ClientProtocol
 
negotiateCodec(Peer) - Method in class org.apache.nifi.remote.protocol.http.StandardHttpFlowFileServerProtocol
 
negotiateCodec(Peer) - Method in interface org.apache.nifi.remote.protocol.ServerProtocol
Negotiates the FlowFileCodec that is to be used for transferring FlowFiles
negotiateCodec(Peer) - Method in class org.apache.nifi.remote.protocol.socket.SocketClientProtocol
 
negotiateCodec(Peer) - Method in class org.apache.nifi.remote.protocol.socket.SocketFlowFileServerProtocol
 
negotiatedFlowFileCodec - Variable in class org.apache.nifi.remote.protocol.AbstractFlowFileServerProtocol
 
negotiateTransportProtocolVersion(HttpServletRequest, VersionNegotiator) - Method in class org.apache.nifi.web.api.ApplicationResource
 
NETSCAPE_COOKIE_POLICY - Static variable in class org.apache.nifi.processors.standard.GetHTTP
 
NETSCAPE_COOKIE_POLICY_STR - Static variable in class org.apache.nifi.processors.standard.GetHTTP
 
NETWORK_CONNECTION_TIMEOUT - Static variable in class org.apache.nifi.processors.standard.util.SFTPUtils
 
NETWORK_DATA_TIMEOUT - Static variable in class org.apache.nifi.processors.standard.util.SFTPUtils
 
NETWORK_DATA_TIMEOUT_KEY - Static variable in class org.apache.nifi.processors.standard.util.FTPUtils
 
NETWORK_INTF_NAME - Static variable in class org.apache.nifi.processor.util.listen.ListenerProperties
 
NETWORK_SOCKET_TIMEOUT_KEY - Static variable in class org.apache.nifi.processors.standard.util.FTPUtils
 
NetworkTransfer - Class in org.apache.nifi.events.network
 
NetworkTransfer(String, Long, Long) - Constructor for class org.apache.nifi.events.network.NetworkTransfer
 
NetworkUtils - Class in org.apache.nifi.remote.io.socket
 
NetworkUtils() - Constructor for class org.apache.nifi.remote.io.socket.NetworkUtils
 
NEVER_IMPACTED - Static variable in interface org.apache.nifi.attribute.expression.language.VariableImpact
 
NEW_LINE_CHAR - Static variable in class org.apache.nifi.processors.splunk.PutSplunk
 
newConnection(HiveEndPoint, boolean, HiveConf, UserGroupInformation) - Method in class org.apache.nifi.util.hive.HiveWriter
 
NEWEST_INDEX_FIRST - Static variable in class org.apache.nifi.provenance.util.DirectoryUtils
 
NewestFirstPrioritizerTest - Class in org.apache.nifi.prioritizer
 
NewestFirstPrioritizerTest() - Constructor for class org.apache.nifi.prioritizer.NewestFirstPrioritizerTest
 
NewestFirstPrioritizerTest.SimpleProcessor - Class in org.apache.nifi.prioritizer
 
NewestFlowFileFirstPrioritizer - Class in org.apache.nifi.prioritizer
 
NewestFlowFileFirstPrioritizer() - Constructor for class org.apache.nifi.prioritizer.NewestFlowFileFirstPrioritizer
 
newExpressionLanguageCompiler() - Method in class org.apache.nifi.bootstrap.notification.NotificationValidationContext
 
newExpressionLanguageCompiler() - Method in interface org.apache.nifi.components.ValidationContext
 
newExpressionLanguageCompiler() - Method in class org.apache.nifi.processor.StandardValidationContext
 
newExpressionLanguageCompiler() - Method in class org.apache.nifi.util.MockValidationContext
 
newInputStream() - Method in class org.apache.nifi.controller.repository.io.ArrayManagedOutputStream
 
newInstance(String) - Method in interface org.apache.nifi.io.nio.consumer.StreamConsumerFactory
 
newInstance(String) - Method in class org.apache.nifi.io.nio.example.ServerMain.ExampleStreamConsumerFactory
 
newProcessContext(Connectable, AtomicLong) - Method in class org.apache.nifi.controller.scheduling.ProcessContextFactory
 
newPropertyValue(String) - Method in class org.apache.nifi.bootstrap.notification.NotificationValidationContext
 
newPropertyValue(String) - Method in interface org.apache.nifi.components.ValidationContext
 
newPropertyValue(String) - Method in class org.apache.nifi.controller.scheduling.ConnectableProcessContext
 
newPropertyValue(String) - Method in class org.apache.nifi.mock.MockProcessContext
 
newPropertyValue(String) - Method in interface org.apache.nifi.processor.ProcessContext
Creates and returns a PropertyValue object that can be used for evaluating the value of the given String
newPropertyValue(String) - Method in class org.apache.nifi.processor.StandardProcessContext
 
newPropertyValue(String) - Method in class org.apache.nifi.processor.StandardSchedulingContext
 
newPropertyValue(String) - Method in class org.apache.nifi.processor.StandardValidationContext
 
newPropertyValue(String) - Method in class org.apache.nifi.util.MockProcessContext
 
newPropertyValue(String) - Method in class org.apache.nifi.util.MockValidationContext
 
newRecordReader(File, Collection<Path>, int) - Static method in class org.apache.nifi.provenance.serialization.RecordReaders
Creates a new Record Reader that is capable of reading Provenance Event Journals
newRecordReader(File, Collection<Path>, int) - Method in interface org.apache.nifi.provenance.store.RecordReaderFactory
 
newResourceClaim(String, String, String, boolean, boolean) - Method in interface org.apache.nifi.controller.repository.claim.ResourceClaimManager
Creates a new Resource Claim with the given id, container, section, and loss tolerance.
newResourceClaim(String, String, String, boolean, boolean) - Method in class org.apache.nifi.controller.repository.claim.StandardResourceClaimManager
 
newResourceClaim(String, String, String, boolean, boolean) - Method in class org.apache.nifi.controller.TestFileSystemSwapManager.NopResourceClaimManager
 
newSchemaRecordWriter(File, AtomicLong, boolean, boolean) - Static method in class org.apache.nifi.provenance.serialization.RecordWriters
 
newSchemaRecordWriter(File, AtomicLong, boolean, boolean, int) - Static method in class org.apache.nifi.provenance.serialization.RecordWriters
 
newSearchableAttribute(String) - Static method in class org.apache.nifi.provenance.SearchableFields
 
newSearchTerm(SearchableField, String) - Static method in class org.apache.nifi.provenance.search.SearchTerms
 
newSizeBasedFilter(double, DataUnit, int) - Static method in class org.apache.nifi.processor.util.FlowFileFilters
Returns a new FlowFileFilter that will pull FlowFiles until the maximum file size has been reached, or the maximum FlowFile Count was been reached (this is important because FlowFiles may be 0 bytes!).
newTestRunner(Processor) - Static method in class org.apache.nifi.util.TestRunners
 
newTestRunner(Class<? extends Processor>) - Static method in class org.apache.nifi.util.TestRunners
 
newThread(Runnable) - Method in class org.apache.nifi.provenance.util.NamedThreadFactory
 
newThrottledInputStream(InputStream) - Method in class org.apache.nifi.stream.io.LeakyBucketStreamThrottler
 
newThrottledInputStream(InputStream) - Method in interface org.apache.nifi.stream.io.StreamThrottler
 
newThrottledOutputStream(OutputStream) - Method in class org.apache.nifi.stream.io.LeakyBucketStreamThrottler
 
newThrottledOutputStream(OutputStream) - Method in interface org.apache.nifi.stream.io.StreamThrottler
 
newValidationContext(Map<PropertyDescriptor, String>, String, String, String) - Method in interface org.apache.nifi.controller.ValidationContextFactory
 
newValidationContext(Set<String>, Map<PropertyDescriptor, String>, String, String, String) - Method in interface org.apache.nifi.controller.ValidationContextFactory
 
newValidationContext(Map<PropertyDescriptor, String>, String, String, String) - Method in class org.apache.nifi.processor.StandardValidationContextFactory
 
newValidationContext(Set<String>, Map<PropertyDescriptor, String>, String, String, String) - Method in class org.apache.nifi.processor.StandardValidationContextFactory
 
next() - Method in class org.apache.nifi.processors.evtx.parser.ChunkHeader
 
next() - Method in class org.apache.nifi.processors.evtx.parser.FileHeader
Returns the next chunkHeader or null if there are no more
next() - Method in class org.apache.nifi.serialization.record.ListRecordSet
 
next() - Method in class org.apache.nifi.serialization.record.PushBackRecordSet
 
next() - Method in interface org.apache.nifi.serialization.record.RecordSet
 
next() - Method in class org.apache.nifi.serialization.record.ResultSetRecordSet
 
nextAvroRecord() - Method in class org.apache.nifi.avro.AvroReaderWithEmbeddedSchema
 
nextAvroRecord() - Method in class org.apache.nifi.avro.AvroReaderWithExplicitSchema
 
nextAvroRecord() - Method in class org.apache.nifi.avro.AvroRecordReader
 
nextEvent() - Method in class org.apache.nifi.provenance.store.iterator.AuthorizingEventIterator
 
nextEvent() - Method in interface org.apache.nifi.provenance.store.iterator.EventIterator
 
nextEvent() - Method in class org.apache.nifi.provenance.store.iterator.SelectiveRecordReaderEventIterator
 
nextEvent() - Method in class org.apache.nifi.provenance.store.iterator.SequentialRecordReaderEventIterator
 
nextFlowFileId() - Method in class org.apache.nifi.util.SharedSessionState
 
nextHit() - Method in interface org.apache.nifi.hl7.query.QueryResult
 
nextHit() - Method in class org.apache.nifi.hl7.query.result.MissedResult
 
nextHit() - Method in class org.apache.nifi.hl7.query.result.StandardQueryResult
 
nextMessage() - Method in interface org.apache.nifi.hl7.io.HL7Reader
 
nextOffsetInfo() - Method in class org.apache.nifi.stream.io.util.TextLineDemarcator
Will compute the next offset info for a text line (line terminated by either '\r', '\n' or '\r\n').
nextOffsetInfo(byte[]) - Method in class org.apache.nifi.stream.io.util.TextLineDemarcator
Will compute the next offset info for a text line (line terminated by either '\r', '\n' or '\r\n').
nextRecord(boolean, boolean) - Method in class org.apache.nifi.avro.AvroRecordReader
 
nextRecord(boolean, boolean) - Method in class org.apache.nifi.csv.CSVRecordReader
 
nextRecord(boolean, boolean) - Method in class org.apache.nifi.grok.GrokRecordReader
 
nextRecord(boolean, boolean) - Method in class org.apache.nifi.json.AbstractJsonRowRecordReader
 
nextRecord() - Method in interface org.apache.nifi.processors.hadoop.record.HDFSRecordReader
 
nextRecord() - Method in class org.apache.nifi.processors.parquet.record.AvroParquetHDFSRecordReader
 
nextRecord(DataInputStream, int) - Method in class org.apache.nifi.provenance.ByteArraySchemaRecordReader
 
nextRecord(DataInputStream, int) - Method in class org.apache.nifi.provenance.EncryptedSchemaRecordReader
 
nextRecord(DataInputStream, int) - Method in class org.apache.nifi.provenance.EventIdFirstSchemaRecordReader
 
nextRecord() - Method in class org.apache.nifi.provenance.serialization.CompressableRecordReader
 
nextRecord(DataInputStream, int) - Method in class org.apache.nifi.provenance.serialization.CompressableRecordReader
 
nextRecord() - Method in class org.apache.nifi.provenance.serialization.EmptyRecordReader
 
nextRecord() - Method in interface org.apache.nifi.provenance.serialization.RecordReader
Returns the next record in the reader, or null if there is no more data available.
nextRecord(DataInputStream, int) - Method in class org.apache.nifi.provenance.StandardRecordReader
 
nextRecord() - Method in interface org.apache.nifi.serialization.RecordReader
Returns the next record in the stream or null if no more records are available.
nextRecord(boolean, boolean) - Method in interface org.apache.nifi.serialization.RecordReader
Reads the next record from the underlying stream.
nextToken() - Method in class org.apache.nifi.stream.io.util.StreamDemarcator
Will read the next data token from the InputStream returning null when it reaches the end of the stream.
nextTuple() - Method in class org.apache.nifi.storm.NiFiSpout
 
nextTxn(boolean) - Method in class org.apache.nifi.util.hive.HiveWriter
if there are remainingTransactions in current txnBatch, begins nextTransactions otherwise creates new txnBatch.
nextTxnBatch(RecordWriter) - Method in class org.apache.nifi.util.hive.HiveWriter
 
NF_SENSITIVE_PROPS_ALGORITHM - Static variable in class org.apache.nifi.encrypt.StringEncryptor
 
NF_SENSITIVE_PROPS_ALGORITHM - Static variable in class org.apache.nifi.util.NiFiProperties
 
NF_SENSITIVE_PROPS_KEY - Static variable in class org.apache.nifi.encrypt.StringEncryptor
 
NF_SENSITIVE_PROPS_KEY - Static variable in class org.apache.nifi.util.NiFiProperties
 
NF_SENSITIVE_PROPS_PROVIDER - Static variable in class org.apache.nifi.encrypt.StringEncryptor
 
NF_SENSITIVE_PROPS_PROVIDER - Static variable in class org.apache.nifi.util.NiFiProperties
 
NiFi - Class in org.apache.nifi
 
NiFi(NiFiProperties) - Constructor for class org.apache.nifi.NiFi
 
NIFI_BOOTSTRAP_SENSITIVE_KEY - Static variable in class org.apache.nifi.bootstrap.RunNiFi
 
NIFI_CA_KEYSTORE - Static variable in class org.apache.nifi.toolkit.tls.service.server.TlsCertificateAuthorityServiceCommandLine
 
NIFI_CERT - Static variable in class org.apache.nifi.toolkit.tls.standalone.TlsToolkitStandalone
 
NIFI_DATA_PACKET - Static variable in class org.apache.nifi.storm.NiFiSpout
 
NIFI_DEAD_NOTIFICATION_SERVICE_IDS_PROP - Static variable in class org.apache.nifi.bootstrap.RunNiFi
 
NIFI_DN_PREFIX_ARG - Static variable in class org.apache.nifi.toolkit.tls.standalone.TlsToolkitStandaloneCommandLine
 
NIFI_DN_SUFFIX_ARG - Static variable in class org.apache.nifi.toolkit.tls.standalone.TlsToolkitStandaloneCommandLine
 
NIFI_FAKE_PROPERTY - Static variable in class org.apache.nifi.toolkit.tls.standalone.TlsToolkitStandaloneTest
 
NIFI_KEY - Static variable in class org.apache.nifi.toolkit.tls.standalone.TlsToolkitStandalone
 
NIFI_LOCK_FILE_NAME - Static variable in class org.apache.nifi.bootstrap.RunNiFi
 
NIFI_NAMESPACE - Static variable in class org.apache.nifi.controller.repository.StandardProvenanceReporter
 
NIFI_PID_DIR_PROP - Static variable in class org.apache.nifi.bootstrap.RunNiFi
 
NIFI_PID_FILE_NAME - Static variable in class org.apache.nifi.bootstrap.RunNiFi
 
NIFI_PROPERTIES - Static variable in class org.apache.nifi.toolkit.tls.standalone.TlsToolkitStandalone
 
NIFI_PROPERTIES_FILE_ARG - Static variable in class org.apache.nifi.toolkit.tls.standalone.TlsToolkitStandaloneCommandLine
 
NIFI_START_NOTIFICATION_SERVICE_IDS_PROP - Static variable in class org.apache.nifi.bootstrap.RunNiFi
 
NIFI_STATUS_FILE_NAME - Static variable in class org.apache.nifi.bootstrap.RunNiFi
 
NIFI_STOP_NOTIFICATION_SERVICE_IDS_PROP - Static variable in class org.apache.nifi.bootstrap.RunNiFi
 
NIFI_TOOLKIT_HOME - Static variable in class org.apache.nifi.toolkit.tls.commandLine.BaseCommandLine
 
NiFiAnonymousUserFilter - Class in org.apache.nifi.web.security.anonymous
 
NiFiAnonymousUserFilter() - Constructor for class org.apache.nifi.web.security.anonymous.NiFiAnonymousUserFilter
 
NiFiAuditor - Class in org.apache.nifi.audit
A NiFi audit service.
NiFiAuditor() - Constructor for class org.apache.nifi.audit.NiFiAuditor
 
NiFiAuthenticationFilter - Class in org.apache.nifi.web.security
 
NiFiAuthenticationFilter() - Constructor for class org.apache.nifi.web.security.NiFiAuthenticationFilter
 
NiFiAuthenticationProvider - Class in org.apache.nifi.web.security
Base AuthenticationProvider that provides common functionality to mapping identities.
NiFiAuthenticationProvider(NiFiProperties, Authorizer) - Constructor for class org.apache.nifi.web.security.NiFiAuthenticationProvider
 
NiFiAuthenticationProviderTest - Class in org.apache.nifi.web.security
 
NiFiAuthenticationProviderTest() - Constructor for class org.apache.nifi.web.security.NiFiAuthenticationProviderTest
 
NiFiAuthenticationRequestToken - Class in org.apache.nifi.web.security
Base class for authentication request tokens in NiFI.
NiFiAuthenticationRequestToken(String) - Constructor for class org.apache.nifi.web.security.NiFiAuthenticationRequestToken
 
NiFiAuthenticationToken - Class in org.apache.nifi.web.security.token
An authentication token that represents an Authenticated and Authorized user of the NiFi Apis.
NiFiAuthenticationToken(UserDetails) - Constructor for class org.apache.nifi.web.security.token.NiFiAuthenticationToken
 
NiFiBolt - Class in org.apache.nifi.storm
A Storm bolt that can send tuples back to NiFi.
NiFiBolt(SiteToSiteClientConfig, NiFiDataPacketBuilder, int) - Constructor for class org.apache.nifi.storm.NiFiBolt
 
NifiChannelSelector - Class in org.apache.nifi.processors.flume
 
NifiChannelSelector(Channel) - Constructor for class org.apache.nifi.processors.flume.NifiChannelSelector
 
NiFiCoreException - Exception in org.apache.nifi.web
Exception indicating an error occurred in the NiFi Core.
NiFiCoreException(String) - Constructor for exception org.apache.nifi.web.NiFiCoreException
 
NiFiCoreException(String, Throwable) - Constructor for exception org.apache.nifi.web.NiFiCoreException
 
NiFiCoreExceptionMapper - Class in org.apache.nifi.web.api.config
Maps NiFi core exceptions into client responses.
NiFiCoreExceptionMapper() - Constructor for class org.apache.nifi.web.api.config.NiFiCoreExceptionMapper
 
NiFiDataPacket - Interface in org.apache.nifi.spark
The NiFiDataPacket provides a packaging around a NiFi FlowFile.
NiFiDataPacket - Interface in org.apache.nifi.storm
The NiFiDataPacket provides a packaging around a NiFi FlowFile.
NiFiDataPacketBuilder - Interface in org.apache.nifi.storm
Converts a Tuple into a NiFiDataPacket.
NiFiFlowTestAuthorizer - Class in org.apache.nifi.integration.util
 
NiFiFlowTestAuthorizer() - Constructor for class org.apache.nifi.integration.util.NiFiFlowTestAuthorizer
Creates a new FileAuthorizationProvider.
NiFiLegacyCipherProvider - Class in org.apache.nifi.security.util.crypto
Deprecated.
NiFiLegacyCipherProvider() - Constructor for class org.apache.nifi.security.util.crypto.NiFiLegacyCipherProvider
Deprecated.
 
NiFiListener - Class in org.apache.nifi.bootstrap
 
NiFiListener() - Constructor for class org.apache.nifi.bootstrap.NiFiListener
 
NiFiLog - Class in org.apache.nifi.logging
 
NiFiLog(Logger) - Constructor for class org.apache.nifi.logging.NiFiLog
 
NiFiOrcUtils - Class in org.apache.hadoop.hive.ql.io.orc
Utility methods for ORC support (conversion from Avro, conversion to Hive types, e.g.
NiFiOrcUtils() - Constructor for class org.apache.hadoop.hive.ql.io.orc.NiFiOrcUtils
 
NiFiProperties - Class in org.apache.nifi.util
The NiFiProperties class holds all properties which are needed for various values to be available at runtime.
NiFiProperties() - Constructor for class org.apache.nifi.util.NiFiProperties
 
NiFiPropertiesLoader - Class in org.apache.nifi.properties
 
NiFiPropertiesLoader() - Constructor for class org.apache.nifi.properties.NiFiPropertiesLoader
 
NiFiPropertiesTest - Class in org.apache.nifi.util
 
NiFiPropertiesTest() - Constructor for class org.apache.nifi.util.NiFiPropertiesTest
 
NifiPropertiesTlsClientConfigWriter - Class in org.apache.nifi.toolkit.tls.manager.writer
Will write a nifi.properties file appropriate for the given client config
NifiPropertiesTlsClientConfigWriter(NiFiPropertiesWriterFactory, File, String, int) - Constructor for class org.apache.nifi.toolkit.tls.manager.writer.NifiPropertiesTlsClientConfigWriter
 
NifiPropertiesTlsClientConfigWriterTest - Class in org.apache.nifi.toolkit.tls.manager.writer
 
NifiPropertiesTlsClientConfigWriterTest() - Constructor for class org.apache.nifi.toolkit.tls.manager.writer.NifiPropertiesTlsClientConfigWriterTest
 
NiFiPropertiesWriter - Class in org.apache.nifi.toolkit.tls.properties
Class capable of writing out updated NiFi properties.
NiFiPropertiesWriter(List<String>) - Constructor for class org.apache.nifi.toolkit.tls.properties.NiFiPropertiesWriter
 
NiFiPropertiesWriterFactory - Class in org.apache.nifi.toolkit.tls.properties
Factory for creating NifiPropertiesWriters so that the lines only have to be read once
NiFiPropertiesWriterFactory() - Constructor for class org.apache.nifi.toolkit.tls.properties.NiFiPropertiesWriterFactory
 
NiFiPropertiesWriterFactory(InputStream) - Constructor for class org.apache.nifi.toolkit.tls.properties.NiFiPropertiesWriterFactory
 
NifiPropertiesWriterTest - Class in org.apache.nifi.toolkit.tls.properties
 
NifiPropertiesWriterTest() - Constructor for class org.apache.nifi.toolkit.tls.properties.NifiPropertiesWriterTest
 
NiFiReceiver - Class in org.apache.nifi.spark
The NiFiReceiver is a Reliable Receiver that provides a way to pull data from Apache NiFi so that it can be processed by Spark Streaming.
NiFiReceiver(SiteToSiteClientConfig, StorageLevel) - Constructor for class org.apache.nifi.spark.NiFiReceiver
 
NiFiServer - Interface in org.apache.nifi
 
NiFiServiceFacade - Interface in org.apache.nifi.web
Defines the NiFiServiceFacade interface.
NiFiServiceFacadeLock - Class in org.apache.nifi.web
Aspect to limit access into the core.
NiFiServiceFacadeLock() - Constructor for class org.apache.nifi.web.NiFiServiceFacadeLock
 
NifiSessionChannel - Class in org.apache.nifi.processors.flume
 
NifiSessionChannel(Relationship) - Constructor for class org.apache.nifi.processors.flume.NifiSessionChannel
 
NifiSessionFactoryChannel - Class in org.apache.nifi.processors.flume
 
NifiSessionFactoryChannel(ProcessSessionFactory, Relationship) - Constructor for class org.apache.nifi.processors.flume.NifiSessionFactoryChannel
 
NifiSinkSessionChannel - Class in org.apache.nifi.processors.flume
 
NifiSinkSessionChannel(Relationship, Relationship) - Constructor for class org.apache.nifi.processors.flume.NifiSinkSessionChannel
 
NiFiSpout - Class in org.apache.nifi.storm
The NiFiSpout provides a way to pull data from Apache NiFi so that it can be processed by Apache Storm.
NiFiSpout(SiteToSiteClientConfig) - Constructor for class org.apache.nifi.storm.NiFiSpout
 
NiFiSpout(SiteToSiteClientConfig, List<String>) - Constructor for class org.apache.nifi.storm.NiFiSpout
 
NiFiStormTopology - Class in org.apache.nifi.storm
Example topology that pulls data from a NiFi Output Port named 'Data for Storm' and writes the same data back to a NiFi Input Port named 'Data from Storm'.
NiFiStormTopology() - Constructor for class org.apache.nifi.storm.NiFiStormTopology
 
NiFiTestAuthorizer - Class in org.apache.nifi.integration.util
Contains extra rules to convenience when in component based access control tests.
NiFiTestAuthorizer() - Constructor for class org.apache.nifi.integration.util.NiFiTestAuthorizer
Creates a new FileAuthorizationProvider.
NiFiTestLoginIdentityProvider - Class in org.apache.nifi.integration.util
 
NiFiTestLoginIdentityProvider() - Constructor for class org.apache.nifi.integration.util.NiFiTestLoginIdentityProvider
Creates a new FileAuthorizationProvider.
NiFiTestServer - Class in org.apache.nifi.integration.util
Creates an embedded server for testing the NiFi REST API.
NiFiTestServer(String, String, NiFiProperties) - Constructor for class org.apache.nifi.integration.util.NiFiTestServer
 
NiFiTestUser - Class in org.apache.nifi.integration.util
 
NiFiTestUser(Client, String) - Constructor for class org.apache.nifi.integration.util.NiFiTestUser
 
NiFiUser - Interface in org.apache.nifi.authorization.user
A representation of a NiFi user that has logged into the application
NiFiUserDetails - Class in org.apache.nifi.authorization.user
User details for a NiFi user.
NiFiUserDetails(NiFiUser) - Constructor for class org.apache.nifi.authorization.user.NiFiUserDetails
Creates a new NiFiUserDetails.
NiFiUserGroup - Class in org.apache.nifi.user
 
NiFiUserGroup() - Constructor for class org.apache.nifi.user.NiFiUserGroup
 
NiFiUserUtils - Class in org.apache.nifi.authorization.user
Utility methods for retrieving information about the current application user.
NiFiUserUtils() - Constructor for class org.apache.nifi.authorization.user.NiFiUserUtils
 
NiFiWebApiConfiguration - Class in org.apache.nifi.web
 
NiFiWebApiConfiguration() - Constructor for class org.apache.nifi.web.NiFiWebApiConfiguration
 
NiFiWebApiSecurityConfiguration - Class in org.apache.nifi.web
NiFi Web Api Spring security
NiFiWebApiSecurityConfiguration() - Constructor for class org.apache.nifi.web.NiFiWebApiSecurityConfiguration
 
NiFiWebApiTest - Class in org.apache.nifi.integration
 
NiFiWebApiTest() - Constructor for class org.apache.nifi.integration.NiFiWebApiTest
 
NiFiWebConfigurationContext - Interface in org.apache.nifi.web
NiFi web context providing limited access to dataflow configuration for component custom UIs.
NiFiWebConfigurationRequestContext - Interface in org.apache.nifi.web
Contextual details required to make a configuration request from a UI extension.
NiFiWebRequestContext - Interface in org.apache.nifi.web
Contextual details required to make a request from a UI extension.
NLKBufferedReader - Class in org.apache.nifi.processors.standard.util
 
NLKBufferedReader(Reader, int) - Constructor for class org.apache.nifi.processors.standard.util.NLKBufferedReader
Creates a buffering character-input stream that uses an input buffer of the specified size.
NLKBufferedReader(Reader) - Constructor for class org.apache.nifi.processors.standard.util.NLKBufferedReader
Creates a buffering character-input stream that uses a default-sized input buffer.
NO_OP - Static variable in interface org.apache.nifi.events.EventReporter
An Event Reporter that performs no action and ignores all given input
NO_POLICY_COMPONENT_NAME - Static variable in class org.apache.nifi.integration.util.NiFiFlowTestAuthorizer
 
NO_POLICY_COMPONENT_NAME - Static variable in class org.apache.nifi.integration.util.NiFiTestAuthorizer
 
NO_SERVER_SIDE_ENCRYPTION - Static variable in class org.apache.nifi.processors.aws.s3.PutS3Object
 
NO_VALUE - Static variable in class org.apache.nifi.fingerprint.FingerprintFactory
 
NO_VALUE - Static variable in class org.apache.nifi.provenance.schema.EventFieldNames
 
NO_VALUE - Static variable in class org.apache.nifi.provenance.schema.LookupTableEventRecordFields
 
NO_VALUE_SCHEMA - Static variable in class org.apache.nifi.provenance.schema.LookupTableEventSchema
 
noCache(Response.ResponseBuilder) - Method in class org.apache.nifi.web.api.ApplicationResource
Edit the response headers to indicating no caching.
NoClusterCoordinatorException - Exception in org.apache.nifi.cluster.exception
 
NoClusterCoordinatorException() - Constructor for exception org.apache.nifi.cluster.exception.NoClusterCoordinatorException
 
NoClusterCoordinatorException(String) - Constructor for exception org.apache.nifi.cluster.exception.NoClusterCoordinatorException
 
NoClusterCoordinatorExceptionMapper - Class in org.apache.nifi.web.api.config
 
NoClusterCoordinatorExceptionMapper() - Constructor for class org.apache.nifi.web.api.config.NoClusterCoordinatorExceptionMapper
 
NoConnectedNodesException - Exception in org.apache.nifi.cluster.manager.exception
Represents the exceptional case when the cluster is unable to service a request because no nodes are connected.
NoConnectedNodesException() - Constructor for exception org.apache.nifi.cluster.manager.exception.NoConnectedNodesException
 
NoConnectedNodesException(String) - Constructor for exception org.apache.nifi.cluster.manager.exception.NoConnectedNodesException
 
NoConnectedNodesException(Throwable) - Constructor for exception org.apache.nifi.cluster.manager.exception.NoConnectedNodesException
 
NoConnectedNodesException(String, Throwable) - Constructor for exception org.apache.nifi.cluster.manager.exception.NoConnectedNodesException
 
NoConnectedNodesExceptionMapper - Class in org.apache.nifi.web.api.config
Maps no connected nodes exceptions into client responses.
NoConnectedNodesExceptionMapper() - Constructor for class org.apache.nifi.web.api.config.NoConnectedNodesExceptionMapper
 
Node - Class in org.apache.nifi.cluster.integration
 
Node(NiFiProperties, FlowElection) - Constructor for class org.apache.nifi.cluster.integration.Node
 
Node(NodeIdentifier, NiFiProperties, FlowElection) - Constructor for class org.apache.nifi.cluster.integration.Node
 
Node - Class in org.apache.nifi.util.search.ahocorasick
 
NODE_CONTINUE - Static variable in interface org.apache.nifi.cluster.coordination.http.replication.RequestReplicator
 
NODE_CONTINUE_STATUS_CODE - Static variable in interface org.apache.nifi.cluster.coordination.http.replication.RequestReplicator
 
NodeBulletinProcessingStrategy - Class in org.apache.nifi.events
 
NodeBulletinProcessingStrategy() - Constructor for class org.apache.nifi.events.NodeBulletinProcessingStrategy
 
NodeBulletins - Class in org.apache.nifi.cluster.protocol
 
NodeBulletins(NodeIdentifier, byte[]) - Constructor for class org.apache.nifi.cluster.protocol.NodeBulletins
 
NodeBulletinsAdapter - Class in org.apache.nifi.cluster.protocol.jaxb.message
 
NodeBulletinsAdapter() - Constructor for class org.apache.nifi.cluster.protocol.jaxb.message.NodeBulletinsAdapter
 
NodeClusterCoordinator - Class in org.apache.nifi.cluster.coordination.node
 
NodeClusterCoordinator(ClusterCoordinationProtocolSenderListener, EventReporter, LeaderElectionManager, FlowElection, ClusterNodeFirewall, RevisionManager, NiFiProperties, NodeProtocolSender) - Constructor for class org.apache.nifi.cluster.coordination.node.NodeClusterCoordinator
 
NodeClusterCoordinatorFactoryBean - Class in org.apache.nifi.cluster.spring
 
NodeClusterCoordinatorFactoryBean() - Constructor for class org.apache.nifi.cluster.spring.NodeClusterCoordinatorFactoryBean
 
NodeConnectionState - Enum in org.apache.nifi.cluster.coordination.node
 
NodeConnectionStatus - Class in org.apache.nifi.cluster.coordination.node
Describes the current status of a node
NodeConnectionStatus(NodeIdentifier, NodeConnectionState) - Constructor for class org.apache.nifi.cluster.coordination.node.NodeConnectionStatus
 
NodeConnectionStatus(NodeIdentifier, DisconnectionCode) - Constructor for class org.apache.nifi.cluster.coordination.node.NodeConnectionStatus
 
NodeConnectionStatus(NodeIdentifier, DisconnectionCode, String) - Constructor for class org.apache.nifi.cluster.coordination.node.NodeConnectionStatus
 
NodeConnectionStatus(NodeIdentifier, NodeConnectionState, DisconnectionCode) - Constructor for class org.apache.nifi.cluster.coordination.node.NodeConnectionStatus
 
NodeConnectionStatus(NodeConnectionStatus) - Constructor for class org.apache.nifi.cluster.coordination.node.NodeConnectionStatus
 
NodeConnectionStatus(NodeIdentifier, NodeConnectionState, DisconnectionCode, String, Long) - Constructor for class org.apache.nifi.cluster.coordination.node.NodeConnectionStatus
 
NodeConnectionStatus(long, NodeIdentifier, NodeConnectionState, DisconnectionCode, String, Long) - Constructor for class org.apache.nifi.cluster.coordination.node.NodeConnectionStatus
 
NodeConnectionStatusAdapter - Class in org.apache.nifi.cluster.protocol.jaxb.message
 
NodeConnectionStatusAdapter() - Constructor for class org.apache.nifi.cluster.protocol.jaxb.message.NodeConnectionStatusAdapter
 
NodeConnectionStatusRequestMessage - Class in org.apache.nifi.cluster.protocol.message
 
NodeConnectionStatusRequestMessage() - Constructor for class org.apache.nifi.cluster.protocol.message.NodeConnectionStatusRequestMessage
 
NodeConnectionStatusResponseMessage - Class in org.apache.nifi.cluster.protocol.message
 
NodeConnectionStatusResponseMessage() - Constructor for class org.apache.nifi.cluster.protocol.message.NodeConnectionStatusResponseMessage
 
NodeConnectionStatusSnapshotDTO - Class in org.apache.nifi.web.api.dto.status
 
NodeConnectionStatusSnapshotDTO() - Constructor for class org.apache.nifi.web.api.dto.status.NodeConnectionStatusSnapshotDTO
 
NodeCountersSnapshotDTO - Class in org.apache.nifi.web.api.dto
 
NodeCountersSnapshotDTO() - Constructor for class org.apache.nifi.web.api.dto.NodeCountersSnapshotDTO
 
NodeDescription - Interface in org.apache.nifi.controller.state
Provides information about a node in a NiFi cluster
NodeDisconnectionException - Exception in org.apache.nifi.cluster.manager.exception
Represents the exceptional case when a disconnection request to a node failed.
NodeDisconnectionException() - Constructor for exception org.apache.nifi.cluster.manager.exception.NodeDisconnectionException
 
NodeDisconnectionException(String) - Constructor for exception org.apache.nifi.cluster.manager.exception.NodeDisconnectionException
 
NodeDisconnectionException(Throwable) - Constructor for exception org.apache.nifi.cluster.manager.exception.NodeDisconnectionException
 
NodeDisconnectionException(String, Throwable) - Constructor for exception org.apache.nifi.cluster.manager.exception.NodeDisconnectionException
 
NodeDisconnectionExceptionMapper - Class in org.apache.nifi.web.api.config
Maps node disconnection exceptions into client responses.
NodeDisconnectionExceptionMapper() - Constructor for class org.apache.nifi.web.api.config.NodeDisconnectionExceptionMapper
 
NodeDTO - Class in org.apache.nifi.web.api.dto
Details of a node within this NiFi.
NodeDTO() - Constructor for class org.apache.nifi.web.api.dto.NodeDTO
 
NodeEntity - Class in org.apache.nifi.web.api.entity
A serialized representation of this class can be placed in the entity body of a request or response to or from the API.
NodeEntity() - Constructor for class org.apache.nifi.web.api.entity.NodeEntity
 
NodeEvent - Interface in org.apache.nifi.cluster.event
 
NodeEventDTO - Class in org.apache.nifi.web.api.dto
A event for a node within this NiFi cluster.
NodeEventDTO() - Constructor for class org.apache.nifi.web.api.dto.NodeEventDTO
 
NodeHeartbeat - Interface in org.apache.nifi.cluster.coordination.heartbeat
 
NodeIdentifier - Class in org.apache.nifi.cluster.protocol
A node identifier denoting the coordinates of a flow controller that is connected to a cluster.
NodeIdentifier(String, String, int, String, int, String, Integer, Integer, boolean) - Constructor for class org.apache.nifi.cluster.protocol.NodeIdentifier
 
NodeIdentifier(String, String, int, String, int, String, Integer, Integer, boolean, String) - Constructor for class org.apache.nifi.cluster.protocol.NodeIdentifier
 
NodeIdentifier() - Constructor for class org.apache.nifi.cluster.protocol.NodeIdentifier
This constructor should not be used and exists solely for the use of JAXB
NodeIdentifierAdapter - Class in org.apache.nifi.cluster.protocol.jaxb.message
 
NodeIdentifierAdapter() - Constructor for class org.apache.nifi.cluster.protocol.jaxb.message.NodeIdentifierAdapter
 
NodeInformant - Interface in org.apache.nifi.remote.cluster
 
NodeInformation - Class in org.apache.nifi.remote.cluster
 
NodeInformation(String, Integer, Integer, int, boolean, int) - Constructor for class org.apache.nifi.remote.cluster.NodeInformation
 
NodeInformationAdapter - Class in org.apache.nifi.remote.cluster
 
NodeInformationAdapter() - Constructor for class org.apache.nifi.remote.cluster.NodeInformationAdapter
 
nodePenalizationPeriod(long, TimeUnit) - Method in class org.apache.nifi.remote.client.SiteToSiteClient.Builder
If there is a problem communicating with a node (i.e., any node in the remote NiFi cluster or the remote instance of NiFi if it is standalone), specifies how long the client should wait before attempting to communicate with that node again.
NodePortStatusDTO - Class in org.apache.nifi.web.api.dto.status
DTO for serializing the port status for a particular node.
NodePortStatusDTO() - Constructor for class org.apache.nifi.web.api.dto.status.NodePortStatusDTO
 
NodePortStatusSnapshotDTO - Class in org.apache.nifi.web.api.dto.status
 
NodePortStatusSnapshotDTO() - Constructor for class org.apache.nifi.web.api.dto.status.NodePortStatusSnapshotDTO
 
NodeProcessGroupStatusSnapshotDTO - Class in org.apache.nifi.web.api.dto.status
 
NodeProcessGroupStatusSnapshotDTO() - Constructor for class org.apache.nifi.web.api.dto.status.NodeProcessGroupStatusSnapshotDTO
 
NodeProcessorStatusSnapshotDTO - Class in org.apache.nifi.web.api.dto.status
DTO for serializing the processor status for a particular node.
NodeProcessorStatusSnapshotDTO() - Constructor for class org.apache.nifi.web.api.dto.status.NodeProcessorStatusSnapshotDTO
 
NodeProtocolSender - Interface in org.apache.nifi.cluster.protocol
An interface for sending protocol messages from a node to the cluster manager.
NodeProtocolSenderListener - Class in org.apache.nifi.cluster.protocol.impl
 
NodeProtocolSenderListener(NodeProtocolSender, ProtocolListener) - Constructor for class org.apache.nifi.cluster.protocol.impl.NodeProtocolSenderListener
 
NodeReconnectionException - Exception in org.apache.nifi.cluster.manager.exception
Represents the exceptional case when a reconnection request to a node failed.
NodeReconnectionException() - Constructor for exception org.apache.nifi.cluster.manager.exception.NodeReconnectionException
 
NodeReconnectionException(String) - Constructor for exception org.apache.nifi.cluster.manager.exception.NodeReconnectionException
 
NodeReconnectionException(Throwable) - Constructor for exception org.apache.nifi.cluster.manager.exception.NodeReconnectionException
 
NodeReconnectionException(String, Throwable) - Constructor for exception org.apache.nifi.cluster.manager.exception.NodeReconnectionException
 
NodeReconnectionExceptionMapper - Class in org.apache.nifi.web.api.config
Maps node reconnection exceptions into client responses.
NodeReconnectionExceptionMapper() - Constructor for class org.apache.nifi.web.api.config.NodeReconnectionExceptionMapper
 
NodeRemoteProcessGroupStatusSnapshotDTO - Class in org.apache.nifi.web.api.dto.status
 
NodeRemoteProcessGroupStatusSnapshotDTO() - Constructor for class org.apache.nifi.web.api.dto.status.NodeRemoteProcessGroupStatusSnapshotDTO
 
NodeResponse - Class in org.apache.nifi.cluster.manager
Encapsulates a node's response in regards to receiving a external API request.
NodeResponse(NodeIdentifier, String, URI, ClientResponse, long, String) - Constructor for class org.apache.nifi.cluster.manager.NodeResponse
 
NodeResponse(NodeIdentifier, String, URI, Throwable) - Constructor for class org.apache.nifi.cluster.manager.NodeResponse
 
NodeResponse(NodeResponse, Entity) - Constructor for class org.apache.nifi.cluster.manager.NodeResponse
 
NodeSearchResultDTO - Class in org.apache.nifi.web.api.dto.search
A search result for a matching node.
NodeSearchResultDTO() - Constructor for class org.apache.nifi.web.api.dto.search.NodeSearchResultDTO
 
NodeStateManager - Class in org.apache.nifi.cluster.coordination.node
 
NodeStateManager() - Constructor for class org.apache.nifi.cluster.coordination.node.NodeStateManager
 
NodeStatusChangeMessage - Class in org.apache.nifi.cluster.protocol.message
Message to indicate that the status of a node in the cluster has changed
NodeStatusChangeMessage() - Constructor for class org.apache.nifi.cluster.protocol.message.NodeStatusChangeMessage
 
NodeStatusDTO - Class in org.apache.nifi.web.api.dto.status
DTO for serializing the node status.
NodeStatusDTO() - Constructor for class org.apache.nifi.web.api.dto.status.NodeStatusDTO
 
NodeStatusEntity - Class in org.apache.nifi.web.api.entity
A serialized representation of this class can be placed in the entity body of a request or response to or from the API.
NodeStatusEntity() - Constructor for class org.apache.nifi.web.api.entity.NodeStatusEntity
 
NodeStatusSnapshotsDTO - Class in org.apache.nifi.web.api.dto.status
DTO for serializing the status history of a single component across the cluster.
NodeStatusSnapshotsDTO() - Constructor for class org.apache.nifi.web.api.dto.status.NodeStatusSnapshotsDTO
 
NodeSystemDiagnosticsSnapshotDTO - Class in org.apache.nifi.web.api.dto
 
NodeSystemDiagnosticsSnapshotDTO() - Constructor for class org.apache.nifi.web.api.dto.NodeSystemDiagnosticsSnapshotDTO
 
nodeTypeErrorResponse(String) - Method in class org.apache.nifi.web.api.ApplicationResource.ResponseCreator
 
NodeTypeProvider - Interface in org.apache.nifi.controller
This interface provides a set of methods for checking NiFi node type.
NODEWISE - Static variable in class org.apache.nifi.web.api.ApplicationResource
 
NodeWorkload - Class in org.apache.nifi.cluster.coordination.node
 
NodeWorkload() - Constructor for class org.apache.nifi.cluster.coordination.node.NodeWorkload
 
NON_BLANK_VALIDATOR - Static variable in class org.apache.nifi.processor.util.StandardValidators
Validator that ensures that value has 1+ non-whitespace characters
NON_EMPTY_EL_VALIDATOR - Static variable in class org.apache.nifi.processor.util.StandardValidators
Validator that ensures that value's length > 0 and that expression language is present
NON_EMPTY_VALIDATOR - Static variable in class org.apache.nifi.processor.util.StandardValidators
Validator that ensures that value's length > 0
NON_GUARANTEED_ENDPOINT - Static variable in class org.apache.nifi.web.api.ApplicationResource
 
NON_NEGATIVE_INTEGER_VALIDATOR - Static variable in class org.apache.nifi.processor.util.StandardValidators
 
NonCloseableInputStream - Class in org.apache.nifi.stream.io
Wraps and InputStream so that the underlying InputStream cannot be closed.
NonCloseableInputStream(InputStream) - Constructor for class org.apache.nifi.stream.io.NonCloseableInputStream
 
NonCloseableInputStream(InputStream) - Constructor for class org.apache.nifi.util.FlowFileUnpackagerV1.NonCloseableInputStream
 
NonCloseableOutputStream - Class in org.apache.nifi.stream.io
 
NonCloseableOutputStream(OutputStream) - Constructor for class org.apache.nifi.stream.io.NonCloseableOutputStream
 
NONE - Static variable in class org.apache.nifi.processors.enrich.AbstractEnrichProcessor
 
NONE_CLIENT_ID - Static variable in class org.apache.nifi.integration.accesscontrol.AccessControlHelper
 
NONE_USER_DN - Static variable in class org.apache.nifi.integration.util.NiFiFlowTestAuthorizer
 
NONE_USER_DN - Static variable in class org.apache.nifi.integration.util.NiFiTestAuthorizer
 
NonEmptyBrokerURIValidator() - Constructor for class org.apache.nifi.jms.cf.JMSConnectionFactoryProviderDefinition.NonEmptyBrokerURIValidator
 
NonThreadSafeCircularBuffer - Class in org.apache.nifi.stream.io.util
 
NonThreadSafeCircularBuffer(byte[]) - Constructor for class org.apache.nifi.stream.io.util.NonThreadSafeCircularBuffer
 
NopResourceClaimManager() - Constructor for class org.apache.nifi.controller.TestFileSystemSwapManager.NopResourceClaimManager
 
NopSchemaAccessWriter - Class in org.apache.nifi.schema.access
 
NopSchemaAccessWriter() - Constructor for class org.apache.nifi.schema.access.NopSchemaAccessWriter
 
NopStateProvider - Class in org.apache.nifi.cluster.integration
 
NopStateProvider() - Constructor for class org.apache.nifi.cluster.integration.NopStateProvider
 
NopTocWriter - Class in org.apache.nifi.provenance.toc
 
NopTocWriter() - Constructor for class org.apache.nifi.provenance.toc.NopTocWriter
 
NoResponseFromNodesException - Exception in org.apache.nifi.cluster.manager.exception
Represents the exceptional case when the cluster is unable to service a request because no nodes returned a response.
NoResponseFromNodesException() - Constructor for exception org.apache.nifi.cluster.manager.exception.NoResponseFromNodesException
 
NoResponseFromNodesException(String) - Constructor for exception org.apache.nifi.cluster.manager.exception.NoResponseFromNodesException
 
NoResponseFromNodesException(Throwable) - Constructor for exception org.apache.nifi.cluster.manager.exception.NoResponseFromNodesException
 
NoResponseFromNodesException(String, Throwable) - Constructor for exception org.apache.nifi.cluster.manager.exception.NoResponseFromNodesException
 
NoResponseFromNodesExceptionMapper - Class in org.apache.nifi.web.api.config
Maps the exceptional case when the cluster is unable to service a request because no nodes returned a response.
NoResponseFromNodesExceptionMapper() - Constructor for class org.apache.nifi.web.api.config.NoResponseFromNodesExceptionMapper
 
NORMAL_SUBSTITUTION_TOKEN - Static variable in class org.apache.nifi.processors.evtx.parser.bxml.BxmlNode
 
NORMALIZE_NAMES_FOR_AVRO - Static variable in class org.apache.nifi.processors.standard.util.JdbcCommon
 
normalizedMergedErrors(Map<String, Set<NodeIdentifier>>, int) - Static method in class org.apache.nifi.cluster.manager.ErrorMerger
Normalizes the validation errors.
normalizeHiveTableName(String) - Static method in class org.apache.hadoop.hive.ql.io.orc.NiFiOrcUtils
 
normalizeNameForAvro(String) - Static method in class org.apache.nifi.processors.standard.util.JdbcCommon
 
normalizeStatusSnapshotDate(Date, long) - Static method in class org.apache.nifi.cluster.coordination.http.endpoints.StatusHistoryEndpointMerger
 
NormalSubstitutionNode - Class in org.apache.nifi.processors.evtx.parser.bxml
Template node marked for substitution with the value the root node has at the given index
NormalSubstitutionNode(BinaryReader, ChunkHeader, BxmlNode) - Constructor for class org.apache.nifi.processors.evtx.parser.bxml.NormalSubstitutionNode
 
NormalSubstitutionNodeTest - Class in org.apache.nifi.processors.evtx.parser.bxml
 
NormalSubstitutionNodeTest() - Constructor for class org.apache.nifi.processors.evtx.parser.bxml.NormalSubstitutionNodeTest
 
NoStartService - Interface in org.apache.nifi.controller.scheduling
 
NoStartServiceImpl - Class in org.apache.nifi.controller.scheduling
 
NoStartServiceImpl() - Constructor for class org.apache.nifi.controller.scheduling.NoStartServiceImpl
 
NOT_A_REAL_USER_IDENTIFIER - Static variable in class org.apache.nifi.authorization.CompositeUserGroupProviderTest
 
NOT_A_REAL_USER_IDENTITY - Static variable in class org.apache.nifi.authorization.CompositeUserGroupProviderTest
 
NOT_CONFIGURABLE_USER_GROUP_PROVIDER - Static variable in class org.apache.nifi.authorization.CompositeConfigurableUserGroupProviderTest
 
NOT_MODIFIED - Static variable in class org.apache.nifi.processors.standard.GetHTTP
 
NotAuthorizedException - Exception in org.apache.nifi.remote.exception
 
NotAuthorizedException(String) - Constructor for exception org.apache.nifi.remote.exception.NotAuthorizedException
 
NotEqualsEvaluator - Class in org.apache.nifi.hl7.query.evaluator.comparison
 
NotEqualsEvaluator(Evaluator<?>, Evaluator<?>) - Constructor for class org.apache.nifi.hl7.query.evaluator.comparison.NotEqualsEvaluator
 
NotEqualsFilter - Class in org.apache.nifi.record.path.filter
 
NotEqualsFilter(RecordPathSegment, RecordPathSegment) - Constructor for class org.apache.nifi.record.path.filter.NotEqualsFilter
 
NotEvaluator - Class in org.apache.nifi.attribute.expression.language.evaluation.functions
 
NotEvaluator(Evaluator<Boolean>) - Constructor for class org.apache.nifi.attribute.expression.language.evaluation.functions.NotEvaluator
 
NotEvaluator - Class in org.apache.nifi.hl7.query.evaluator.comparison
 
NotEvaluator(BooleanEvaluator) - Constructor for class org.apache.nifi.hl7.query.evaluator.comparison.NotEvaluator
 
NotFilter - Class in org.apache.nifi.record.path.filter
 
NotFilter(RecordPathFilter) - Constructor for class org.apache.nifi.record.path.filter.NotFilter
 
notFound() - Method in class org.apache.nifi.processors.standard.TestFetchFile
 
NotFoundExceptionMapper - Class in org.apache.nifi.web.api.config
Maps not found exceptions into client responses.
NotFoundExceptionMapper() - Constructor for class org.apache.nifi.web.api.config.NotFoundExceptionMapper
 
NOTIFICATION_ATTEMPTS_PROP - Static variable in class org.apache.nifi.bootstrap.RunNiFi
 
NOTIFICATION_SERVICES_FILE_PROP - Static variable in class org.apache.nifi.bootstrap.RunNiFi
 
NOTIFICATION_SUBJECT_KEY - Static variable in class org.apache.nifi.bootstrap.notification.http.HttpNotificationService
 
NOTIFICATION_TYPE_KEY - Static variable in class org.apache.nifi.bootstrap.notification.http.HttpNotificationService
 
NotificationContext - Interface in org.apache.nifi.bootstrap.notification
 
NotificationFailedException - Exception in org.apache.nifi.bootstrap.notification
 
NotificationFailedException(String) - Constructor for exception org.apache.nifi.bootstrap.notification.NotificationFailedException
 
NotificationFailedException(String, Throwable) - Constructor for exception org.apache.nifi.bootstrap.notification.NotificationFailedException
 
NotificationFailedException(Throwable) - Constructor for exception org.apache.nifi.bootstrap.notification.NotificationFailedException
 
NotificationInitializationContext - Interface in org.apache.nifi.bootstrap.notification
 
NotificationService - Interface in org.apache.nifi.bootstrap.notification
A NotificationService is simple mechanism that the Bootstrap can use to notify interested parties when some event takes place, such as NiFi being started, stopped, or restarted because the process died.
NotificationServiceManager - Class in org.apache.nifi.bootstrap
 
NotificationServiceManager() - Constructor for class org.apache.nifi.bootstrap.NotificationServiceManager
 
NotificationType - Enum in org.apache.nifi.bootstrap.notification
 
NotificationValidationContext - Class in org.apache.nifi.bootstrap.notification
 
NotificationValidationContext(NotificationContext, VariableRegistry) - Constructor for class org.apache.nifi.bootstrap.notification.NotificationValidationContext
 
NOTIFIED_ATTRIBUTE_NAME - Static variable in class org.apache.nifi.processors.standard.Notify
 
notify(NotificationContext, NotificationType, String, String) - Method in class org.apache.nifi.bootstrap.notification.email.EmailNotificationService
 
notify(NotificationContext, NotificationType, String, String) - Method in class org.apache.nifi.bootstrap.notification.http.HttpNotificationService
 
notify(NotificationContext, NotificationType, String, String) - Method in interface org.apache.nifi.bootstrap.notification.NotificationService
Notifies the configured recipients of some event
notify(NotificationContext, NotificationType, String, String) - Method in class org.apache.nifi.bootstrap.notification.TestCustomNotificationService
 
notify(NotificationType, String, String) - Method in class org.apache.nifi.bootstrap.NotificationServiceManager
 
Notify - Class in org.apache.nifi.processors.standard
 
Notify() - Constructor for class org.apache.nifi.processors.standard.Notify
 
notify(String, Map<String, Integer>, Map<String, String>) - Method in class org.apache.nifi.processors.standard.WaitNotifyProtocol
Notify a signal to increase a counter.
notify(String, String, int, Map<String, String>) - Method in class org.apache.nifi.processors.standard.WaitNotifyProtocol
Notify a signal to increase a counter.
notifyNodeStatusChange(Set<NodeIdentifier>, NodeStatusChangeMessage) - Method in interface org.apache.nifi.cluster.protocol.ClusterCoordinationProtocolSender
Notifies all nodes in the given set that a node in the cluster has a new status
notifyNodeStatusChange(Set<NodeIdentifier>, NodeStatusChangeMessage) - Method in class org.apache.nifi.cluster.protocol.impl.ClusterCoordinationProtocolSenderListener
 
notifyNodeStatusChange(Set<NodeIdentifier>, NodeStatusChangeMessage) - Method in class org.apache.nifi.cluster.protocol.impl.StandardClusterCoordinationProtocolSender
 
notifyStop() - Method in class org.apache.nifi.bootstrap.RunNiFi
 
NotNullEvaluator - Class in org.apache.nifi.attribute.expression.language.evaluation.functions
 
NotNullEvaluator(Evaluator<?>) - Constructor for class org.apache.nifi.attribute.expression.language.evaluation.functions.NotNullEvaluator
 
NotNullEvaluator - Class in org.apache.nifi.hl7.query.evaluator.comparison
 
NotNullEvaluator(Evaluator<?>) - Constructor for class org.apache.nifi.hl7.query.evaluator.comparison.NotNullEvaluator
 
notSettingHdfsPathToWatchShouldThrowError() - Method in class org.apache.nifi.processors.hadoop.inotify.TestGetHDFSEvents
 
notValid() - Method in class org.apache.nifi.spring.SpringContextProcessorTest
 
NoVariablesImpacted - Class in org.apache.nifi.attribute.expression.language
 
NoVariablesImpacted() - Constructor for class org.apache.nifi.attribute.expression.language.NoVariablesImpacted
 
NowEvaluator - Class in org.apache.nifi.attribute.expression.language.evaluation.functions
 
NowEvaluator() - Constructor for class org.apache.nifi.attribute.expression.language.evaluation.functions.NowEvaluator
 
NULL_DESCRIPTOR - Static variable in class org.apache.nifi.components.PropertyDescriptor
 
NULL_VALUE_DEFAULT_REPRESENTATION - Static variable in class org.apache.nifi.processors.standard.AbstractJsonPathProcessor
 
NULL_VALUE_FOR_EMPTY_STRING - Static variable in class org.apache.nifi.processors.standard.AttributesToJSON
 
nullInputShouldProperlyFail() - Method in class org.apache.nifi.processors.hadoop.inotify.TestEventTypeValidator
 
NullOutputStream - Class in org.apache.nifi.stream.io
OutputStream that throws away all data, just like as if writing to /dev/null
NullOutputStream() - Constructor for class org.apache.nifi.stream.io.NullOutputStream
 
nullStream() - Method in class org.apache.nifi.stream.io.util.TextLineDemarcatorTest
 
NullSuppression - Enum in org.apache.nifi.json
 
NullTypeNode - Class in org.apache.nifi.processors.evtx.parser.bxml.value
Node containing null value
NullTypeNode(BinaryReader, ChunkHeader, BxmlNode, int) - Constructor for class org.apache.nifi.processors.evtx.parser.bxml.value.NullTypeNode
 
NullTypeNodeTest - Class in org.apache.nifi.processors.evtx.parser.bxml.value
 
NullTypeNodeTest() - Constructor for class org.apache.nifi.processors.evtx.parser.bxml.value.NullTypeNodeTest
 
NUM_DATA_POINTS_PROPERTY - Static variable in class org.apache.nifi.controller.status.history.VolatileComponentStatusRepository
 
NUM_ELEMENTS_MODIFIED_ATTR - Static variable in class org.apache.nifi.ModifyHTMLElement
 
NUM_RECORDS_TO_ANALYZE - Static variable in class org.apache.nifi.processors.kite.InferAvroSchema
 
NUM_RELATIONSHIPS - Static variable in class org.apache.nifi.processors.standard.DistributeLoad
 
NUM_REPO_SECTIONS - Static variable in class org.apache.nifi.controller.repository.TestFileSystemRepository
 
NUMBER_PATTERN - Static variable in class org.apache.nifi.attribute.expression.language.evaluation.cast.DateCastEvaluator
 
NUMBER_PATTERN - Static variable in class org.apache.nifi.processors.hive.AbstractHiveQLProcessor
 
NUMBER_PATTERN - Static variable in class org.apache.nifi.processors.standard.HandleHttpResponse
 
NUMBER_PATTERN - Static variable in class org.apache.nifi.processors.standard.MergeContent
 
NUMBER_PATTERN - Static variable in class org.apache.nifi.provenance.PersistentProvenanceRepository
 
NUMBER_VALIDATOR - Static variable in class org.apache.nifi.processor.util.StandardValidators
 
NumberCastEvaluator - Class in org.apache.nifi.attribute.expression.language.evaluation.cast
 
NumberCastEvaluator(Evaluator<?>) - Constructor for class org.apache.nifi.attribute.expression.language.evaluation.cast.NumberCastEvaluator
 
NumberEvaluator - Class in org.apache.nifi.attribute.expression.language.evaluation
 
NumberEvaluator() - Constructor for class org.apache.nifi.attribute.expression.language.evaluation.NumberEvaluator
 
numberHashNumberRangeTableName - Static variable in class org.apache.nifi.processors.aws.dynamodb.ITAbstractDynamoDBTest
 
numberHashOnlyTableName - Static variable in class org.apache.nifi.processors.aws.dynamodb.ITAbstractDynamoDBTest
 
NumberParsing - Class in org.apache.nifi.attribute.expression.language.evaluation.util
 
NumberParsing.ParseResultType - Enum in org.apache.nifi.attribute.expression.language.evaluation.util
 
numberPermissions(String) - Method in class org.apache.nifi.processors.standard.util.FTPTransfer
 
numberPermissions(String) - Method in class org.apache.nifi.processors.standard.util.SFTPTransfer
 
NumberQueryResult - Class in org.apache.nifi.attribute.expression.language.evaluation
 
NumberQueryResult(Number) - Constructor for class org.apache.nifi.attribute.expression.language.evaluation.NumberQueryResult
 
NumberToDateEvaluator - Class in org.apache.nifi.attribute.expression.language.evaluation.functions
 
NumberToDateEvaluator(Evaluator<Long>) - Constructor for class org.apache.nifi.attribute.expression.language.evaluation.functions.NumberToDateEvaluator
 
NumberUtil - Class in org.apache.nifi.processors.evtx.parser
Util methods for conveniently checking numbers
NumberUtil() - Constructor for class org.apache.nifi.processors.evtx.parser.NumberUtil
 
NumericBinaryOperatorFilter - Class in org.apache.nifi.record.path.filter
 
NumericBinaryOperatorFilter(RecordPathSegment, RecordPathSegment) - Constructor for class org.apache.nifi.record.path.filter.NumericBinaryOperatorFilter
 
NumericRange - Class in org.apache.nifi.record.path
 
NumericRange(int, int) - Constructor for class org.apache.nifi.record.path.NumericRange
 
A B C D E F G H I J K L M N O P Q R S T U V W X Y Z 
Skip navigation links