- C() - Constructor for class org.apache.nifi.util.ReflectionUtilsTest.C
-
- C_DATA_SECTION_TOKEN - Static variable in class org.apache.nifi.processors.evtx.parser.bxml.BxmlNode
-
- CACHE_CONTROL_ATTR - Static variable in class org.apache.nifi.processors.gcp.storage.StorageAttributes
-
- CACHE_CONTROL_DESC - Static variable in class org.apache.nifi.processors.gcp.storage.StorageAttributes
-
- CACHE_ENTRY_IDENTIFIER - Static variable in class org.apache.nifi.processors.standard.DetectDuplicate
-
- CACHE_ENTRY_IDENTIFIER - Static variable in class org.apache.nifi.processors.standard.PutDistributedMapCache
-
- CACHE_ENTRY_MAX_BYTES - Static variable in class org.apache.nifi.processors.standard.PutDistributedMapCache
-
- CACHE_IDENTIFIER - Static variable in class org.apache.nifi.processors.standard.DetectDuplicate
-
- CACHE_NAME - Static variable in class org.apache.nifi.processors.ignite.cache.AbstractIgniteCacheProcessor
-
Ignite cache name
- CACHE_SIZE - Static variable in class org.apache.nifi.processors.standard.TransformXml
-
- CACHE_TTL_AFTER_LAST_ACCESS - Static variable in class org.apache.nifi.processors.standard.TransformXml
-
- CACHE_UPDATE_KEEP_ORIGINAL - Static variable in class org.apache.nifi.processors.standard.PutDistributedMapCache
-
- CACHE_UPDATE_REPLACE - Static variable in class org.apache.nifi.processors.standard.PutDistributedMapCache
-
- CACHE_UPDATE_STRATEGY - Static variable in class org.apache.nifi.processors.standard.PutDistributedMapCache
-
- cacheConfig(ConfigurationContext) - Method in class org.apache.nifi.distributed.cache.client.DistributedMapCacheClientService
-
- cacheConfiguredValues(ConfigurationContext) - Method in class org.apache.nifi.lookup.SimpleKeyValueLookupService
-
- CACHED_ATTRIBUTE_NAME - Static variable in class org.apache.nifi.processors.standard.PutDistributedMapCache
-
- CachedQuery - Interface in org.apache.nifi.provenance.index.lucene
-
- CacheKey - Class in org.apache.nifi.web.security.util
-
Key for the cache.
- CacheKey(String) - Constructor for class org.apache.nifi.web.security.util.CacheKey
-
- CacheRecord - Class in org.apache.nifi.distributed.cache.server
-
- CacheRecord() - Constructor for class org.apache.nifi.distributed.cache.server.CacheRecord
-
- CacheServer - Interface in org.apache.nifi.distributed.cache.server
-
- CacheValueDeserializer() - Constructor for class org.apache.nifi.processors.standard.FetchDistributedMapCache.CacheValueDeserializer
-
- CacheValueDeserializer() - Constructor for class org.apache.nifi.processors.standard.PutDistributedMapCache.CacheValueDeserializer
-
- CacheValueSerializer() - Constructor for class org.apache.nifi.processors.standard.PutDistributedMapCache.CacheValueSerializer
-
- CachingIndexManager - Class in org.apache.nifi.provenance.lucene
-
- CachingIndexManager() - Constructor for class org.apache.nifi.provenance.lucene.CachingIndexManager
-
- CachingSchemaRegistryClient - Class in org.apache.nifi.confluent.schemaregistry.client
-
- CachingSchemaRegistryClient(SchemaRegistryClient, int, long) - Constructor for class org.apache.nifi.confluent.schemaregistry.client.CachingSchemaRegistryClient
-
- calcDefaultDn(String) - Method in class org.apache.nifi.toolkit.tls.configuration.TlsConfig
-
- calculateDataRate(long) - Method in class org.apache.nifi.util.StopWatch
-
- calculateDefaultOutputDirectory(Path) - Static method in class org.apache.nifi.toolkit.tls.standalone.TlsToolkitStandaloneCommandLine
-
- calculateExpectedMemory(int, int, int) - Static method in class org.apache.nifi.security.util.crypto.scrypt.Scrypt
-
Returns the expected memory cost of the provided parameters in bytes.
- calculateHMac(String, PublicKey) - Static method in class org.apache.nifi.toolkit.tls.util.TlsHelper
-
- calculateProcessingNanos(ProcessGroupStatus) - Method in class org.apache.nifi.reporting.ambari.metrics.MetricsService
-
- calculateProcessingNanos(ProcessGroupStatus) - Method in class org.apache.nifi.reporting.datadog.metrics.MetricsService
-
- call() - Method in class org.apache.nifi.controller.tasks.ContinuallyRunConnectableTask
-
- call() - Method in class org.apache.nifi.controller.tasks.ContinuallyRunProcessorTask
-
- callTimeout - Variable in class org.apache.nifi.util.hive.HiveOptions
-
- callTimeoutPool - Variable in class org.apache.nifi.processors.hive.PutHiveStreaming
-
- cancel() - Method in class org.apache.nifi.controller.queue.ListFlowFileRequest
-
- cancel() - Method in class org.apache.nifi.provenance.AsyncLineageSubmission
-
- cancel() - Method in class org.apache.nifi.provenance.AsyncQuerySubmission
-
- cancel() - Method in interface org.apache.nifi.provenance.lineage.ComputeLineageSubmission
-
Cancels the lineage computation
- cancel() - Method in interface org.apache.nifi.provenance.search.QuerySubmission
-
Cancels the query
- cancel() - Method in class org.apache.nifi.registry.variable.VariableRegistryUpdateRequest
-
- cancel(String) - Method in class org.apache.nifi.remote.AbstractTransaction
-
- cancel(String) - Method in interface org.apache.nifi.remote.Transaction
-
Cancels this transaction, indicating to the sender that the data has not
been successfully received so that the sender can retry or handle however
is appropriate.
- cancelDropFlowFileRequest(String) - Method in interface org.apache.nifi.controller.queue.FlowFileQueue
-
Cancels the request to drop FlowFiles that has the given identifier.
- cancelDropFlowFileRequest(String) - Method in class org.apache.nifi.controller.StandardFlowFileQueue
-
- cancelListFlowFileRequest(String) - Method in interface org.apache.nifi.controller.queue.FlowFileQueue
-
Cancels the request to list FlowFiles that has the given identifier.
- cancelListFlowFileRequest(String) - Method in class org.apache.nifi.controller.StandardFlowFileQueue
-
- cancelOrComplete() - Method in class org.apache.nifi.processor.util.put.AbstractPutEventProcessor.FlowFileMessageBatch
-
- cancelTransaction(String) - Method in class org.apache.nifi.remote.HttpRemoteSiteListener
-
- canCreateDerivedCredential(Map<PropertyDescriptor, String>) - Method in interface org.apache.nifi.processors.aws.credentials.provider.factory.CredentialsStrategy
-
Determines if this strategy can create derived credentials using the given properties.
- canCreateDerivedCredential(Map<PropertyDescriptor, String>) - Method in class org.apache.nifi.processors.aws.credentials.provider.factory.strategies.AbstractCredentialsStrategy
-
- canCreateDerivedCredential(Map<PropertyDescriptor, String>) - Method in class org.apache.nifi.processors.aws.credentials.provider.factory.strategies.AssumeRoleCredentialsStrategy
-
- canCreatePrimaryCredential(Map<PropertyDescriptor, String>) - Method in interface org.apache.nifi.processors.aws.credentials.provider.factory.CredentialsStrategy
-
Determines if this strategy can create primary credentials using the given properties.
- canCreatePrimaryCredential(Map<PropertyDescriptor, String>) - Method in class org.apache.nifi.processors.aws.credentials.provider.factory.strategies.AbstractBooleanCredentialsStrategy
-
- canCreatePrimaryCredential(Map<PropertyDescriptor, String>) - Method in class org.apache.nifi.processors.aws.credentials.provider.factory.strategies.AbstractCredentialsStrategy
-
- canCreatePrimaryCredential(Map<PropertyDescriptor, String>) - Method in class org.apache.nifi.processors.aws.credentials.provider.factory.strategies.AssumeRoleCredentialsStrategy
-
- canCreatePrimaryCredential(Map<PropertyDescriptor, String>) - Method in interface org.apache.nifi.processors.gcp.credentials.factory.CredentialsStrategy
-
Determines if this strategy can create primary credentials using the given properties.
- canCreatePrimaryCredential(Map<PropertyDescriptor, String>) - Method in class org.apache.nifi.processors.gcp.credentials.factory.strategies.AbstractBooleanCredentialsStrategy
-
- canCreatePrimaryCredential(Map<PropertyDescriptor, String>) - Method in class org.apache.nifi.processors.gcp.credentials.factory.strategies.AbstractCredentialsStrategy
-
- canHandle(ProtocolMessage) - Method in class org.apache.nifi.cluster.coordination.heartbeat.ClusterProtocolHeartbeatMonitor
-
- canHandle(URI, String) - Method in interface org.apache.nifi.cluster.coordination.http.EndpointResponseMerger
-
Indicates whether or not this EndpointResponseMapper can handle mapping responses
for the given URI and HTTP Method
- canHandle(URI, String) - Method in class org.apache.nifi.cluster.coordination.http.endpoints.AccessPolicyEndpointMerger
-
- canHandle(URI, String) - Method in class org.apache.nifi.cluster.coordination.http.endpoints.BulletinBoardEndpointMerger
-
- canHandle(URI, String) - Method in class org.apache.nifi.cluster.coordination.http.endpoints.ComponentStateEndpointMerger
-
- canHandle(URI, String) - Method in class org.apache.nifi.cluster.coordination.http.endpoints.ConnectionEndpointMerger
-
- canHandle(URI, String) - Method in class org.apache.nifi.cluster.coordination.http.endpoints.ConnectionsEndpointMerger
-
- canHandle(URI, String) - Method in class org.apache.nifi.cluster.coordination.http.endpoints.ConnectionStatusEndpointMerger
-
- canHandle(URI, String) - Method in class org.apache.nifi.cluster.coordination.http.endpoints.ControllerBulletinsEndpointMerger
-
- canHandle(URI, String) - Method in class org.apache.nifi.cluster.coordination.http.endpoints.ControllerConfigurationEndpointMerger
-
- canHandle(URI, String) - Method in class org.apache.nifi.cluster.coordination.http.endpoints.ControllerEndpointMerger
-
- canHandle(URI, String) - Method in class org.apache.nifi.cluster.coordination.http.endpoints.ControllerServiceEndpointMerger
-
- canHandle(URI, String) - Method in class org.apache.nifi.cluster.coordination.http.endpoints.ControllerServiceReferenceEndpointMerger
-
- canHandle(URI, String) - Method in class org.apache.nifi.cluster.coordination.http.endpoints.ControllerServicesEndpointMerger
-
- canHandle(URI, String) - Method in class org.apache.nifi.cluster.coordination.http.endpoints.ControllerServiceTypesEndpointMerger
-
- canHandle(URI, String) - Method in class org.apache.nifi.cluster.coordination.http.endpoints.ControllerStatusEndpointMerger
-
- canHandle(URI, String) - Method in class org.apache.nifi.cluster.coordination.http.endpoints.CountersEndpointMerger
-
- canHandle(URI, String) - Method in class org.apache.nifi.cluster.coordination.http.endpoints.CurrentUserEndpointMerger
-
- canHandle(URI, String) - Method in class org.apache.nifi.cluster.coordination.http.endpoints.DropRequestEndpointMerger
-
- canHandle(URI, String) - Method in class org.apache.nifi.cluster.coordination.http.endpoints.FlowConfigurationEndpointMerger
-
- canHandle(URI, String) - Method in class org.apache.nifi.cluster.coordination.http.endpoints.FlowMerger
-
- canHandle(URI, String) - Method in class org.apache.nifi.cluster.coordination.http.endpoints.FlowSnippetEndpointMerger
-
- canHandle(URI, String) - Method in class org.apache.nifi.cluster.coordination.http.endpoints.FunnelEndpointMerger
-
- canHandle(URI, String) - Method in class org.apache.nifi.cluster.coordination.http.endpoints.FunnelsEndpointMerger
-
- canHandle(URI, String) - Method in class org.apache.nifi.cluster.coordination.http.endpoints.GroupStatusEndpointMerger
-
- canHandle(URI, String) - Method in class org.apache.nifi.cluster.coordination.http.endpoints.InputPortsEndpointMerger
-
- canHandle(URI, String) - Method in class org.apache.nifi.cluster.coordination.http.endpoints.LabelEndpointMerger
-
- canHandle(URI, String) - Method in class org.apache.nifi.cluster.coordination.http.endpoints.LabelsEndpointMerger
-
- canHandle(URI, String) - Method in class org.apache.nifi.cluster.coordination.http.endpoints.ListFlowFilesEndpointMerger
-
- canHandle(URI, String) - Method in class org.apache.nifi.cluster.coordination.http.endpoints.OutputPortsEndpointMerger
-
- canHandle(URI, String) - Method in class org.apache.nifi.cluster.coordination.http.endpoints.PortEndpointMerger
-
- canHandle(URI, String) - Method in class org.apache.nifi.cluster.coordination.http.endpoints.PortStatusEndpointMerger
-
- canHandle(URI, String) - Method in class org.apache.nifi.cluster.coordination.http.endpoints.PrioritizerTypesEndpointMerger
-
- canHandle(URI, String) - Method in class org.apache.nifi.cluster.coordination.http.endpoints.ProcessGroupEndpointMerger
-
- canHandle(URI, String) - Method in class org.apache.nifi.cluster.coordination.http.endpoints.ProcessGroupsEndpointMerger
-
- canHandle(URI, String) - Method in class org.apache.nifi.cluster.coordination.http.endpoints.ProcessorEndpointMerger
-
- canHandle(URI, String) - Method in class org.apache.nifi.cluster.coordination.http.endpoints.ProcessorsEndpointMerger
-
- canHandle(URI, String) - Method in class org.apache.nifi.cluster.coordination.http.endpoints.ProcessorStatusEndpointMerger
-
- canHandle(URI, String) - Method in class org.apache.nifi.cluster.coordination.http.endpoints.ProcessorTypesEndpointMerger
-
- canHandle(URI, String) - Method in class org.apache.nifi.cluster.coordination.http.endpoints.ProvenanceEventEndpointMerger
-
- canHandle(URI, String) - Method in class org.apache.nifi.cluster.coordination.http.endpoints.ProvenanceQueryEndpointMerger
-
- canHandle(URI, String) - Method in class org.apache.nifi.cluster.coordination.http.endpoints.RemoteProcessGroupEndpointMerger
-
- canHandle(URI, String) - Method in class org.apache.nifi.cluster.coordination.http.endpoints.RemoteProcessGroupsEndpointMerger
-
- canHandle(URI, String) - Method in class org.apache.nifi.cluster.coordination.http.endpoints.RemoteProcessGroupStatusEndpointMerger
-
- canHandle(URI, String) - Method in class org.apache.nifi.cluster.coordination.http.endpoints.ReportingTaskEndpointMerger
-
- canHandle(URI, String) - Method in class org.apache.nifi.cluster.coordination.http.endpoints.ReportingTasksEndpointMerger
-
- canHandle(URI, String) - Method in class org.apache.nifi.cluster.coordination.http.endpoints.ReportingTaskTypesEndpointMerger
-
- canHandle(URI, String) - Method in class org.apache.nifi.cluster.coordination.http.endpoints.SearchUsersEndpointMerger
-
- canHandle(URI, String) - Method in class org.apache.nifi.cluster.coordination.http.endpoints.StatusHistoryEndpointMerger
-
- canHandle(URI, String) - Method in class org.apache.nifi.cluster.coordination.http.endpoints.SystemDiagnosticsEndpointMerger
-
- canHandle(URI, String) - Method in class org.apache.nifi.cluster.coordination.http.endpoints.TemplatesEndpointMerger
-
- canHandle(URI, String) - Method in class org.apache.nifi.cluster.coordination.http.endpoints.UserEndpointMerger
-
- canHandle(URI, String) - Method in class org.apache.nifi.cluster.coordination.http.endpoints.UserGroupEndpointMerger
-
- canHandle(URI, String) - Method in class org.apache.nifi.cluster.coordination.http.endpoints.UserGroupsEndpointMerger
-
- canHandle(URI, String) - Method in class org.apache.nifi.cluster.coordination.http.endpoints.UsersEndpointMerger
-
- canHandle(URI, String) - Method in class org.apache.nifi.cluster.coordination.http.endpoints.VariableRegistryEndpointMerger
-
- canHandle(ProtocolMessage) - Method in class org.apache.nifi.cluster.coordination.node.NodeClusterCoordinator
-
- canHandle(ProtocolMessage) - Method in class org.apache.nifi.cluster.protocol.impl.testutils.DelayedProtocolHandler
-
- canHandle(ProtocolMessage) - Method in class org.apache.nifi.cluster.protocol.impl.testutils.ReflexiveProtocolHandler
-
- canHandle(ProtocolMessage) - Method in interface org.apache.nifi.cluster.protocol.ProtocolHandler
-
- canHandle(ProtocolMessage) - Method in class org.apache.nifi.controller.StandardFlowService
-
- CANNED_ACL - Static variable in class org.apache.nifi.processors.aws.s3.AbstractS3Processor
-
- CANON_EQ - Static variable in class org.apache.nifi.processors.standard.ExtractText
-
- canRollback() - Method in class org.apache.nifi.processor.util.pattern.RollbackOnFailure
-
- CapabilityDescription - Annotation Type in org.apache.nifi.annotation.documentation
-
- capture(ProcessGroupStatus) - Method in interface org.apache.nifi.controller.status.history.ComponentStatusRepository
-
Captures the status information provided in the given report
- capture(ProcessGroupStatus, Date) - Method in interface org.apache.nifi.controller.status.history.ComponentStatusRepository
-
Captures the status information provided in the given report, providing a
timestamp that indicates the time at which the status report was
generated.
- capture(ProcessGroupStatus) - Method in class org.apache.nifi.controller.status.history.VolatileComponentStatusRepository
-
- capture(ProcessGroupStatus, Date) - Method in class org.apache.nifi.controller.status.history.VolatileComponentStatusRepository
-
- CaptureChangeMySQL - Class in org.apache.nifi.cdc.mysql.processors
-
A processor to retrieve Change Data Capture (CDC) events and send them as flow files.
- CaptureChangeMySQL() - Constructor for class org.apache.nifi.cdc.mysql.processors.CaptureChangeMySQL
-
- CAPTURED_HEADERS - Static variable in class org.apache.nifi.processors.email.ExtractEmailHeaders
-
- CaptureServlet - Class in org.apache.nifi.processors.slack
-
- CaptureServlet() - Constructor for class org.apache.nifi.processors.slack.CaptureServlet
-
- CaptureServlet - Class in org.apache.nifi.processors.standard
-
- CaptureServlet() - Constructor for class org.apache.nifi.processors.standard.CaptureServlet
-
- captureSession(WebSocketSession) - Method in class org.apache.nifi.websocket.WebSocketMessageRouter
-
- captureValues(ConfigurationContext) - Method in class org.apache.nifi.serialization.DateTimeTextRecordSetWriter
-
- CapturingLogger - Class in org.apache.nifi.util
-
Implementation of SLF4J logger that records every log message and provides a mechanism
to retrieve them.
- CapturingLogger(Logger) - Constructor for class org.apache.nifi.util.CapturingLogger
-
- CARDINALITY - Static variable in class org.apache.nifi.processors.standard.JoltTransformJSON
-
- CASE_INSENSITIVE - Static variable in class org.apache.nifi.processors.standard.ExtractText
-
- CassandraQueryTestUtil - Class in org.apache.nifi.processors.cassandra
-
Utility methods for Cassandra processors' unit tests
- CassandraQueryTestUtil() - Constructor for class org.apache.nifi.processors.cassandra.CassandraQueryTestUtil
-
- cassandraSession - Variable in class org.apache.nifi.processors.cassandra.AbstractCassandraProcessor
-
- castVote(DataFlow, NodeIdentifier) - Method in interface org.apache.nifi.cluster.coordination.flow.FlowElection
-
If the election has not yet completed, adds the given DataFlow to the list of candidates
(if it is not already in the running) and increments the number of votes for this DataFlow by 1.
- castVote(DataFlow, NodeIdentifier) - Method in class org.apache.nifi.cluster.coordination.flow.PopularVoteFlowElection
-
- CATALOG - Static variable in class org.apache.nifi.processors.standard.ListDatabaseTables
-
- CatchAllFilter - Class in org.apache.nifi.web.filter
-
Filter for forward all requests to index.jsp.
- CatchAllFilter() - Constructor for class org.apache.nifi.web.filter.CatchAllFilter
-
- CC - Static variable in class org.apache.nifi.bootstrap.notification.email.EmailNotificationService
-
- CC - Static variable in class org.apache.nifi.processors.standard.PutEmail
-
- CD_ATTACHMENT - Static variable in class org.apache.nifi.processors.gcp.storage.PutGCSObject
-
- CD_INLINE - Static variable in class org.apache.nifi.processors.gcp.storage.PutGCSObject
-
- CDataSectionNode - Class in org.apache.nifi.processors.evtx.parser.bxml
-
CData section
- CDataSectionNode(BinaryReader, ChunkHeader, BxmlNode) - Constructor for class org.apache.nifi.processors.evtx.parser.bxml.CDataSectionNode
-
- CDataSectionNodeTest - Class in org.apache.nifi.processors.evtx.parser.bxml
-
- CDataSectionNodeTest() - Constructor for class org.apache.nifi.processors.evtx.parser.bxml.CDataSectionNodeTest
-
- CDAValidationHandler() - Constructor for class org.apache.nifi.processors.ccda.ExtractCCDAAttributes.CDAValidationHandler
-
- CDC_EVENT_TYPE_ATTRIBUTE - Static variable in interface org.apache.nifi.cdc.event.io.EventWriter
-
- CDCException - Exception in org.apache.nifi.cdc
-
An exception class representing errors that occur during Change Data Capture (CDC) processing
- CDCException() - Constructor for exception org.apache.nifi.cdc.CDCException
-
- CDCException(String) - Constructor for exception org.apache.nifi.cdc.CDCException
-
- CDCException(String, Throwable) - Constructor for exception org.apache.nifi.cdc.CDCException
-
- CDCException(Throwable) - Constructor for exception org.apache.nifi.cdc.CDCException
-
- CDCException(String, Throwable, boolean, boolean) - Constructor for exception org.apache.nifi.cdc.CDCException
-
- CERTIFICATE_AUTHORITY_HOSTNAME_ARG - Static variable in class org.apache.nifi.toolkit.tls.commandLine.BaseCommandLine
-
- CERTIFICATE_DIRECTORY - Static variable in class org.apache.nifi.toolkit.tls.service.client.TlsCertificateAuthorityClientCommandLine
-
- CertificateStatusException - Exception in org.apache.nifi.web.security.x509.ocsp
-
Represents the exceptional case when a users certificate status is not GOOD.
- CertificateStatusException() - Constructor for exception org.apache.nifi.web.security.x509.ocsp.CertificateStatusException
-
- CertificateStatusException(String) - Constructor for exception org.apache.nifi.web.security.x509.ocsp.CertificateStatusException
-
- CertificateStatusException(String, Throwable) - Constructor for exception org.apache.nifi.web.security.x509.ocsp.CertificateStatusException
-
- CertificateStatusException(Throwable) - Constructor for exception org.apache.nifi.web.security.x509.ocsp.CertificateStatusException
-
- CertificateStatusException(String, Throwable, boolean, boolean) - Constructor for exception org.apache.nifi.web.security.x509.ocsp.CertificateStatusException
-
- CertificateUtils - Class in org.apache.nifi.security.util
-
- CertificateUtils.ClientAuth - Enum in org.apache.nifi.security.util
-
- CF_IMPL - Static variable in interface org.apache.nifi.jms.cf.JMSConnectionFactoryProviderDefinition
-
- CF_LIB - Static variable in interface org.apache.nifi.jms.cf.JMSConnectionFactoryProviderDefinition
-
- chain(NiFiUser) - Method in class org.apache.nifi.authorization.user.StandardNiFiUser.Builder
-
Sets the chain.
- CHAINR - Static variable in class org.apache.nifi.processors.standard.JoltTransformJSON
-
- CHANGE_GROUP - Static variable in class org.apache.nifi.processors.standard.PutFile
-
- CHANGE_LAST_MODIFIED_TIME - Static variable in class org.apache.nifi.processors.standard.PutFile
-
- CHANGE_OWNER - Static variable in class org.apache.nifi.processors.standard.PutFile
-
- CHANGE_PERMISSIONS - Static variable in class org.apache.nifi.processors.standard.PutFile
-
- changeOwner(FileSystem, Path, String, String) - Method in class org.apache.nifi.processors.hadoop.AbstractPutHDFSRecord
-
Changes the ownership of the given file.
- changeOwner(ProcessContext, FileSystem, Path, FlowFile) - Method in class org.apache.nifi.processors.hadoop.PutHDFS
-
- changeWorkingDirectory(FTPClient, String, boolean, Processor) - Static method in class org.apache.nifi.processors.standard.util.FTPUtils
-
Handles the logic required to change to the given directory RELATIVE TO THE CURRENT DIRECTORY which can include creating new directories needed.
- changeWorkingDirectory(ChannelSftp, String, boolean, Processor) - Static method in class org.apache.nifi.processors.standard.util.SFTPUtils
-
- channel - Variable in class org.apache.nifi.processor.util.put.sender.SocketChannelSender
-
- CHANNEL - Static variable in class org.apache.nifi.processors.slack.PutSlack
-
- CHANNEL - Static variable in class org.apache.nifi.processors.windows.event.log.ConsumeWindowsEventLog
-
- ChannelDispatcher - Class in org.apache.nifi.io.nio
-
- ChannelDispatcher(Selector, Selector, ScheduledExecutorService, StreamConsumerFactory, BufferPool, long, TimeUnit, boolean) - Constructor for class org.apache.nifi.io.nio.ChannelDispatcher
-
- ChannelDispatcher - Interface in org.apache.nifi.processor.util.listen.dispatcher
-
Dispatches handlers for a given channel.
- ChannelHandler<E extends Event,D extends ChannelDispatcher> - Class in org.apache.nifi.processor.util.listen.handler
-
Base class for all channel handlers.
- ChannelHandler(SelectionKey, D, Charset, EventFactory<E>, BlockingQueue<E>, ComponentLog) - Constructor for class org.apache.nifi.processor.util.listen.handler.ChannelHandler
-
- ChannelHandlerFactory<E extends Event,D extends ChannelDispatcher> - Interface in org.apache.nifi.processor.util.listen.handler
-
Factory that can produce ChannelHandlers for the given type of Event and ChannelDispatcher.
- ChannelListener - Class in org.apache.nifi.io.nio
-
This class provides the entry point to NIO based socket listeners for NiFi
processors and services.
- ChannelListener(int, StreamConsumerFactory, BufferPool, int, TimeUnit, boolean) - Constructor for class org.apache.nifi.io.nio.ChannelListener
-
- ChannelResponder<C extends java.nio.channels.SelectableChannel> - Interface in org.apache.nifi.processor.util.listen.response
-
A responder for a given channel.
- ChannelResponse - Interface in org.apache.nifi.processor.util.listen.response
-
A response to send back over channel.
- ChannelSender - Class in org.apache.nifi.processor.util.put.sender
-
Base class for sending messages over a channel.
- ChannelSender(String, int, int, ComponentLog) - Constructor for class org.apache.nifi.processor.util.put.sender.ChannelSender
-
- CHARACTER_ENCODING - Static variable in class org.apache.nifi.processors.aws.sns.PutSNS
-
- CHARACTER_SET - Static variable in class org.apache.nifi.processors.hl7.ExtractHL7Attributes
-
- CHARACTER_SET - Static variable in class org.apache.nifi.processors.hl7.RouteHL7
-
- CHARACTER_SET - Static variable in class org.apache.nifi.processors.standard.ExtractGrok
-
- CHARACTER_SET - Static variable in class org.apache.nifi.processors.standard.ExtractText
-
- CHARACTER_SET - Static variable in class org.apache.nifi.processors.standard.ReplaceText
-
- CHARACTER_SET - Static variable in class org.apache.nifi.processors.standard.ReplaceTextWithMapping
-
- CHARACTER_SET - Static variable in class org.apache.nifi.processors.standard.RouteOnContent
-
- CHARACTER_SET - Static variable in class org.apache.nifi.processors.standard.RouteText
-
- CHARACTER_SET - Static variable in class org.apache.nifi.processors.yandex.YandexTranslate
-
- CHARACTER_SET_VALIDATOR - Static variable in class org.apache.nifi.processor.util.StandardValidators
-
- characterDevice(BufferedReader, PrintWriter) - Static method in class org.apache.nifi.util.console.TextDevices
-
Returns a text I/O device wrapping the given streams.
- CharacterFilterUtils - Class in org.apache.nifi.util
-
- CharacterFilterUtils() - Constructor for class org.apache.nifi.util.CharacterFilterUtils
-
- CharacterFilterUtilsTest - Class in org.apache.nifi.util
-
- CharacterFilterUtilsTest() - Constructor for class org.apache.nifi.util.CharacterFilterUtilsTest
-
- characters(char[], int, int) - Method in class org.apache.nifi.processors.standard.util.XmlSplitterSaxParser
-
- CharSequenceTranslatorEvaluator - Class in org.apache.nifi.attribute.expression.language.evaluation.functions
-
- CharSequenceTranslatorEvaluator(Evaluator<String>, CharSequenceTranslator) - Constructor for class org.apache.nifi.attribute.expression.language.evaluation.functions.CharSequenceTranslatorEvaluator
-
- CHARSET - Static variable in class org.apache.nifi.processor.util.listen.AbstractListenEventProcessor
-
- charset - Variable in class org.apache.nifi.processor.util.listen.AbstractListenEventProcessor
-
- charset - Variable in class org.apache.nifi.processor.util.listen.handler.ChannelHandler
-
- CHARSET - Static variable in class org.apache.nifi.processor.util.put.AbstractPutEventProcessor
-
- CHARSET - Static variable in class org.apache.nifi.processors.aws.sqs.GetSQS
-
- CHARSET - Static variable in class org.apache.nifi.processors.cassandra.AbstractCassandraProcessor
-
- CHARSET - Static variable in class org.apache.nifi.processors.elasticsearch.AbstractElasticsearchProcessor
-
- CHARSET - Static variable in class org.apache.nifi.processors.hive.AbstractHiveQLProcessor
-
- CHARSET - Static variable in class org.apache.nifi.processors.kite.InferAvroSchema
-
- CHARSET - Static variable in class org.apache.nifi.processors.standard.AbstractSyslogProcessor
-
- CHARSET - Static variable in class org.apache.nifi.processors.standard.GenerateFlowFile
-
- CHARSET - Static variable in class org.apache.nifi.processors.standard.LogAttribute
-
- CHARSET - Static variable in class org.apache.nifi.processors.standard.ParseSyslog
-
- CHARSET_NAME - Static variable in class org.apache.nifi.websocket.WebSocketMessage
-
- check(String, String) - Static method in class org.apache.nifi.security.util.crypto.scrypt.Scrypt
-
Compare the supplied plaintext password to a hashed password.
- CHECK_SUM - Static variable in class org.apache.nifi.web.api.DataTransferResource
-
- checkAndPut(String, byte[], byte[], byte[], byte[], PutColumn) - Method in class org.apache.nifi.hbase.HBase_1_1_2_ClientService
-
- checkAndPut(String, byte[], byte[], byte[], byte[], PutColumn) - Method in interface org.apache.nifi.hbase.HBaseClientService
-
Atomically checks if a row/family/qualifier value matches the expected value.
- checkAndPut(String, byte[], byte[], byte[], byte[], PutColumn) - Method in class org.apache.nifi.hbase.MockHBaseClientService
-
- checkAndReset() - Method in class org.apache.nifi.util.file.monitor.SynchronousFileWatcher
-
Checks if the file has been updated according to the configured
UpdateMonitor
and resets the state
- checkAndThrowInterruptedException() - Static method in class org.apache.nifi.util.hive.HiveWriter
-
If the current thread has been interrupted, then throws an
exception.
- checkAuthorization(Authorizer, RequestAction, NiFiUser, Map<String, String>) - Method in class org.apache.nifi.authorization.resource.AccessPolicyAuthorizable
-
- checkAuthorization(Authorizer, RequestAction, NiFiUser, Map<String, String>) - Method in interface org.apache.nifi.authorization.resource.Authorizable
-
Returns the result of an authorization request for the specified user for the specified action on the specified
resource.
- checkAuthorization(Authorizer, RequestAction, NiFiUser) - Method in interface org.apache.nifi.authorization.resource.Authorizable
-
Returns the result of an authorization request for the specified user for the specified action on the specified
resource.
- checkAuthorization(Authorizer, RequestAction, NiFiUser, Map<String, String>) - Method in class org.apache.nifi.authorization.resource.DataAuthorizable
-
- checkAuthorization(NiFiUser) - Method in interface org.apache.nifi.authorization.RootGroupPortAuthorizable
-
Checks the authorization for the specified user.
- checkAuthorization(Authorizer, RequestAction, NiFiUser, Map<String, String>) - Method in class org.apache.nifi.connectable.StandardConnection
-
- checkAuthorization(Authorizer, RequestAction, NiFiUser, Map<String, String>) - Method in interface org.apache.nifi.controller.ConfiguredComponent
-
- checkFlowInheritability(DataFlow, DataFlow, FlowController) - Method in class org.apache.nifi.controller.StandardFlowSynchronizer
-
Returns true if the given controller can inherit the proposed flow
without orphaning flow files.
- checkHdfsUriForTimeout(Configuration) - Method in class org.apache.nifi.processors.hadoop.AbstractHadoopProcessor
-
- checkInheritability(String) - Method in class org.apache.nifi.authorization.AbstractPolicyBasedAuthorizer
-
Returns whether the proposed fingerprint is inheritable.
- checkInheritability(String) - Method in class org.apache.nifi.authorization.CompositeConfigurableUserGroupProvider
-
- checkInheritability(String) - Method in interface org.apache.nifi.authorization.ConfigurableAccessPolicyProvider
-
When the fingerprints are not equal, this method will check if the proposed fingerprint is inheritable.
- checkInheritability(String) - Method in interface org.apache.nifi.authorization.ConfigurableUserGroupProvider
-
When the fingerprints are not equal, this method will check if the proposed fingerprint is inheritable.
- checkInheritability(String) - Method in class org.apache.nifi.authorization.FileAccessPolicyProvider
-
- checkInheritability(String) - Method in class org.apache.nifi.authorization.FileUserGroupProvider
-
- checkInheritability(String) - Method in interface org.apache.nifi.authorization.ManagedAuthorizer
-
When the fingerprints are not equal, this method will check if the proposed fingerprint is inheritable.
- checkInheritability(String) - Method in class org.apache.nifi.authorization.SimpleConfigurableUserGroupProvider
-
- checkInheritability(String) - Method in class org.apache.nifi.authorization.StandardManagedAuthorizer
-
- checkInheritability(String) - Method in class org.apache.nifi.ranger.authorization.ManagedRangerAuthorizer
-
- checkMemory(double) - Method in class org.apache.hadoop.hive.ql.io.orc.OrcFlowFileWriter
-
- checkMissingComponentsInheritability(DataFlow, DataFlow) - Method in class org.apache.nifi.controller.StandardFlowSynchronizer
-
- checkpoint() - Method in class org.apache.nifi.controller.repository.StandardProcessSession
-
- checkpoint() - Method in class org.apache.nifi.controller.repository.WriteAheadFlowFileRepository
-
- checkpoint() - Method in class org.wali.MinimalLockingWriteAheadLog
-
- checkpoint() - Method in interface org.wali.WriteAheadRepository
-
Compacts the contents of the Repository so that rather than having a
Snapshot and an Edit Log indicating many Updates to the Snapshot, the
Snapshot is updated to contain the current state of the Repository, and
the edit log is purged.
- checkPortStatus(Peer, String) - Method in class org.apache.nifi.remote.protocol.AbstractFlowFileServerProtocol
-
- checkpw(String, String) - Static method in class org.apache.nifi.security.util.crypto.bcrypt.BCrypt
-
Check that a plaintext password matches a previously hashed
one
- checksum - Variable in class org.apache.nifi.remote.io.http.HttpCommunicationsSession
-
- checkUserAuthorization(String) - Method in interface org.apache.nifi.remote.RootGroupPort
-
- checkUserAuthorization(NiFiUser) - Method in interface org.apache.nifi.remote.RootGroupPort
-
Verifies that the specified user is authorized to interact with this port
and returns a
PortAuthorizationResult
indicating why the user is
unauthorized if this assumption fails
- checkUserAuthorization(String) - Method in class org.apache.nifi.remote.StandardRootGroupPort
-
- checkUserAuthorization(NiFiUser) - Method in class org.apache.nifi.remote.StandardRootGroupPort
-
- CHILD_UUIDS - Static variable in class org.apache.nifi.provenance.schema.EventFieldNames
-
- CHILD_UUIDS - Static variable in class org.apache.nifi.provenance.schema.EventRecordFields
-
- CHILD_UUIDS - Static variable in class org.apache.nifi.provenance.schema.LookupTableEventRecordFields
-
- ChildFieldPath - Class in org.apache.nifi.record.path.paths
-
- children - Variable in class org.apache.nifi.processors.evtx.parser.bxml.BxmlNode
-
- ChoiceDataType - Class in org.apache.nifi.serialization.record.type
-
- ChoiceDataType(List<DataType>) - Constructor for class org.apache.nifi.serialization.record.type.ChoiceDataType
-
- chooseDataType(Object, ChoiceDataType) - Static method in class org.apache.nifi.serialization.record.util.DataTypeUtils
-
- CHUNK - Static variable in class org.apache.nifi.processors.evtx.ParseEvtx
-
- CHUNK_SIZE - Static variable in class org.apache.nifi.processors.evtx.parser.FileHeader
-
- CHUNKED_ENCODING - Static variable in class org.apache.nifi.processors.standard.PostHTTP
-
- chunkGranularityLifecycleTest() - Method in class org.apache.nifi.processors.evtx.ParseEvtxTest
-
- chunkHeader - Variable in class org.apache.nifi.processors.evtx.parser.bxml.BxmlNodeTestBase
-
- ChunkHeader - Class in org.apache.nifi.processors.evtx.parser
-
A Chunk is a self-contained group of templates, strings, and nodes
- ChunkHeader(BinaryReader, ComponentLog, long, int) - Constructor for class org.apache.nifi.processors.evtx.parser.ChunkHeader
-
- ChunkHeaderTest - Class in org.apache.nifi.processors.evtx.parser
-
- ChunkHeaderTest() - Constructor for class org.apache.nifi.processors.evtx.parser.ChunkHeaderTest
-
- cipherByteLength - Variable in class org.apache.nifi.provenance.EncryptionMetadata
-
- CipherProvider - Interface in org.apache.nifi.security.util.crypto
-
Marker interface for cipher providers.
- CipherProviderFactory - Class in org.apache.nifi.security.util.crypto
-
- CipherProviderFactory() - Constructor for class org.apache.nifi.security.util.crypto.CipherProviderFactory
-
- CipherUtility - Class in org.apache.nifi.security.util.crypto
-
- CipherUtility() - Constructor for class org.apache.nifi.security.util.crypto.CipherUtility
-
- city(InetAddress) - Method in class org.apache.nifi.lookup.maxmind.DatabaseReader
-
- city(InetAddress) - Method in class org.apache.nifi.processors.maxmind.DatabaseReader
-
- CitySchema - Class in org.apache.nifi.lookup.maxmind
-
- CitySchema() - Constructor for class org.apache.nifi.lookup.maxmind.CitySchema
-
- CLAIM_CONTAINER - Static variable in class org.apache.nifi.controller.repository.schema.ContentClaimSchema
-
- CLAIM_IDENTIFIER - Static variable in class org.apache.nifi.controller.repository.schema.ContentClaimSchema
-
- CLAIM_SECTION - Static variable in class org.apache.nifi.controller.repository.schema.ContentClaimSchema
-
- ClassLoaderUtils - Class in org.apache.nifi.util.file.classloader
-
- ClassLoaderUtils() - Constructor for class org.apache.nifi.util.file.classloader.ClassLoaderUtils
-
- CLASSPATH_RESOURCE - Static variable in class org.apache.nifi.test.processors.ModifiesClasspathNoAnnotationProcessor
-
- cleanConnectString(String) - Static method in class org.apache.nifi.controller.cluster.ZooKeeperClientConfig
-
Takes a given connect string and splits it by ',' character.
- cleanup() - Method in class org.apache.nifi.authorization.FileAccessPolicyProviderTest
-
- cleanup() - Method in class org.apache.nifi.authorization.FileAuthorizerTest
-
- cleanup() - Method in class org.apache.nifi.authorization.FileUserGroupProviderTest
-
- cleanup() - Method in class org.apache.nifi.controller.reporting.TestStandardReportingContext
-
- cleanup() - Method in interface org.apache.nifi.controller.repository.ContentRepository
-
Performs any cleanup actions that may need to be taken upon system
restart.
- cleanup() - Method in class org.apache.nifi.controller.repository.FileSystemRepository
-
- cleanup() - Method in class org.apache.nifi.controller.repository.TestStandardProcessSession
-
- cleanup() - Method in class org.apache.nifi.controller.repository.VolatileContentRepository
-
- cleanup() - Method in class org.apache.nifi.controller.state.providers.local.TestWriteAheadLocalStateProvider
-
- cleanup() - Method in class org.apache.nifi.controller.TestFlowController
-
- cleanup() - Method in class org.apache.nifi.hbase.TestGetHBase
-
- cleanup() - Method in class org.apache.nifi.http.StandardHttpContextMap
-
- cleanup() - Method in class org.apache.nifi.integration.accesscontrol.AccessControlHelper
-
- cleanup() - Static method in class org.apache.nifi.integration.accesscontrol.ITAccessTokenEndpoint
-
- cleanup() - Static method in class org.apache.nifi.integration.accesscontrol.ITConnectionAccessControl
-
- cleanup() - Static method in class org.apache.nifi.integration.accesscontrol.ITCountersAccessControl
-
- cleanup() - Static method in class org.apache.nifi.integration.accesscontrol.ITFlowAccessControl
-
- cleanup() - Static method in class org.apache.nifi.integration.accesscontrol.ITFunnelAccessControl
-
- cleanup() - Static method in class org.apache.nifi.integration.accesscontrol.ITInputPortAccessControl
-
- cleanup() - Static method in class org.apache.nifi.integration.accesscontrol.ITLabelAccessControl
-
- cleanup() - Static method in class org.apache.nifi.integration.accesscontrol.ITOutputPortAccessControl
-
- cleanup() - Static method in class org.apache.nifi.integration.accesscontrol.ITProcessGroupAccessControl
-
- cleanup() - Static method in class org.apache.nifi.integration.accesscontrol.ITProcessorAccessControl
-
- cleanup - Variable in class org.apache.nifi.processor.util.pattern.Put
-
- cleanup(PartialFunctions.Cleanup<FC, C>) - Method in class org.apache.nifi.processor.util.pattern.Put
-
Specify an optional function which will be called in a finally block.
- cleanUp() - Method in class org.apache.nifi.processors.email.TestConsumeEmail
-
- cleanUp() - Method in class org.apache.nifi.processors.hadoop.AbstractHadoopTest
-
- cleanup() - Method in class org.apache.nifi.processors.hive.PutHiveStreaming
-
- cleanup() - Method in class org.apache.nifi.processors.hive.TestPutHiveStreaming
-
- cleanup() - Method in class org.apache.nifi.processors.splunk.PutSplunk
-
- cleanup() - Method in class org.apache.nifi.processors.standard.FetchFileTransfer
-
- cleanup() - Method in class org.apache.nifi.processors.standard.QueryRecord
-
- cleanup() - Method in class org.apache.nifi.processors.standard.TailFile
-
- cleanup() - Method in class org.apache.nifi.processors.standard.TestPostHTTP
-
- cleanup() - Method in class org.apache.nifi.processors.standard.TestPutUDP
-
- cleanup() - Method in class org.apache.nifi.processors.standard.TestTailFile
-
- cleanup() - Method in class org.apache.nifi.processors.standard.util.TestPutTCPCommon
-
- cleanup() - Method in class org.apache.nifi.provenance.lucene.TestCachingIndexManager
-
- cleanup() - Method in class org.apache.nifi.storm.NiFiBolt
-
- cleanup() - Method in class org.apache.nifi.toolkit.repos.flowfile.TestRepairCorruptedFileEndings
-
- cleanUpAfterClass() - Static method in class org.apache.nifi.processors.standard.QueryDatabaseTableTest
-
- cleanUpAfterClass() - Static method in class org.apache.nifi.processors.standard.TestGenerateTableFetch
-
- cleanUpAfterClass() - Static method in class org.apache.nifi.processors.standard.TestListDatabaseTables
-
- cleanUpClient() - Method in class org.apache.nifi.processors.riemann.PutRiemann
-
- cleanUpResources() - Method in interface org.apache.nifi.authorization.ComponentAuthorizable
-
Cleans up any resources resulting from the creation of these temporary components.
- cleanupResources() - Method in class org.apache.nifi.processors.standard.GetJMSQueue
-
Deprecated.
- cleanupResources() - Method in class org.apache.nifi.processors.standard.GetJMSTopic
-
Deprecated.
- cleanupResources() - Method in class org.apache.nifi.processors.standard.PutJMS
-
Deprecated.
- clear() - Method in class org.apache.nifi.attribute.expression.language.AttributesAndState
-
- clear() - Method in class org.apache.nifi.cluster.coordination.heartbeat.TestAbstractHeartbeatMonitor
-
- clear(String) - Method in class org.apache.nifi.cluster.integration.NopStateProvider
-
- clear(Scope) - Method in interface org.apache.nifi.components.state.StateManager
-
Clears all keys and values from the component's state
- clear(String) - Method in interface org.apache.nifi.components.state.StateProvider
-
Removes all values from the component's state that is stored using the given scope
- clear() - Method in class org.apache.nifi.controller.SnippetManager
-
- clear(String) - Method in class org.apache.nifi.controller.state.providers.local.WriteAheadLocalStateProvider
-
- clear() - Method in class org.apache.nifi.controller.state.providers.zookeeper.TestZooKeeperStateProvider
-
- clear(String) - Method in class org.apache.nifi.controller.state.providers.zookeeper.ZooKeeperStateProvider
-
- clear(Scope) - Method in class org.apache.nifi.controller.state.StandardStateManager
-
- clear(String) - Method in class org.apache.nifi.redis.state.RedisStateProvider
-
- clear() - Method in class org.apache.nifi.remote.client.PeerSelector
-
- clear() - Method in class org.apache.nifi.remote.io.socket.BufferStateManager
-
Clears the contents of the buffer and sets direction to WRITE
- clear(Scope) - Method in class org.apache.nifi.state.MockStateManager
-
- clear() - Method in class org.apache.nifi.util.NaiveSearchRingBuffer
-
Clears the internal buffer so that a new search may begin
- clearAssertionStatus() - Method in class org.apache.nifi.nar.NarThreadContextClassLoader
-
- clearBinaryReader() - Method in class org.apache.nifi.processors.evtx.parser.Block
-
- clearCommitted() - Method in class org.apache.nifi.util.MockProcessSession
-
- clearControllerServiceState(String) - Method in interface org.apache.nifi.web.NiFiServiceFacade
-
Clears the state for the specified controller service.
- clearControllerServiceState(String) - Method in class org.apache.nifi.web.StandardNiFiServiceFacade
-
- clearControllerServiceStateAdvice(ProceedingJoinPoint, ControllerServiceNode) - Method in class org.apache.nifi.audit.ComponentStateAuditor
-
Audits clearing of state from a Controller Service.
- clearEventStream() - Method in class org.apache.nifi.processors.riemann.TestPutRiemann
-
- clearGroups() - Method in class org.apache.nifi.authorization.AccessPolicy.Builder
-
Clears the builder's set of groups so that it is non-null and size == 0.
- clearHandlers() - Method in class org.apache.nifi.processors.slack.TestServer
-
- clearHandlers() - Method in class org.apache.nifi.processors.standard.TestServer
-
- clearInit() - Method in class org.apache.nifi.processors.standard.HandleHttpRequest
-
- clearLock(ProceedingJoinPoint) - Method in class org.apache.nifi.web.NiFiServiceFacadeLock
-
- clearProcessorState(String) - Method in interface org.apache.nifi.web.NiFiServiceFacade
-
Clears the state for the specified processor.
- clearProcessorState(String) - Method in class org.apache.nifi.web.StandardNiFiServiceFacade
-
- clearProcessorStateAdvice(ProceedingJoinPoint, ProcessorNode) - Method in class org.apache.nifi.audit.ComponentStateAuditor
-
Audits clearing of state from a Processor.
- clearProvenanceEvents() - Method in class org.apache.nifi.util.StandardProcessorTestRunner
-
- clearProvenanceEvents() - Method in interface org.apache.nifi.util.TestRunner
-
Clears the Provenance Events that have been emitted by the Processor
- clearQueue() - Method in class org.apache.nifi.util.StandardProcessorTestRunner
-
- clearRepo() - Method in class org.apache.nifi.controller.repository.TestWriteAheadFlowFileRepository
-
- clearReportingTaskState(String) - Method in interface org.apache.nifi.web.NiFiServiceFacade
-
Clears the state for the specified reporting task.
- clearReportingTaskState(String) - Method in class org.apache.nifi.web.StandardNiFiServiceFacade
-
- clearReportingTaskStateAdvice(ProceedingJoinPoint, ReportingTaskNode) - Method in class org.apache.nifi.audit.ComponentStateAuditor
-
Audits clearing of state from a Processor.
- clearRollback() - Method in class org.apache.nifi.util.MockProcessSession
-
- clearState(HttpServletRequest, String) - Method in class org.apache.nifi.web.api.ControllerServiceResource
-
Clears the state for a controller service.
- clearState(HttpServletRequest, String) - Method in class org.apache.nifi.web.api.ProcessorResource
-
Clears the state for a processor.
- clearState(HttpServletRequest, String) - Method in class org.apache.nifi.web.api.ReportingTaskResource
-
Clears the state for a reporting task.
- clearState(ProcessorNode) - Method in interface org.apache.nifi.web.dao.ComponentStateDAO
-
Clears the state for the specified processor.
- clearState(ControllerServiceNode) - Method in interface org.apache.nifi.web.dao.ComponentStateDAO
-
Clears the state for the specified controller service.
- clearState(ReportingTaskNode) - Method in interface org.apache.nifi.web.dao.ComponentStateDAO
-
Clears the state for the specified reporting task.
- clearState(String) - Method in interface org.apache.nifi.web.dao.ControllerServiceDAO
-
Clears the state of the specified controller service.
- clearState(ProcessorNode) - Method in class org.apache.nifi.web.dao.impl.StandardComponentStateDAO
-
- clearState(ControllerServiceNode) - Method in class org.apache.nifi.web.dao.impl.StandardComponentStateDAO
-
- clearState(ReportingTaskNode) - Method in class org.apache.nifi.web.dao.impl.StandardComponentStateDAO
-
- clearState(String) - Method in class org.apache.nifi.web.dao.impl.StandardControllerServiceDAO
-
- clearState(String) - Method in class org.apache.nifi.web.dao.impl.StandardProcessorDAO
-
- clearState(String) - Method in class org.apache.nifi.web.dao.impl.StandardReportingTaskDAO
-
- clearState(String) - Method in interface org.apache.nifi.web.dao.ProcessorDAO
-
Clears the state of the specified processor.
- clearState(String) - Method in interface org.apache.nifi.web.dao.ReportingTaskDAO
-
Clears the state of the specified reporting task.
- clearTransferState() - Method in class org.apache.nifi.util.MockProcessSession
-
Removes all state information about FlowFiles that have been transferred
- clearTransferState() - Method in class org.apache.nifi.util.StandardProcessorTestRunner
-
- clearTransferState() - Method in interface org.apache.nifi.util.TestRunner
-
Resets the Transfer Counts that indicate how many FlowFiles have been
transferred to each Relationship and removes from memory any FlowFiles
that have been transferred to this Relationships.
- clearUsers() - Method in class org.apache.nifi.authorization.AccessPolicy.Builder
-
Clears the builder's set of users so that it is non-null and size == 0.
- clearUsers() - Method in class org.apache.nifi.authorization.Group.Builder
-
Clears the builder's set of users so that users is non-null with size 0.
- client - Variable in class org.apache.nifi.processors.aws.AbstractAWSProcessor
-
Deprecated.
- client - Static variable in class org.apache.nifi.processors.aws.s3.AbstractS3IT
-
- CLIENT_AUTH - Static variable in class org.apache.nifi.mongodb.AbstractMongoDBControllerService
-
- CLIENT_AUTH - Static variable in class org.apache.nifi.processors.cassandra.AbstractCassandraProcessor
-
- CLIENT_AUTH - Static variable in class org.apache.nifi.processors.mongodb.AbstractMongoProcessor
-
- CLIENT_AUTH - Static variable in class org.apache.nifi.processors.standard.HandleHttpRequest
-
- CLIENT_AUTH - Static variable in class org.apache.nifi.processors.standard.ListenRELP
-
- CLIENT_AUTH - Static variable in class org.apache.nifi.processors.standard.ListenSyslog
-
- CLIENT_AUTH - Static variable in class org.apache.nifi.processors.standard.ListenTCP
-
- CLIENT_AUTH - Static variable in class org.apache.nifi.websocket.jetty.JettyWebSocketServer
-
- CLIENT_CERT_DN_ARG - Static variable in class org.apache.nifi.toolkit.tls.standalone.TlsToolkitStandaloneCommandLine
-
- CLIENT_CERT_PASSWORD_ARG - Static variable in class org.apache.nifi.toolkit.tls.standalone.TlsToolkitStandaloneCommandLine
-
- CLIENT_ID - Static variable in class org.apache.nifi.web.api.ApplicationResource
-
- CLIENT_ID_FIXED_PREFIX - Static variable in class org.apache.nifi.processors.standard.util.JmsFactory
-
- CLIENT_ID_PARAM - Static variable in class org.apache.nifi.web.StandardNiFiContentAccess
-
- CLIENT_ID_PREFIX - Static variable in class org.apache.nifi.processors.standard.util.JmsProperties
-
- CLIENT_LIB_DIR_PATH - Static variable in interface org.apache.nifi.jms.cf.JMSConnectionFactoryProviderDefinition
-
- CLIENT_NAME - Static variable in class org.apache.nifi.processors.kafka.GetKafka
-
- CLIENT_NAME - Static variable in class org.apache.nifi.processors.kafka.PutKafka
-
- CLIENT_NEED - Static variable in class org.apache.nifi.processors.standard.HandleHttpRequest
-
- CLIENT_NEED - Static variable in class org.apache.nifi.websocket.jetty.JettyWebSocketServer
-
- CLIENT_NONE - Static variable in class org.apache.nifi.processors.standard.HandleHttpRequest
-
- CLIENT_NONE - Static variable in class org.apache.nifi.websocket.jetty.JettyWebSocketServer
-
- CLIENT_WANT - Static variable in class org.apache.nifi.processors.standard.HandleHttpRequest
-
- CLIENT_WANT - Static variable in class org.apache.nifi.websocket.jetty.JettyWebSocketServer
-
- clientAddress(String) - Method in class org.apache.nifi.authorization.user.StandardNiFiUser.Builder
-
Sets the client address.
- clientID - Variable in class org.apache.nifi.processors.mqtt.common.AbstractMQTTProcessor
-
- clientId - Variable in class org.apache.nifi.processors.mqtt.common.MqttTestClient
-
- ClientIdParameter - Class in org.apache.nifi.web.api.request
-
Class for parsing handling client ids.
- ClientIdParameter(String) - Constructor for class org.apache.nifi.web.api.request.ClientIdParameter
-
- ClientIdParameter() - Constructor for class org.apache.nifi.web.api.request.ClientIdParameter
-
- clientIdPrefixEquals(String, String) - Static method in class org.apache.nifi.processors.standard.util.JmsFactory
-
- ClientLibValidator() - Constructor for class org.apache.nifi.jms.cf.JMSConnectionFactoryProviderDefinition.ClientLibValidator
-
- ClientProtocol - Interface in org.apache.nifi.remote.protocol
-
- ClientResponseUtils - Class in org.apache.nifi.web.util
-
- ClientResponseUtils() - Constructor for class org.apache.nifi.web.util.ClientResponseUtils
-
- clientService - Variable in class org.apache.nifi.hbase.AbstractPutHBase
-
- clientService - Variable in class org.apache.nifi.websocket.jetty.TestJettyWebSocketCommunication
-
- clientServiceContext - Variable in class org.apache.nifi.websocket.jetty.TestJettyWebSocketCommunication
-
- ClientTransactionCompletion - Class in org.apache.nifi.remote
-
- ClientTransactionCompletion(boolean, int, long, long) - Constructor for class org.apache.nifi.remote.ClientTransactionCompletion
-
- ClientUtils - Class in org.apache.nifi.web.util
-
- ClientUtils(Client) - Constructor for class org.apache.nifi.web.util.ClientUtils
-
- ClojureScriptEngine - Class in org.apache.nifi.processors.script.engine
-
A ScriptEngine implementation for the Clojure language
- ClojureScriptEngine(ScriptEngineFactory) - Constructor for class org.apache.nifi.processors.script.engine.ClojureScriptEngine
-
- ClojureScriptEngineConfigurator - Class in org.apache.nifi.script.impl
-
- ClojureScriptEngineConfigurator() - Constructor for class org.apache.nifi.script.impl.ClojureScriptEngineConfigurator
-
- ClojureScriptEngineFactory - Class in org.apache.nifi.processors.script.engine
-
A ScriptEngineFactory implementation for the Clojure language
- ClojureScriptEngineFactory() - Constructor for class org.apache.nifi.processors.script.engine.ClojureScriptEngineFactory
-
- clone(ContentClaim, boolean) - Method in interface org.apache.nifi.controller.repository.ContentRepository
-
Clones the content for the given content claim and returns content claim
of the new object
- clone(ContentClaim, boolean) - Method in class org.apache.nifi.controller.repository.FileSystemRepository
-
- clone(FlowFile) - Method in class org.apache.nifi.controller.repository.StandardProcessSession
-
- clone(FlowFile, long, long) - Method in class org.apache.nifi.controller.repository.StandardProcessSession
-
- clone(FlowFile, FlowFile) - Method in class org.apache.nifi.controller.repository.StandardProvenanceReporter
-
- clone(ContentClaim, boolean) - Method in class org.apache.nifi.controller.repository.VolatileContentRepository
-
- clone() - Method in class org.apache.nifi.controller.status.ConnectionStatus
-
- clone() - Method in class org.apache.nifi.controller.status.PortStatus
-
- clone() - Method in class org.apache.nifi.controller.status.ProcessGroupStatus
-
- clone() - Method in class org.apache.nifi.controller.status.ProcessorStatus
-
- clone() - Method in class org.apache.nifi.controller.status.RemoteProcessGroupStatus
-
- clone() - Method in class org.apache.nifi.diagnostics.GarbageCollection
-
- clone() - Method in class org.apache.nifi.diagnostics.StorageUsage
-
- clone() - Method in class org.apache.nifi.diagnostics.SystemDiagnostics
-
- clone(FlowFile) - Method in interface org.apache.nifi.processor.ProcessSession
-
Creates a new FlowFile that is a clone of the given FlowFile as of the
time this is called, both in content and attributes.
- clone(FlowFile, long, long) - Method in interface org.apache.nifi.processor.ProcessSession
-
Creates a new FlowFile whose parent is the given FlowFile.
- clone(FlowFile, FlowFile) - Method in interface org.apache.nifi.provenance.ProvenanceReporter
-
Emits a Provenance Event of type
CLONE
that establishes that the given child is an exact replica of the parent.
- clone(FlowFile) - Method in class org.apache.nifi.util.MockProcessSession
-
- clone(FlowFile, long, long) - Method in class org.apache.nifi.util.MockProcessSession
-
- clone(FlowFile, FlowFile) - Method in class org.apache.nifi.util.MockProvenanceReporter
-
- clone() - Method in class org.apache.nifi.web.api.dto.CounterDTO
-
- clone() - Method in class org.apache.nifi.web.api.dto.CountersSnapshotDTO
-
- clone() - Method in class org.apache.nifi.web.api.dto.NodeCountersSnapshotDTO
-
- clone() - Method in class org.apache.nifi.web.api.dto.NodeSystemDiagnosticsSnapshotDTO
-
- clone() - Method in class org.apache.nifi.web.api.dto.status.ConnectionStatusDTO
-
- clone() - Method in class org.apache.nifi.web.api.dto.status.ConnectionStatusSnapshotDTO
-
- clone() - Method in class org.apache.nifi.web.api.dto.status.ControllerStatusDTO
-
- clone() - Method in class org.apache.nifi.web.api.dto.status.NodeConnectionStatusSnapshotDTO
-
- clone() - Method in class org.apache.nifi.web.api.dto.status.NodePortStatusSnapshotDTO
-
- clone() - Method in class org.apache.nifi.web.api.dto.status.NodeProcessGroupStatusSnapshotDTO
-
- clone() - Method in class org.apache.nifi.web.api.dto.status.NodeProcessorStatusSnapshotDTO
-
- clone() - Method in class org.apache.nifi.web.api.dto.status.NodeRemoteProcessGroupStatusSnapshotDTO
-
- clone() - Method in class org.apache.nifi.web.api.dto.status.PortStatusSnapshotDTO
-
- clone() - Method in class org.apache.nifi.web.api.dto.status.ProcessGroupStatusSnapshotDTO
-
- clone() - Method in class org.apache.nifi.web.api.dto.status.ProcessorStatusDTO
-
- clone() - Method in class org.apache.nifi.web.api.dto.status.ProcessorStatusSnapshotDTO
-
- clone() - Method in class org.apache.nifi.web.api.dto.status.RemoteProcessGroupStatusSnapshotDTO
-
- clone() - Method in class org.apache.nifi.web.api.dto.SystemDiagnosticsSnapshotDTO
-
- clone() - Method in class org.apache.nifi.web.api.dto.SystemDiagnosticsSnapshotDTO.GarbageCollectionDTO
-
- clone() - Method in class org.apache.nifi.web.api.dto.SystemDiagnosticsSnapshotDTO.StorageUsageDTO
-
- clone() - Method in class org.apache.nifi.web.api.dto.SystemDiagnosticsSnapshotDTO.VersionInfoDTO
-
- clone() - Method in class org.apache.nifi.web.api.entity.ConnectionStatusSnapshotEntity
-
- clone() - Method in class org.apache.nifi.web.api.entity.ControllerBulletinsEntity
-
- clone() - Method in class org.apache.nifi.web.api.entity.PortStatusSnapshotEntity
-
- clone() - Method in class org.apache.nifi.web.api.entity.ProcessGroupStatusSnapshotEntity
-
- clone() - Method in class org.apache.nifi.web.api.entity.ProcessorStatusSnapshotEntity
-
- clone() - Method in class org.apache.nifi.web.api.entity.RemoteProcessGroupStatusSnapshotEntity
-
- cloneControllerService(ControllerServiceProvider, ControllerServiceNode) - Static method in class org.apache.nifi.controller.service.ControllerServiceLoader
-
- close() - Method in class org.apache.hadoop.hive.ql.io.orc.OrcFlowFileWriter
-
- close() - Method in class org.apache.nifi.admin.service.transaction.impl.StandardTransaction
-
- close() - Method in class org.apache.nifi.amqp.processors.PublishAMQPTest.LocalPublishAMQP
-
- close() - Method in class org.apache.nifi.avro.AvroReaderWithEmbeddedSchema
-
- close() - Method in class org.apache.nifi.avro.AvroReaderWithExplicitSchema
-
- close() - Method in class org.apache.nifi.avro.WriteAvroResultWithSchema
-
- close() - Method in class org.apache.nifi.bootstrap.util.LimitingInputStream
-
- close() - Method in class org.apache.nifi.controller.cluster.ClusterProtocolHeartbeater
-
- close() - Method in class org.apache.nifi.controller.repository.io.DisableOnCloseInputStream
-
- close() - Method in class org.apache.nifi.controller.repository.io.DisableOnCloseOutputStream
-
- close() - Method in class org.apache.nifi.controller.repository.io.FlowFileAccessInputStream
-
- close() - Method in class org.apache.nifi.controller.repository.io.FlowFileAccessOutputStream
-
- close() - Method in class org.apache.nifi.controller.repository.io.LimitedInputStream
-
- close() - Method in class org.apache.nifi.controller.repository.io.SyncOnCloseOutputStream
-
- close() - Method in class org.apache.nifi.controller.repository.metrics.RingBufferEventRepository
-
- close() - Method in class org.apache.nifi.controller.repository.VolatileFlowFileRepository
-
- close() - Method in class org.apache.nifi.controller.repository.WriteAheadFlowFileRepository
-
- close() - Method in class org.apache.nifi.csv.CSVRecordReader
-
- close() - Method in class org.apache.nifi.csv.WriteCSVResult
-
- close() - Method in interface org.apache.nifi.distributed.cache.client.DistributedMapCacheClient
-
Attempts to notify the server that we are finished communicating with it
and cleans up resources
- close() - Method in class org.apache.nifi.distributed.cache.client.DistributedMapCacheClientService
-
- close() - Method in interface org.apache.nifi.distributed.cache.client.DistributedSetCacheClient
-
Attempts to notify the server that we are finished communicating with it
and cleans up resources
- close() - Method in class org.apache.nifi.distributed.cache.client.DistributedSetCacheClientService
-
- close() - Method in class org.apache.nifi.distributed.cache.client.SSLCommsSession
-
- close() - Method in class org.apache.nifi.distributed.cache.client.StandardCommsSession
-
- close() - Method in class org.apache.nifi.grok.GrokRecordReader
-
- close() - Method in class org.apache.nifi.hbase.HBase_1_1_2_ClientMapCacheService
-
- close() - Method in class org.apache.nifi.json.AbstractJsonRowRecordReader
-
- close() - Method in class org.apache.nifi.json.JsonPathRowRecordReader
-
- close() - Method in class org.apache.nifi.json.WriteJsonResult
-
- close() - Method in class org.apache.nifi.lookup.maxmind.DatabaseReader
-
Closes the database.
- close() - Method in class org.apache.nifi.nar.NarCloseable
-
- close() - Method in interface org.apache.nifi.processor.util.listen.dispatcher.ChannelDispatcher
-
Closes all listeners and stops all handler threads.
- close() - Method in class org.apache.nifi.processor.util.listen.dispatcher.DatagramChannelDispatcher
-
- close() - Method in class org.apache.nifi.processor.util.listen.dispatcher.SocketChannelDispatcher
-
- close() - Method in class org.apache.nifi.processor.util.put.sender.ChannelSender
-
Close the underlying channel
- close() - Method in class org.apache.nifi.processor.util.put.sender.DatagramChannelSender
-
- close() - Method in class org.apache.nifi.processor.util.put.sender.SocketChannelSender
-
- close() - Method in class org.apache.nifi.processor.util.put.sender.SSLSocketChannelSender
-
- close() - Method in class org.apache.nifi.processors.evtx.XmlRootNodeHandler
-
- close() - Method in class org.apache.nifi.processors.kafka.pubsub.ConsumeKafka
-
- close() - Method in class org.apache.nifi.processors.kafka.pubsub.ConsumeKafka_0_10
-
- close() - Method in class org.apache.nifi.processors.kafka.pubsub.ConsumeKafka_0_11
-
- close() - Method in class org.apache.nifi.processors.kafka.pubsub.ConsumeKafkaRecord_0_10
-
- close() - Method in class org.apache.nifi.processors.kafka.pubsub.ConsumeKafkaRecord_0_11
-
- close() - Method in class org.apache.nifi.processors.kafka.pubsub.ConsumerLease
-
Abstract method that is intended to be extended by the pool that created
this ConsumerLease object.
- close() - Method in class org.apache.nifi.processors.kafka.pubsub.ConsumerPool
-
Closes all consumers in the pool.
- close() - Method in class org.apache.nifi.processors.kafka.pubsub.Partitioners.RoundRobinPartitioner
-
- close() - Method in class org.apache.nifi.processors.kafka.pubsub.PublisherLease
-
- close() - Method in class org.apache.nifi.processors.kafka.pubsub.PublisherPool
-
- close() - Method in class org.apache.nifi.processors.kafka.test.EmbeddedKafkaProducerHelper
-
Will close the underlying Kafka producer.
- close() - Method in class org.apache.nifi.processors.kudu.TestPutKudu
-
- close() - Method in class org.apache.nifi.processors.maxmind.DatabaseReader
-
Closes the database.
- close() - Method in class org.apache.nifi.processors.mqtt.common.MqttTestClient
-
- close() - Method in class org.apache.nifi.processors.parquet.record.AvroParquetHDFSRecordReader
-
- close() - Method in class org.apache.nifi.processors.parquet.record.AvroParquetHDFSRecordWriter
-
- close() - Method in class org.apache.nifi.processors.rethinkdb.DeleteRethinkDB
-
- close() - Method in class org.apache.nifi.processors.rethinkdb.GetRethinkDB
-
- close() - Method in class org.apache.nifi.processors.rethinkdb.PutRethinkDB
-
Shutdown client connection
- close() - Method in class org.apache.nifi.processors.standard.util.FTPTransfer
-
- close() - Method in class org.apache.nifi.processors.standard.util.SFTPConnection
-
- close() - Method in class org.apache.nifi.processors.standard.util.SFTPTransfer
-
- close(ComponentLog) - Method in class org.apache.nifi.processors.standard.util.WrappedMessageConsumer
-
- close(ComponentLog) - Method in class org.apache.nifi.processors.standard.util.WrappedMessageProducer
-
- close() - Method in class org.apache.nifi.provenance.AbstractRecordWriter
-
- close() - Method in class org.apache.nifi.provenance.index.lucene.LuceneEventIndex
-
- close() - Method in class org.apache.nifi.provenance.LoopingInputStream
-
- close() - Method in class org.apache.nifi.provenance.lucene.CachingIndexManager
-
- close() - Method in class org.apache.nifi.provenance.lucene.LuceneEventIndexSearcher
-
- close() - Method in class org.apache.nifi.provenance.lucene.LuceneEventIndexWriter
-
- close() - Method in class org.apache.nifi.provenance.lucene.SimpleIndexManager
-
- close(SimpleIndexManager.IndexWriterCount) - Method in class org.apache.nifi.provenance.lucene.SimpleIndexManager
-
- close() - Method in class org.apache.nifi.provenance.lucene.SimpleIndexManager.IndexWriterCount
-
- close() - Method in class org.apache.nifi.provenance.MockProvenanceRepository
-
- close() - Method in class org.apache.nifi.provenance.PersistentProvenanceRepository
-
- close() - Method in interface org.apache.nifi.provenance.ProvenanceEventRepository
-
Closes the repository, freeing any resources
- close() - Method in class org.apache.nifi.provenance.serialization.CompressableRecordReader
-
- close() - Method in class org.apache.nifi.provenance.serialization.EmptyRecordReader
-
- close() - Method in class org.apache.nifi.provenance.store.ArrayListEventStore
-
- close() - Method in class org.apache.nifi.provenance.store.iterator.AuthorizingEventIterator
-
- close() - Method in class org.apache.nifi.provenance.store.iterator.SelectiveRecordReaderEventIterator
-
- close() - Method in class org.apache.nifi.provenance.store.iterator.SequentialRecordReaderEventIterator
-
- close() - Method in class org.apache.nifi.provenance.store.PartitionedEventStore
-
- close() - Method in class org.apache.nifi.provenance.store.PartitionedWriteAheadEventStore
-
- close() - Method in class org.apache.nifi.provenance.store.RecordWriterLease
-
- close() - Method in class org.apache.nifi.provenance.store.WriteAheadStorePartition
-
- close() - Method in class org.apache.nifi.provenance.toc.NopTocWriter
-
- close() - Method in class org.apache.nifi.provenance.toc.StandardTocReader
-
- close() - Method in class org.apache.nifi.provenance.toc.StandardTocWriter
-
- close() - Method in class org.apache.nifi.provenance.VolatileProvenanceRepository
-
- close() - Method in class org.apache.nifi.provenance.WriteAheadProvenanceRepository
-
- close() - Method in class org.apache.nifi.queryrecord.FlowFileEnumerator
-
- close() - Method in class org.apache.nifi.record.listen.SocketChannelRecordReaderDispatcher
-
- close() - Method in class org.apache.nifi.record.listen.SSLSocketChannelRecordReader
-
- close() - Method in class org.apache.nifi.record.listen.StandardSocketChannelRecordReader
-
- close() - Method in class org.apache.nifi.redis.service.RedisDistributedMapCacheClientService
-
- close() - Method in class org.apache.nifi.remote.AbstractTransaction
-
- close() - Method in class org.apache.nifi.remote.client.http.HttpClient
-
- close() - Method in class org.apache.nifi.remote.client.socket.SocketClient
-
- close() - Method in class org.apache.nifi.remote.io.CompressionInputStream
-
Calls Inflater.end()
to free acquired memory to prevent OutOfMemory error.
- close() - Method in class org.apache.nifi.remote.io.CompressionOutputStream
-
Flushes remaining buffer and calls Deflater.end()
to free acquired memory to prevent OutOfMemory error.
- close() - Method in class org.apache.nifi.remote.io.http.HttpCommunicationsSession
-
- close() - Method in class org.apache.nifi.remote.io.InterruptableInputStream
-
- close() - Method in class org.apache.nifi.remote.io.InterruptableOutputStream
-
- close() - Method in class org.apache.nifi.remote.io.socket.SocketChannelCommunicationsSession
-
- close() - Method in class org.apache.nifi.remote.io.socket.SocketChannelInputStream
-
Closes the underlying socket channel.
- close() - Method in class org.apache.nifi.remote.io.socket.SocketChannelOutputStream
-
Closes the underlying SocketChannel
- close() - Method in class org.apache.nifi.remote.io.socket.ssl.SSLSocketChannel
-
- close() - Method in class org.apache.nifi.remote.io.socket.ssl.SSLSocketChannelCommunicationsSession
-
- close() - Method in class org.apache.nifi.remote.io.socket.ssl.SSLSocketChannelInputStream
-
Closes the underlying SSLSocketChannel, which will also close the OutputStream and connection
- close() - Method in class org.apache.nifi.remote.io.socket.ssl.SSLSocketChannelOutputStream
-
Closes the underlying SSLSocketChannel, which also will close the InputStream and the connection
- close() - Method in class org.apache.nifi.remote.Peer
-
- close() - Method in class org.apache.nifi.remote.protocol.http.HttpClientTransaction
-
- close() - Method in class org.apache.nifi.remote.util.SiteToSiteRestApiClient
-
- close() - Method in class org.apache.nifi.schemaregistry.hortonworks.HortonworksSchemaRegistry
-
- close() - Method in class org.apache.nifi.schemaregistry.services.AvroSchemaRegistry
-
- close() - Method in class org.apache.nifi.serialization.AbstractRecordSetWriter
-
- close() - Method in class org.apache.nifi.serialization.record.ResultSetRecordSet
-
- close() - Method in class org.apache.nifi.storm.NiFiSpout
-
- close() - Method in class org.apache.nifi.stream.io.ByteCountingInputStream
-
- close() - Method in class org.apache.nifi.stream.io.ByteCountingOutputStream
-
- close() - Method in class org.apache.nifi.stream.io.LeakyBucketStreamThrottler
-
- close() - Method in class org.apache.nifi.stream.io.LimitingInputStream
-
- close() - Method in class org.apache.nifi.stream.io.NonCloseableInputStream
-
- close() - Method in class org.apache.nifi.stream.io.NonCloseableOutputStream
-
- close() - Method in class org.apache.nifi.stream.io.NullOutputStream
-
- close() - Method in class org.apache.nifi.stream.io.SynchronizedByteCountingOutputStream
-
- close() - Method in class org.apache.nifi.toolkit.tls.SystemExitCapturer
-
- close() - Method in class org.apache.nifi.util.FlowFileUnpackagerV1.NonCloseableInputStream
-
- close() - Method in class org.apache.nifi.util.hive.HiveWriter
-
Close the Transaction Batch and connection
- close() - Method in class org.apache.nifi.util.LimitingInputStream
-
- close(String) - Method in class org.apache.nifi.websocket.jetty.JettyWebSocketSession
-
- close(String) - Method in interface org.apache.nifi.websocket.WebSocketSession
-
- close() - Method in interface org.wali.SerDe
-
Closes any resources that the SerDe is holding open
- CLOSE_ELEMENT_TOKEN - Static variable in class org.apache.nifi.processors.evtx.parser.bxml.BxmlNode
-
- CLOSE_EMPTY_ELEMENT_TOKEN - Static variable in class org.apache.nifi.processors.evtx.parser.bxml.BxmlNode
-
- CLOSE_FRAME - Static variable in class org.apache.nifi.processors.standard.relp.frame.TestRELPDecoder
-
- CLOSE_START_ELEMENT_TOKEN - Static variable in class org.apache.nifi.processors.evtx.parser.bxml.BxmlNode
-
- CloseableUtil - Class in org.apache.nifi.provenance.util
-
- CloseableUtil() - Constructor for class org.apache.nifi.provenance.util.CloseableUtil
-
- closeClient() - Method in class org.apache.nifi.mongodb.AbstractMongoDBControllerService
-
- closeClient() - Method in class org.apache.nifi.processors.elasticsearch.AbstractElasticsearchTransportClientProcessor
-
Dispose of ElasticSearch client
- closeClient() - Method in class org.apache.nifi.processors.elasticsearch.DeleteElasticsearch5
-
- closeClient() - Method in class org.apache.nifi.processors.elasticsearch.FetchElasticsearch
-
Dispose of ElasticSearch client
- closeClient() - Method in class org.apache.nifi.processors.elasticsearch.FetchElasticsearch5
-
Dispose of ElasticSearch client
- closeClient() - Method in class org.apache.nifi.processors.elasticsearch.PutElasticsearch
-
Dispose of ElasticSearch client
- closeClient() - Method in class org.apache.nifi.processors.elasticsearch.PutElasticsearch5
-
Dispose of ElasticSearch client
- closeClient() - Method in class org.apache.nifi.processors.kudu.AbstractKudu
-
- closeClient() - Method in class org.apache.nifi.processors.mongodb.AbstractMongoProcessor
-
- closeClient() - Method in class org.apache.nifi.processors.solr.SolrProcessor
-
- closeConnection() - Method in class org.apache.nifi.util.hive.HiveWriter
-
- closed - Variable in class org.apache.nifi.util.hive.HiveWriter
-
- CloseElementNode - Class in org.apache.nifi.processors.evtx.parser.bxml
-
Close tag
- CloseElementNode(BinaryReader, ChunkHeader, BxmlNode) - Constructor for class org.apache.nifi.processors.evtx.parser.bxml.CloseElementNode
-
- CloseElementNodeTest - Class in org.apache.nifi.processors.evtx.parser.bxml
-
- CloseElementNodeTest() - Constructor for class org.apache.nifi.processors.evtx.parser.bxml.CloseElementNodeTest
-
- CloseEmptyElementNode - Class in org.apache.nifi.processors.evtx.parser.bxml
-
Close tag
- CloseEmptyElementNode(BinaryReader, ChunkHeader, BxmlNode) - Constructor for class org.apache.nifi.processors.evtx.parser.bxml.CloseEmptyElementNode
-
- CloseEmptyElementNodeTest - Class in org.apache.nifi.processors.evtx.parser.bxml
-
- CloseEmptyElementNodeTest() - Constructor for class org.apache.nifi.processors.evtx.parser.bxml.CloseEmptyElementNodeTest
-
- closeIgnite() - Method in class org.apache.nifi.processors.ignite.AbstractIgniteProcessor
-
Close ignite instance
- closeIgniteCache() - Method in class org.apache.nifi.processors.ignite.cache.AbstractIgniteCacheProcessor
-
Close Ignite cache instance and calls base class closeIgnite
- closeIgniteDataStreamer() - Method in class org.apache.nifi.processors.ignite.cache.PutIgniteCache
-
Close data streamer and calls base classes close ignite cache
- closeIgniteDataStreamerAndCache() - Method in class org.apache.nifi.processors.ignite.cache.PutIgniteCache
-
- closePool() - Method in class org.apache.nifi.processors.kafka.pubsub.PublishKafka
-
- closePool() - Method in class org.apache.nifi.processors.kafka.pubsub.PublishKafka_0_10
-
- closePool() - Method in class org.apache.nifi.processors.kafka.pubsub.PublishKafka_0_11
-
- closePool() - Method in class org.apache.nifi.processors.kafka.pubsub.PublishKafkaRecord_0_10
-
- closePool() - Method in class org.apache.nifi.processors.kafka.pubsub.PublishKafkaRecord_0_11
-
- closeQuietly(Statement) - Static method in class org.apache.nifi.admin.RepositoryUtils
-
Closes the given statement quietly - no logging, no exceptions
- closeQuietly(ResultSet) - Static method in class org.apache.nifi.admin.RepositoryUtils
-
Closes the given result set quietly - no logging, no exceptions
- closeQuietly(Connection) - Static method in class org.apache.nifi.admin.RepositoryUtils
-
Closes the given connection quietly - no logging, no exceptions
- closeQuietly(MulticastSocket) - Static method in class org.apache.nifi.io.socket.multicast.MulticastUtils
-
- closeQuietly(MulticastSocket, InetAddress) - Static method in class org.apache.nifi.io.socket.multicast.MulticastUtils
-
- closeQuietly(Socket) - Static method in class org.apache.nifi.io.socket.SocketUtils
-
- closeQuietly(ServerSocket) - Static method in class org.apache.nifi.io.socket.SocketUtils
-
- closeQuietly(Closeable...) - Static method in class org.apache.nifi.provenance.util.CloseableUtil
-
- closeQuietly(Closeable) - Static method in class org.apache.nifi.record.listen.IOUtils
-
- closeQuietly(Closeable) - Static method in class org.apache.nifi.util.file.FileUtils
-
Closes the given closeable quietly - no logging, no exceptions...
- closeReader() - Method in class org.apache.nifi.lookup.maxmind.IPLookupService
-
- closeReader() - Method in class org.apache.nifi.processors.AbstractEnrichIP
-
- closeRepo() - Method in class org.apache.nifi.provenance.TestPersistentProvenanceRepository
-
- closeSenders() - Method in class org.apache.nifi.processor.util.put.AbstractPutEventProcessor
-
- closeSpringContext(ProcessContext) - Method in class org.apache.nifi.spring.SpringContextProcessor
-
Will close the 'exchanger' which in turn will close both Spring
Application Context and the ClassLoader that loaded it allowing new
instance of Spring Application Context to be created upon the next start
(which may have an updated classpath and functionality) without
restarting NiFi.
- CloseStartElementNode - Class in org.apache.nifi.processors.evtx.parser.bxml
-
Close tag
- CloseStartElementNode(BinaryReader, ChunkHeader, BxmlNode) - Constructor for class org.apache.nifi.processors.evtx.parser.bxml.CloseStartElementNode
-
- CloseStartElementNodeTest - Class in org.apache.nifi.processors.evtx.parser.bxml
-
- CloseStartElementNodeTest() - Constructor for class org.apache.nifi.processors.evtx.parser.bxml.CloseStartElementNodeTest
-
- closeTxnBatch() - Method in class org.apache.nifi.util.hive.HiveWriter
-
- closeURLClassLoader(String, ClassLoader) - Static method in class org.apache.nifi.nar.ExtensionManager
-
Closes the given ClassLoader if it is an instance of URLClassLoader.
- cloudService - Variable in class org.apache.nifi.processors.gcp.AbstractGCPProcessor
-
- Cluster - Class in org.apache.nifi.cluster.integration
-
- Cluster() - Constructor for class org.apache.nifi.cluster.integration.Cluster
-
- Cluster(long, TimeUnit, Integer) - Constructor for class org.apache.nifi.cluster.integration.Cluster
-
- cluster - Variable in class org.apache.nifi.processors.cassandra.AbstractCassandraProcessor
-
- cluster - Static variable in class org.apache.nifi.processors.kite.TestKiteProcessorsCluster
-
- CLUSTER_COORDINATOR - Static variable in class org.apache.nifi.cluster.coordination.node.ClusterRoles
-
- CLUSTER_FIREWALL_FILE - Static variable in class org.apache.nifi.util.NiFiProperties
-
- CLUSTER_ID_GENERATION_SEED_HEADER - Static variable in interface org.apache.nifi.cluster.coordination.http.replication.RequestReplicator
-
- CLUSTER_IS_NODE - Static variable in class org.apache.nifi.util.NiFiProperties
-
- CLUSTER_MAX_REDIRECTS - Static variable in class org.apache.nifi.redis.util.RedisUtils
-
- CLUSTER_NAME - Static variable in class org.apache.nifi.processors.elasticsearch.AbstractElasticsearchTransportClientProcessor
-
- CLUSTER_NODE_ADDRESS - Static variable in class org.apache.nifi.util.NiFiProperties
-
- CLUSTER_NODE_CONNECTION_TIMEOUT - Static variable in class org.apache.nifi.util.NiFiProperties
-
- CLUSTER_NODE_MAX_CONCURRENT_REQUESTS - Static variable in class org.apache.nifi.util.NiFiProperties
-
- CLUSTER_NODE_PROTOCOL_MAX_THREADS - Static variable in class org.apache.nifi.util.NiFiProperties
-
- CLUSTER_NODE_PROTOCOL_PORT - Static variable in class org.apache.nifi.util.NiFiProperties
-
- CLUSTER_NODE_PROTOCOL_THREADS - Static variable in class org.apache.nifi.util.NiFiProperties
-
- CLUSTER_NODE_READ_TIMEOUT - Static variable in class org.apache.nifi.util.NiFiProperties
-
- CLUSTER_PROTOCOL_HEARTBEAT_INTERVAL - Static variable in class org.apache.nifi.util.NiFiProperties
-
- CLUSTER_PROTOCOL_IS_SECURE - Static variable in class org.apache.nifi.util.NiFiProperties
-
- ClusterConnectionIT - Class in org.apache.nifi.cluster.integration
-
- ClusterConnectionIT() - Constructor for class org.apache.nifi.cluster.integration.ClusterConnectionIT
-
- ClusterCoordinationProtocolSender - Interface in org.apache.nifi.cluster.protocol
-
An interface for sending protocol messages from the cluster coordinator to nodes.
- ClusterCoordinationProtocolSenderListener - Class in org.apache.nifi.cluster.protocol.impl
-
A wrapper class for consolidating a protocol sender and listener for the
cluster manager.
- ClusterCoordinationProtocolSenderListener(ClusterCoordinationProtocolSender, ProtocolListener) - Constructor for class org.apache.nifi.cluster.protocol.impl.ClusterCoordinationProtocolSenderListener
-
- ClusterCoordinator - Interface in org.apache.nifi.cluster.coordination
-
Responsible for coordinating nodes in the cluster
- clusterCoordinator - Variable in class org.apache.nifi.cluster.coordination.heartbeat.AbstractHeartbeatMonitor
-
- ClusterCoordinatorNodeInformant - Class in org.apache.nifi.controller
-
- ClusterCoordinatorNodeInformant(ClusterCoordinator) - Constructor for class org.apache.nifi.controller.ClusterCoordinatorNodeInformant
-
- ClusterDTO - Class in org.apache.nifi.web.api.dto
-
Details about the composition of the cluster at a specific date/time.
- ClusterDTO() - Constructor for class org.apache.nifi.web.api.dto.ClusterDTO
-
- ClusterEntity - 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.
- ClusterEntity() - Constructor for class org.apache.nifi.web.api.entity.ClusterEntity
-
- ClusterException - Exception in org.apache.nifi.cluster.exception
-
The base exception class for cluster related exceptions.
- ClusterException() - Constructor for exception org.apache.nifi.cluster.exception.ClusterException
-
- ClusterException(String) - Constructor for exception org.apache.nifi.cluster.exception.ClusterException
-
- ClusterException(Throwable) - Constructor for exception org.apache.nifi.cluster.exception.ClusterException
-
- ClusterException(String, Throwable) - Constructor for exception org.apache.nifi.cluster.exception.ClusterException
-
- ClusterExceptionMapper - Class in org.apache.nifi.web.api.config
-
Maps cluster core exceptions into client responses.
- ClusterExceptionMapper() - Constructor for class org.apache.nifi.web.api.config.ClusterExceptionMapper
-
- clusterName - Variable in class org.apache.nifi.processors.elasticsearch.ITDeleteElasticsearch5Test
-
- ClusterNodeFirewall - Interface in org.apache.nifi.cluster.firewall
-
Defines the interface for restricting external client connections to a set of hosts or IPs.
- ClusterNodeInformation - Class in org.apache.nifi.remote.cluster
-
- ClusterNodeInformation() - Constructor for class org.apache.nifi.remote.cluster.ClusterNodeInformation
-
- ClusterProtocolHeartbeater - Class in org.apache.nifi.controller.cluster
-
Uses Leader Election Manager in order to determine which node is the elected
Cluster Coordinator and to indicate that this node is part of the cluster.
- ClusterProtocolHeartbeater(NodeProtocolSender, ClusterCoordinator, LeaderElectionManager) - Constructor for class org.apache.nifi.controller.cluster.ClusterProtocolHeartbeater
-
- ClusterProtocolHeartbeatMonitor - Class in org.apache.nifi.cluster.coordination.heartbeat
-
Uses Apache ZooKeeper to advertise the address to send heartbeats to, and
then relies on the NiFi Cluster Protocol to receive heartbeat messages from
nodes in the cluster.
- ClusterProtocolHeartbeatMonitor(ClusterCoordinator, ProtocolListener, NiFiProperties) - Constructor for class org.apache.nifi.cluster.coordination.heartbeat.ClusterProtocolHeartbeatMonitor
-
- ClusterRequestException - Exception in org.apache.nifi.web
-
An general error occurred when attempting to communicate with the cluster.
- ClusterRequestException(Throwable) - Constructor for exception org.apache.nifi.web.ClusterRequestException
-
- ClusterRequestException(String, Throwable) - Constructor for exception org.apache.nifi.web.ClusterRequestException
-
- ClusterRequestException(String) - Constructor for exception org.apache.nifi.web.ClusterRequestException
-
- ClusterRequestException() - Constructor for exception org.apache.nifi.web.ClusterRequestException
-
- ClusterRoles - Class in org.apache.nifi.cluster.coordination.node
-
- ClusterRoles() - Constructor for class org.apache.nifi.cluster.coordination.node.ClusterRoles
-
- ClusterSearchResultsEntity - 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.
- ClusterSearchResultsEntity() - Constructor for class org.apache.nifi.web.api.entity.ClusterSearchResultsEntity
-
- ClusterState - Interface in org.apache.nifi.controller.state
-
- ClusterStatusDTO - Class in org.apache.nifi.web.api.dto.status
-
DTO for serializing the controller status.
- ClusterStatusDTO() - Constructor for class org.apache.nifi.web.api.dto.status.ClusterStatusDTO
-
- ClusterStatusEntity - 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.
- ClusterStatusEntity() - Constructor for class org.apache.nifi.web.api.entity.ClusterStatusEntity
-
- ClusterSummaryDTO - Class in org.apache.nifi.web.api.dto
-
Details for the controller configuration.
- ClusterSummaryDTO() - Constructor for class org.apache.nifi.web.api.dto.ClusterSummaryDTO
-
- ClusterUtils - Class in org.apache.nifi.cluster.integration
-
- ClusterUtils() - Constructor for class org.apache.nifi.cluster.integration.ClusterUtils
-
- clusterWorkload(ClusterWorkloadRequestMessage) - Method in class org.apache.nifi.cluster.protocol.AbstractNodeProtocolSender
-
- clusterWorkload(ClusterWorkloadRequestMessage) - Method in class org.apache.nifi.cluster.protocol.impl.NodeProtocolSenderListener
-
- clusterWorkload(ClusterWorkloadRequestMessage) - Method in interface org.apache.nifi.cluster.protocol.NodeProtocolSender
-
Sends a "cluster workflow request" message to the Cluster Coordinator.
- ClusterWorkloadRequestMessage - Class in org.apache.nifi.cluster.protocol.message
-
- ClusterWorkloadRequestMessage() - Constructor for class org.apache.nifi.cluster.protocol.message.ClusterWorkloadRequestMessage
-
- ClusterWorkloadResponseMessage - Class in org.apache.nifi.cluster.protocol.message
-
- ClusterWorkloadResponseMessage() - Constructor for class org.apache.nifi.cluster.protocol.message.ClusterWorkloadResponseMessage
-
- ClusteSummaryEntity - 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.
- ClusteSummaryEntity() - Constructor for class org.apache.nifi.web.api.entity.ClusteSummaryEntity
-
- codec - Variable in class org.apache.nifi.remote.AbstractTransaction
-
- codecRegistry - Static variable in class org.apache.nifi.processors.cassandra.AbstractCassandraProcessor
-
- COLLECTION - Static variable in class org.apache.nifi.processors.solr.SolrProcessor
-
- COLLECTION_NAME - Static variable in class org.apache.nifi.mongodb.AbstractMongoDBControllerService
-
- COLLECTION_NAME - Static variable in class org.apache.nifi.processors.mongodb.AbstractMongoProcessor
-
- COLLECTION_PARAM_NAME - Static variable in class org.apache.nifi.processors.solr.PutSolrContentStream
-
- Column - Class in org.apache.nifi.hbase.scan
-
Wrapper to encapsulate a column family and qualifier.
- Column(byte[], byte[]) - Constructor for class org.apache.nifi.hbase.scan.Column
-
- COLUMN_FAMILY - Static variable in class org.apache.nifi.hbase.AbstractPutHBase
-
- COLUMN_NAMES - Static variable in class org.apache.nifi.processors.standard.AbstractDatabaseFetchProcessor
-
- COLUMN_QUALIFIER - Static variable in class org.apache.nifi.hbase.AbstractPutHBase
-
- ColumnDefinition - Class in org.apache.nifi.cdc.event
-
A class that specifies a definition for a relational table column, including type, name, etc.
- ColumnDefinition(int) - Constructor for class org.apache.nifi.cdc.event.ColumnDefinition
-
- ColumnDefinition(int, String) - Constructor for class org.apache.nifi.cdc.event.ColumnDefinition
-
- ColumnDescription(String, int, boolean, Integer) - Constructor for class org.apache.nifi.processors.standard.PutDatabaseRecord.ColumnDescription
-
- columnTypeMap - Variable in class org.apache.nifi.processors.standard.AbstractDatabaseFetchProcessor
-
- COMMAND - Static variable in class org.apache.nifi.processors.standard.ExecuteProcess
-
- command(String) - Method in class org.apache.nifi.processors.standard.relp.frame.RELPFrame.Builder
-
- COMMAND_ARGUMENTS - Static variable in class org.apache.nifi.processors.standard.ExecuteProcess
-
- COMMAND_KEY - Static variable in interface org.apache.nifi.processors.standard.relp.event.RELPMetadata
-
- CommandLineParseException - Exception in org.apache.nifi.toolkit.tls.commandLine
-
Exception for errors while parsing the command line
- CommandLineParseException(String, ExitCode) - Constructor for exception org.apache.nifi.toolkit.tls.commandLine.CommandLineParseException
-
- CommaSeparatedRecordReader - Class in org.apache.nifi.serialization.record
-
- CommaSeparatedRecordReader() - Constructor for class org.apache.nifi.serialization.record.CommaSeparatedRecordReader
-
- CommaSeparatedRecordReader(int) - Constructor for class org.apache.nifi.serialization.record.CommaSeparatedRecordReader
-
- COMMENTS - Static variable in class org.apache.nifi.processors.standard.ExtractText
-
- commit() - Method in class org.apache.nifi.admin.service.transaction.impl.StandardTransaction
-
- commit() - Method in interface org.apache.nifi.admin.service.transaction.Transaction
-
Commits the current transaction.
- commit() - Method in class org.apache.nifi.controller.repository.StandardProcessSession
-
- commit() - Method in interface org.apache.nifi.processor.ProcessSession
-
Commits the current session ensuring all operations against FlowFiles
within this session are atomically persisted.
- commit() - Method in interface org.apache.nifi.provenance.index.EventIndexWriter
-
- commit(EventIndexWriter) - Method in class org.apache.nifi.provenance.index.lucene.EventIndexTask
-
- commit() - Method in class org.apache.nifi.provenance.lucene.LuceneEventIndexWriter
-
- commit() - Method in class org.apache.nifi.util.MockProcessSession
-
- COMMIT_EVENT - Static variable in interface org.apache.nifi.cdc.event.EventInfo
-
- COMMIT_PHASE - Static variable in class org.apache.nifi.cluster.coordination.http.replication.StandardAsyncClusterResponse
-
- COMMIT_WITHIN - Static variable in class org.apache.nifi.processors.solr.PutSolrContentStream
-
- COMMIT_WITHIN_PARAM_NAME - Static variable in class org.apache.nifi.processors.solr.PutSolrContentStream
-
- commitChanges(String) - Method in interface org.apache.nifi.provenance.index.EventIndex
-
Instructs the Event Index to commit any changes that have been made to the partition with the given name
- commitChanges(String) - Method in class org.apache.nifi.provenance.index.lucene.LuceneEventIndex
-
- CommitFailure(HiveEndPoint, Long, Throwable) - Constructor for exception org.apache.nifi.util.hive.HiveWriter.CommitFailure
-
- commitInputPortTransaction(Integer, String, String, HttpServletRequest, ServletContext, InputStream) - Method in class org.apache.nifi.web.api.DataTransferResource
-
- commitOutputPortTransaction(Integer, String, String, String, HttpServletRequest, ServletContext, InputStream) - Method in class org.apache.nifi.web.api.DataTransferResource
-
- CommitPreference - Enum in org.apache.nifi.provenance.index.lucene
-
- commitReceiveTransaction(Peer, FlowFileTransaction) - Method in class org.apache.nifi.remote.protocol.AbstractFlowFileServerProtocol
-
- commitReceiveTransaction(Peer) - Method in interface org.apache.nifi.remote.protocol.http.HttpFlowFileServerProtocol
-
- commitReceiveTransaction(Peer, FlowFileTransaction) - Method in class org.apache.nifi.remote.protocol.http.StandardHttpFlowFileServerProtocol
-
- commitReceiveTransaction(Peer) - Method in class org.apache.nifi.remote.protocol.http.StandardHttpFlowFileServerProtocol
-
- commitReceivingFlowFiles(String, ResponseCode, String) - Method in class org.apache.nifi.remote.util.SiteToSiteRestApiClient
-
- CommitTransactionEventInfo - Class in org.apache.nifi.cdc.mysql.event
-
An event implementation corresponding to the beginning of a MySQL transaction (update rows, e.g.)
- CommitTransactionEventInfo(String, Long, String, long) - Constructor for class org.apache.nifi.cdc.mysql.event.CommitTransactionEventInfo
-
- CommitTransactionEventWriter - Class in org.apache.nifi.cdc.mysql.event.io
-
A writer for events corresponding to the end (i.e.
- CommitTransactionEventWriter() - Constructor for class org.apache.nifi.cdc.mysql.event.io.CommitTransactionEventWriter
-
- commitTransferFlowFiles(String, ResponseCode) - Method in class org.apache.nifi.remote.util.SiteToSiteRestApiClient
-
- commitTransferTransaction(Peer, FlowFileTransaction) - Method in class org.apache.nifi.remote.protocol.AbstractFlowFileServerProtocol
-
- commitTransferTransaction(Peer, String) - Method in interface org.apache.nifi.remote.protocol.http.HttpFlowFileServerProtocol
-
- commitTransferTransaction(Peer, FlowFileTransaction) - Method in class org.apache.nifi.remote.protocol.http.StandardHttpFlowFileServerProtocol
-
- commitTransferTransaction(Peer, String) - Method in class org.apache.nifi.remote.protocol.http.StandardHttpFlowFileServerProtocol
-
- commitTxn() - Method in class org.apache.nifi.util.hive.HiveWriter
-
- CommonsConfigurationLookupService<T extends org.apache.commons.configuration2.FileBasedConfiguration> - Class in org.apache.nifi.lookup.configuration2
-
This abstract class defines a generic LookupService
backed by an
Apache Commons Configuration FileBasedConfiguration
.
- CommonsConfigurationLookupService() - Constructor for class org.apache.nifi.lookup.configuration2.CommonsConfigurationLookupService
-
- CommonTest - Class in org.apache.nifi.jms.processors
-
- CommonTest() - Constructor for class org.apache.nifi.jms.processors.CommonTest
-
- CommsSession - Interface in org.apache.nifi.distributed.cache.client
-
- Communicant - Interface in org.apache.nifi.remote
-
Represents the remote entity that the client is communicating with
- communicate() - Method in class org.apache.nifi.bootstrap.BootstrapCodec
-
- COMMUNICATION_TIMEOUT - Static variable in class org.apache.nifi.redis.util.RedisUtils
-
- COMMUNICATIONS_TIMEOUT - Static variable in class org.apache.nifi.distributed.cache.client.DistributedMapCacheClientService
-
- COMMUNICATIONS_TIMEOUT - Static variable in class org.apache.nifi.distributed.cache.client.DistributedSetCacheClientService
-
- CommunicationsException - Exception in org.apache.nifi.controller.exception
-
- CommunicationsException() - Constructor for exception org.apache.nifi.controller.exception.CommunicationsException
-
- CommunicationsException(Throwable) - Constructor for exception org.apache.nifi.controller.exception.CommunicationsException
-
- CommunicationsException(String) - Constructor for exception org.apache.nifi.controller.exception.CommunicationsException
-
- CommunicationsException(String, Throwable) - Constructor for exception org.apache.nifi.controller.exception.CommunicationsException
-
- CommunicationsFailure - Class in org.apache.nifi.events.network
-
- CommunicationsFailure(String) - Constructor for class org.apache.nifi.events.network.CommunicationsFailure
-
- CommunicationsInput - Interface in org.apache.nifi.remote.protocol
-
- CommunicationsOutput - Interface in org.apache.nifi.remote.protocol
-
- CommunicationsSession - Interface in org.apache.nifi.remote.protocol
-
- compact() - Method in class org.apache.nifi.remote.io.socket.BufferStateManager
-
- compare(FlowFileSummary, FlowFileSummary) - Method in enum org.apache.nifi.controller.queue.SortColumn
-
- compare(CacheRecord, CacheRecord) - Method in class org.apache.nifi.distributed.cache.server.EvictionPolicy.FIFOComparator
-
- compare(CacheRecord, CacheRecord) - Method in class org.apache.nifi.distributed.cache.server.EvictionPolicy.LFUComparator
-
- compare(CacheRecord, CacheRecord) - Method in class org.apache.nifi.distributed.cache.server.EvictionPolicy.LRUComparator
-
- compare(Object, Object) - Method in class org.apache.nifi.hl7.query.evaluator.comparison.AbstractComparisonEvaluator
-
- compare(Object, Object) - Method in class org.apache.nifi.hl7.query.evaluator.comparison.AbstractNumericComparison
-
- compare(Object, Object) - Method in class org.apache.nifi.hl7.query.evaluator.comparison.EqualsEvaluator
-
- compare(Object, Object) - Method in class org.apache.nifi.hl7.query.evaluator.comparison.NotEqualsEvaluator
-
- compare(FlowFile, FlowFile) - Method in class org.apache.nifi.integration.util.TestPrioritizer
-
- compare(FlowFile, FlowFile) - Method in class org.apache.nifi.prioritizer.FirstInFirstOutPrioritizer
-
- compare(FlowFile, FlowFile) - Method in class org.apache.nifi.prioritizer.NewestFlowFileFirstPrioritizer
-
- compare(FlowFile, FlowFile) - Method in class org.apache.nifi.prioritizer.OldestFlowFileFirstPrioritizer
-
- compare(FlowFile, FlowFile) - Method in class org.apache.nifi.prioritizer.PriorityAttributePrioritizer
-
- compare(Number, Number) - Method in class org.apache.nifi.record.path.filter.GreaterThanFilter
-
- compare(Number, Number) - Method in class org.apache.nifi.record.path.filter.GreaterThanOrEqualFilter
-
- compare(Number, Number) - Method in class org.apache.nifi.record.path.filter.LessThanFilter
-
- compare(Number, Number) - Method in class org.apache.nifi.record.path.filter.LessThanOrEqualFilter
-
- compare(Number, Number) - Method in class org.apache.nifi.record.path.filter.NumericBinaryOperatorFilter
-
- compare(Revision, Revision) - Method in class org.apache.nifi.web.revision.RevisionComparator
-
- compareDNs(String, String) - Static method in class org.apache.nifi.security.util.CertificateUtils
-
Returns true if the two provided DNs are equivalent, regardless of the order of the elements.
- CompareFuzzyHash - Class in org.apache.nifi.processors.cybersecurity
-
- CompareFuzzyHash() - Constructor for class org.apache.nifi.processors.cybersecurity.CompareFuzzyHash
-
- compareNumbers(Double, Double) - Method in class org.apache.nifi.hl7.query.evaluator.comparison.AbstractNumericComparison
-
- compareNumbers(Double, Double) - Method in class org.apache.nifi.hl7.query.evaluator.comparison.GreaterThanEvaluator
-
- compareNumbers(Double, Double) - Method in class org.apache.nifi.hl7.query.evaluator.comparison.GreaterThanOrEqualEvaluator
-
- compareNumbers(Double, Double) - Method in class org.apache.nifi.hl7.query.evaluator.comparison.LessThanEvaluator
-
- compareNumbers(Double, Double) - Method in class org.apache.nifi.hl7.query.evaluator.comparison.LessThanOrEqualEvaluator
-
- compareTo(PropertyDescriptor) - Method in class org.apache.nifi.components.PropertyDescriptor
-
- compareTo(ResourceClaim) - Method in interface org.apache.nifi.controller.repository.claim.ResourceClaim
-
Provides the natural ordering for ResourceClaim objects.
- compareTo(ContentClaim) - Method in class org.apache.nifi.controller.repository.claim.StandardContentClaim
-
- compareTo(FlowFile) - Method in class org.apache.nifi.controller.repository.StandardFlowFileRecord
-
Provides the natural ordering for FlowFile objects which is based on their identifier.
- compareTo(FlowFile) - Method in class org.apache.nifi.controller.swap.MockFlowFile
-
- compareTo(Relationship) - Method in class org.apache.nifi.processor.Relationship
-
- compareTo(BlobInfo) - Method in class org.apache.nifi.processors.azure.storage.utils.BlobInfo
-
- compareTo(FileInfo) - Method in class org.apache.nifi.processors.standard.util.FileInfo
-
- compareTo(VariableDescriptor) - Method in class org.apache.nifi.registry.VariableDescriptor
-
- compareTo(Bulletin) - Method in class org.apache.nifi.reporting.Bulletin
-
- compareTo(ActionDTO) - Method in class org.apache.nifi.update.attributes.dto.ActionDTO
-
- compareTo(ConditionDTO) - Method in class org.apache.nifi.update.attributes.dto.ConditionDTO
-
- compareTo(FlowFile) - Method in class org.apache.nifi.util.MockFlowFile
-
- compile(String) - Method in class org.apache.nifi.attribute.expression.language.compile.ExpressionCompiler
-
- compile(String) - Static method in class org.apache.nifi.attribute.expression.language.Query
-
- compile(String) - Method in class org.apache.nifi.attribute.expression.language.StandardExpressionLanguageCompiler
-
- compile(String) - Method in interface org.apache.nifi.expression.ExpressionLanguageCompiler
-
Compiles the given Attribute Expression string into an
AttributeExpression that can be evaluated
- compile(String) - Static method in class org.apache.nifi.hl7.query.HL7Query
-
- compile(Tree, RecordPathSegment, boolean) - Static method in class org.apache.nifi.record.path.paths.RecordPathCompiler
-
- compile(String) - Static method in interface org.apache.nifi.record.path.RecordPath
-
Compiles a RecordPath from the given text
- CompiledExpression - Class in org.apache.nifi.attribute.expression.language.compile
-
- CompiledExpression(String, Evaluator<?>, Tree, Set<Evaluator<?>>) - Constructor for class org.apache.nifi.attribute.expression.language.compile.CompiledExpression
-
- compileJsonPaths(ConfigurationContext) - Method in class org.apache.nifi.json.JsonPathReader
-
- complete(String) - Method in interface org.apache.nifi.http.HttpContextMap
-
Marks the HTTP request/response for the given identifier as complete
- complete(String) - Method in class org.apache.nifi.http.StandardHttpContextMap
-
- complete() - Method in class org.apache.nifi.processors.kafka.pubsub.PublisherLease
-
- complete(String) - Method in class org.apache.nifi.processors.standard.merge.RecordBin
-
- complete(String) - Method in class org.apache.nifi.processors.standard.WaitNotifyProtocol
-
Finish protocol and remove the cache entry.
- complete() - Method in class org.apache.nifi.remote.AbstractTransaction
-
- complete() - Method in interface org.apache.nifi.remote.Transaction
-
Completes the transaction and indicates to both the sender and receiver
that the data transfer was successful.
- completeBatches - Variable in class org.apache.nifi.processor.util.put.AbstractPutEventProcessor
-
- completeConnection(SelectionKey) - Method in interface org.apache.nifi.processor.util.listen.dispatcher.AsyncChannelDispatcher
-
Informs the dispatcher that the connection for the given key is complete.
- completeConnection(SelectionKey) - Method in class org.apache.nifi.processor.util.listen.dispatcher.SocketChannelDispatcher
-
- completeExpiredBins() - Method in class org.apache.nifi.processors.standard.merge.RecordBinManager
-
- completeOldestBin() - Method in class org.apache.nifi.processors.standard.merge.RecordBinManager
-
- completeSession() - Method in class org.apache.nifi.processor.util.put.AbstractPutEventProcessor.FlowFileMessageBatch
-
- CompletionCallback - Interface in org.apache.nifi.cluster.coordination.http.replication
-
- COMPLEX_FIELD_FAIL - Static variable in class org.apache.nifi.hbase.PutHBaseJSON
-
- COMPLEX_FIELD_FAIL - Static variable in class org.apache.nifi.hbase.PutHBaseRecord
-
- COMPLEX_FIELD_IGNORE - Static variable in class org.apache.nifi.hbase.PutHBaseJSON
-
- COMPLEX_FIELD_IGNORE - Static variable in class org.apache.nifi.hbase.PutHBaseRecord
-
- COMPLEX_FIELD_STRATEGY - Static variable in class org.apache.nifi.hbase.PutHBaseJSON
-
- COMPLEX_FIELD_STRATEGY - Static variable in class org.apache.nifi.hbase.PutHBaseRecord
-
- COMPLEX_FIELD_TEXT - Static variable in class org.apache.nifi.hbase.PutHBaseJSON
-
- COMPLEX_FIELD_TEXT - Static variable in class org.apache.nifi.hbase.PutHBaseRecord
-
- COMPLEX_FIELD_WARN - Static variable in class org.apache.nifi.hbase.PutHBaseJSON
-
- COMPLEX_FIELD_WARN - Static variable in class org.apache.nifi.hbase.PutHBaseRecord
-
- ComplexRecordField - Class in org.apache.nifi.repository.schema
-
- ComplexRecordField(String, Repetition, RecordField...) - Constructor for class org.apache.nifi.repository.schema.ComplexRecordField
-
- ComplexRecordField(String, Repetition, List<RecordField>) - Constructor for class org.apache.nifi.repository.schema.ComplexRecordField
-
- Component - Enum in org.apache.nifi.action
-
Defines possible components for a given action.
- COMPONENT_COUNT_ATTR - Static variable in class org.apache.nifi.processors.gcp.storage.StorageAttributes
-
- COMPONENT_COUNT_DESC - Static variable in class org.apache.nifi.processors.gcp.storage.StorageAttributes
-
- COMPONENT_DETAIL_DESTINATION_NAME - Static variable in interface org.apache.nifi.controller.status.history.ComponentStatusRepository
-
- COMPONENT_DETAIL_GROUP_ID - Static variable in interface org.apache.nifi.controller.status.history.ComponentStatusRepository
-
- COMPONENT_DETAIL_ID - Static variable in interface org.apache.nifi.controller.status.history.ComponentStatusRepository
-
- COMPONENT_DETAIL_NAME - Static variable in interface org.apache.nifi.controller.status.history.ComponentStatusRepository
-
- COMPONENT_DETAIL_SOURCE_NAME - Static variable in interface org.apache.nifi.controller.status.history.ComponentStatusRepository
-
- COMPONENT_DETAIL_TYPE - Static variable in interface org.apache.nifi.controller.status.history.ComponentStatusRepository
-
- COMPONENT_DETAIL_URI - Static variable in interface org.apache.nifi.controller.status.history.ComponentStatusRepository
-
- COMPONENT_DOCS_DIRECTORY - Static variable in class org.apache.nifi.util.NiFiProperties
-
- COMPONENT_ID - Static variable in class org.apache.nifi.provenance.schema.EventFieldNames
-
- COMPONENT_ID - Static variable in class org.apache.nifi.provenance.schema.EventRecordFields
-
- COMPONENT_ID - Static variable in class org.apache.nifi.provenance.schema.LookupTableEventRecordFields
-
- COMPONENT_IDS - Static variable in class org.apache.nifi.provenance.schema.EventIdFirstHeaderSchema.FieldNames
-
- COMPONENT_STATUS_REPOSITORY_IMPLEMENTATION - Static variable in class org.apache.nifi.util.NiFiProperties
-
- COMPONENT_STATUS_SNAPSHOT_FREQUENCY - Static variable in class org.apache.nifi.util.NiFiProperties
-
- COMPONENT_TYPE - Static variable in class org.apache.nifi.provenance.schema.EventFieldNames
-
- COMPONENT_TYPE - Static variable in class org.apache.nifi.provenance.schema.EventRecordFields
-
- COMPONENT_TYPE - Static variable in class org.apache.nifi.provenance.schema.LookupTableEventRecordFields
-
- COMPONENT_TYPE_CONTROLLER_SERVICE - Static variable in class org.apache.nifi.web.api.dto.AffectedComponentDTO
-
- COMPONENT_TYPE_PROCESSOR - Static variable in class org.apache.nifi.web.api.dto.AffectedComponentDTO
-
- COMPONENT_TYPES - Static variable in class org.apache.nifi.provenance.schema.EventIdFirstHeaderSchema.FieldNames
-
- ComponentAuthorizable - Interface in org.apache.nifi.authorization
-
Authorizable for a component that references a ControllerService.
- ComponentAuthorizable - Interface in org.apache.nifi.authorization.resource
-
Not all Authorizables are components, however all ComponentAuthorizable's are components.
- ComponentBulletin - Class in org.apache.nifi.events
-
- ComponentDAO - Class in org.apache.nifi.web.dao.impl
-
- ComponentDAO() - Constructor for class org.apache.nifi.web.dao.impl.ComponentDAO
-
- ComponentDescriptor - Class in org.apache.nifi.web
-
- ComponentDescriptor.Builder - Class in org.apache.nifi.web
-
- ComponentDetails - Interface in org.apache.nifi.action.component.details
-
Base interface for providing component details to an Action.
- ComponentDetails - Class in org.apache.nifi.web
-
Details about a given component.
- ComponentDetails.Builder - Class in org.apache.nifi.web
-
- ComponentDetailsDTO - Class in org.apache.nifi.web.api.dto.action.component.details
-
- ComponentDetailsDTO() - Constructor for class org.apache.nifi.web.api.dto.action.component.details.ComponentDetailsDTO
-
- ComponentDTO - Class in org.apache.nifi.web.api.dto
-
Base class for all nifi components.
- ComponentDTO() - Constructor for class org.apache.nifi.web.api.dto.ComponentDTO
-
- ComponentEntity - Class in org.apache.nifi.web.api.entity
-
A base type for request/response entities.
- ComponentEntity() - Constructor for class org.apache.nifi.web.api.entity.ComponentEntity
-
- ComponentEntityMerger<EntityType extends ComponentEntity & Permissible> - Interface in org.apache.nifi.cluster.manager
-
- ComponentEntityStatusMerger<StatusDtoType> - Interface in org.apache.nifi.cluster.manager
-
- ComponentHistoryDTO - Class in org.apache.nifi.web.api.dto
-
History of a component's properties.
- ComponentHistoryDTO() - Constructor for class org.apache.nifi.web.api.dto.ComponentHistoryDTO
-
- ComponentHistoryEntity - 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.
- ComponentHistoryEntity() - Constructor for class org.apache.nifi.web.api.entity.ComponentHistoryEntity
-
- componentId - Variable in class org.apache.nifi.controller.state.providers.AbstractTestStateProvider
-
- ComponentID - Static variable in class org.apache.nifi.provenance.SearchableFields
-
- componentId - Variable in class org.apache.nifi.redis.state.ITRedisStateProvider
-
- ComponentIdGenerator - Class in org.apache.nifi.util
-
IMPORTANT: This component is not part of public API!
====================================================
- ComponentIdGenerator() - Constructor for class org.apache.nifi.util.ComponentIdGenerator
-
- ComponentLifeCycleException - Exception in org.apache.nifi.controller.exception
-
- ComponentLifeCycleException(String, Throwable) - Constructor for exception org.apache.nifi.controller.exception.ComponentLifeCycleException
-
- ComponentLifeCycleException(Throwable) - Constructor for exception org.apache.nifi.controller.exception.ComponentLifeCycleException
-
- ComponentLog - Interface in org.apache.nifi.logging
-
The ComponentLog provides a mechanism to ensure that all NiFi components are
logging and reporting information in a consistent way.
- ComponentReferenceDTO - Class in org.apache.nifi.web.api.dto
-
Details for the access configuration.
- ComponentReferenceDTO() - Constructor for class org.apache.nifi.web.api.dto.ComponentReferenceDTO
-
- ComponentReferenceEntity - 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.
- ComponentReferenceEntity() - Constructor for class org.apache.nifi.web.api.entity.ComponentReferenceEntity
-
- ComponentRevision - Class in org.apache.nifi.cluster.protocol
-
- ComponentRevision() - Constructor for class org.apache.nifi.cluster.protocol.ComponentRevision
-
- ComponentSearchResultDTO - Class in org.apache.nifi.web.api.dto.search
-
The components that match a search performed on this NiFi.
- ComponentSearchResultDTO() - Constructor for class org.apache.nifi.web.api.dto.search.ComponentSearchResultDTO
-
- ComponentSpecificControllerServiceLookup - Class in org.apache.nifi.processor
-
- ComponentSpecificControllerServiceLookup(ControllerServiceProvider, String, String) - Constructor for class org.apache.nifi.processor.ComponentSpecificControllerServiceLookup
-
- ComponentStateAuditor - Class in org.apache.nifi.audit
-
- ComponentStateAuditor() - Constructor for class org.apache.nifi.audit.ComponentStateAuditor
-
- ComponentStateDAO - Interface in org.apache.nifi.web.dao
-
- ComponentStateDTO - Class in org.apache.nifi.web.api.dto
-
State for a given component.
- ComponentStateDTO() - Constructor for class org.apache.nifi.web.api.dto.ComponentStateDTO
-
- ComponentStateEndpointMerger - Class in org.apache.nifi.cluster.coordination.http.endpoints
-
- ComponentStateEndpointMerger() - Constructor for class org.apache.nifi.cluster.coordination.http.endpoints.ComponentStateEndpointMerger
-
- ComponentStateEntity - 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.
- ComponentStateEntity() - Constructor for class org.apache.nifi.web.api.entity.ComponentStateEntity
-
- ComponentStatusReport - Class in org.apache.nifi.util
-
ComponentStatusReport is a util class that can be used to "flatten" a ProcessGroupStatus into a collection of Map's so that retrieval of a Status for a particular component is very efficient
- ComponentStatusReport.ComponentType - Enum in org.apache.nifi.util
-
- ComponentStatusRepository - Interface in org.apache.nifi.controller.status.history
-
A repository for storing and retrieving components' historical status
information
- ComponentType - Enum in org.apache.nifi.reporting
-
An Enumeration for indicating which type of component a Bulletin is associated with
- ComponentVariableRegistry - Interface in org.apache.nifi.registry
-
- CompositeConfigurableUserGroupProvider - Class in org.apache.nifi.authorization
-
- CompositeConfigurableUserGroupProvider() - Constructor for class org.apache.nifi.authorization.CompositeConfigurableUserGroupProvider
-
- CompositeConfigurableUserGroupProviderTest - Class in org.apache.nifi.authorization
-
- CompositeConfigurableUserGroupProviderTest() - Constructor for class org.apache.nifi.authorization.CompositeConfigurableUserGroupProviderTest
-
- CompositeUserGroupProvider - Class in org.apache.nifi.authorization
-
- CompositeUserGroupProvider() - Constructor for class org.apache.nifi.authorization.CompositeUserGroupProvider
-
- CompositeUserGroupProvider(boolean) - Constructor for class org.apache.nifi.authorization.CompositeUserGroupProvider
-
- CompositeUserGroupProviderTest - Class in org.apache.nifi.authorization
-
- CompositeUserGroupProviderTest() - Constructor for class org.apache.nifi.authorization.CompositeUserGroupProviderTest
-
- CompoundUpdateMonitor - Class in org.apache.nifi.util.file.monitor
-
An
UpdateMonitor
that combines multiple
UpdateMonitor
s such that it will indicate a change in a file only if ALL sub-monitors indicate a change.
- CompoundUpdateMonitor(UpdateMonitor, UpdateMonitor...) - Constructor for class org.apache.nifi.util.file.monitor.CompoundUpdateMonitor
-
- compress(File, TocReader, File, TocWriter) - Static method in class org.apache.nifi.provenance.serialization.EventFileCompressor
-
- CompressableRecordReader - Class in org.apache.nifi.provenance.serialization
-
- CompressableRecordReader(InputStream, String, int) - Constructor for class org.apache.nifi.provenance.serialization.CompressableRecordReader
-
- CompressableRecordReader(InputStream, String, TocReader, int) - Constructor for class org.apache.nifi.provenance.serialization.CompressableRecordReader
-
- CompressableRecordWriter - Class in org.apache.nifi.provenance.serialization
-
- CompressableRecordWriter(File, AtomicLong, TocWriter, boolean, int) - Constructor for class org.apache.nifi.provenance.serialization.CompressableRecordWriter
-
- CompressableRecordWriter(OutputStream, String, AtomicLong, TocWriter, boolean, int) - Constructor for class org.apache.nifi.provenance.serialization.CompressableRecordWriter
-
- compressAndWrite() - Method in class org.apache.nifi.remote.io.CompressionOutputStream
-
Compresses the currently buffered chunk of data and sends it to the output stream
- CompressContent - Class in org.apache.nifi.processors.standard
-
- CompressContent() - Constructor for class org.apache.nifi.processors.standard.CompressContent
-
- COMPRESSION_CODEC - Static variable in class org.apache.nifi.processors.hadoop.AbstractHadoopProcessor
-
- COMPRESSION_CODEC - Static variable in class org.apache.nifi.processors.kafka.PutKafka
-
- COMPRESSION_CODEC_GZIP - Static variable in class org.apache.nifi.processors.kafka.PutKafka
-
AllowableValue for sending messages to Kafka with GZIP compression
- COMPRESSION_CODEC_NONE - Static variable in class org.apache.nifi.processors.kafka.PutKafka
-
AllowableValue for sending messages to Kafka without compression
- COMPRESSION_CODEC_SNAPPY - Static variable in class org.apache.nifi.processors.kafka.PutKafka
-
AllowableValue for sending messages to Kafka with Snappy compression
- COMPRESSION_FORMAT - Static variable in class org.apache.nifi.processors.standard.CompressContent
-
- COMPRESSION_FORMAT_ATTRIBUTE - Static variable in class org.apache.nifi.processors.standard.CompressContent
-
- COMPRESSION_FORMAT_BZIP2 - Static variable in class org.apache.nifi.processors.standard.CompressContent
-
- COMPRESSION_FORMAT_GZIP - Static variable in class org.apache.nifi.processors.standard.CompressContent
-
- COMPRESSION_FORMAT_LZMA - Static variable in class org.apache.nifi.processors.standard.CompressContent
-
- COMPRESSION_FORMAT_SNAPPY - Static variable in class org.apache.nifi.processors.standard.CompressContent
-
- COMPRESSION_FORMAT_SNAPPY_FRAMED - Static variable in class org.apache.nifi.processors.standard.CompressContent
-
- COMPRESSION_FORMAT_XZ_LZMA2 - Static variable in class org.apache.nifi.processors.standard.CompressContent
-
- COMPRESSION_LEVEL - Static variable in class org.apache.nifi.processors.standard.CompressContent
-
- COMPRESSION_LEVEL - Static variable in class org.apache.nifi.processors.standard.MergeContent
-
- COMPRESSION_LEVEL - Static variable in class org.apache.nifi.processors.standard.PostHTTP
-
- COMPRESSION_OPTION - Static variable in class org.apache.nifi.toolkit.s2s.SiteToSiteCliMain
-
- COMPRESSION_TYPE - Static variable in class org.apache.nifi.processors.hadoop.AbstractPutHDFSRecord
-
- COMPRESSION_TYPE - Static variable in class org.apache.nifi.processors.hive.ConvertAvroToORC
-
- COMPRESSION_TYPES - Static variable in class org.apache.nifi.processors.parquet.PutParquet
-
- CompressionInputStream - Class in org.apache.nifi.remote.io
-
- CompressionInputStream(InputStream) - Constructor for class org.apache.nifi.remote.io.CompressionInputStream
-
- CompressionOutputStream - Class in org.apache.nifi.remote.io
-
- CompressionOutputStream(OutputStream) - Constructor for class org.apache.nifi.remote.io.CompressionOutputStream
-
- CompressionOutputStream(OutputStream, int) - Constructor for class org.apache.nifi.remote.io.CompressionOutputStream
-
- CompressionOutputStream(OutputStream, int, int, int) - Constructor for class org.apache.nifi.remote.io.CompressionOutputStream
-
- CompressionType - Enum in org.apache.nifi.processors.hadoop
-
Compression Type Enum for Hadoop related processors.
- ComputeEngineCredentialsStrategy - Class in org.apache.nifi.processors.gcp.credentials.factory.strategies
-
Supports Google Compute Engine credentials.
- ComputeEngineCredentialsStrategy() - Constructor for class org.apache.nifi.processors.gcp.credentials.factory.strategies.ComputeEngineCredentialsStrategy
-
- computeLineage(String, NiFiUser) - Method in class org.apache.nifi.provenance.VolatileProvenanceRepository
-
- computeLineageForFlowFiles(IndexManager, File, String, Collection<String>, DocumentToEventConverter) - Static method in class org.apache.nifi.provenance.lucene.LineageQuery
-
- ComputeLineageResult - Interface in org.apache.nifi.provenance.lineage
-
- ComputeLineageSubmission - Interface in org.apache.nifi.provenance.lineage
-
- computeMd5Digest(File) - Static method in class org.apache.nifi.util.file.FileUtils
-
Returns the MD5 hash of the given file.
- computeMd5Digest(InputStream) - Static method in class org.apache.nifi.util.file.FileUtils
-
Returns the MD5 hash of the given stream.
- con - Static variable in class org.apache.nifi.processors.standard.util.TestJdbcCommon
-
Setting up Connection is expensive operation.
- Concat - Class in org.apache.nifi.record.path.functions
-
- Concat(RecordPathSegment[], boolean) - Constructor for class org.apache.nifi.record.path.functions.Concat
-
- concatByteArrays(byte[]...) - Static method in class org.apache.nifi.security.kms.CryptoUtils
-
Concatenates multiple byte[] into a single byte[].
- CONCURRENT_MERGE_THREADS - Static variable in class org.apache.nifi.provenance.RepositoryConfiguration
-
- Condition - Class in org.apache.nifi.update.attributes
-
- Condition() - Constructor for class org.apache.nifi.update.attributes.Condition
-
- CONDITIONAL_SUBSTITUTION_TOKEN - Static variable in class org.apache.nifi.processors.evtx.parser.bxml.BxmlNode
-
- ConditionalSubstitutionNode - 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
- ConditionalSubstitutionNode(BinaryReader, ChunkHeader, BxmlNode) - Constructor for class org.apache.nifi.processors.evtx.parser.bxml.ConditionalSubstitutionNode
-
- ConditionalSubstitutionNodeTest - Class in org.apache.nifi.processors.evtx.parser.bxml
-
- ConditionalSubstitutionNodeTest() - Constructor for class org.apache.nifi.processors.evtx.parser.bxml.ConditionalSubstitutionNodeTest
-
- ConditionDTO - Class in org.apache.nifi.update.attributes.dto
-
- ConditionDTO() - Constructor for class org.apache.nifi.update.attributes.dto.ConditionDTO
-
- ConditionEntity - Class in org.apache.nifi.update.attributes.entity
-
- ConditionEntity() - Constructor for class org.apache.nifi.update.attributes.entity.ConditionEntity
-
- CONF - Static variable in class org.apache.nifi.toolkit.tls.manager.writer.NifiPropertiesTlsClientConfigWriter
-
- config - Variable in class org.apache.nifi.remote.client.AbstractSiteToSiteClient
-
- CONFIG_JSON_ARG - Static variable in class org.apache.nifi.toolkit.tls.service.BaseCertificateAuthorityCommandLine
-
- configContext - Variable in class org.apache.nifi.ssl.StandardSSLContextService
-
- ConfigFilesValidator - Class in org.apache.nifi.hbase.validate
-
- ConfigFilesValidator() - Constructor for class org.apache.nifi.hbase.validate.ConfigFilesValidator
-
- ConfigParseException - Exception in org.apache.nifi.controller.state
-
- ConfigParseException(String) - Constructor for exception org.apache.nifi.controller.state.ConfigParseException
-
- ConfigParseException(String, Throwable) - Constructor for exception org.apache.nifi.controller.state.ConfigParseException
-
- CONFIGURABLE_USER_GROUP_PROVIDER - Static variable in class org.apache.nifi.authorization.CompositeConfigurableUserGroupProviderTest
-
- ConfigurableAccessPolicyProvider - Interface in org.apache.nifi.authorization
-
Provides support for configuring AccessPolicies.
- ConfigurableComponent - Interface in org.apache.nifi.components
-
- ConfigurableComponentInitializer - Interface in org.apache.nifi.init
-
An interface for initializing and tearing down a ConfigurableComponent.
- ConfigurableComponentInitializerFactory - Class in org.apache.nifi.init
-
- ConfigurableComponentInitializerFactory() - Constructor for class org.apache.nifi.init.ConfigurableComponentInitializerFactory
-
- ConfigurableUserGroupProvider - Interface in org.apache.nifi.authorization
-
Provides support for configuring Users and Groups.
- CONFIGURATION_FILE - Static variable in class org.apache.nifi.lookup.configuration2.CommonsConfigurationLookupService
-
- ConfigurationAction - Class in org.apache.nifi.web
-
An action that represents the configuration of a component.
- ConfigurationAction.Builder - Class in org.apache.nifi.web
-
- ConfigurationContext - Interface in org.apache.nifi.controller
-
This context is passed to ControllerServices and Reporting Tasks in order
to expose their configuration to them.
- configurationContext - Variable in class org.apache.nifi.script.AbstractScriptedControllerService
-
- ConfigurationRequest<T> - Interface in org.apache.nifi.web
-
Represents a request to configure.
- ConfigurationResult<T> - Interface in org.apache.nifi.web
-
Represents a request to configure.
- ConfigurationSnapshot<T> - Class in org.apache.nifi.web
-
Response object that captures the context of a given configuration.
- ConfigurationSnapshot(Long) - Constructor for class org.apache.nifi.web.ConfigurationSnapshot
-
Creates a new ConfigurationSnapshot with no configuration object.
- ConfigurationSnapshot(Long, T) - Constructor for class org.apache.nifi.web.ConfigurationSnapshot
-
Creates a new ConfigurationSnapshot with the specified configuration
object.
- ConfigurationSnapshot(Long, T, boolean) - Constructor for class org.apache.nifi.web.ConfigurationSnapshot
-
Creates a new ConfigurationSnapshot with the specified configuration
object.
- ConfigurationState(Map<String, String>) - Constructor for class org.apache.nifi.processors.standard.ReplaceTextWithMapping.ConfigurationState
-
- ConfigurationWriter<T> - Interface in org.apache.nifi.toolkit.tls.manager.writer
-
Class that can write out configuration information on the given object
- configure(Context) - Method in class org.apache.nifi.processors.flume.NifiChannelSelector
-
- configure(Context) - Method in class org.apache.nifi.processors.flume.NifiSessionChannel
-
- configure(Context) - Method in class org.apache.nifi.processors.flume.NifiSessionFactoryChannel
-
- configure(Context) - Method in class org.apache.nifi.processors.flume.NifiSinkSessionChannel
-
- configure(Map<String, ?>) - Method in class org.apache.nifi.processors.kafka.pubsub.Partitioners.RoundRobinPartitioner
-
- configure(WebSecurity) - Method in class org.apache.nifi.web.NiFiWebApiSecurityConfiguration
-
- configure(HttpSecurity) - Method in class org.apache.nifi.web.NiFiWebApiSecurityConfiguration
-
- configure(AuthenticationManagerBuilder) - Method in class org.apache.nifi.web.NiFiWebApiSecurityConfiguration
-
- configure() - Method in class org.apache.nifi.web.standard.api.processor.TestProcessorResource
-
- configure() - Method in class org.apache.nifi.web.standard.api.transformjson.TestTransformJSONResource
-
- configure(WebSocketServletFactory) - Method in class org.apache.nifi.websocket.example.WebSocketServerExample.WSServlet
-
- configure(WebSocketServletFactory) - Method in class org.apache.nifi.websocket.jetty.JettyWebSocketServer.JettyWebSocketServlet
-
- ConfiguredComponent - Interface in org.apache.nifi.controller
-
- ConfigureDetails - Interface in org.apache.nifi.action.details
-
Provides details about a configure action.
- ConfigureDetailsDTO - Class in org.apache.nifi.web.api.dto.action.details
-
Configuration details for an Action.
- ConfigureDetailsDTO() - Constructor for class org.apache.nifi.web.api.dto.action.details.ConfigureDetailsDTO
-
- configureLogging() - Static method in class org.apache.nifi.processors.kafka.TestGetKafka
-
- configurePolicy(ConfigurationContext, WebSocketPolicy) - Method in class org.apache.nifi.websocket.jetty.AbstractJettyWebSocketService
-
- configureProperties(String, int, String, boolean, boolean) - Method in class org.apache.nifi.processors.standard.TestPutTCP
-
- configureProperties(String, int, String, boolean, boolean) - Method in class org.apache.nifi.processors.standard.TestPutTcpSSL
-
- configureProperties(String, int, String, boolean, boolean) - Method in class org.apache.nifi.processors.standard.util.TestPutTCPCommon
-
- configureSslContextFactory(SslContextFactory, NiFiProperties) - Static method in class org.apache.nifi.web.server.JettyServer
-
- confirm() - Method in class org.apache.nifi.remote.AbstractTransaction
-
- confirm() - Method in interface org.apache.nifi.remote.Transaction
-
Confirms the data that was sent or received by comparing CRC32's of the
data sent and the data received.
- CONFLICT_OPTION_KEY - Variable in class org.apache.nifi.processors.rethinkdb.PutRethinkDB
-
- CONFLICT_RESOLUTION - Static variable in class org.apache.nifi.processors.hadoop.PutHDFS
-
- CONFLICT_RESOLUTION - Static variable in class org.apache.nifi.processors.standard.PutFile
-
- CONFLICT_RESOLUTION - Static variable in interface org.apache.nifi.processors.standard.util.FileTransfer
-
- CONFLICT_RESOLUTION_FAIL - Static variable in interface org.apache.nifi.processors.standard.util.FileTransfer
-
- CONFLICT_RESOLUTION_IGNORE - Static variable in interface org.apache.nifi.processors.standard.util.FileTransfer
-
- CONFLICT_RESOLUTION_NONE - Static variable in interface org.apache.nifi.processors.standard.util.FileTransfer
-
- CONFLICT_RESOLUTION_REJECT - Static variable in interface org.apache.nifi.processors.standard.util.FileTransfer
-
- CONFLICT_RESOLUTION_RENAME - Static variable in interface org.apache.nifi.processors.standard.util.FileTransfer
-
- CONFLICT_RESOLUTION_REPLACE - Static variable in interface org.apache.nifi.processors.standard.util.FileTransfer
-
- CONFLICT_STRATEGY - Static variable in class org.apache.nifi.processors.rethinkdb.PutRethinkDB
-
- CONFLICT_STRATEGY_ERROR - Static variable in class org.apache.nifi.processors.rethinkdb.PutRethinkDB
-
- CONFLICT_STRATEGY_REPLACE - Static variable in class org.apache.nifi.processors.rethinkdb.PutRethinkDB
-
- CONFLICT_STRATEGY_UPDATE - Static variable in class org.apache.nifi.processors.rethinkdb.PutRethinkDB
-
- ConflictingNodeIdException - Exception in org.apache.nifi.cluster.manager.exception
-
- ConflictingNodeIdException(String, String, int) - Constructor for exception org.apache.nifi.cluster.manager.exception.ConflictingNodeIdException
-
- confLocation - Variable in class org.apache.nifi.processors.kite.TestConfigurationProperty
-
- CONFLUENT_ENCODED_SCHEMA - Static variable in class org.apache.nifi.schema.access.SchemaAccessUtils
-
- ConfluentSchemaRegistry - Class in org.apache.nifi.confluent.schemaregistry
-
- ConfluentSchemaRegistry() - Constructor for class org.apache.nifi.confluent.schemaregistry.ConfluentSchemaRegistry
-
- ConfluentSchemaRegistryStrategy - Class in org.apache.nifi.schema.access
-
- ConfluentSchemaRegistryStrategy(SchemaRegistry) - Constructor for class org.apache.nifi.schema.access.ConfluentSchemaRegistryStrategy
-
- ConfluentSchemaRegistryWriter - Class in org.apache.nifi.schema.access
-
- ConfluentSchemaRegistryWriter() - Constructor for class org.apache.nifi.schema.access.ConfluentSchemaRegistryWriter
-
- connect(List<InetSocketAddress>, String, String, Long, boolean, String, String, long) - Method in class org.apache.nifi.cdc.mysql.processors.CaptureChangeMySQL
-
- connect() - Method in class org.apache.nifi.processors.mqtt.common.MqttTestClient
-
- connect(MqttConnectOptions) - Method in class org.apache.nifi.processors.mqtt.common.MqttTestClient
-
- connect(FTPUtils.FTPConfiguration, ProtocolCommandListener) - Static method in class org.apache.nifi.processors.standard.util.FTPUtils
-
Creates a new FTPClient connected to an FTP server.
- connect() - Method in class org.apache.nifi.remote.io.socket.ssl.SSLSocketChannel
-
- connect(String) - Method in class org.apache.nifi.websocket.jetty.JettyWebSocketClient
-
- connect(String) - Method in interface org.apache.nifi.websocket.WebSocketClientService
-
- CONNECT_TIMEOUT - Static variable in class org.apache.nifi.cdc.mysql.processors.CaptureChangeMySQL
-
- CONNECT_TIMEOUT - Static variable in class org.apache.nifi.processors.elasticsearch.AbstractElasticsearchHttpProcessor
-
- Connectable - Interface in org.apache.nifi.connectable
-
Represents a connectable component to which or from which data can flow.
- ConnectableDTO - Class in org.apache.nifi.web.api.dto
-
Details about a connectable component.
- ConnectableDTO() - Constructor for class org.apache.nifi.web.api.dto.ConnectableDTO
-
- ConnectableProcessContext - Class in org.apache.nifi.controller.scheduling
-
This class is essentially an empty shell for
Connectable
s that are not Processors
- ConnectableProcessContext(Connectable, StringEncryptor, StateManager) - Constructor for class org.apache.nifi.controller.scheduling.ConnectableProcessContext
-
- Connectables - Class in org.apache.nifi.util
-
- Connectables() - Constructor for class org.apache.nifi.util.Connectables
-
- ConnectableType - Enum in org.apache.nifi.connectable
-
- ConnectableTypeParameter - Class in org.apache.nifi.web.api.request
-
Class for parsing connectable types and providing user friendly messages.
- ConnectableTypeParameter(String) - Constructor for class org.apache.nifi.web.api.request.ConnectableTypeParameter
-
- ConnectDetails - Interface in org.apache.nifi.action.details
-
Provides details about a connect action.
- ConnectDetailsDTO - Class in org.apache.nifi.web.api.dto.action.details
-
Details for connect Actions.
- ConnectDetailsDTO() - Constructor for class org.apache.nifi.web.api.dto.action.details.ConnectDetailsDTO
-
- connected - Variable in class org.apache.nifi.processors.mqtt.common.MqttTestClient
-
- connected(WebSocketSessionInfo) - Method in class org.apache.nifi.processors.websocket.AbstractWebSocketGatewayProcessor
-
- connected(WebSocketSessionInfo) - Method in interface org.apache.nifi.websocket.ConnectedListener
-
- ConnectedListener - Interface in org.apache.nifi.websocket
-
To be performed when a WebSocket connection is established.
- ConnectFailure(HiveEndPoint, Throwable) - Constructor for exception org.apache.nifi.util.hive.HiveWriter.ConnectFailure
-
- ConnectingNodeMutableRequestException - Exception in org.apache.nifi.cluster.manager.exception
-
Represents the exceptional case when a HTTP request that may change a node's dataflow is to be replicated while a node is connecting to the cluster.
- ConnectingNodeMutableRequestException() - Constructor for exception org.apache.nifi.cluster.manager.exception.ConnectingNodeMutableRequestException
-
- ConnectingNodeMutableRequestException(String) - Constructor for exception org.apache.nifi.cluster.manager.exception.ConnectingNodeMutableRequestException
-
- ConnectingNodeMutableRequestException(Throwable) - Constructor for exception org.apache.nifi.cluster.manager.exception.ConnectingNodeMutableRequestException
-
- ConnectingNodeMutableRequestException(String, Throwable) - Constructor for exception org.apache.nifi.cluster.manager.exception.ConnectingNodeMutableRequestException
-
- ConnectingNodeMutableRequestExceptionMapper - Class in org.apache.nifi.web.api.config
-
Maps connecting node mutable request exceptions into client responses.
- ConnectingNodeMutableRequestExceptionMapper() - Constructor for class org.apache.nifi.web.api.config.ConnectingNodeMutableRequestExceptionMapper
-
- Connection - Interface in org.apache.nifi.connectable
-
- connection - Variable in class org.apache.nifi.processors.rethinkdb.ITAbstractRethinkDBTest
-
- CONNECTION_ATTEMPT_COUNT - Static variable in class org.apache.nifi.processors.gettcp.GetTCP
-
- CONNECTION_DESTINATION_ID - Static variable in interface org.apache.nifi.reporting.datadog.metrics.MetricNames
-
- CONNECTION_FACTORY_IMPL - Static variable in interface org.apache.nifi.jms.cf.JMSConnectionFactoryProviderDefinition
-
- CONNECTION_GROUP_ID - Static variable in interface org.apache.nifi.reporting.datadog.metrics.MetricNames
-
- CONNECTION_ID - Static variable in interface org.apache.nifi.reporting.datadog.metrics.MetricNames
-
- CONNECTION_MODE - Static variable in class org.apache.nifi.processors.standard.util.FTPTransfer
-
- CONNECTION_MODE_ACTIVE - Static variable in class org.apache.nifi.processors.standard.util.FTPTransfer
-
- CONNECTION_MODE_KEY - Static variable in class org.apache.nifi.processors.standard.util.FTPUtils
-
- CONNECTION_MODE_PASSIVE - Static variable in class org.apache.nifi.processors.standard.util.FTPTransfer
-
- CONNECTION_NAME - Static variable in interface org.apache.nifi.reporting.datadog.metrics.MetricNames
-
- CONNECTION_PER_FLOWFILE - Static variable in class org.apache.nifi.processor.util.put.AbstractPutEventProcessor
-
- CONNECTION_SOURCE_ID - Static variable in interface org.apache.nifi.reporting.datadog.metrics.MetricNames
-
- CONNECTION_SOURCE_NAME - Static variable in interface org.apache.nifi.reporting.datadog.metrics.MetricNames
-
- CONNECTION_STATUS_HISTORY_URI_PATTERN - Static variable in class org.apache.nifi.cluster.coordination.http.endpoints.StatusHistoryEndpointMerger
-
- CONNECTION_STATUS_URI_PATTERN - Static variable in class org.apache.nifi.cluster.coordination.http.endpoints.ConnectionStatusEndpointMerger
-
- CONNECTION_STRING - Static variable in class org.apache.nifi.couchbase.CouchbaseClusterService
-
- CONNECTION_STRING - Static variable in class org.apache.nifi.redis.util.RedisUtils
-
- CONNECTION_TIMEOUT - Static variable in class org.apache.nifi.processors.standard.GetHTTP
-
- CONNECTION_TIMEOUT - Static variable in class org.apache.nifi.processors.standard.PostHTTP
-
- CONNECTION_TIMEOUT - Static variable in interface org.apache.nifi.processors.standard.util.FileTransfer
-
- CONNECTION_TIMEOUT - Static variable in class org.apache.nifi.websocket.jetty.JettyWebSocketClient
-
- CONNECTION_URI_PATTERN - Static variable in class org.apache.nifi.cluster.coordination.http.endpoints.ConnectionEndpointMerger
-
- ConnectionAuthorizable - Interface in org.apache.nifi.authorization
-
Authorizable for a Connection and its Group, Source, and Destination.
- ConnectionCheckServlet() - Constructor for class org.apache.nifi.websocket.example.WebSocketServerExample.ConnectionCheckServlet
-
- connectionCompleted() - Method in class org.apache.nifi.record.listen.SocketChannelRecordReaderDispatcher
-
- ConnectionDAO - Interface in org.apache.nifi.web.dao
-
- ConnectionDTO - Class in org.apache.nifi.web.api.dto
-
A connection between two connectable components.
- ConnectionDTO() - Constructor for class org.apache.nifi.web.api.dto.ConnectionDTO
-
- ConnectionEndpointMerger - Class in org.apache.nifi.cluster.coordination.http.endpoints
-
- ConnectionEndpointMerger() - Constructor for class org.apache.nifi.cluster.coordination.http.endpoints.ConnectionEndpointMerger
-
- ConnectionEntity - Class in org.apache.nifi.web.api.entity
-
A serialized representation of this class can be placed in the entity body of a response to the API.
- ConnectionEntity() - Constructor for class org.apache.nifi.web.api.entity.ConnectionEntity
-
- ConnectionEntityMerger - Class in org.apache.nifi.cluster.manager
-
- ConnectionEntityMerger() - Constructor for class org.apache.nifi.cluster.manager.ConnectionEntityMerger
-
- ConnectionException - Exception in org.apache.nifi.cluster
-
Represents the exceptional case when connection to the cluster fails.
- ConnectionException(String, Throwable, boolean, boolean) - Constructor for exception org.apache.nifi.cluster.ConnectionException
-
- ConnectionException() - Constructor for exception org.apache.nifi.cluster.ConnectionException
-
- ConnectionException(String) - Constructor for exception org.apache.nifi.cluster.ConnectionException
-
- ConnectionException(Throwable) - Constructor for exception org.apache.nifi.cluster.ConnectionException
-
- ConnectionException(String, Throwable) - Constructor for exception org.apache.nifi.cluster.ConnectionException
-
- ConnectionRequest - Class in org.apache.nifi.cluster.protocol
-
A node's request to connect to the cluster.
- ConnectionRequest(NodeIdentifier, DataFlow) - Constructor for class org.apache.nifi.cluster.protocol.ConnectionRequest
-
- ConnectionRequestAdapter - Class in org.apache.nifi.cluster.protocol.jaxb.message
-
- ConnectionRequestAdapter() - Constructor for class org.apache.nifi.cluster.protocol.jaxb.message.ConnectionRequestAdapter
-
- ConnectionRequestMessage - Class in org.apache.nifi.cluster.protocol.message
-
- ConnectionRequestMessage() - Constructor for class org.apache.nifi.cluster.protocol.message.ConnectionRequestMessage
-
- ConnectionResource - Class in org.apache.nifi.web.api
-
RESTful endpoint for managing a Connection.
- ConnectionResource() - Constructor for class org.apache.nifi.web.api.ConnectionResource
-
- ConnectionResponse - Class in org.apache.nifi.cluster.protocol
-
The cluster manager's response to a node's connection request.
- ConnectionResponse(NodeIdentifier, DataFlow, String, List<NodeConnectionStatus>, List<ComponentRevision>) - Constructor for class org.apache.nifi.cluster.protocol.ConnectionResponse
-
- ConnectionResponse(int, String) - Constructor for class org.apache.nifi.cluster.protocol.ConnectionResponse
-
- ConnectionResponseAdapter - Class in org.apache.nifi.cluster.protocol.jaxb.message
-
- ConnectionResponseAdapter() - Constructor for class org.apache.nifi.cluster.protocol.jaxb.message.ConnectionResponseAdapter
-
- ConnectionResponseMessage - Class in org.apache.nifi.cluster.protocol.message
-
- ConnectionResponseMessage() - Constructor for class org.apache.nifi.cluster.protocol.message.ConnectionResponseMessage
-
- CONNECTIONS_URI_PATTERN - Static variable in class org.apache.nifi.cluster.coordination.http.endpoints.ConnectionEndpointMerger
-
- CONNECTIONS_URI_PATTERN - Static variable in class org.apache.nifi.cluster.coordination.http.endpoints.ConnectionsEndpointMerger
-
- ConnectionsEndpointMerger - Class in org.apache.nifi.cluster.coordination.http.endpoints
-
- ConnectionsEndpointMerger() - Constructor for class org.apache.nifi.cluster.coordination.http.endpoints.ConnectionsEndpointMerger
-
- ConnectionsEntity - Class in org.apache.nifi.web.api.entity
-
A serialized representation of this class can be placed in the entity body of a response to the API.
- ConnectionsEntity() - Constructor for class org.apache.nifi.web.api.entity.ConnectionsEntity
-
- ConnectionsEntityMerger - Class in org.apache.nifi.cluster.manager
-
- ConnectionsEntityMerger() - Constructor for class org.apache.nifi.cluster.manager.ConnectionsEntityMerger
-
- ConnectionStatus - Class in org.apache.nifi.controller.status
-
- ConnectionStatus() - Constructor for class org.apache.nifi.controller.status.ConnectionStatus
-
- ConnectionStatusDescriptor - Enum in org.apache.nifi.controller.status.history
-
- ConnectionStatusDTO - Class in org.apache.nifi.web.api.dto.status
-
- ConnectionStatusDTO() - Constructor for class org.apache.nifi.web.api.dto.status.ConnectionStatusDTO
-
- ConnectionStatusEndpointMerger - Class in org.apache.nifi.cluster.coordination.http.endpoints
-
- ConnectionStatusEndpointMerger() - Constructor for class org.apache.nifi.cluster.coordination.http.endpoints.ConnectionStatusEndpointMerger
-
- ConnectionStatusEntity - 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.
- ConnectionStatusEntity() - Constructor for class org.apache.nifi.web.api.entity.ConnectionStatusEntity
-
- ConnectionStatusSnapshotDTO - Class in org.apache.nifi.web.api.dto.status
-
DTO for serializing the status of a connection.
- ConnectionStatusSnapshotDTO() - Constructor for class org.apache.nifi.web.api.dto.status.ConnectionStatusSnapshotDTO
-
- ConnectionStatusSnapshotEntity - 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.
- ConnectionStatusSnapshotEntity() - Constructor for class org.apache.nifi.web.api.entity.ConnectionStatusSnapshotEntity
-
- connectionType(InetAddress) - Method in class org.apache.nifi.lookup.maxmind.DatabaseReader
-
Look up an IP address in a GeoIP2 Connection Type database.
- connectionType(InetAddress) - Method in class org.apache.nifi.processors.maxmind.DatabaseReader
-
Look up an IP address in a GeoIP2 Connection Type database.
- connectSftp(SFTPUtils.SFTPConfiguration) - Static method in class org.apache.nifi.processors.standard.util.SFTPUtils
-
- connectSocket(int, Socket, HttpHost, InetSocketAddress, InetSocketAddress, HttpContext) - Method in class org.apache.nifi.toolkit.tls.service.client.TlsCertificateAuthorityClientSocketFactory
-
- CONNECTTION_DESTINATION_NAME - Static variable in interface org.apache.nifi.reporting.datadog.metrics.MetricNames
-
- connectToCassandra(ProcessContext) - Method in class org.apache.nifi.processors.cassandra.AbstractCassandraProcessor
-
- ConnectWebSocket - Class in org.apache.nifi.processors.websocket
-
- ConnectWebSocket() - Constructor for class org.apache.nifi.processors.websocket.ConnectWebSocket
-
- connectWithResult(MqttConnectOptions) - Method in class org.apache.nifi.processors.mqtt.common.MqttTestClient
-
- connOpts - Variable in class org.apache.nifi.processors.mqtt.common.AbstractMQTTProcessor
-
- consecutiveAndMixedCRLF() - Method in class org.apache.nifi.stream.io.util.TextLineDemarcatorTest
-
- CONSISTENCY_LEVEL - Static variable in class org.apache.nifi.processors.cassandra.AbstractCassandraProcessor
-
- ConsoleException - Exception in org.apache.nifi.util.console
-
Runtime exception for handling console errors.
- ConsoleException(Throwable) - Constructor for exception org.apache.nifi.util.console.ConsoleException
-
- constructorConfig() - Method in class org.apache.nifi.provenance.TestPersistentProvenanceRepository
-
- constructorNiFiProperties() - Method in class org.apache.nifi.provenance.TestPersistentProvenanceRepository
-
- constructorNoArgs() - Method in class org.apache.nifi.provenance.TestPersistentProvenanceRepository
-
- constructProcess() - Method in class org.apache.nifi.processors.hive.PutHiveQL
-
- constructProcess() - Method in class org.apache.nifi.processors.standard.PutSQL
-
- consume(ProcessContext, ProcessSession, WrappedMessageConsumer) - Method in class org.apache.nifi.processors.standard.JmsConsumer
-
- consume(WebSocketSessionInfo, String) - Method in class org.apache.nifi.processors.websocket.AbstractWebSocketGatewayProcessor
-
- consume(WebSocketSessionInfo, byte[], int, int) - Method in class org.apache.nifi.processors.websocket.AbstractWebSocketGatewayProcessor
-
- consume() - Method in class org.apache.nifi.remote.io.http.HttpInput
-
- consume() - Method in class org.apache.nifi.remote.io.socket.SocketChannelInput
-
- consume() - Method in class org.apache.nifi.remote.io.socket.SocketChannelInputStream
-
- consume() - Method in class org.apache.nifi.remote.io.socket.ssl.SSLSocketChannel
-
- consume() - Method in class org.apache.nifi.remote.io.socket.ssl.SSLSocketChannelInput
-
- consume() - Method in class org.apache.nifi.remote.io.socket.ssl.SSLSocketChannelInputStream
-
- consume() - Method in interface org.apache.nifi.remote.protocol.CommunicationsInput
-
Reads all data currently on the socket and throws it away
- consume(WebSocketSessionInfo, byte[], int, int) - Method in interface org.apache.nifi.websocket.BinaryMessageConsumer
-
- consume(WebSocketSessionInfo, String) - Method in interface org.apache.nifi.websocket.TextMessageConsumer
-
- ConsumeAMQP - Class in org.apache.nifi.amqp.processors
-
Consuming AMQP processor which upon each invocation of
AbstractAMQPProcessor.onTrigger(ProcessContext, ProcessSession)
method will construct a
FlowFile
containing the body of the consumed AMQP message and AMQP
properties that came with message which are added to a
FlowFile
as
attributes.
- ConsumeAMQP() - Constructor for class org.apache.nifi.amqp.processors.ConsumeAMQP
-
- ConsumeAMQPTest - Class in org.apache.nifi.amqp.processors
-
- ConsumeAMQPTest() - Constructor for class org.apache.nifi.amqp.processors.ConsumeAMQPTest
-
- ConsumeAMQPTest.LocalConsumeAMQP - Class in org.apache.nifi.amqp.processors
-
- CONSUMED_COUNT_NAME - Static variable in class org.apache.nifi.processors.standard.WaitNotifyProtocol
-
- ConsumeEWS - Class in org.apache.nifi.processors.email
-
- ConsumeEWS() - Constructor for class org.apache.nifi.processors.email.ConsumeEWS
-
- ConsumeIMAP - Class in org.apache.nifi.processors.email
-
- ConsumeIMAP() - Constructor for class org.apache.nifi.processors.email.ConsumeIMAP
-
- ConsumeJMS - Class in org.apache.nifi.jms.processors
-
Consuming JMS processor which upon each invocation of
AbstractJMSProcessor.onTrigger(ProcessContext, ProcessSession)
method will construct a
FlowFile
containing the body of the consumed JMS message and JMS
properties that came with message which are added to a
FlowFile
as
attributes.
- ConsumeJMS() - Constructor for class org.apache.nifi.jms.processors.ConsumeJMS
-
- ConsumeJMSTest - Class in org.apache.nifi.jms.processors
-
- ConsumeJMSTest() - Constructor for class org.apache.nifi.jms.processors.ConsumeJMSTest
-
- ConsumeKafka - Class in org.apache.nifi.processors.kafka.pubsub
-
- ConsumeKafka() - Constructor for class org.apache.nifi.processors.kafka.pubsub.ConsumeKafka
-
- ConsumeKafka_0_10 - Class in org.apache.nifi.processors.kafka.pubsub
-
- ConsumeKafka_0_10() - Constructor for class org.apache.nifi.processors.kafka.pubsub.ConsumeKafka_0_10
-
- ConsumeKafka_0_11 - Class in org.apache.nifi.processors.kafka.pubsub
-
- ConsumeKafka_0_11() - Constructor for class org.apache.nifi.processors.kafka.pubsub.ConsumeKafka_0_11
-
- ConsumeKafkaRecord_0_10 - Class in org.apache.nifi.processors.kafka.pubsub
-
- ConsumeKafkaRecord_0_10() - Constructor for class org.apache.nifi.processors.kafka.pubsub.ConsumeKafkaRecord_0_10
-
- ConsumeKafkaRecord_0_11 - Class in org.apache.nifi.processors.kafka.pubsub
-
- ConsumeKafkaRecord_0_11() - Constructor for class org.apache.nifi.processors.kafka.pubsub.ConsumeKafkaRecord_0_11
-
- ConsumeKafkaTest - Class in org.apache.nifi.processors.kafka.pubsub
-
- ConsumeKafkaTest() - Constructor for class org.apache.nifi.processors.kafka.pubsub.ConsumeKafkaTest
-
- ConsumeMQTT - Class in org.apache.nifi.processors.mqtt
-
- ConsumeMQTT() - Constructor for class org.apache.nifi.processors.mqtt.ConsumeMQTT
-
- ConsumePOP3 - Class in org.apache.nifi.processors.email
-
- ConsumePOP3() - Constructor for class org.apache.nifi.processors.email.ConsumePOP3
-
- CONSUMER_KEY - Static variable in class org.apache.nifi.processors.twitter.GetTwitter
-
- CONSUMER_SECRET - Static variable in class org.apache.nifi.processors.twitter.GetTwitter
-
- ConsumerLease - Class in org.apache.nifi.processors.kafka.pubsub
-
This class represents a lease to access a Kafka Consumer object.
- ConsumerPool - Class in org.apache.nifi.processors.kafka.pubsub
-
A pool of Kafka Consumers for a given topic.
- ConsumerPool(int, byte[], Map<String, Object>, List<String>, long, String, String, String, ComponentLog) - Constructor for class org.apache.nifi.processors.kafka.pubsub.ConsumerPool
-
Creates a pool of KafkaConsumer objects that will grow up to the maximum
indicated threads from the given context.
- ConsumerPoolTest - Class in org.apache.nifi.processors.kafka.pubsub
-
- ConsumerPoolTest() - Constructor for class org.apache.nifi.processors.kafka.pubsub.ConsumerPoolTest
-
- ConsumerRunner(StreamConsumer) - Constructor for class org.apache.nifi.io.nio.example.ServerMain.ConsumerRunner
-
- ConsumeWindowsEventLog - Class in org.apache.nifi.processors.windows.event.log
-
- ConsumeWindowsEventLog() - Constructor for class org.apache.nifi.processors.windows.event.log.ConsumeWindowsEventLog
-
Framework constructor
- ConsumeWindowsEventLog(WEvtApi, Kernel32) - Constructor for class org.apache.nifi.processors.windows.event.log.ConsumeWindowsEventLog
-
Constructor that allows injection of JNA interfaces
- ConsumeWindowsEventLogFailTest - Class in org.apache.nifi.processors.windows.event.log
-
Test scenario where we can't load the native libraries
- ConsumeWindowsEventLogFailTest() - Constructor for class org.apache.nifi.processors.windows.event.log.ConsumeWindowsEventLogFailTest
-
- ConsumeWindowsEventLogTest - Class in org.apache.nifi.processors.windows.event.log
-
- ConsumeWindowsEventLogTest() - Constructor for class org.apache.nifi.processors.windows.event.log.ConsumeWindowsEventLogTest
-
- CONTACT_POINTS - Static variable in class org.apache.nifi.processors.cassandra.AbstractCassandraProcessor
-
- CONTAINER - Static variable in class org.apache.nifi.processors.azure.AzureConstants
-
- CONTAINER_ARRAY - Static variable in class org.apache.nifi.processors.avro.ConvertAvroToJSON
-
- CONTAINER_NAME - Static variable in class org.apache.nifi.controller.repository.VolatileContentRepository
-
- CONTAINER_NAME - Static variable in class org.apache.nifi.provenance.VolatileProvenanceRepository
-
- CONTAINER_NONE - Static variable in class org.apache.nifi.processors.avro.ConvertAvroToJSON
-
- CONTAINER_QUEUE_SIZE - Static variable in class org.apache.nifi.processors.standard.HandleHttpRequest
-
- ContainerSchema - Class in org.apache.nifi.lookup.maxmind
-
- ContainerSchema() - Constructor for class org.apache.nifi.lookup.maxmind.ContainerSchema
-
- contains(T, Serializer<T>) - Method in interface org.apache.nifi.distributed.cache.client.DistributedSetCacheClient
-
- contains(T, Serializer<T>) - Method in class org.apache.nifi.distributed.cache.client.DistributedSetCacheClientService
-
- contains(ByteBuffer) - Method in class org.apache.nifi.distributed.cache.server.set.PersistentSetCache
-
- contains(ByteBuffer) - Method in interface org.apache.nifi.distributed.cache.server.set.SetCache
-
- contains(ByteBuffer) - Method in class org.apache.nifi.distributed.cache.server.set.SimpleSetCache
-
- contains(ResultCell) - Method in class org.apache.nifi.hbase.GetHBase.ScanResult
-
- contains(Relationship) - Method in class org.apache.nifi.processor.util.pattern.RoutingResult
-
- CONTAINS - Static variable in class org.apache.nifi.processors.standard.RouteText
-
- Contains - Class in org.apache.nifi.record.path.filter
-
- Contains(RecordPathSegment, RecordPathSegment) - Constructor for class org.apache.nifi.record.path.filter.Contains
-
- CONTAINS_REGULAR_EXPRESSION - Static variable in class org.apache.nifi.processors.standard.RouteText
-
- ContainsEvaluator - Class in org.apache.nifi.attribute.expression.language.evaluation.functions
-
- ContainsEvaluator(Evaluator<String>, Evaluator<String>) - Constructor for class org.apache.nifi.attribute.expression.language.evaluation.functions.ContainsEvaluator
-
- containsInputPort(String) - Method in class org.apache.nifi.remote.StandardRemoteProcessGroup
-
- containsKey(Object) - Method in class org.apache.nifi.attribute.expression.language.AttributesAndState
-
- containsKey(K, Serializer<K>) - Method in interface org.apache.nifi.distributed.cache.client.DistributedMapCacheClient
-
Determines if the given value is present in the cache and if so returns
true
, else returns false
- containsKey(K, Serializer<K>) - Method in class org.apache.nifi.distributed.cache.client.DistributedMapCacheClientService
-
- containsKey(ByteBuffer) - Method in interface org.apache.nifi.distributed.cache.server.map.MapCache
-
- containsKey(ByteBuffer) - Method in class org.apache.nifi.distributed.cache.server.map.PersistentMapCache
-
- containsKey(ByteBuffer) - Method in class org.apache.nifi.distributed.cache.server.map.SimpleMapCache
-
- containsKey(K, Serializer<K>) - Method in class org.apache.nifi.hbase.HBase_1_1_2_ClientMapCacheService
-
- containsKey(K, Serializer<K>) - Method in class org.apache.nifi.redis.service.RedisDistributedMapCacheClientService
-
- containsMessage() - Method in enum org.apache.nifi.remote.protocol.ResponseCode
-
- containsOldBins() - Method in class org.apache.nifi.processor.util.bin.BinManager
-
- containsOutputPort(String) - Method in class org.apache.nifi.remote.StandardRemoteProcessGroup
-
Returns a boolean indicating whether or not an Output Port exists with
the given ID
- ContainsRegex - Class in org.apache.nifi.record.path.filter
-
- ContainsRegex(RecordPathSegment, RecordPathSegment) - Constructor for class org.apache.nifi.record.path.filter.ContainsRegex
-
- containsSession(String) - Method in class org.apache.nifi.websocket.WebSocketMessageRouter
-
- containsValue(Object) - Method in class org.apache.nifi.attribute.expression.language.AttributesAndState
-
- CONTENT_ARCHIVE_BACK_PRESSURE_PERCENTAGE - Static variable in class org.apache.nifi.util.NiFiProperties
-
- CONTENT_ARCHIVE_CLEANUP_FREQUENCY - Static variable in class org.apache.nifi.util.NiFiProperties
-
- CONTENT_ARCHIVE_ENABLED - Static variable in class org.apache.nifi.util.NiFiProperties
-
- CONTENT_ARCHIVE_MAX_RETENTION_PERIOD - Static variable in class org.apache.nifi.util.NiFiProperties
-
- CONTENT_ARCHIVE_MAX_USAGE_PERCENTAGE - Static variable in class org.apache.nifi.util.NiFiProperties
-
- CONTENT_CLAIM - Static variable in class org.apache.nifi.controller.repository.schema.FlowFileSchema
-
- CONTENT_CLAIM - Static variable in class org.apache.nifi.provenance.schema.EventFieldNames
-
- CONTENT_CLAIM_CONTAINER - Static variable in class org.apache.nifi.provenance.schema.EventFieldNames
-
- CONTENT_CLAIM_CONTAINER - Static variable in class org.apache.nifi.provenance.schema.EventRecordFields
-
- CONTENT_CLAIM_CONTAINER - Static variable in class org.apache.nifi.provenance.schema.LookupTableEventRecordFields
-
- CONTENT_CLAIM_IDENTIFIER - Static variable in class org.apache.nifi.provenance.schema.EventFieldNames
-
- CONTENT_CLAIM_IDENTIFIER - Static variable in class org.apache.nifi.provenance.schema.EventRecordFields
-
- CONTENT_CLAIM_IDENTIFIER - Static variable in class org.apache.nifi.provenance.schema.LookupTableEventRecordFields
-
- CONTENT_CLAIM_LENGTH - Static variable in class org.apache.nifi.controller.repository.schema.ContentClaimSchema
-
- CONTENT_CLAIM_OFFSET - Static variable in class org.apache.nifi.controller.repository.schema.ContentClaimSchema
-
- CONTENT_CLAIM_OFFSET - Static variable in class org.apache.nifi.provenance.schema.EventFieldNames
-
- CONTENT_CLAIM_OFFSET - Static variable in class org.apache.nifi.provenance.schema.EventRecordFields
-
- CONTENT_CLAIM_OFFSET - Static variable in class org.apache.nifi.provenance.schema.LookupTableEventRecordFields
-
- CONTENT_CLAIM_SCHEMA - Static variable in class org.apache.nifi.provenance.schema.LookupTableEventSchema
-
- CONTENT_CLAIM_SCHEMA_V1 - Static variable in class org.apache.nifi.controller.repository.schema.ContentClaimSchema
-
- CONTENT_CLAIM_SECTION - Static variable in class org.apache.nifi.provenance.schema.EventFieldNames
-
- CONTENT_CLAIM_SECTION - Static variable in class org.apache.nifi.provenance.schema.EventRecordFields
-
- CONTENT_CLAIM_SECTION - Static variable in class org.apache.nifi.provenance.schema.LookupTableEventRecordFields
-
- CONTENT_CLAIM_SIZE - Static variable in class org.apache.nifi.provenance.schema.EventFieldNames
-
- CONTENT_CLAIM_SIZE - Static variable in class org.apache.nifi.provenance.schema.EventRecordFields
-
- CONTENT_CLAIM_SIZE - Static variable in class org.apache.nifi.provenance.schema.LookupTableEventRecordFields
-
- CONTENT_DISPOSITION_ATTR - Static variable in class org.apache.nifi.processors.gcp.storage.StorageAttributes
-
- CONTENT_DISPOSITION_DESC - Static variable in class org.apache.nifi.processors.gcp.storage.StorageAttributes
-
- CONTENT_DISPOSITION_TYPE - Static variable in class org.apache.nifi.processors.gcp.storage.PutGCSObject
-
- CONTENT_ENCODING - Static variable in class org.apache.nifi.remote.protocol.http.HttpHeaders
-
- CONTENT_ENCODING_ATTR - Static variable in class org.apache.nifi.processors.gcp.storage.StorageAttributes
-
- CONTENT_ENCODING_DESC - Static variable in class org.apache.nifi.processors.gcp.storage.StorageAttributes
-
- CONTENT_ENCODING_GZIP_VALUE - Static variable in class org.apache.nifi.processors.standard.PostHTTP
-
- CONTENT_ENCODING_HEADER - Static variable in class org.apache.nifi.processors.standard.PostHTTP
-
- CONTENT_LANGUAGE_ATTR - Static variable in class org.apache.nifi.processors.gcp.storage.StorageAttributes
-
- CONTENT_LANGUAGE_DESC - Static variable in class org.apache.nifi.processors.gcp.storage.StorageAttributes
-
- CONTENT_REPOSITORY_IMPLEMENTATION - Static variable in class org.apache.nifi.util.NiFiProperties
-
- CONTENT_REQUEST_ATTRIBUTE - Static variable in interface org.apache.nifi.web.ViewableContent
-
- CONTENT_STREAM_PATH - Static variable in class org.apache.nifi.processors.solr.PutSolrContentStream
-
- CONTENT_TYPE - Static variable in class org.apache.nifi.bootstrap.notification.email.EmailNotificationService
-
- CONTENT_TYPE - Static variable in class org.apache.nifi.processors.aws.s3.PutS3Object
-
- CONTENT_TYPE - Static variable in class org.apache.nifi.processors.gcp.storage.PutGCSObject
-
- CONTENT_TYPE - Static variable in class org.apache.nifi.processors.solr.PutSolrContentStream
-
- CONTENT_TYPE - Static variable in class org.apache.nifi.processors.standard.PostHTTP
-
- CONTENT_TYPE - Static variable in class org.apache.nifi.processors.standard.PutEmail
-
- CONTENT_TYPE - Static variable in class org.apache.nifi.remote.StandardRemoteGroupPort
-
- CONTENT_TYPE_HEADER - Static variable in class org.apache.nifi.processors.standard.PostHTTP
-
- CONTENT_VIEWER_URL - Static variable in class org.apache.nifi.util.NiFiProperties
-
- ContentAccess - Interface in org.apache.nifi.web
-
Provides access to content within NiFi.
- ContentAcknowledgmentServlet - Class in org.apache.nifi.processors.standard.servlets
-
- ContentAcknowledgmentServlet() - Constructor for class org.apache.nifi.processors.standard.servlets.ContentAcknowledgmentServlet
-
- ContentAvailability - Interface in org.apache.nifi.controller
-
Provides information about whether or not the data referenced in a Provenance
Event can be replayed or downloaded
- ContentClaim - Interface in org.apache.nifi.controller.repository.claim
-
A reference to a section of a
ResourceClaim
, which may or may not encompass
the entire ResourceClaim.
- contentClaim(ContentClaim) - Method in class org.apache.nifi.controller.repository.StandardFlowFileRecord.Builder
-
- ContentClaimContainer - Static variable in class org.apache.nifi.provenance.SearchableFields
-
- ContentClaimFieldMap - Class in org.apache.nifi.controller.repository.schema
-
- ContentClaimFieldMap(ContentClaim, long, RecordSchema) - Constructor for class org.apache.nifi.controller.repository.schema.ContentClaimFieldMap
-
- ContentClaimIdentifier - Static variable in class org.apache.nifi.provenance.SearchableFields
-
- contentClaimOffset(long) - Method in class org.apache.nifi.controller.repository.StandardFlowFileRecord.Builder
-
- ContentClaimOffset - Static variable in class org.apache.nifi.provenance.SearchableFields
-
- ContentClaimSchema - Class in org.apache.nifi.controller.repository.schema
-
- ContentClaimSchema() - Constructor for class org.apache.nifi.controller.repository.schema.ContentClaimSchema
-
- ContentClaimSection - Static variable in class org.apache.nifi.provenance.SearchableFields
-
- ContentClaimWriteCache - Class in org.apache.nifi.controller.repository.claim
-
- ContentClaimWriteCache(ContentRepository) - Constructor for class org.apache.nifi.controller.repository.claim.ContentClaimWriteCache
-
- ContentClaimWriteCache(ContentRepository, int) - Constructor for class org.apache.nifi.controller.repository.claim.ContentClaimWriteCache
-
- ContentDirection - Enum in org.apache.nifi.controller.repository.claim
-
Specifies one side of the Provenance Event for which the Content Claim is being referenced
- contentLanguage(String) - Method in class org.apache.nifi.processors.azure.storage.utils.BlobInfo.Builder
-
- ContentNotFoundException - Exception in org.apache.nifi.controller.repository
-
- ContentNotFoundException(ContentClaim) - Constructor for exception org.apache.nifi.controller.repository.ContentNotFoundException
-
- ContentNotFoundException(ContentClaim, Throwable) - Constructor for exception org.apache.nifi.controller.repository.ContentNotFoundException
-
- ContentNotFoundException(ContentClaim, String) - Constructor for exception org.apache.nifi.controller.repository.ContentNotFoundException
-
- ContentRepository - Interface in org.apache.nifi.controller.repository
-
Defines the capabilities of a content repository.
- ContentRequestContext - Interface in org.apache.nifi.web
-
A request for content.
- contentType(String) - Method in class org.apache.nifi.processors.azure.storage.utils.BlobInfo.Builder
-
- ContentViewerController - Class in org.apache.nifi.web
-
Controller servlet for viewing content.
- ContentViewerController() - Constructor for class org.apache.nifi.web.ContentViewerController
-
- CONTEXT_ATTRIBUTE_AUTHORITY_PATTERN - Static variable in class org.apache.nifi.processors.standard.ListenHTTP
-
- CONTEXT_ATTRIBUTE_BASE_PATH - Static variable in class org.apache.nifi.processors.standard.ListenHTTP
-
- CONTEXT_ATTRIBUTE_FLOWFILE_MAP - Static variable in class org.apache.nifi.processors.standard.ListenHTTP
-
- CONTEXT_ATTRIBUTE_HEADER_PATTERN - Static variable in class org.apache.nifi.processors.standard.ListenHTTP
-
- CONTEXT_ATTRIBUTE_LOGGER - Static variable in class org.apache.nifi.processors.standard.ListenHTTP
-
- CONTEXT_ATTRIBUTE_PROCESS_CONTEXT_HOLDER - Static variable in class org.apache.nifi.processors.standard.ListenHTTP
-
- CONTEXT_ATTRIBUTE_PROCESSOR - Static variable in class org.apache.nifi.processors.standard.ListenHTTP
-
- CONTEXT_ATTRIBUTE_SESSION_FACTORY_HOLDER - Static variable in class org.apache.nifi.processors.standard.ListenHTTP
-
- CONTEXT_ATTRIBUTE_STREAM_THROTTLER - Static variable in class org.apache.nifi.processors.standard.ListenHTTP
-
- contextDestroyed(ServletContextEvent) - Method in class org.apache.nifi.web.contextlistener.ApplicationStartupContextListener
-
- contextInitialized(ServletContextEvent) - Method in class org.apache.nifi.web.contextlistener.ApplicationStartupContextListener
-
- CONTINUALLY_SEND_MESSAGES - Static variable in class org.apache.nifi.processors.standard.MonitorActivity
-
- ContinuallyRunConnectableTask - Class in org.apache.nifi.controller.tasks
-
Continually runs a Connectable as long as the processor has work to do.
- ContinuallyRunConnectableTask(ProcessContextFactory, Connectable, ScheduleState, ProcessContext) - Constructor for class org.apache.nifi.controller.tasks.ContinuallyRunConnectableTask
-
- ContinuallyRunProcessorTask - Class in org.apache.nifi.controller.tasks
-
Continually runs a processor as long as the processor has work to do.
- ContinuallyRunProcessorTask(SchedulingAgent, ProcessorNode, FlowController, ProcessContextFactory, ScheduleState, StandardProcessContext) - Constructor for class org.apache.nifi.controller.tasks.ContinuallyRunProcessorTask
-
- CONTROLLER_ARCHIVE_URI_PATTERN - Static variable in class org.apache.nifi.cluster.coordination.http.endpoints.ProcessGroupEndpointMerger
-
- CONTROLLER_BULLETINS_URI_PATTERN - Static variable in class org.apache.nifi.cluster.coordination.http.endpoints.ControllerBulletinsEndpointMerger
-
- CONTROLLER_CONFIGURATION_URI_PATTERN - Static variable in class org.apache.nifi.cluster.coordination.http.endpoints.ControllerConfigurationEndpointMerger
-
- CONTROLLER_CONTROLLER_SERVICES_URI - Static variable in class org.apache.nifi.cluster.coordination.http.endpoints.ControllerServiceEndpointMerger
-
- CONTROLLER_SERVICE_REFERENCES_URI_PATTERN - Static variable in class org.apache.nifi.cluster.coordination.http.endpoints.ControllerServiceReferenceEndpointMerger
-
- CONTROLLER_SERVICE_STATE_URI_PATTERN - Static variable in class org.apache.nifi.cluster.coordination.http.endpoints.ComponentStateEndpointMerger
-
- CONTROLLER_SERVICE_TYPES_URI_PATTERN - Static variable in class org.apache.nifi.cluster.coordination.http.endpoints.ControllerServiceTypesEndpointMerger
-
- CONTROLLER_SERVICE_URI_PATTERN - Static variable in class org.apache.nifi.cluster.coordination.http.endpoints.ControllerServiceEndpointMerger
-
- CONTROLLER_SERVICES_URI - Static variable in class org.apache.nifi.cluster.coordination.http.endpoints.ControllerServicesEndpointMerger
-
- CONTROLLER_STATUS_URI_PATTERN - Static variable in class org.apache.nifi.cluster.coordination.http.endpoints.ControllerStatusEndpointMerger
-
- CONTROLLER_URI_PATTERN - Static variable in class org.apache.nifi.cluster.coordination.http.endpoints.ControllerEndpointMerger
-
- ControllerAuditor - Class in org.apache.nifi.audit
-
Audits configuration changes to the controller.
- ControllerAuditor() - Constructor for class org.apache.nifi.audit.ControllerAuditor
-
- ControllerBulletinsEndpointMerger - Class in org.apache.nifi.cluster.coordination.http.endpoints
-
- ControllerBulletinsEndpointMerger() - Constructor for class org.apache.nifi.cluster.coordination.http.endpoints.ControllerBulletinsEndpointMerger
-
- ControllerBulletinsEntity - 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.
- ControllerBulletinsEntity() - Constructor for class org.apache.nifi.web.api.entity.ControllerBulletinsEntity
-
- ControllerConfigurationDTO - Class in org.apache.nifi.web.api.dto
-
Details for the controller configuration.
- ControllerConfigurationDTO() - Constructor for class org.apache.nifi.web.api.dto.ControllerConfigurationDTO
-
- ControllerConfigurationEndpointMerger - Class in org.apache.nifi.cluster.coordination.http.endpoints
-
- ControllerConfigurationEndpointMerger() - Constructor for class org.apache.nifi.cluster.coordination.http.endpoints.ControllerConfigurationEndpointMerger
-
- ControllerConfigurationEntity - 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.
- ControllerConfigurationEntity() - Constructor for class org.apache.nifi.web.api.entity.ControllerConfigurationEntity
-
- ControllerDTO - Class in org.apache.nifi.web.api.dto
-
Configuration details for a NiFi controller.
- ControllerDTO() - Constructor for class org.apache.nifi.web.api.dto.ControllerDTO
-
- ControllerEndpointMerger - Class in org.apache.nifi.cluster.coordination.http.endpoints
-
- ControllerEndpointMerger() - Constructor for class org.apache.nifi.cluster.coordination.http.endpoints.ControllerEndpointMerger
-
- ControllerEntity - 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.
- ControllerEntity() - Constructor for class org.apache.nifi.web.api.entity.ControllerEntity
-
- ControllerFacade - Class in org.apache.nifi.web.controller
-
- ControllerFacade() - Constructor for class org.apache.nifi.web.controller.ControllerFacade
-
- ControllerResource - Class in org.apache.nifi.web.api
-
RESTful endpoint for managing a Flow Controller.
- ControllerResource() - Constructor for class org.apache.nifi.web.api.ControllerResource
-
- ControllerService - Interface in org.apache.nifi.controller
-
This interface provides a mechanism for creating services that are shared
among all
Processor
s,
ReportingTask
s, and other
ControllerService
s.
- ControllerServiceAlreadyExistsException - Exception in org.apache.nifi.controller.exception
-
- ControllerServiceAlreadyExistsException(String) - Constructor for exception org.apache.nifi.controller.exception.ControllerServiceAlreadyExistsException
-
- ControllerServiceApiDTO - Class in org.apache.nifi.web.api.dto
-
Class used for providing details of a Controller Service API.
- ControllerServiceApiDTO() - Constructor for class org.apache.nifi.web.api.dto.ControllerServiceApiDTO
-
- ControllerServiceAuditor - Class in org.apache.nifi.audit
-
Audits controller service creation/removal and configuration changes.
- ControllerServiceAuditor() - Constructor for class org.apache.nifi.audit.ControllerServiceAuditor
-
- ControllerServiceConfiguration - Class in org.apache.nifi.util
-
- ControllerServiceConfiguration(ControllerService) - Constructor for class org.apache.nifi.util.ControllerServiceConfiguration
-
- ControllerServiceDAO - Interface in org.apache.nifi.web.dao
-
- ControllerServiceDetails - Class in org.apache.nifi.controller.service
-
Holder for StandardControllerServiceNode to atomically swap out the component.
- ControllerServiceDetails(LoggableComponent<ControllerService>, LoggableComponent<ControllerService>, ControllerServiceInvocationHandler) - Constructor for class org.apache.nifi.controller.service.ControllerServiceDetails
-
- ControllerServiceDTO - Class in org.apache.nifi.web.api.dto
-
A Controller Service that can be shared by other components
- ControllerServiceDTO() - Constructor for class org.apache.nifi.web.api.dto.ControllerServiceDTO
-
- ControllerServiceEndpointMerger - Class in org.apache.nifi.cluster.coordination.http.endpoints
-
- ControllerServiceEndpointMerger() - Constructor for class org.apache.nifi.cluster.coordination.http.endpoints.ControllerServiceEndpointMerger
-
- ControllerServiceEntity - Class in org.apache.nifi.web.api.entity
-
A serialized representation of this class can be placed in the entity body of a response to the API.
- ControllerServiceEntity() - Constructor for class org.apache.nifi.web.api.entity.ControllerServiceEntity
-
- ControllerServiceEntityMerger - Class in org.apache.nifi.cluster.manager
-
- ControllerServiceEntityMerger() - Constructor for class org.apache.nifi.cluster.manager.ControllerServiceEntityMerger
-
- ControllerServiceInitializationContext - Interface in org.apache.nifi.controller
-
- ControllerServiceInitializer - Class in org.apache.nifi.init
-
Initializes a ControllerService using a MockControllerServiceInitializationContext
- ControllerServiceInitializer() - Constructor for class org.apache.nifi.init.ControllerServiceInitializer
-
- ControllerServiceInstantiationException - Exception in org.apache.nifi.controller.exception
-
- ControllerServiceInstantiationException() - Constructor for exception org.apache.nifi.controller.exception.ControllerServiceInstantiationException
-
- ControllerServiceInstantiationException(String) - Constructor for exception org.apache.nifi.controller.exception.ControllerServiceInstantiationException
-
- ControllerServiceInstantiationException(Throwable) - Constructor for exception org.apache.nifi.controller.exception.ControllerServiceInstantiationException
-
- ControllerServiceInstantiationException(String, Throwable) - Constructor for exception org.apache.nifi.controller.exception.ControllerServiceInstantiationException
-
- ControllerServiceInvocationHandler - Interface in org.apache.nifi.controller.service
-
- ControllerServiceLoader - Class in org.apache.nifi.controller.service
-
- ControllerServiceLoader() - Constructor for class org.apache.nifi.controller.service.ControllerServiceLoader
-
- ControllerServiceLogObserver - Class in org.apache.nifi.logging
-
- ControllerServiceLogObserver(BulletinRepository, ControllerServiceNode) - Constructor for class org.apache.nifi.logging.ControllerServiceLogObserver
-
- ControllerServiceLookup - Interface in org.apache.nifi.controller
-
- ControllerServiceNode - Interface in org.apache.nifi.controller.service
-
- ControllerServiceProvider - Interface in org.apache.nifi.controller.service
-
- ControllerServiceProviderFactoryBean - Class in org.apache.nifi.web.spring
-
- ControllerServiceProviderFactoryBean() - Constructor for class org.apache.nifi.web.spring.ControllerServiceProviderFactoryBean
-
- ControllerServiceReference - Interface in org.apache.nifi.controller.service
-
Provides a collection of components that are referencing a Controller Service
- ControllerServiceReferenceEndpointMerger - Class in org.apache.nifi.cluster.coordination.http.endpoints
-
- ControllerServiceReferenceEndpointMerger() - Constructor for class org.apache.nifi.cluster.coordination.http.endpoints.ControllerServiceReferenceEndpointMerger
-
- ControllerServiceReferencingComponentDTO - Class in org.apache.nifi.web.api.dto
-
A component referencing a controller service.
- ControllerServiceReferencingComponentDTO() - Constructor for class org.apache.nifi.web.api.dto.ControllerServiceReferencingComponentDTO
-
- ControllerServiceReferencingComponentEntity - Class in org.apache.nifi.web.api.entity
-
A serialized representation of this class can be placed in the entity body of a response to the API.
- ControllerServiceReferencingComponentEntity() - Constructor for class org.apache.nifi.web.api.entity.ControllerServiceReferencingComponentEntity
-
- ControllerServiceReferencingComponentsEntity - Class in org.apache.nifi.web.api.entity
-
A serialized representation of this class can be placed in the entity body of a response to the API.
- ControllerServiceReferencingComponentsEntity() - Constructor for class org.apache.nifi.web.api.entity.ControllerServiceReferencingComponentsEntity
-
- ControllerServiceResource - Class in org.apache.nifi.web.api
-
RESTful endpoint for managing a Controller Service.
- ControllerServiceResource() - Constructor for class org.apache.nifi.web.api.ControllerServiceResource
-
- ControllerServicesEndpointMerger - Class in org.apache.nifi.cluster.coordination.http.endpoints
-
- ControllerServicesEndpointMerger() - Constructor for class org.apache.nifi.cluster.coordination.http.endpoints.ControllerServicesEndpointMerger
-
- ControllerServicesEntity - Class in org.apache.nifi.web.api.entity
-
A serialized representation of this class can be placed in the entity body of a response to the API.
- ControllerServicesEntity() - Constructor for class org.apache.nifi.web.api.entity.ControllerServicesEntity
-
- ControllerServicesEntityMerger - Class in org.apache.nifi.cluster.manager
-
- ControllerServicesEntityMerger() - Constructor for class org.apache.nifi.cluster.manager.ControllerServicesEntityMerger
-
- ControllerServiceState - Enum in org.apache.nifi.controller.service
-
Represents the valid states for a Controller Service.
- ControllerServiceTestContext - Class in org.apache.nifi.websocket.jetty
-
- ControllerServiceTestContext(ControllerService, String) - Constructor for class org.apache.nifi.websocket.jetty.ControllerServiceTestContext
-
- ControllerServiceTypesEndpointMerger - Class in org.apache.nifi.cluster.coordination.http.endpoints
-
- ControllerServiceTypesEndpointMerger() - Constructor for class org.apache.nifi.cluster.coordination.http.endpoints.ControllerServiceTypesEndpointMerger
-
- ControllerServiceTypesEntity - Class in org.apache.nifi.web.api.entity
-
A serialized representation of this class can be placed in the entity body of a response to the API.
- ControllerServiceTypesEntity() - Constructor for class org.apache.nifi.web.api.entity.ControllerServiceTypesEntity
-
- ControllerServiceWithLogger - Class in org.apache.nifi.documentation.example
-
- ControllerServiceWithLogger() - Constructor for class org.apache.nifi.documentation.example.ControllerServiceWithLogger
-
- ControllerStatusDTO - Class in org.apache.nifi.web.api.dto.status
-
The status of this NiFi controller.
- ControllerStatusDTO() - Constructor for class org.apache.nifi.web.api.dto.status.ControllerStatusDTO
-
- ControllerStatusEndpointMerger - Class in org.apache.nifi.cluster.coordination.http.endpoints
-
- ControllerStatusEndpointMerger() - Constructor for class org.apache.nifi.cluster.coordination.http.endpoints.ControllerStatusEndpointMerger
-
- ControllerStatusEntity - 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.
- ControllerStatusEntity() - Constructor for class org.apache.nifi.web.api.entity.ControllerStatusEntity
-
- ControllerStatusReportingTask - Class in org.apache.nifi.controller
-
- ControllerStatusReportingTask() - Constructor for class org.apache.nifi.controller.ControllerStatusReportingTask
-
- ControlRate - Class in org.apache.nifi.processors.standard
-
- ControlRate() - Constructor for class org.apache.nifi.processors.standard.ControlRate
-
- convert(String, DataType, String) - Method in class org.apache.nifi.csv.CSVRecordReader
-
- convert(DataType, Object, String) - Method in class org.apache.nifi.grok.GrokRecordReader
-
- convert(Object, DataType) - Method in class org.apache.nifi.json.JsonPathRowRecordReader
-
- convert(Object, DataType, String, Object) - Method in class org.apache.nifi.json.JsonPathRowRecordReader
-
- convert(double, DataUnit) - Method in enum org.apache.nifi.processor.DataUnit
-
- convert(GenericData.Record) - Method in class org.apache.nifi.processors.kite.AvroRecordConverter
-
Converts one record to another given a input and output schema plus
explicit mappings for certain target fields.
- convert(ProvenanceEventRecord, StorageSummary) - Method in class org.apache.nifi.provenance.index.lucene.ConvertEventToLuceneDocument
-
- convert(TopDocs, IndexReader) - Method in interface org.apache.nifi.provenance.lucene.DocumentToEventConverter
-
- convertAbstractX509Certificate(Certificate) - Static method in class org.apache.nifi.security.util.CertificateUtils
-
Accepts an abstract Certificate
and returns an X509Certificate
.
- convertAvroRecordToMap(GenericRecord, RecordSchema) - Static method in class org.apache.nifi.avro.AvroTypeUtil
-
- ConvertAvroSchema - Class in org.apache.nifi.processors.kite
-
- ConvertAvroSchema() - Constructor for class org.apache.nifi.processors.kite.ConvertAvroSchema
-
- ConvertAvroToJSON - Class in org.apache.nifi.processors.avro
-
- ConvertAvroToJSON() - Constructor for class org.apache.nifi.processors.avro.ConvertAvroToJSON
-
- ConvertAvroToORC - Class in org.apache.nifi.processors.hive
-
The ConvertAvroToORC processor takes an Avro-formatted flow file as input and converts it into ORC format.
- ConvertAvroToORC() - Constructor for class org.apache.nifi.processors.hive.ConvertAvroToORC
-
- convertByteArray(byte[]) - Static method in class org.apache.nifi.avro.AvroTypeUtil
-
- convertByteArray(Object[]) - Static method in class org.apache.nifi.avro.AvroTypeUtil
-
- convertBytesToGB(BigDecimal) - Static method in class org.apache.nifi.toolkit.flowanalyzer.FlowAnalyzerDriver
-
- convertBytesToGB() - Method in class org.apache.nifi.toolkit.FlowAnalyzerDriverTest
-
- ConvertCharacterSet - Class in org.apache.nifi.processors.standard
-
This processor reads files in as text according to the specified character set and it outputs another text file according to the given character set.
- ConvertCharacterSet() - Constructor for class org.apache.nifi.processors.standard.ConvertCharacterSet
-
- ConvertCSVToAvro - Class in org.apache.nifi.processors.kite
-
- ConvertCSVToAvro() - Constructor for class org.apache.nifi.processors.kite.ConvertCSVToAvro
-
- ConvertEventToLuceneDocument - Class in org.apache.nifi.provenance.index.lucene
-
- ConvertEventToLuceneDocument(List<SearchableField>, List<SearchableField>) - Constructor for class org.apache.nifi.provenance.index.lucene.ConvertEventToLuceneDocument
-
- ConvertExcelToCSVProcessor - Class in org.apache.nifi.processors.poi
-
- ConvertExcelToCSVProcessor() - Constructor for class org.apache.nifi.processors.poi.ConvertExcelToCSVProcessor
-
- ConvertExcelToCSVProcessorTest - Class in org.apache.nifi.processors.poi
-
- ConvertExcelToCSVProcessorTest() - Constructor for class org.apache.nifi.processors.poi.ConvertExcelToCSVProcessorTest
-
- convertField(JsonNode, String, DataType, boolean) - Method in class org.apache.nifi.json.JsonTreeRowRecordReader
-
- convertJson(String) - Method in interface org.apache.nifi.mongodb.MongoDBClientService
-
- convertJsonNodeToRecord(JsonNode, RecordSchema, boolean, boolean) - Method in class org.apache.nifi.json.AbstractJsonRowRecordReader
-
- convertJsonNodeToRecord(JsonNode, RecordSchema, boolean, boolean) - Method in class org.apache.nifi.json.JsonPathRowRecordReader
-
- convertJsonNodeToRecord(JsonNode, RecordSchema, boolean, boolean) - Method in class org.apache.nifi.json.JsonTreeRowRecordReader
-
- ConvertJSONToAvro - Class in org.apache.nifi.processors.kite
-
- ConvertJSONToAvro() - Constructor for class org.apache.nifi.processors.kite.ConvertJSONToAvro
-
- ConvertJSONToSQL - Class in org.apache.nifi.processors.standard
-
- ConvertJSONToSQL() - Constructor for class org.apache.nifi.processors.standard.ConvertJSONToSQL
-
- convertLegacyX509Certificate(X509Certificate) - Static method in class org.apache.nifi.security.util.CertificateUtils
-
Accepts a legacy X509Certificate
and returns an X509Certificate
.
- convertNames(boolean) - Method in class org.apache.nifi.processors.standard.util.JdbcCommon.AvroConversionOptions.Builder
-
- convertQuery(Query) - Static method in class org.apache.nifi.provenance.lucene.LuceneUtil
-
- ConvertRecord - Class in org.apache.nifi.processors.standard
-
- ConvertRecord() - Constructor for class org.apache.nifi.processors.standard.ConvertRecord
-
- convertSizeToByteValue(String) - Static method in class org.apache.nifi.toolkit.flowanalyzer.FlowAnalyzerDriver
-
- convertToAvroObject(Object, Schema) - Static method in class org.apache.nifi.avro.AvroTypeUtil
-
Convert a raw value to an Avro object to serialize in Avro type system.
- convertToAvroStream(ResultSet, OutputStream, long, TimeUnit) - Static method in class org.apache.nifi.processors.cassandra.QueryCassandra
-
Converts a result set into an Avro record and writes it to the given stream.
- convertToAvroStream(ResultSet, OutputStream, boolean) - Static method in class org.apache.nifi.processors.standard.util.JdbcCommon
-
- convertToAvroStream(ResultSet, OutputStream, String, boolean) - Static method in class org.apache.nifi.processors.standard.util.JdbcCommon
-
- convertToAvroStream(ResultSet, OutputStream, String, JdbcCommon.ResultSetRowCallback, boolean) - Static method in class org.apache.nifi.processors.standard.util.JdbcCommon
-
- convertToAvroStream(ResultSet, OutputStream, String, JdbcCommon.ResultSetRowCallback, int, boolean) - Static method in class org.apache.nifi.processors.standard.util.JdbcCommon
-
- convertToAvroStream(ResultSet, OutputStream, JdbcCommon.AvroConversionOptions, JdbcCommon.ResultSetRowCallback) - Static method in class org.apache.nifi.processors.standard.util.JdbcCommon
-
- convertToAvroStream(ResultSet, OutputStream) - Static method in class org.apache.nifi.util.hive.HiveJdbcCommon
-
- convertToAvroStream(ResultSet, OutputStream, String, HiveJdbcCommon.ResultSetRowCallback) - Static method in class org.apache.nifi.util.hive.HiveJdbcCommon
-
- convertToCsvStream(ResultSet, OutputStream, CsvOutputOptions) - Static method in class org.apache.nifi.util.hive.HiveJdbcCommon
-
- convertToCsvStream(ResultSet, OutputStream, String, HiveJdbcCommon.ResultSetRowCallback, CsvOutputOptions) - Static method in class org.apache.nifi.util.hive.HiveJdbcCommon
-
- convertToJsonStream(ResultSet, OutputStream, Charset, long, TimeUnit) - Static method in class org.apache.nifi.processors.cassandra.QueryCassandra
-
Converts a result set into an Json object and writes it to the given stream using the specified character set.
- convertToORCObject(TypeInfo, Object) - Static method in class org.apache.hadoop.hive.ql.io.orc.NiFiOrcUtils
-
- convertType(Object, DataType, String) - Static method in class org.apache.nifi.serialization.record.util.DataTypeUtils
-
- convertType(Object, DataType, Supplier<DateFormat>, Supplier<DateFormat>, Supplier<DateFormat>, String) - Static method in class org.apache.nifi.serialization.record.util.DataTypeUtils
-
- CookieTestingServlet - Class in org.apache.nifi.processors.standard
-
- CookieTestingServlet() - Constructor for class org.apache.nifi.processors.standard.CookieTestingServlet
-
- CookieVerificationTestingServlet - Class in org.apache.nifi.processors.standard
-
- CookieVerificationTestingServlet() - Constructor for class org.apache.nifi.processors.standard.CookieVerificationTestingServlet
-
- coordinate(BundleCoordinate) - Method in class org.apache.nifi.bundle.BundleDetails.Builder
-
- copy() - Method in interface org.apache.nifi.provenance.ProvenanceEventBuilder
-
- copy() - Method in class org.apache.nifi.provenance.StandardProvenanceEventRecord.Builder
-
- copy(StandardProvenanceEventRecord) - Static method in class org.apache.nifi.provenance.StandardProvenanceEventRecord
-
- copy(RelTraitSet, List<RelNode>) - Method in class org.apache.nifi.queryrecord.FlowFileTableScan
-
- copy(InputStream, OutputStream) - Method in class org.apache.nifi.stream.io.LeakyBucketStreamThrottler
-
- copy(InputStream, OutputStream, long) - Method in class org.apache.nifi.stream.io.LeakyBucketStreamThrottler
-
- copy(InputStream, OutputStream) - Method in interface org.apache.nifi.stream.io.StreamThrottler
-
- copy(InputStream, OutputStream, long) - Method in interface org.apache.nifi.stream.io.StreamThrottler
-
- copy(InputStream, OutputStream) - Static method in class org.apache.nifi.stream.io.StreamUtils
-
- copy(InputStream, OutputStream, long) - Static method in class org.apache.nifi.stream.io.StreamUtils
-
Copies numBytes
from source
to destination
.
- copy(InputStream, OutputStream) - Static method in class org.apache.nifi.util.file.FileUtils
-
- copy(InputStream, OutputStream) - Static method in class org.apache.nifi.util.FlowFilePackagerV1
-
- copy(InputStream, OutputStream, long) - Method in class org.apache.nifi.util.FlowFileUnpackagerV2
-
- copy(InputStream, OutputStream, long) - Method in class org.apache.nifi.util.FlowFileUnpackagerV3
-
- copy(LabelDTO) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
- copy(ControllerServiceDTO) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
- copy(FunnelDTO) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
- copy(BundleDTO) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
- copy(ProcessorDTO) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
- copy(ConnectionDTO) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
- copy(BulletinDTO) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
- copy(PortDTO) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
- copy(RemoteProcessGroupPortDTO) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
- copy(ProcessGroupDTO, boolean) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
- copy(RemoteProcessGroupDTO) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
- copy(FlowSnippetDTO, ProcessGroup, String, boolean) - Method in class org.apache.nifi.web.util.SnippetUtils
-
- COPY_ATTRIBUTES - Static variable in class org.apache.nifi.processors.standard.MonitorActivity
-
- copyAttributesToOriginal(ProcessSession, FlowFile, String, int) - Static method in enum org.apache.nifi.flowfile.attributes.FragmentAttributes
-
- copyBytes(byte[], File, boolean) - Static method in class org.apache.nifi.util.file.FileUtils
-
- copyCurrentFlow(OutputStream) - Method in class org.apache.nifi.controller.StandardFlowService
-
- copyCurrentFlow(OutputStream) - Method in interface org.apache.nifi.services.FlowService
-
Copies the contents of the current flow.xml to the given OutputStream
- copyExclusive(InputStream, OutputStream, int, byte[]...) - Static method in class org.apache.nifi.stream.io.StreamUtils
-
Copies data from in to out until either we are out of data (returns null) or we hit one of the byte patterns identified by the stoppers
parameter (returns the byte pattern
matched).
- copyFile(File, File, boolean, boolean, boolean, Logger) - Static method in class org.apache.nifi.util.file.FileUtils
-
Copies the given source file to the given destination file.
- copyFile(File, File, boolean, boolean, Logger) - Static method in class org.apache.nifi.util.file.FileUtils
-
Copies the given source file to the given destination file.
- copyFile(File, OutputStream, boolean, boolean) - Static method in class org.apache.nifi.util.file.FileUtils
-
- copyFile(InputStream, File, boolean, boolean) - Static method in class org.apache.nifi.util.file.FileUtils
-
- copyInclusive(InputStream, OutputStream, int, byte[]...) - Static method in class org.apache.nifi.stream.io.StreamUtils
-
Copies data from in to out until either we are out of data (returns null) or we hit one of the byte patterns identified by the stoppers
parameter (returns the byte pattern
matched).
- CopyingInputStream - Class in org.apache.nifi.cluster.protocol.impl
-
- CopyingInputStream(InputStream, int) - Constructor for class org.apache.nifi.cluster.protocol.impl.CopyingInputStream
-
- copyLock(ProceedingJoinPoint) - Method in class org.apache.nifi.web.NiFiServiceFacadeLock
-
- copyResources() - Static method in class org.apache.nifi.nar.NarUnpackerTest
-
- copySnippet(HttpServletRequest, String, CopySnippetRequestEntity) - Method in class org.apache.nifi.web.api.ProcessGroupResource
-
Copies the specified snippet within this ProcessGroup.
- copySnippet(String, String, Double, Double, String) - Method in class org.apache.nifi.web.dao.impl.StandardSnippetDAO
-
- copySnippet(String, String, Double, Double, String) - Method in interface org.apache.nifi.web.dao.SnippetDAO
-
Copies the specified snippet and added the copy to the flow in the specified group.
- copySnippet(String, String, Double, Double, String) - Method in interface org.apache.nifi.web.NiFiServiceFacade
-
Creates a new snippet based off the existing snippet.
- copySnippet(String, String, Double, Double, String) - Method in class org.apache.nifi.web.StandardNiFiServiceFacade
-
- copySnippetAdvice(ProceedingJoinPoint) - Method in class org.apache.nifi.audit.SnippetAuditor
-
Audits copy/paste.
- copySnippetContents(FlowSnippetDTO) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
Copies the specified snippet.
- CopySnippetRequestEntity - Class in org.apache.nifi.web.api.entity
-
A serialized representation of this class can be placed in the entity body of a request to the API.
- CopySnippetRequestEntity() - Constructor for class org.apache.nifi.web.api.entity.CopySnippetRequestEntity
-
- CoreAttributes - Enum in org.apache.nifi.flowfile.attributes
-
- CORRELATION_ATTRIBUTE_NAME - Static variable in class org.apache.nifi.processors.standard.MergeContent
-
- CORRELATION_ATTRIBUTE_NAME - Static variable in class org.apache.nifi.processors.standard.MergeRecord
-
- COUCHBASE_CLUSTER_SERVICE - Static variable in class org.apache.nifi.processors.couchbase.AbstractCouchbaseProcessor
-
- CouchbaseAttributes - Enum in org.apache.nifi.couchbase
-
Couchbase related attribute keys.
- CouchbaseClusterControllerService - Interface in org.apache.nifi.couchbase
-
Provides a connection to a Couchbase Server cluster throughout a NiFi Data
flow.
- CouchbaseClusterService - Class in org.apache.nifi.couchbase
-
Provides a centralized Couchbase connection and bucket passwords management.
- CouchbaseClusterService() - Constructor for class org.apache.nifi.couchbase.CouchbaseClusterService
-
- CouchbaseExceptionMappings - Class in org.apache.nifi.processors.couchbase
-
- CouchbaseExceptionMappings() - Constructor for class org.apache.nifi.processors.couchbase.CouchbaseExceptionMappings
-
- count(Document) - Method in interface org.apache.nifi.mongodb.MongoDBClientService
-
- count(Document) - Method in class org.apache.nifi.mongodb.MongoDBControllerService
-
- COUNT_APPEND_KEY - Static variable in class org.apache.nifi.processors.stateful.analysis.AttributeRollingWindow
-
- COUNT_APPEND_KEY_LENGTH - Static variable in class org.apache.nifi.processors.stateful.analysis.AttributeRollingWindow
-
- COUNT_KEY - Static variable in class org.apache.nifi.processors.stateful.analysis.AttributeRollingWindow
-
- Counter - Interface in org.apache.nifi.controller
-
- CounterAdapter - Class in org.apache.nifi.jaxb
-
- CounterAdapter() - Constructor for class org.apache.nifi.jaxb.CounterAdapter
-
- CounterDTO - Class in org.apache.nifi.web.api.dto
-
Counter value for a specific component in a specific context.
- CounterDTO() - Constructor for class org.apache.nifi.web.api.dto.CounterDTO
-
- CounterEntity - Class in org.apache.nifi.web.api.entity
-
A serialized representation of this class can be placed in the entity body of a response from the API.
- CounterEntity() - Constructor for class org.apache.nifi.web.api.entity.CounterEntity
-
- CounterRepository - Interface in org.apache.nifi.controller.repository
-
- COUNTERS_URI_PATTERN - Static variable in class org.apache.nifi.cluster.coordination.http.endpoints.CountersEndpointMerger
-
- CountersDTO - Class in org.apache.nifi.web.api.dto
-
- CountersDTO() - Constructor for class org.apache.nifi.web.api.dto.CountersDTO
-
- CountersEndpointMerger - Class in org.apache.nifi.cluster.coordination.http.endpoints
-
- CountersEndpointMerger() - Constructor for class org.apache.nifi.cluster.coordination.http.endpoints.CountersEndpointMerger
-
- CountersEntity - Class in org.apache.nifi.web.api.entity
-
A serialized representation of this class can be placed in the entity body of a response from the API.
- CountersEntity() - Constructor for class org.apache.nifi.web.api.entity.CountersEntity
-
- CountersResource - Class in org.apache.nifi.web.api
-
RESTful endpoint for managing a cluster.
- CountersResource() - Constructor for class org.apache.nifi.web.api.CountersResource
-
- CountersSnapshotDTO - Class in org.apache.nifi.web.api.dto
-
All the counters in this NiFi instance at a given time.
- CountersSnapshotDTO() - Constructor for class org.apache.nifi.web.api.dto.CountersSnapshotDTO
-
- CountEvaluator - Class in org.apache.nifi.attribute.expression.language.evaluation.reduce
-
- CountEvaluator(Evaluator<?>) - Constructor for class org.apache.nifi.attribute.expression.language.evaluation.reduce.CountEvaluator
-
- countLines(String) - Static method in class org.apache.nifi.processors.standard.TestRouteText
-
- country(InetAddress) - Method in class org.apache.nifi.lookup.maxmind.DatabaseReader
-
- country(InetAddress) - Method in class org.apache.nifi.processors.maxmind.DatabaseReader
-
- Counts() - Constructor for class org.apache.nifi.processors.kafka.pubsub.InFlightMessageTracker.Counts
-
- countSelectedElements(RingBuffer.Filter<T>) - Method in class org.apache.nifi.util.RingBuffer
-
- CountSizeEntityAccess - Class in org.apache.nifi.util.timebuffer
-
- CountSizeEntityAccess() - Constructor for class org.apache.nifi.util.timebuffer.CountSizeEntityAccess
-
- CQL_SELECT_QUERY - Static variable in class org.apache.nifi.processors.cassandra.QueryCassandra
-
- CRC32C - Static variable in class org.apache.nifi.processors.gcp.storage.PutGCSObject
-
- CRC32C_ATTR - Static variable in class org.apache.nifi.processors.gcp.storage.StorageAttributes
-
- CRC32C_DESC - Static variable in class org.apache.nifi.processors.gcp.storage.StorageAttributes
-
- create(ZooKeeperClientConfig) - Method in class org.apache.nifi.controller.leader.election.CuratorACLProviderFactory
-
- create(boolean) - Method in interface org.apache.nifi.controller.repository.ContentRepository
-
Creates a new content claim
- create(boolean) - Method in class org.apache.nifi.controller.repository.FileSystemRepository
-
- create() - Method in class org.apache.nifi.controller.repository.StandardProcessSession
-
- create(FlowFile) - Method in class org.apache.nifi.controller.repository.StandardProcessSession
-
- create(Collection<FlowFile>) - Method in class org.apache.nifi.controller.repository.StandardProcessSession
-
- create(FlowFile) - Method in class org.apache.nifi.controller.repository.StandardProvenanceReporter
-
- create(FlowFile, String) - Method in class org.apache.nifi.controller.repository.StandardProvenanceReporter
-
- create(boolean) - Method in class org.apache.nifi.controller.repository.VolatileContentRepository
-
- create(NiFiProperties, VariableRegistry) - Static method in class org.apache.nifi.controller.state.manager.StandardStateManagerProvider
-
- create(NiFiProperties) - Static method in class org.apache.nifi.controller.state.server.ZooKeeperStateServer
-
- create(FlowFileRepository, ContentRepository, ProvenanceRepository) - Method in class org.apache.nifi.diagnostics.SystemDiagnosticsFactory
-
- create(NiFiProperties) - Static method in class org.apache.nifi.nar.SystemBundle
-
Returns a bundle representing the system class loader.
- create() - Method in interface org.apache.nifi.processor.ProcessSession
-
Creates a new FlowFile in the repository with no content and without any
linkage to a parent FlowFile.
- create(FlowFile) - Method in interface org.apache.nifi.processor.ProcessSession
-
Creates a new FlowFile in the repository with no content but with a
parent linkage to parent
.
- create(Collection<FlowFile>) - Method in interface org.apache.nifi.processor.ProcessSession
-
Creates a new FlowFile in the repository with no content but with a
parent linkage to the FlowFiles specified by the parents Collection.
- create(byte[], Map<String, String>, ChannelResponder) - Method in interface org.apache.nifi.processor.util.listen.event.EventFactory
-
Creates an event for the given data and metadata.
- create(byte[], Map<String, String>, ChannelResponder) - Method in class org.apache.nifi.processor.util.listen.event.StandardEventFactory
-
- create(byte[], Map<String, String>, ChannelResponder) - Method in class org.apache.nifi.processors.beats.event.BeatsEventFactory
-
- create(BinaryReader, ChunkHeader, BxmlNode) - Method in interface org.apache.nifi.processors.evtx.parser.bxml.BxmlNodeFactory
-
- create(BinaryReader, ChunkHeader, BxmlNode, int) - Method in interface org.apache.nifi.processors.evtx.parser.bxml.value.VariantTypeNodeFactory
-
- create(InputStream, ComponentLog) - Method in interface org.apache.nifi.processors.evtx.parser.FileHeaderFactory
-
- create(OutputStream) - Method in interface org.apache.nifi.processors.evtx.RootNodeHandlerFactory
-
- create(XMLStreamWriter, RootNode) - Method in interface org.apache.nifi.processors.evtx.XmlBxmlNodeVisitorFactory
-
- create(byte[], Map<String, String>, ChannelResponder) - Method in class org.apache.nifi.processors.lumberjack.event.LumberjackEventFactory
-
Deprecated.
- create(String) - Static method in class org.apache.nifi.processors.solr.EmbeddedSolrServerFactory
-
Use the defaults to create the core.
- create(String, String, String) - Static method in class org.apache.nifi.processors.solr.EmbeddedSolrServerFactory
-
- create(byte[], Map<String, String>, ChannelResponder) - Method in class org.apache.nifi.processors.standard.relp.event.RELPEventFactory
-
- create(FlowFile) - Method in interface org.apache.nifi.provenance.ProvenanceReporter
-
Emits a Provenance Event of type
CREATE
that indicates that the given
FlowFile was created by NiFi from data that was not received from an
external entity.
- create(FlowFile, String) - Method in interface org.apache.nifi.provenance.ProvenanceReporter
-
Emits a Provenance Event of type
CREATE
that indicates that the given
FlowFile was created by NiFi from data that was not received from an
external entity.
- create(NiFiProperties) - Static method in class org.apache.nifi.provenance.RepositoryConfiguration
-
- create(byte[]) - Static method in class org.apache.nifi.toolkit.s2s.DataPacketDtoTest
-
- create() - Method in class org.apache.nifi.toolkit.tls.properties.NiFiPropertiesWriterFactory
-
Returns a NifiPropertiesWriter with based on the read nifi.properties
- create(File) - Method in interface org.apache.nifi.toolkit.tls.util.InputStreamFactory
-
- create(File) - Method in interface org.apache.nifi.toolkit.tls.util.OutputStreamFactory
-
- create() - Method in class org.apache.nifi.util.MockProcessSession
-
- create(FlowFile) - Method in class org.apache.nifi.util.MockProcessSession
-
- create(Collection<FlowFile>) - Method in class org.apache.nifi.util.MockProcessSession
-
- create(FlowFile) - Method in class org.apache.nifi.util.MockProvenanceReporter
-
- create(FlowFile, String) - Method in class org.apache.nifi.util.MockProvenanceReporter
-
- CREATE_DIRECTORY - Static variable in interface org.apache.nifi.processors.standard.util.FileTransfer
-
- CREATE_DIRS - Static variable in class org.apache.nifi.processors.standard.PutFile
-
- CREATE_OR_UPDATE_ACTION - Static variable in class org.apache.nifi.controller.repository.schema.RepositoryRecordSchema
-
- CREATE_OR_UPDATE_SCHEMA_V1 - Static variable in class org.apache.nifi.controller.repository.schema.RepositoryRecordSchema
-
- CREATE_OR_UPDATE_SCHEMA_V2 - Static variable in class org.apache.nifi.controller.repository.schema.RepositoryRecordSchema
-
- CREATE_TIME_ATTR - Static variable in class org.apache.nifi.processors.gcp.storage.StorageAttributes
-
- CREATE_TIME_DESC - Static variable in class org.apache.nifi.processors.gcp.storage.StorageAttributes
-
- createAccessPolicy(HttpServletRequest, AccessPolicyEntity) - Method in class org.apache.nifi.web.api.AccessPolicyResource
-
Creates a new access policy.
- createAccessPolicy(AccessPolicyDTO) - Method in interface org.apache.nifi.web.dao.AccessPolicyDAO
-
Creates an access policy.
- createAccessPolicy(AccessPolicyDTO) - Method in class org.apache.nifi.web.dao.impl.StandardPolicyBasedAuthorizerDAO
-
- createAccessPolicy(Revision, AccessPolicyDTO) - Method in interface org.apache.nifi.web.NiFiServiceFacade
-
Creates an access policy.
- createAccessPolicy(Revision, AccessPolicyDTO) - Method in class org.apache.nifi.web.StandardNiFiServiceFacade
-
- createAccessPolicyAdvice(ProceedingJoinPoint) - Method in class org.apache.nifi.audit.AccessPolicyAuditor
-
Audits the creation of policies via createAccessPolicy().
- createAccessPolicyDto(AccessPolicy, Set<TenantEntity>, Set<TenantEntity>, ComponentReferenceEntity) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
- createAccessPolicyEntity(AccessPolicyDTO, RevisionDTO, PermissionsDTO) - Method in class org.apache.nifi.web.api.dto.EntityFactory
-
- createAccessPolicySummaryDto(AccessPolicy, ComponentReferenceEntity) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
- createAccessPolicySummaryEntity(AccessPolicySummaryDTO, RevisionDTO, PermissionsDTO) - Method in class org.apache.nifi.web.api.dto.EntityFactory
-
- createAccessToken(HttpServletRequest, String, String) - Method in class org.apache.nifi.web.api.AccessResource
-
Creates a token for accessing the REST API via username/password.
- createAccessTokenFromTicket(HttpServletRequest) - Method in class org.apache.nifi.web.api.AccessResource
-
Creates a token for accessing the REST API via Kerberos ticket exchange / SPNEGO negotiation.
- createACL(ProcessContext, FlowFile) - Method in class org.apache.nifi.processors.aws.s3.AbstractS3Processor
-
Create AccessControlList if appropriate properties are configured.
- createAction(Action) - Method in interface org.apache.nifi.admin.dao.ActionDAO
-
Persists the specified action.
- createAction(Action) - Method in class org.apache.nifi.admin.dao.impl.StandardActionDAO
-
- createAction(UriInfo, String, ActionEntity) - Method in class org.apache.nifi.update.attributes.api.RuleResource
-
- createAction(ActionDTO) - Method in class org.apache.nifi.update.attributes.UpdateAttributeModelFactory
-
- createActionDTO(Action) - Static method in class org.apache.nifi.update.attributes.dto.DtoFactory
-
- createActionDto(Action) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
Creates an ActionDTO for the specified Action.
- createActionEntity(ActionDTO, boolean) - Method in class org.apache.nifi.web.api.dto.EntityFactory
-
- createActions(Set<ActionDTO>) - Method in class org.apache.nifi.update.attributes.UpdateAttributeModelFactory
-
- createAdjustError(ComponentLog) - Static method in class org.apache.nifi.processor.util.pattern.RollbackOnFailure
-
Create a function to use with
ExceptionHandler
that adjust error type based on functional context.
- createAdjustRoute(Relationship...) - Static method in class org.apache.nifi.processor.util.pattern.RollbackOnFailure
-
- createAffectedComponentDto(ConfiguredComponent) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
- createAffectedComponentEntities(Set<ConfiguredComponent>, RevisionManager) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
- createAffectedComponentEntity(AffectedComponentDTO, RevisionDTO, PermissionsDTO) - Method in class org.apache.nifi.web.api.dto.EntityFactory
-
- createAllowableValueEntity(AllowableValueDTO, boolean) - Method in class org.apache.nifi.web.api.dto.EntityFactory
-
- createAttributeExpressionLanguageValidator(AttributeExpression.ResultType) - Static method in class org.apache.nifi.processor.util.StandardValidators
-
- createAttributeExpressionLanguageValidator(AttributeExpression.ResultType, boolean) - Static method in class org.apache.nifi.processor.util.StandardValidators
-
- createAttributeMap(Message) - Static method in class org.apache.nifi.processors.standard.util.JmsFactory
-
- createAttributes(T, ProcessContext) - Method in class org.apache.nifi.processor.util.list.AbstractListProcessor
-
Creates a Map of attributes that should be applied to the FlowFile to represent this entity.
- createAttributes(BlobInfo, ProcessContext) - Method in class org.apache.nifi.processors.azure.storage.ListAzureBlobStorage
-
- createAttributes(FileInfo, ProcessContext) - Method in class org.apache.nifi.processors.standard.ListFile
-
- createAttributes(FileInfo, ProcessContext) - Method in class org.apache.nifi.processors.standard.ListFileTransfer
-
- createAuthentication(HttpServletRequest) - Method in class org.apache.nifi.web.security.anonymous.NiFiAnonymousUserFilter
-
- createAvroRecord(Record, Schema) - Static method in class org.apache.nifi.avro.AvroTypeUtil
-
- createBasicNiFiProperties(String, Map<String, String>) - Static method in class org.apache.nifi.util.NiFiProperties
-
Creates an instance of NiFiProperties.
- createBindings() - Method in class org.apache.nifi.processors.script.engine.ClojureScriptEngine
-
- createBlockedByFirewallResponse() - Static method in class org.apache.nifi.cluster.protocol.ConnectionResponse
-
- createBufferPool(int, int) - Method in class org.apache.nifi.processor.util.listen.AbstractListenEventProcessor
-
Creates a pool of ByteBuffers with the given size.
- createBuffers(int, int, boolean) - Static method in class org.apache.nifi.io.nio.BufferPool
-
- createBulletin(String, Severity, String) - Method in class org.apache.nifi.controller.reporting.StandardReportingContext
-
- createBulletin(String, String, Severity, String) - Method in class org.apache.nifi.controller.reporting.StandardReportingContext
-
- createBulletin(Connectable, String, String, String) - Static method in class org.apache.nifi.events.BulletinFactory
-
- createBulletin(String, String, ComponentType, String, String, String, String) - Static method in class org.apache.nifi.events.BulletinFactory
-
- createBulletin(String, String, String, ComponentType, String, String, String, String) - Static method in class org.apache.nifi.events.BulletinFactory
-
- createBulletin(String, String, String) - Static method in class org.apache.nifi.events.BulletinFactory
-
- createBulletin(String, String, String, String, String, String) - Static method in class org.apache.nifi.reporting.BulletinFactory
-
- createBulletin(String, String, String, String, String, String, String) - Static method in class org.apache.nifi.reporting.BulletinFactory
-
- createBulletin(String, String, String) - Static method in class org.apache.nifi.reporting.BulletinFactory
-
- createBulletin(String, Severity, String) - Method in interface org.apache.nifi.reporting.ReportingContext
-
Creates a controller-level
Bulletin
with the given category, severity
level, and message, so that the Bulletin can be added to the
BulletinRepository
.
- createBulletin(String, String, Severity, String) - Method in interface org.apache.nifi.reporting.ReportingContext
-
Creates a
Bulletin
for the component with the specified
identifier.
- createBulletin(String, Severity, String) - Method in class org.apache.nifi.util.MockReportingContext
-
- createBulletin(String, String, Severity, String) - Method in class org.apache.nifi.util.MockReportingContext
-
- createBulletin(HttpServletRequest, BulletinEntity) - Method in class org.apache.nifi.web.api.ControllerResource
-
Creates a Bulletin.
- createBulletin(BulletinDTO, Boolean) - Method in interface org.apache.nifi.web.NiFiServiceFacade
-
Create a system bulletin
- createBulletin(BulletinDTO, Boolean) - Method in class org.apache.nifi.web.StandardNiFiServiceFacade
-
- createBulletinBoardDto(List<BulletinEntity>) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
Creates a BulletinBoardDTO for the specified bulletins.
- createBulletinDto(Bulletin) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
Creates a BulletinDTO for the specified Bulletin.
- createBulletinDtos(List<Bulletin>) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
Creates BulletinDTOs for the specified Bulletins.
- createBulletinEntity(BulletinDTO, boolean) - Method in class org.apache.nifi.web.api.dto.EntityFactory
-
- createBundleDto(BundleCoordinate) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
Creates a bundle DTO from the specified class.
- createByteArray(Message) - Static method in class org.apache.nifi.processors.standard.util.JmsFactory
-
- createCacheServer(ConfigurationContext) - Method in class org.apache.nifi.distributed.cache.server.DistributedCacheServer
-
- createCacheServer(ConfigurationContext) - Method in class org.apache.nifi.distributed.cache.server.DistributedSetCacheServer
-
- createCacheServer(ConfigurationContext) - Method in class org.apache.nifi.distributed.cache.server.map.DistributedMapCacheServer
-
- createCannedACL(ProcessContext, FlowFile) - Method in class org.apache.nifi.processors.aws.s3.AbstractS3Processor
-
- createCertificateSigningRequestPerformer() - Method in class org.apache.nifi.toolkit.tls.configuration.TlsClientConfig
-
- createChannelReader(ProcessContext, String, BlockingQueue<ByteBuffer>, BlockingQueue<ListenSyslog.RawSyslogEvent>, int, SSLContextService, Charset) - Method in class org.apache.nifi.processors.standard.ListenSyslog
-
- createClient(ConfigurationContext) - Method in class org.apache.nifi.mongodb.AbstractMongoDBControllerService
-
- createClient(ProcessContext, AWSCredentialsProvider, ClientConfiguration) - Method in class org.apache.nifi.processors.aws.AbstractAWSCredentialsProviderProcessor
-
Abstract method to create aws client using credentials provider.
- createClient(ProcessContext, AWSCredentials, ClientConfiguration) - Method in class org.apache.nifi.processors.aws.AbstractAWSProcessor
-
- createClient(ProcessContext, AWSCredentialsProvider, ClientConfiguration) - Method in class org.apache.nifi.processors.aws.cloudwatch.PutCloudWatchMetric
-
Create client using aws credentials provider.
- createClient(ProcessContext, AWSCredentials, ClientConfiguration) - Method in class org.apache.nifi.processors.aws.cloudwatch.PutCloudWatchMetric
-
- createClient(ProcessContext, AWSCredentialsProvider, ClientConfiguration) - Method in class org.apache.nifi.processors.aws.credentials.provider.factory.MockAWSProcessor
-
Create client using credentials provider.
- createClient(ProcessContext, AWSCredentials, ClientConfiguration) - Method in class org.apache.nifi.processors.aws.credentials.provider.factory.MockAWSProcessor
-
- createClient(ProcessContext, AWSCredentialsProvider, ClientConfiguration) - Method in class org.apache.nifi.processors.aws.dynamodb.AbstractDynamoDBProcessor
-
Create client using credentials provider.
- createClient(ProcessContext, AWSCredentials, ClientConfiguration) - Method in class org.apache.nifi.processors.aws.dynamodb.AbstractDynamoDBProcessor
-
- createClient(ProcessContext, AWSCredentialsProvider, ClientConfiguration) - Method in class org.apache.nifi.processors.aws.kinesis.firehose.AbstractKinesisFirehoseProcessor
-
Create client using aws credentials provider.
- createClient(ProcessContext, AWSCredentials, ClientConfiguration) - Method in class org.apache.nifi.processors.aws.kinesis.firehose.AbstractKinesisFirehoseProcessor
-
- createClient(ProcessContext, AWSCredentialsProvider, ClientConfiguration) - Method in class org.apache.nifi.processors.aws.kinesis.stream.AbstractKinesisStreamProcessor
-
Create client using aws credentials provider.
- createClient(ProcessContext, AWSCredentials, ClientConfiguration) - Method in class org.apache.nifi.processors.aws.kinesis.stream.AbstractKinesisStreamProcessor
-
- createClient(ProcessContext, AWSCredentialsProvider, ClientConfiguration) - Method in class org.apache.nifi.processors.aws.lambda.AbstractAWSLambdaProcessor
-
Create client using aws credentials provider.
- createClient(ProcessContext, AWSCredentials, ClientConfiguration) - Method in class org.apache.nifi.processors.aws.lambda.AbstractAWSLambdaProcessor
-
- createClient(ProcessContext, AWSCredentialsProvider, ClientConfiguration) - Method in class org.apache.nifi.processors.aws.s3.AbstractS3Processor
-
Create client using credentials provider.
- createClient(ProcessContext, AWSCredentials, ClientConfiguration) - Method in class org.apache.nifi.processors.aws.s3.AbstractS3Processor
-
- createClient(ProcessContext, AWSCredentialsProvider, ClientConfiguration) - Method in class org.apache.nifi.processors.aws.sns.AbstractSNSProcessor
-
Create client using aws credentials provider.
- createClient(ProcessContext, AWSCredentials, ClientConfiguration) - Method in class org.apache.nifi.processors.aws.sns.AbstractSNSProcessor
-
- createClient(ProcessContext, AWSCredentialsProvider, ClientConfiguration) - Method in class org.apache.nifi.processors.aws.sqs.AbstractSQSProcessor
-
Create client using credentials provider.
- createClient(ProcessContext, AWSCredentials, ClientConfiguration) - Method in class org.apache.nifi.processors.aws.sqs.AbstractSQSProcessor
-
- createClient() - Method in class org.apache.nifi.processors.enrich.QueryWhois
-
- createClient(ProcessContext) - Method in class org.apache.nifi.processors.mongodb.AbstractMongoProcessor
-
- createClient() - Method in class org.apache.nifi.reporting.ambari.AmbariReportingTask
-
- createClient(ClientConfig) - Static method in class org.apache.nifi.web.util.WebUtils
-
Creates a client for non-secure requests.
- createClient(ClientConfig, SSLContext) - Static method in class org.apache.nifi.web.util.WebUtils
-
Creates a client for secure requests.
- createClientConfig() - Method in class org.apache.nifi.toolkit.tls.service.client.TlsCertificateAuthorityClientCommandLine
-
- createClientId(ProcessContext) - Static method in class org.apache.nifi.processors.standard.util.JmsFactory
-
- createClientProtocol(String) - Static method in class org.apache.nifi.remote.RemoteResourceManager
-
- createCloseEvent() - Static method in class org.apache.nifi.processors.hadoop.inotify.util.EventTestUtils
-
- createCluster() - Method in class org.apache.nifi.cluster.integration.ClusterConnectionIT
-
- createCluster(List<InetSocketAddress>, SSLContext, String, String) - Method in class org.apache.nifi.processors.cassandra.AbstractCassandraProcessor
-
Uses a Cluster.Builder to create a Cassandra cluster reference using the given parameters
- createCluster(List<InetSocketAddress>, SSLContext, String, String) - Method in class org.apache.nifi.processors.cassandra.AbstractCassandraProcessorTest.MockAbstractCassandraProcessor
-
- createClusteredInstance(FlowFileEventRepository, NiFiProperties, Authorizer, AuditService, StringEncryptor, NodeProtocolSender, BulletinRepository, ClusterCoordinator, HeartbeatMonitor, LeaderElectionManager, VariableRegistry) - Static method in class org.apache.nifi.controller.FlowController
-
- createClusteredInstance(FlowController, NiFiProperties, NodeProtocolSenderListener, ClusterCoordinator, StringEncryptor, RevisionManager, Authorizer) - Static method in class org.apache.nifi.controller.StandardFlowService
-
- createClusterWorkloadRequest() - Method in class org.apache.nifi.cluster.protocol.jaxb.message.ObjectFactory
-
- createClusterWorkloadResponse() - Method in class org.apache.nifi.cluster.protocol.jaxb.message.ObjectFactory
-
- createCodec(CompressionKind) - Static method in class org.apache.hadoop.hive.ql.io.orc.OrcFlowFileWriter
-
- createCodec(String, int) - Static method in class org.apache.nifi.remote.RemoteResourceManager
-
- createCommandStrings(ProcessContext, String, String) - Method in class org.apache.nifi.processors.standard.ExecuteProcess
-
- createCommsSession(ConfigurationContext) - Method in class org.apache.nifi.distributed.cache.client.DistributedMapCacheClientService
-
- createCommsSession(ConfigurationContext) - Method in class org.apache.nifi.distributed.cache.client.DistributedSetCacheClientService
-
- createCommTarget(String, String, int) - Static method in class org.apache.nifi.snmp.processors.SNMPUtilsTest
-
Method to create community target
- createComponentInitializer(Class<? extends ConfigurableComponent>) - Static method in class org.apache.nifi.init.ConfigurableComponentInitializerFactory
-
Returns a ConfigurableComponentInitializer for the type of component.
- createComponentReferenceDto(Authorizable) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
- createComponentReferenceEntity(ComponentReferenceDTO, RevisionDTO, PermissionsDTO) - Method in class org.apache.nifi.web.api.dto.EntityFactory
-
- createComponentStateDTO(String, Class<?>, StateMap, StateMap) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
Creates a ComponentStateDTO for the given component and state's.
- createConciseProcessGroupStatusDto(ProcessGroupStatus) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
- createCondition(UriInfo, String, ConditionEntity) - Method in class org.apache.nifi.update.attributes.api.RuleResource
-
- createCondition(ConditionDTO) - Method in class org.apache.nifi.update.attributes.UpdateAttributeModelFactory
-
- createConditionDTO(Condition) - Static method in class org.apache.nifi.update.attributes.dto.DtoFactory
-
- createConditions(Set<ConditionDTO>) - Method in class org.apache.nifi.update.attributes.UpdateAttributeModelFactory
-
- createConfig(NiFiProperties) - Static method in class org.apache.nifi.controller.cluster.ZooKeeperClientConfig
-
- createConfig() - Method in class org.apache.nifi.toolkit.tls.service.server.TlsCertificateAuthorityServiceCommandLine
-
- createConfig() - Method in class org.apache.nifi.toolkit.tls.standalone.TlsToolkitStandaloneCommandLine
-
Creates the StandaloneConfig for use in running TlsToolkitStandalone
- createConfiguration(ProcessContext) - Method in class org.apache.nifi.processors.aws.AbstractAWSProcessor
-
Deprecated.
- createConflictingNodeIdResponse(String) - Static method in class org.apache.nifi.cluster.protocol.ConnectionResponse
-
- createConnectableDto(Connectable) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
Creates a ConnectableDTO from the specified Connectable.
- createConnectableDto(PortDTO, ConnectableType) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
- createConnectableDto(ProcessorDTO) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
- createConnectableDto(FunnelDTO) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
- createConnectableDto(RemoteProcessGroupPortDTO, ConnectableType) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
- createConnectDetails(Connection, Collection<Relationship>) - Method in class org.apache.nifi.audit.RelationshipAuditor
-
- createConnectDetails(Connection, Connectable, Collection<Relationship>, Connectable) - Method in class org.apache.nifi.audit.RelationshipAuditor
-
Creates action details for connect/disconnect actions.
- createConnection(String, String, Connectable, Connectable, Collection<String>) - Method in class org.apache.nifi.controller.FlowController
-
Creates a connection between two Connectable objects.
- createConnection(ConfigurationContext) - Method in class org.apache.nifi.hbase.HBase_1_1_2_ClientService
-
- createConnection(ConfigurationContext) - Method in class org.apache.nifi.hbase.MockHBaseClientService
-
- createConnection(ProcessContext) - Static method in class org.apache.nifi.processors.standard.util.JmsFactory
-
- createConnection(ProcessContext, String) - Static method in class org.apache.nifi.processors.standard.util.JmsFactory
-
- createConnection(String, String, String, String, int) - Static method in class org.apache.nifi.processors.standard.util.JmsFactory
-
- createConnection(HttpServletRequest, String, ConnectionEntity) - Method in class org.apache.nifi.web.api.ProcessGroupResource
-
Creates a new connection.
- createConnection(String, ConnectionDTO) - Method in interface org.apache.nifi.web.dao.ConnectionDAO
-
Creates a new Connection.
- createConnection(String, ConnectionDTO) - Method in class org.apache.nifi.web.dao.impl.StandardConnectionDAO
-
- createConnection(Revision, String, ConnectionDTO) - Method in interface org.apache.nifi.web.NiFiServiceFacade
-
Creates a new Relationship target.
- createConnection(Revision, String, ConnectionDTO) - Method in class org.apache.nifi.web.StandardNiFiServiceFacade
-
- createConnectionAdvice(ProceedingJoinPoint) - Method in class org.apache.nifi.audit.RelationshipAuditor
-
Audits the creation of relationships via createConnection().
- createConnectionDto(Connection) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
Creates a ConnectionDTO from the specified Connection.
- createConnectionEntity(ConnectionDTO, RevisionDTO, PermissionsDTO, ConnectionStatusDTO) - Method in class org.apache.nifi.web.api.dto.EntityFactory
-
- createConnectionFactory(URI, int, String) - Static method in class org.apache.nifi.processors.standard.util.JmsFactory
-
- createConnectionFactory(String, int, String) - Static method in class org.apache.nifi.processors.standard.util.JmsFactory
-
- createConnectionFactory(PropertyContext, ComponentLog) - Static method in class org.apache.nifi.redis.util.RedisUtils
-
- createConnectionRequestMessage() - Method in class org.apache.nifi.cluster.protocol.jaxb.message.ObjectFactory
-
- createConnectionResponseMessage() - Method in class org.apache.nifi.cluster.protocol.jaxb.message.ObjectFactory
-
- createConnectionStatusDto(ConnectionStatus) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
- createConnectionStatusEntity(ConnectionStatusDTO, PermissionsDTO) - Method in class org.apache.nifi.web.api.dto.EntityFactory
-
- createConnectionStatusSnapshotEntity(ConnectionStatusSnapshotDTO, PermissionsDTO) - Method in class org.apache.nifi.web.api.dto.EntityFactory
-
- createConsumerPool(ProcessContext, ComponentLog) - Method in class org.apache.nifi.processors.kafka.pubsub.ConsumeKafka
-
- createConsumerPool(ProcessContext, ComponentLog) - Method in class org.apache.nifi.processors.kafka.pubsub.ConsumeKafka_0_10
-
- createConsumerPool(ProcessContext, ComponentLog) - Method in class org.apache.nifi.processors.kafka.pubsub.ConsumeKafka_0_11
-
- createConsumerPool(ProcessContext, ComponentLog) - Method in class org.apache.nifi.processors.kafka.pubsub.ConsumeKafkaRecord_0_10
-
- createConsumerPool(ProcessContext, ComponentLog) - Method in class org.apache.nifi.processors.kafka.pubsub.ConsumeKafkaRecord_0_11
-
- createConsumers(ProcessContext) - Method in class org.apache.nifi.processors.kafka.GetKafka
-
- createContentClaim(String, ResourceClaimManager) - Static method in class org.apache.nifi.controller.swap.MockFlowFile
-
- createControllerConfigurationDto(ControllerFacade) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
- createControllerConfigurationEntity(ControllerConfigurationDTO, RevisionDTO, PermissionsDTO) - Method in class org.apache.nifi.web.api.dto.EntityFactory
-
- createControllerService(String, String, BundleCoordinate, Set<URL>, boolean) - Method in class org.apache.nifi.controller.FlowController
-
- createControllerService(String, String, BundleCoordinate, Set<URL>, boolean) - Method in interface org.apache.nifi.controller.service.ControllerServiceProvider
-
Creates a new Controller Service of the specified type and assigns it the
given id.
- createControllerService(String, String, BundleCoordinate, Set<URL>, boolean) - Method in class org.apache.nifi.controller.service.StandardControllerServiceProvider
-
- createControllerService(HttpServletRequest, ControllerServiceEntity) - Method in class org.apache.nifi.web.api.ControllerResource
-
Creates a new Controller Service.
- createControllerService(HttpServletRequest, String, ControllerServiceEntity) - Method in class org.apache.nifi.web.api.ProcessGroupResource
-
Creates a new Controller Service.
- createControllerService(ControllerServiceDTO) - Method in interface org.apache.nifi.web.dao.ControllerServiceDAO
-
Creates a controller service.
- createControllerService(ControllerServiceDTO) - Method in class org.apache.nifi.web.dao.impl.StandardControllerServiceDAO
-
- createControllerService(Revision, String, ControllerServiceDTO) - Method in interface org.apache.nifi.web.NiFiServiceFacade
-
Creates a controller service.
- createControllerService(Revision, String, ControllerServiceDTO) - Method in class org.apache.nifi.web.StandardNiFiServiceFacade
-
- createControllerServiceAdvice(ProceedingJoinPoint) - Method in class org.apache.nifi.audit.ControllerServiceAuditor
-
Audits the creation of controller service via createControllerService().
- createControllerServiceDto(ControllerServiceNode) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
- createControllerServiceEntity(ControllerServiceDTO, RevisionDTO, PermissionsDTO, List<BulletinEntity>) - Method in class org.apache.nifi.web.api.dto.EntityFactory
-
- createControllerServiceReferencingComponentDTO(ConfiguredComponent) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
- createControllerServiceReferencingComponentEntity(ControllerServiceReferencingComponentDTO, RevisionDTO, PermissionsDTO) - Method in class org.apache.nifi.web.api.dto.EntityFactory
-
- createCounterDto(Counter) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
Creates a CounterDTO from the specified Counter.
- createCountersDto(Collection<CounterDTO>) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
Creates CounterDTOs for each Counter specified.
- createCreateEvent() - Static method in class org.apache.nifi.processors.hadoop.inotify.util.EventTestUtils
-
- createCSVProperties(ProcessContext) - Method in class org.apache.nifi.processors.kite.ConvertCSVToAvro
-
- createCuratorClient() - Method in class org.apache.nifi.cluster.integration.Cluster
-
- createDataFlow() - Method in class org.apache.nifi.controller.StandardFlowService
-
- createDataFlow() - Method in interface org.apache.nifi.services.FlowService
-
Creates a DataFlow object by first looking for a flow on from disk, and falling back to the controller's flow otherwise.
- createDataFlowFromController() - Method in class org.apache.nifi.controller.StandardFlowService
-
- createDataFlowFromController() - Method in interface org.apache.nifi.services.FlowService
-
Creates a DataFlow object by serializing the flow controller's flow.
- createDataPacket(String) - Static method in class org.apache.nifi.remote.protocol.SiteToSiteTestUtils
-
- createDataset() - Method in class org.apache.nifi.processors.kite.TestKiteStorageProcessor
-
- createDataSizeBoundsValidator(long, long) - Static method in class org.apache.nifi.processor.util.StandardValidators
-
- createDefinition(InstanceIdentifier, int, Supplier<String>, Supplier<String>, Supplier<String>) - Static method in class org.apache.nifi.toolkit.tls.configuration.InstanceDefinition
-
- createDefinitions(Stream<String>, Stream<String>, Supplier<String>, Supplier<String>, Supplier<String>) - Static method in class org.apache.nifi.toolkit.tls.configuration.InstanceDefinition
-
Creates a list of instance definitions
- createDirectory(FileSystem, Path, String, String) - Method in class org.apache.nifi.processors.hadoop.AbstractPutHDFSRecord
-
Creates the given directory and changes the ownership to the specified owner/group.
- createDirectoryExistsValidator(boolean, boolean) - Static method in class org.apache.nifi.processor.util.StandardValidators
-
- createDisconnectionMessage() - Method in class org.apache.nifi.cluster.protocol.jaxb.message.ObjectFactory
-
- createDispatcher(ProcessContext, BlockingQueue<E>) - Method in class org.apache.nifi.processor.util.listen.AbstractListenEventProcessor
-
- createDispatcher(ProcessContext, BlockingQueue<BeatsEvent>) - Method in class org.apache.nifi.processors.beats.ListenBeats
-
- createDispatcher(ProcessContext, BlockingQueue<LumberjackEvent>) - Method in class org.apache.nifi.processors.lumberjack.ListenLumberjack
-
Deprecated.
- createDispatcher(ProcessContext, BlockingQueue<RELPEvent>) - Method in class org.apache.nifi.processors.standard.ListenRELP
-
- createDispatcher(ProcessContext, BlockingQueue<StandardEvent>) - Method in class org.apache.nifi.processors.standard.ListenTCP
-
- createDispatcher(ProcessContext, BlockingQueue<StandardEvent>) - Method in class org.apache.nifi.processors.standard.ListenUDP
-
- createDispatcher(ProcessContext, BlockingQueue<StandardEvent>) - Method in class org.apache.nifi.processors.standard.ListenUDPRecord
-
- createDomainAlternativeNamesExtensions(String, String) - Static method in class org.apache.nifi.toolkit.tls.util.TlsHelper
-
- createDownloadToken(HttpServletRequest) - Method in class org.apache.nifi.web.api.AccessResource
-
Creates a single use access token for downloading FlowFile content.
- createDropRequest(HttpServletRequest, String) - Method in class org.apache.nifi.web.api.FlowFileQueueResource
-
Creates a request to delete the flowfiles in the queue of the specified connection.
- createDropRequestDTO(DropFlowFileStatus) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
Creates a DropRequestDTO from the specified flow file status.
- createElasticsearchClient(ProcessContext) - Method in class org.apache.nifi.processors.elasticsearch.AbstractElasticsearchHttpProcessor
-
- createElasticsearchClient(ProcessContext) - Method in class org.apache.nifi.processors.elasticsearch.AbstractElasticsearchProcessor
-
- createElasticsearchClient(ProcessContext) - Method in class org.apache.nifi.processors.elasticsearch.AbstractElasticsearchTransportClientProcessor
-
Instantiate ElasticSearch Client.
- createEmpty() - Static method in class org.apache.nifi.util.ComponentStatusReport
-
- createEncryptor(NiFiProperties) - Static method in class org.apache.nifi.encrypt.StringEncryptor
-
- createEncryptor(String, String, String) - Static method in class org.apache.nifi.encrypt.StringEncryptor
-
Creates an instance of the NiFi sensitive property encryptor.
- createEvent() - Method in class org.apache.nifi.provenance.AbstractTestRecordReaderWriter
-
- createEvent() - Static method in class org.apache.nifi.provenance.TestUtil
-
- createEventHubClient(String, String, String, String) - Method in class org.apache.nifi.processors.azure.eventhub.PutAzureEventHub
-
- createEventIterator(long) - Method in interface org.apache.nifi.provenance.store.EventStorePartition
-
Returns an
EventIterator
that is capable of iterating over the events in the store beginning with the given
record id.
- createEventIterator(List<Long>) - Method in interface org.apache.nifi.provenance.store.EventStorePartition
-
Returns an
EventIterator
that iterates over the given event ID's and returns one ProvenanceEventRecord for
each given, if the ID given can be found.
- createEventIterator(long) - Method in class org.apache.nifi.provenance.store.WriteAheadStorePartition
-
- createEventIterator(List<Long>) - Method in class org.apache.nifi.provenance.store.WriteAheadStorePartition
-
- createFieldDescriptorDtos(Collection<MetricDescriptor<?>>) - Static method in class org.apache.nifi.controller.status.history.StatusHistoryUtil
-
- createFieldDescriptorDtos(StatusHistory) - Static method in class org.apache.nifi.controller.status.history.StatusHistoryUtil
-
- createFileTransfer(ProcessContext) - Method in class org.apache.nifi.processors.standard.FetchFileTransfer
-
Creates a new instance of a FileTransfer that can be used to pull files from a remote system.
- createFileTransfer(ProcessContext) - Method in class org.apache.nifi.processors.standard.FetchFTP
-
- createFileTransfer(ProcessContext) - Method in class org.apache.nifi.processors.standard.FetchSFTP
-
- createFingerprint(byte[]) - Method in class org.apache.nifi.fingerprint.FingerprintFactory
-
Creates a fingerprint of a flow.
- createFingerprint(byte[], FlowController) - Method in class org.apache.nifi.fingerprint.FingerprintFactory
-
Creates a fingerprint of a flow.
- createFlowBreadcrumbEntity(FlowBreadcrumbDTO, PermissionsDTO) - Method in class org.apache.nifi.web.api.dto.EntityFactory
-
- createFlowConfigurationDto(String) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
- createFlowDto(ProcessGroup, ProcessGroupStatus, FlowSnippetDTO, RevisionManager, Function<ProcessGroup, List<BulletinEntity>>) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
- createFlowDto(ProcessGroup, ProcessGroupStatus, RevisionManager, Function<ProcessGroup, List<BulletinEntity>>) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
- createFlowFile(long, long, Map<String, String>) - Static method in class org.apache.nifi.provenance.TestUtil
-
- createFlowFile(long, Map<String, String>) - Static method in class org.apache.nifi.reporting.TestSiteToSiteProvenanceReportingTask
-
- createFlowFile(long, Map<String, String>) - Static method in class org.apache.nifi.reporting.TestSiteToSiteStatusReportingTask
-
- createFlowFile(File) - Method in class org.apache.nifi.util.MockProcessSession
-
- createFlowFile(byte[]) - Method in class org.apache.nifi.util.MockProcessSession
-
- createFlowFile(byte[], Map<String, String>) - Method in class org.apache.nifi.util.MockProcessSession
-
- createFlowFileDropRequest(String, String) - Method in interface org.apache.nifi.web.dao.ConnectionDAO
-
Creates a new flow file drop request.
- createFlowFileDropRequest(String, String) - Method in class org.apache.nifi.web.dao.impl.StandardConnectionDAO
-
- createFlowFileDropRequest(String, String) - Method in interface org.apache.nifi.web.NiFiServiceFacade
-
Creates a new flow file drop request.
- createFlowFileDropRequest(String, String) - Method in class org.apache.nifi.web.StandardNiFiServiceFacade
-
- createFlowFileDTO(FlowFileRecord) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
Creates a FlowFileDTO from the specified FlowFileRecord.
- createFlowFileListing(HttpServletRequest, String) - Method in class org.apache.nifi.web.api.FlowFileQueueResource
-
Creates a request to list the flowfiles in the queue of the specified connection.
- createFlowFileListingRequest(String, String) - Method in interface org.apache.nifi.web.dao.ConnectionDAO
-
Creates a new flow file listing request.
- createFlowFileListingRequest(String, String) - Method in class org.apache.nifi.web.dao.impl.StandardConnectionDAO
-
- createFlowFileListingRequest(String, String) - Method in interface org.apache.nifi.web.NiFiServiceFacade
-
Creates a new flow file listing request.
- createFlowFileListingRequest(String, String) - Method in class org.apache.nifi.web.StandardNiFiServiceFacade
-
- createFlowFileNodeDTO(LineageNode) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
Creates a FlowFileNodeDTO for the specified LineageNode.
- createFlowFiles(TestRunner) - Static method in class org.apache.nifi.processors.standard.util.TestInvokeHttpCommon
-
- createFlowFileSummaryDTO(FlowFileSummary, Date) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
Creates a FlowFileSummaryDTO from the specified FlowFileSummary.
- createFlowRequestMessage() - Method in class org.apache.nifi.cluster.protocol.jaxb.message.ObjectFactory
-
- createFlowResponseMessage() - Method in class org.apache.nifi.cluster.protocol.jaxb.message.ObjectFactory
-
- createFromRequestLine(String) - Static method in class org.apache.nifi.cluster.manager.testutils.HttpRequest
-
- createFunnel(String) - Method in class org.apache.nifi.controller.FlowController
-
Creates a funnel
- createFunnel(HttpServletRequest, String, FunnelEntity) - Method in class org.apache.nifi.web.api.ProcessGroupResource
-
Creates a new Funnel.
- createFunnel(String, FunnelDTO) - Method in interface org.apache.nifi.web.dao.FunnelDAO
-
Creates a funnel in the specified group.
- createFunnel(String, FunnelDTO) - Method in class org.apache.nifi.web.dao.impl.StandardFunnelDAO
-
- createFunnel(Revision, String, FunnelDTO) - Method in interface org.apache.nifi.web.NiFiServiceFacade
-
Creates a funnel.
- createFunnel(Revision, String, FunnelDTO) - Method in class org.apache.nifi.web.StandardNiFiServiceFacade
-
- createFunnelAdvice(ProceedingJoinPoint) - Method in class org.apache.nifi.audit.FunnelAuditor
-
Audits the creation of a funnel.
- createFunnelDto(Funnel) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
Creates a FunnelDTO from the specified Funnel.
- createFunnelEntity(FunnelDTO, RevisionDTO, PermissionsDTO) - Method in class org.apache.nifi.web.api.dto.EntityFactory
-
- createGarbageCollectionDTO(String, GarbageCollection) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
Creates a GarbageCollectionDTO from the specified GarbageCollection.
- createGrantee(String) - Method in class org.apache.nifi.processors.aws.s3.AbstractS3Processor
-
- createGrantees(String) - Method in class org.apache.nifi.processors.aws.s3.AbstractS3Processor
-
- CreateHadoopSequenceFile - Class in org.apache.nifi.processors.hadoop
-
This processor is used to create a Hadoop Sequence File, which essentially is a file of key/value pairs.
- CreateHadoopSequenceFile() - Constructor for class org.apache.nifi.processors.hadoop.CreateHadoopSequenceFile
-
- createHandler(SelectionKey, D, Charset, EventFactory<E>, BlockingQueue<E>, ComponentLog) - Method in interface org.apache.nifi.processor.util.listen.handler.ChannelHandlerFactory
-
- createHandler(SelectionKey, AsyncChannelDispatcher, Charset, EventFactory<E>, BlockingQueue<E>, ComponentLog) - Method in class org.apache.nifi.processor.util.listen.handler.socket.SocketChannelHandlerFactory
-
- createHandler(SelectionKey, AsyncChannelDispatcher, Charset, EventFactory<E>, BlockingQueue<E>, ComponentLog) - Method in class org.apache.nifi.processors.beats.handler.BeatsSocketChannelHandlerFactory
-
- createHandler(SelectionKey, AsyncChannelDispatcher, Charset, EventFactory<E>, BlockingQueue<E>, ComponentLog) - Method in class org.apache.nifi.processors.lumberjack.handler.LumberjackSocketChannelHandlerFactory
-
Deprecated.
- createHandler(SelectionKey, AsyncChannelDispatcher, Charset, EventFactory<E>, BlockingQueue<E>, ComponentLog) - Method in class org.apache.nifi.processors.standard.relp.handler.RELPSocketChannelHandlerFactory
-
- createHDFSRecordReader(ProcessContext, FlowFile, Configuration, Path) - Method in class org.apache.nifi.processors.hadoop.AbstractFetchHDFSRecord
-
Sub-classes provide the appropriate HDFSRecordReader.
- createHDFSRecordReader(ProcessContext, FlowFile, Configuration, Path) - Method in class org.apache.nifi.processors.parquet.FetchParquet
-
- createHDFSRecordWriter(ProcessContext, FlowFile, Configuration, Path, RecordSchema) - Method in class org.apache.nifi.processors.hadoop.AbstractPutHDFSRecord
-
Sub-classes provide the appropriate HDFSRecordWriter.
- createHDFSRecordWriter(ProcessContext, FlowFile, Configuration, Path, RecordSchema) - Method in class org.apache.nifi.processors.parquet.PutParquet
-
- createHeartbeatMessage() - Method in class org.apache.nifi.cluster.protocol.jaxb.message.ObjectFactory
-
- createHeartbeatResponse() - Method in class org.apache.nifi.cluster.protocol.jaxb.message.ObjectFactory
-
- createHistoryDto(History) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
Creates a HistoryDTO from the specified History.
- createHttpServer(ProcessContext) - Method in class org.apache.nifi.processors.standard.ListenHTTP
-
- createIdentifiers(Stream<String>) - Static method in class org.apache.nifi.toolkit.tls.configuration.InstanceIdentifier
-
Creates a stream of hostname identifiers from a stream of hostname expressions
- createIndexingAction() - Method in class org.apache.nifi.provenance.PersistentProvenanceRepository
-
This method is protected and exists for testing purposes.
- createInputPort(HttpServletRequest, String, PortEntity) - Method in class org.apache.nifi.web.api.ProcessGroupResource
-
Creates a new input port.
- createInputPort(Revision, String, PortDTO) - Method in interface org.apache.nifi.web.NiFiServiceFacade
-
Creates a new input port.
- createInputPort(Revision, String, PortDTO) - Method in class org.apache.nifi.web.StandardNiFiServiceFacade
-
- createInsertSelectDrop(Connection) - Method in class org.apache.nifi.dbcp.DBCPServiceTest
-
- createInstance(String, Class<T>, NiFiProperties) - Static method in class org.apache.nifi.nar.NarThreadContextClassLoader
-
Constructs an instance of the given type using either default no args
constructor or a constructor which takes a NiFiProperties object
(preferred).
- createInstanceClassLoader(String, String, Bundle, Set<URL>) - Static method in class org.apache.nifi.nar.ExtensionManager
-
Determines the effective ClassLoader for the instance of the given type.
- createKafkaConsumer() - Method in class org.apache.nifi.processors.kafka.pubsub.ConsumerPool
-
Exposed as protected method for easier unit testing
- createKey(String) - Method in class org.apache.nifi.admin.dao.impl.StandardKeyDAO
-
- createKey(String) - Method in interface org.apache.nifi.admin.dao.KeyDAO
-
Creates a key for the specified user identity.
- createLabel(String, String) - Method in class org.apache.nifi.controller.FlowController
-
Creates a new Label
- createLabel(HttpServletRequest, String, LabelEntity) - Method in class org.apache.nifi.web.api.ProcessGroupResource
-
Creates a new Label.
- createLabel(String, LabelDTO) - Method in class org.apache.nifi.web.dao.impl.StandardLabelDAO
-
- createLabel(String, LabelDTO) - Method in interface org.apache.nifi.web.dao.LabelDAO
-
Creates a label in the specified group.
- createLabel(Revision, String, LabelDTO) - Method in interface org.apache.nifi.web.NiFiServiceFacade
-
Creates a label.
- createLabel(Revision, String, LabelDTO) - Method in class org.apache.nifi.web.StandardNiFiServiceFacade
-
- createLabelDto(Label) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
Creates a LabelDTO from the specified Label.
- createLabelEntity(LabelDTO, RevisionDTO, PermissionsDTO) - Method in class org.apache.nifi.web.api.dto.EntityFactory
-
- createLineageDto(ComputeLineageSubmission) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
Creates a LineageDTO for the specified Lineage.
- createListingRequestDTO(ListFlowFileStatus) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
Creates a ListingRequestDTO from the specified ListFlowFileStatus.
- createListValidator(boolean, boolean, Validator) - Static method in class org.apache.nifi.processor.util.StandardValidators
-
- createLocalDataAuthorizable(String) - Method in class org.apache.nifi.controller.FlowController
-
- createLocalDataAuthorizable(String) - Method in interface org.apache.nifi.provenance.ProvenanceAuthorizableFactory
-
Generates an Authorizable object for the Data of the component with the given ID.
- createLocalInputPort(String, String) - Method in class org.apache.nifi.controller.FlowController
-
Creates a Port to use as an Input Port for a Process Group
- createLocalOutputPort(String, String) - Method in class org.apache.nifi.controller.FlowController
-
Creates a Port to use as an Output Port for a Process Group
- createLock(ProceedingJoinPoint) - Method in class org.apache.nifi.web.NiFiServiceFacadeLock
-
- createLogger() - Static method in class org.apache.nifi.processors.standard.util.SFTPUtils
-
- createLongValidator(long, long, boolean) - Static method in class org.apache.nifi.processor.util.StandardValidators
-
- createMapCacheServer(int, int, SSLContext, EvictionPolicy, File) - Method in class org.apache.nifi.distributed.cache.server.map.DistributedMapCacheServer
-
- createMapMessage() - Static method in class org.apache.nifi.processors.standard.TestJmsConsumer
-
- createMapMessageValues(MapMessage) - Static method in class org.apache.nifi.processors.standard.JmsConsumer
-
- createMapWithSender(String) - Static method in class org.apache.nifi.processor.util.listen.event.EventFactoryUtil
-
- createMarshaller() - Method in class org.apache.nifi.cluster.protocol.jaxb.JaxbProtocolContext
-
- createMarshaller() - Method in interface org.apache.nifi.cluster.protocol.ProtocolContext
-
Creates a marshaller for serializing protocol messages.
- createMessageProducer(ProcessContext) - Static method in class org.apache.nifi.processors.standard.util.JmsFactory
-
- createMessageProducer(ProcessContext, boolean) - Static method in class org.apache.nifi.processors.standard.util.JmsFactory
-
- createMetadataUpdateEvent() - Static method in class org.apache.nifi.processors.hadoop.inotify.util.EventTestUtils
-
- createMockResultSet() - Static method in class org.apache.nifi.processors.cassandra.CassandraQueryTestUtil
-
- createMockResultSetOneColumn() - Static method in class org.apache.nifi.processors.cassandra.CassandraQueryTestUtil
-
- createModuleClassLoader(URL[], ClassLoader) - Static method in class org.apache.nifi.util.file.classloader.ClassLoaderUtils
-
- createMoveDetails(String, String, Logger) - Method in class org.apache.nifi.audit.NiFiAuditor
-
- createMulticastProtocolMessage() - Method in class org.apache.nifi.cluster.protocol.jaxb.message.ObjectFactory
-
- createMulticastSocket(MulticastConfiguration) - Static method in class org.apache.nifi.io.socket.multicast.MulticastUtils
-
- createMulticastSocket(int, MulticastConfiguration) - Static method in class org.apache.nifi.io.socket.multicast.MulticastUtils
-
- createMultipleFilesExistValidator() - Static method in class org.apache.nifi.util.hive.HiveUtils
-
Validates that one or more files exist, as specified in a single property.
- createNew() - Method in class org.apache.nifi.util.timebuffer.CountSizeEntityAccess
-
- createNew() - Method in interface org.apache.nifi.util.timebuffer.EntityAccess
-
- createNew() - Method in class org.apache.nifi.util.timebuffer.LongEntityAccess
-
- createNiFiDataPacket(Tuple) - Method in interface org.apache.nifi.storm.NiFiDataPacketBuilder
-
- createNifiKeystoresAndTrustStores(StandaloneConfig) - Method in class org.apache.nifi.toolkit.tls.standalone.TlsToolkitStandalone
-
- createNode() - Method in class org.apache.nifi.cluster.integration.Cluster
-
- createNodeConnectionStatusRequestMessage() - Method in class org.apache.nifi.cluster.protocol.jaxb.message.ObjectFactory
-
- createNodeConnectionStatusResponsetMessage() - Method in class org.apache.nifi.cluster.protocol.jaxb.message.ObjectFactory
-
- createNodeDTO(NodeIdentifier, NodeConnectionStatus, NodeHeartbeat, List<NodeEvent>, Set<String>) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
- createNodeStatusChangeMessage() - Method in class org.apache.nifi.cluster.protocol.jaxb.message.ObjectFactory
-
- createOnError(ProcessContext, ProcessSession, RoutingResult, Relationship, Relationship) - Static method in class org.apache.nifi.processor.util.pattern.ExceptionHandler
-
- createOnError(ExceptionHandler.OnError<FCT, I>) - Static method in class org.apache.nifi.processor.util.pattern.RollbackOnFailure
-
- createOnGroupError(ProcessContext, ProcessSession, RoutingResult, Relationship, Relationship) - Static method in class org.apache.nifi.processor.util.pattern.ExceptionHandler
-
- createOrcStruct(TypeInfo, Object...) - Static method in class org.apache.hadoop.hive.ql.io.orc.NiFiOrcUtils
-
Create an object of OrcStruct given a TypeInfo and a list of objects
- createOrderMap(Stream<String>) - Static method in class org.apache.nifi.toolkit.tls.configuration.InstanceIdentifier
-
Creates a map that can be used to deterministically assign global instance numbers
- createOutputPort(HttpServletRequest, String, PortEntity) - Method in class org.apache.nifi.web.api.ProcessGroupResource
-
Creates a new output port.
- createOutputPort(Revision, String, PortDTO) - Method in interface org.apache.nifi.web.NiFiServiceFacade
-
Creates a new output port.
- createOutputPort(Revision, String, PortDTO) - Method in class org.apache.nifi.web.StandardNiFiServiceFacade
-
- createPermissionsDto(Authorizable) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
Creates the PermissionsDTO based on the specified Authorizable.
- createPermissionsDto(Authorizable, NiFiUser) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
Creates the PermissionsDTO based on the specified Authorizable for the given user
- createPingMessage() - Method in class org.apache.nifi.cluster.protocol.jaxb.message.ObjectFactory
-
- createPort(String, PortDTO) - Method in class org.apache.nifi.web.dao.impl.StandardInputPortDAO
-
- createPort(String, PortDTO) - Method in class org.apache.nifi.web.dao.impl.StandardOutputPortDAO
-
- createPort(String, PortDTO) - Method in interface org.apache.nifi.web.dao.PortDAO
-
Creates a port in the specified group.
- createPortAdvice(ProceedingJoinPoint) - Method in class org.apache.nifi.audit.PortAuditor
-
Audits the creation of a port.
- createPortDto(Port) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
Creates a PortDTO from the specified Port.
- createPortEntity(PortDTO, RevisionDTO, PermissionsDTO, PortStatusDTO, List<BulletinEntity>) - Method in class org.apache.nifi.web.api.dto.EntityFactory
-
- createPortStatusDto(PortStatus) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
Creates a PortStatusDTO for the specified PortStatus.
- createPortStatusEntity(PortStatusDTO, PermissionsDTO) - Method in class org.apache.nifi.web.api.dto.EntityFactory
-
- createPortStatusSnapshotEntity(PortStatusSnapshotDTO, PermissionsDTO) - Method in class org.apache.nifi.web.api.dto.EntityFactory
-
- createPortTransaction(String, String, HttpServletRequest, ServletContext, UriInfo, InputStream) - Method in class org.apache.nifi.web.api.DataTransferResource
-
- createPositionDto(Position) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
Creates a PositionDTO from the specified position
- createPrioritizer(String) - Method in class org.apache.nifi.controller.FlowController
-
- createProcessGroup(String) - Method in class org.apache.nifi.controller.FlowController
-
Creates a ProcessGroup with the given ID
- createProcessGroup(HttpServletRequest, String, ProcessGroupEntity) - Method in class org.apache.nifi.web.api.ProcessGroupResource
-
Adds the specified process group.
- createProcessGroup(String, ProcessGroupDTO) - Method in class org.apache.nifi.web.dao.impl.StandardProcessGroupDAO
-
- createProcessGroup(String, ProcessGroupDTO) - Method in interface org.apache.nifi.web.dao.ProcessGroupDAO
-
Creates a process group reference.
- createProcessGroup(Revision, String, ProcessGroupDTO) - Method in interface org.apache.nifi.web.NiFiServiceFacade
-
Creates a new process group.
- createProcessGroup(Revision, String, ProcessGroupDTO) - Method in class org.apache.nifi.web.StandardNiFiServiceFacade
-
- createProcessGroupAdvice(ProceedingJoinPoint) - Method in class org.apache.nifi.audit.ProcessGroupAuditor
-
Audits the creation of process groups via createProcessGroup().
- createProcessGroupDto(ProcessGroup) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
Creates a ProcessGroupDTO from the specified ProcessGroup.
- createProcessGroupDto(ProcessGroup, boolean) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
Creates a ProcessGroupDTO from the specified ProcessGroup.
- createProcessGroupEntity(ProcessGroupDTO, RevisionDTO, PermissionsDTO, ProcessGroupStatusDTO, List<BulletinEntity>) - Method in class org.apache.nifi.web.api.dto.EntityFactory
-
- createProcessGroupFlowDto(ProcessGroup, ProcessGroupStatus, RevisionManager, Function<ProcessGroup, List<BulletinEntity>>) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
- createProcessGroupFlowEntity(ProcessGroupFlowDTO, PermissionsDTO) - Method in class org.apache.nifi.web.api.dto.EntityFactory
-
- createProcessGroupStatusDto(ProcessGroup, ProcessGroupStatus) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
- createProcessGroupStatusEntity(ProcessGroupStatusDTO, PermissionsDTO) - Method in class org.apache.nifi.web.api.dto.EntityFactory
-
- createProcessGroupStatusSnapshotEntity(ProcessGroupStatusSnapshotDTO, PermissionsDTO) - Method in class org.apache.nifi.web.api.dto.EntityFactory
-
- createProcessor(String, String, BundleCoordinate) - Method in class org.apache.nifi.controller.FlowController
-
Creates a new ProcessorNode with the given type and identifier and
initializes it invoking the methods annotated with
OnAdded
.
- createProcessor(String, String, BundleCoordinate, boolean) - Method in class org.apache.nifi.controller.FlowController
-
Creates a new ProcessorNode with the given type and identifier and
optionally initializes it.
- createProcessor(String, String, BundleCoordinate, Set<URL>, boolean, boolean) - Method in class org.apache.nifi.controller.FlowController
-
Creates a new ProcessorNode with the given type and identifier and
optionally initializes it.
- createProcessor(AccessControlHelper, String) - Static method in class org.apache.nifi.integration.accesscontrol.ITProcessorAccessControl
-
- createProcessor(HttpServletRequest, String, ProcessorEntity) - Method in class org.apache.nifi.web.api.ProcessGroupResource
-
Creates a new processor.
- createProcessor(String, ProcessorDTO) - Method in class org.apache.nifi.web.dao.impl.StandardProcessorDAO
-
- createProcessor(String, ProcessorDTO) - Method in interface org.apache.nifi.web.dao.ProcessorDAO
-
Creates a new Processor.
- createProcessor(Revision, String, ProcessorDTO) - Method in interface org.apache.nifi.web.NiFiServiceFacade
-
Creates a new Processor.
- createProcessor(Revision, String, ProcessorDTO) - Method in class org.apache.nifi.web.StandardNiFiServiceFacade
-
- createProcessorAdvice(ProceedingJoinPoint) - Method in class org.apache.nifi.audit.ProcessorAuditor
-
Audits the creation of processors via createProcessor().
- createProcessorConfigDto(ProcessorNode) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
Creates a ProcessorConfigDTO from the specified ProcessorNode.
- createProcessorDto(ProcessorNode) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
Creates a ProcessorDTO from the specified ProcessorNode.
- createProcessorEntity(ProcessorDTO, RevisionDTO, PermissionsDTO, ProcessorStatusDTO, List<BulletinEntity>) - Method in class org.apache.nifi.web.api.dto.EntityFactory
-
- createProcessorStatusDto(ProcessorStatus) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
- createProcessorStatusEntity(ProcessorStatusDTO, PermissionsDTO) - Method in class org.apache.nifi.web.api.dto.EntityFactory
-
- createProcessorStatusSnapshotEntity(ProcessorStatusSnapshotDTO, PermissionsDTO) - Method in class org.apache.nifi.web.api.dto.EntityFactory
-
- createPropertyDescriptorDto(PropertyDescriptor, String) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
Creates a PropertyDesriptorDTO from the specified PropertyDesriptor.
- createProvenanceEventNodeDTO(ProvenanceEventLineageNode) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
Creates a ProvenanceEventNodeDTO for the specified ProvenanceEventLineageNode.
- createProvenanceLinkDTO(LineageEdge) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
Creates a ProvenanceLinkDTO for the specified LineageEdge.
- createPublisherPool(ProcessContext) - Method in class org.apache.nifi.processors.kafka.pubsub.PublishKafka
-
- createPublisherPool(ProcessContext) - Method in class org.apache.nifi.processors.kafka.pubsub.PublishKafka_0_10
-
- createPublisherPool(ProcessContext) - Method in class org.apache.nifi.processors.kafka.pubsub.PublishKafka_0_11
-
- createPublisherPool(ProcessContext) - Method in class org.apache.nifi.processors.kafka.pubsub.PublishKafkaRecord_0_10
-
- createPublisherPool(ProcessContext) - Method in class org.apache.nifi.processors.kafka.pubsub.PublishKafkaRecord_0_11
-
- createPut(ProcessSession, ProcessContext, FlowFile) - Method in class org.apache.nifi.hbase.AbstractPutHBase
-
Sub-classes provide the implementation to create a put from a FlowFile.
- createPut(ProcessSession, ProcessContext, FlowFile) - Method in class org.apache.nifi.hbase.PutHBaseCell
-
- createPut(ProcessSession, ProcessContext, FlowFile) - Method in class org.apache.nifi.hbase.PutHBaseJSON
-
- createPut(ProcessSession, ProcessContext, FlowFile) - Method in class org.apache.nifi.hbase.PutHBaseRecord
-
- createPut(ProcessContext, Record, RecordSchema, FlowFile, String, String, String, String, String, String) - Method in class org.apache.nifi.hbase.PutHBaseRecord
-
- createQueue(ProcessContext) - Static method in class org.apache.nifi.processors.standard.util.JmsFactory
-
- createQueue(ProcessContext, String) - Static method in class org.apache.nifi.processors.standard.util.JmsFactory
-
- createQueue(String, String) - Static method in class org.apache.nifi.processors.standard.util.JmsFactory
-
- createQueueMessageConsumer(ProcessContext) - Static method in class org.apache.nifi.processors.standard.util.JmsFactory
-
- createRangerBasePlugin(String, String) - Method in class org.apache.nifi.ranger.authorization.ManagedRangerAuthorizer
-
- createRangerBasePlugin(String, String) - Method in class org.apache.nifi.ranger.authorization.RangerNiFiAuthorizer
-
- createReader(InputStream, String, TocReader, int) - Method in class org.apache.nifi.provenance.AbstractTestRecordReaderWriter
-
- createReader(InputStream, String, TocReader, int) - Method in class org.apache.nifi.provenance.TestEventIdFirstSchemaRecordReaderWriter
-
- createReader(InputStream, String, TocReader, int) - Method in class org.apache.nifi.provenance.TestSchemaRecordReaderWriter
-
- createReader(InputStream, String, TocReader, int) - Method in class org.apache.nifi.provenance.TestStandardRecordReaderWriter
-
- createReconnectionRequestMessage() - Method in class org.apache.nifi.cluster.protocol.jaxb.message.ObjectFactory
-
- createReconnectionResponseMessage() - Method in class org.apache.nifi.cluster.protocol.jaxb.message.ObjectFactory
-
- createRecord(ProvenanceEventRecord, long) - Method in class org.apache.nifi.provenance.ByteArraySchemaRecordWriter
-
- createRecord(ProvenanceEventRecord, long) - Method in class org.apache.nifi.provenance.EventIdFirstSchemaRecordWriter
-
- createRecordPaths(ProcessContext) - Method in class org.apache.nifi.processors.standard.UpdateRecord
-
- createRecordReader(Map<String, String>, InputStream, ComponentLog) - Method in class org.apache.nifi.avro.AvroReader
-
- createRecordReader(Map<String, String>, InputStream, ComponentLog) - Method in class org.apache.nifi.csv.CSVReader
-
- createRecordReader(Map<String, String>, InputStream, ComponentLog) - Method in class org.apache.nifi.grok.GrokReader
-
- createRecordReader(Map<String, String>, InputStream, ComponentLog) - Method in class org.apache.nifi.json.JsonPathReader
-
- createRecordReader(Map<String, String>, InputStream, ComponentLog) - Method in class org.apache.nifi.json.JsonTreeReader
-
- createRecordReader(Map<String, String>, InputStream, ComponentLog) - Method in class org.apache.nifi.processors.kafka.pubsub.util.MockRecordParser
-
- createRecordReader(FlowFile, ComponentLog) - Method in interface org.apache.nifi.record.listen.SocketChannelRecordReader
-
Currently a RecordReader can only be created with a FlowFile.
- createRecordReader(FlowFile, ComponentLog) - Method in class org.apache.nifi.record.listen.SSLSocketChannelRecordReader
-
- createRecordReader(FlowFile, ComponentLog) - Method in class org.apache.nifi.record.listen.StandardSocketChannelRecordReader
-
- createRecordReader(Map<String, String>, InputStream, ComponentLog) - Method in class org.apache.nifi.record.script.ScriptedReader
-
- createRecordReader(Map<String, String>, InputStream, ComponentLog) - Method in class org.apache.nifi.serialization.record.CommaSeparatedRecordReader
-
- createRecordReader(Map<String, String>, InputStream, ComponentLog) - Method in class org.apache.nifi.serialization.record.MockRecordParser
-
- createRecordReader(FlowFile, InputStream, ComponentLog) - Method in interface org.apache.nifi.serialization.RecordReaderFactory
-
Create a RecordReader instance to read records from specified InputStream.
- createRecordReader(Map<String, String>, InputStream, ComponentLog) - Method in interface org.apache.nifi.serialization.RecordReaderFactory
-
Create a RecordReader instance to read records from specified InputStream.
- createRecordSet() - Method in interface org.apache.nifi.serialization.RecordReader
-
- createRegexMatchingValidator(Pattern) - Static method in class org.apache.nifi.processor.util.StandardValidators
-
- createRegexValidator(int, int, boolean) - Static method in class org.apache.nifi.processor.util.StandardValidators
-
Creates a @{link Validator} that ensure that a value is a valid Java
Regular Expression with at least minCapturingGroups
capturing groups and at most maxCapturingGroups
capturing
groups.
- createRejectionResponse(String) - Static method in class org.apache.nifi.cluster.protocol.ConnectionResponse
-
- createRemoteDataAuthorizable(String) - Method in class org.apache.nifi.controller.FlowController
-
- createRemoteDataAuthorizable(String) - Method in interface org.apache.nifi.provenance.ProvenanceAuthorizableFactory
-
Generates an Authorizable object for the Data of the remote group port with the given ID.
- createRemoteInputPort(String, String) - Method in class org.apache.nifi.controller.FlowController
-
Creates a Port to use as an Input Port for the root Process Group, which
is used for Site-to-Site communications
- createRemoteOutputPort(String, String) - Method in class org.apache.nifi.controller.FlowController
-
Creates a Port to use as an Output Port for the root Process Group, which
is used for Site-to-Site communications and will queue flow files waiting
to be delivered to remote instances
- createRemoteProcessGroup(String, String) - Method in class org.apache.nifi.controller.FlowController
-
Creates a new Remote Process Group with the given ID that points to the
given URI
- createRemoteProcessGroup(HttpServletRequest, String, RemoteProcessGroupEntity) - Method in class org.apache.nifi.web.api.ProcessGroupResource
-
Creates a new remote process group.
- createRemoteProcessGroup(String, RemoteProcessGroupDTO) - Method in class org.apache.nifi.web.dao.impl.StandardRemoteProcessGroupDAO
-
Creates a remote process group reference.
- createRemoteProcessGroup(String, RemoteProcessGroupDTO) - Method in interface org.apache.nifi.web.dao.RemoteProcessGroupDAO
-
Creates a remote process group reference.
- createRemoteProcessGroup(Revision, String, RemoteProcessGroupDTO) - Method in interface org.apache.nifi.web.NiFiServiceFacade
-
Creates a new remote process group.
- createRemoteProcessGroup(Revision, String, RemoteProcessGroupDTO) - Method in class org.apache.nifi.web.StandardNiFiServiceFacade
-
- createRemoteProcessGroupAdvice(ProceedingJoinPoint) - Method in class org.apache.nifi.audit.RemoteProcessGroupAuditor
-
Audits the creation of remote process groups via createRemoteProcessGroup().
- createRemoteProcessGroupDto(RemoteProcessGroup) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
Creates a RemoteProcessGroupDTO from the specified RemoteProcessGroup.
- createRemoteProcessGroupEntity(RemoteProcessGroupDTO, RevisionDTO, PermissionsDTO, RemoteProcessGroupStatusDTO, List<BulletinEntity>) - Method in class org.apache.nifi.web.api.dto.EntityFactory
-
- createRemoteProcessGroupPortDto(RemoteGroupPort) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
- createRemoteProcessGroupPortEntity(RemoteProcessGroupPortDTO, RevisionDTO, PermissionsDTO) - Method in class org.apache.nifi.web.api.dto.EntityFactory
-
- createRemoteProcessGroupStatusDto(RemoteProcessGroupStatus) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
- createRemoteProcessGroupStatusEntity(RemoteProcessGroupStatusDTO, PermissionsDTO) - Method in class org.apache.nifi.web.api.dto.EntityFactory
-
- createRemoteProcessGroupStatusSnapshotEntity(RemoteProcessGroupStatusSnapshotDTO, PermissionsDTO) - Method in class org.apache.nifi.web.api.dto.EntityFactory
-
- createReportingTask(String, BundleCoordinate) - Method in class org.apache.nifi.controller.FlowController
-
- createReportingTask(String, BundleCoordinate, boolean) - Method in class org.apache.nifi.controller.FlowController
-
- createReportingTask(String, String, BundleCoordinate, boolean) - Method in class org.apache.nifi.controller.FlowController
-
- createReportingTask(String, String, BundleCoordinate, Set<URL>, boolean, boolean) - Method in class org.apache.nifi.controller.FlowController
-
- createReportingTask(String, String, BundleCoordinate, boolean) - Method in interface org.apache.nifi.controller.reporting.ReportingTaskProvider
-
Creates a new instance of a reporting task
- createReportingTask(HttpServletRequest, ReportingTaskEntity) - Method in class org.apache.nifi.web.api.ControllerResource
-
Creates a new Reporting Task.
- createReportingTask(ReportingTaskDTO) - Method in class org.apache.nifi.web.dao.impl.StandardReportingTaskDAO
-
- createReportingTask(ReportingTaskDTO) - Method in interface org.apache.nifi.web.dao.ReportingTaskDAO
-
Creates a reporting task.
- createReportingTask(Revision, ReportingTaskDTO) - Method in interface org.apache.nifi.web.NiFiServiceFacade
-
Creates a reporting task.
- createReportingTask(Revision, ReportingTaskDTO) - Method in class org.apache.nifi.web.StandardNiFiServiceFacade
-
- createReportingTaskAdvice(ProceedingJoinPoint) - Method in class org.apache.nifi.audit.ReportingTaskAuditor
-
Audits the creation of reporting task via createReportingTask().
- createReportingTaskDto(ReportingTaskNode) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
- createReportingTaskEntity(ReportingTaskDTO, RevisionDTO, PermissionsDTO, List<BulletinEntity>) - Method in class org.apache.nifi.web.api.dto.EntityFactory
-
- createResourceDto(Resource) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
Creates a ResourceDTO from the specified Resource.
- createResources() - Method in class org.apache.nifi.script.ScriptingComponentHelper
-
This method creates all resources needed for the script processor to function, such as script engines,
script file reloader threads, etc.
- createRevisionDTO(FlowModification) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
Factory method for creating a new RevisionDTO based on this controller.
- createRevisionDTO(Revision) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
- createRollbackOnFailureProperty(String) - Static method in class org.apache.nifi.processor.util.pattern.RollbackOnFailure
-
- createRow(String, String, String, Set<String>, List<String>, Map<Date, String>, boolean, float, double) - Static method in class org.apache.nifi.processors.cassandra.CassandraQueryTestUtil
-
- createRow(String) - Static method in class org.apache.nifi.processors.cassandra.CassandraQueryTestUtil
-
- createRule(UriInfo, RuleEntity) - Method in class org.apache.nifi.update.attributes.api.RuleResource
-
- createRule(RuleDTO) - Method in class org.apache.nifi.update.attributes.UpdateAttributeModelFactory
-
- createRuleDTO(Rule) - Static method in class org.apache.nifi.update.attributes.dto.DtoFactory
-
- createSafeReader(InputStream) - Static method in class org.apache.nifi.security.xml.XmlUtils
-
- createSafeReader(StreamSource) - Static method in class org.apache.nifi.security.xml.XmlUtils
-
- createSchema(Schema) - Static method in class org.apache.nifi.avro.AvroTypeUtil
-
- createSchema(Schema, String, SchemaIdentifier) - Static method in class org.apache.nifi.avro.AvroTypeUtil
-
Converts an Avro Schema to a RecordSchema
- createSchema(ResultSet) - Static method in class org.apache.nifi.processors.cassandra.QueryCassandra
-
Creates an Avro schema from the given result set.
- createSchema(ResultSet) - Static method in class org.apache.nifi.processors.standard.util.JdbcCommon
-
- createSchema(ResultSet, String, boolean) - Static method in class org.apache.nifi.processors.standard.util.JdbcCommon
-
- createSchema(ResultSet, JdbcCommon.AvroConversionOptions) - Static method in class org.apache.nifi.processors.standard.util.JdbcCommon
-
Creates an Avro schema from a result set.
- createSchema(ResultSet) - Static method in class org.apache.nifi.util.hive.HiveJdbcCommon
-
- createSchema(ResultSet, String) - Static method in class org.apache.nifi.util.hive.HiveJdbcCommon
-
Creates an Avro schema from a result set.
- createScriptEngine() - Method in class org.apache.nifi.script.ScriptingComponentHelper
-
Provides a ScriptEngine corresponding to the currently selected script engine name.
- createSender(ProcessContext) - Method in class org.apache.nifi.processor.util.put.AbstractPutEventProcessor
-
Sub-classes create a ChannelSender given a context.
- createSender(String, String, int, int, int, SSLContext) - Method in class org.apache.nifi.processor.util.put.AbstractPutEventProcessor
-
Helper for sub-classes to create a sender.
- createSender(ProcessContext) - Method in class org.apache.nifi.processors.splunk.PutSplunk
-
- createSender(ProcessContext) - Method in class org.apache.nifi.processors.standard.PutSyslog
-
- createSender(SSLContextService, String, String, int, int, int) - Method in class org.apache.nifi.processors.standard.PutSyslog
-
- createSender(ProcessContext) - Method in class org.apache.nifi.processors.standard.PutTCP
-
Creates a concrete instance of a ChannelSender object to use for sending messages over a TCP stream.
- createSender(ProcessContext) - Method in class org.apache.nifi.processors.standard.PutUDP
-
Creates a concrete instance of a ChannelSender object to use for sending UDP datagrams.
- createSerDe(String) - Method in class org.apache.nifi.controller.repository.RepositoryRecordSerdeFactory
-
- createSerDe(String) - Method in interface org.wali.SerDeFactory
-
Returns a new SerDe
- createSerDe(String) - Method in class org.wali.SingletonSerDeFactory
-
- createServerProtocol(String) - Static method in class org.apache.nifi.remote.RemoteResourceManager
-
- createServerSocket(int, int, InetAddress) - Method in class org.apache.nifi.framework.security.util.SslServerSocketFactory
-
- createServerSocket(int, int) - Method in class org.apache.nifi.framework.security.util.SslServerSocketFactory
-
- createServerSocket(int) - Method in class org.apache.nifi.framework.security.util.SslServerSocketFactory
-
- createServerSocket() - Method in class org.apache.nifi.framework.security.util.SslServerSocketFactory
-
- createServerSocket(int, ServerSocketConfiguration) - Static method in class org.apache.nifi.io.socket.SocketUtils
-
- createServiceBroadcastMessage() - Method in class org.apache.nifi.cluster.protocol.jaxb.message.ObjectFactory
-
- createSession() - Method in class org.apache.nifi.controller.repository.BatchingSessionFactory
-
- createSession() - Method in class org.apache.nifi.controller.repository.StandardProcessSessionFactory
-
- createSession() - Method in interface org.apache.nifi.processor.ProcessSessionFactory
-
- createSession(ProcessContext, Connection, boolean) - Static method in class org.apache.nifi.processors.standard.util.JmsFactory
-
- createSession(Connection, String, boolean) - Static method in class org.apache.nifi.processors.standard.util.JmsFactory
-
- createSession(SFTPUtils.SFTPConfiguration, JSch) - Static method in class org.apache.nifi.processors.standard.util.SFTPUtils
-
- createSession() - Method in class org.apache.nifi.util.MockSessionFactory
-
- createSession() - Method in class org.apache.nifi.util.SingleSessionFactory
-
- createSinkValidator() - Static method in class org.apache.nifi.processors.flume.AbstractFlumeProcessor
-
- createSiteToSiteClient() - Method in class org.apache.nifi.storm.NiFiBolt
-
- createSiteToSiteRestApiClient(SSLContext, HttpProxy) - Method in class org.apache.nifi.remote.client.SiteInfoProvider
-
- createSnippet(HttpServletRequest, SnippetEntity) - Method in class org.apache.nifi.web.api.SnippetResource
-
Creates a snippet based off the specified configuration.
- createSnippet(SnippetDTO) - Method in class org.apache.nifi.web.dao.impl.StandardSnippetDAO
-
- createSnippet(SnippetDTO) - Method in interface org.apache.nifi.web.dao.SnippetDAO
-
Creates a snippet.
- createSnippet(SnippetDTO) - Method in interface org.apache.nifi.web.NiFiServiceFacade
-
Creates a new snippet.
- createSnippet(SnippetDTO) - Method in class org.apache.nifi.web.StandardNiFiServiceFacade
-
- createSnippetDto(Snippet) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
Creates a SnippetDTO from the specified Snippet.
- createSnippetEntity(SnippetDTO) - Method in class org.apache.nifi.web.api.dto.EntityFactory
-
- createSnmp() - Static method in class org.apache.nifi.snmp.processors.SNMPUtilsTest
-
Method to create an instance of SNMP
- createSocket(Socket, String, int, boolean) - Method in class org.apache.nifi.framework.security.util.SslSocketFactory
-
- createSocket(InetAddress, int, InetAddress, int) - Method in class org.apache.nifi.framework.security.util.SslSocketFactory
-
- createSocket(InetAddress, int) - Method in class org.apache.nifi.framework.security.util.SslSocketFactory
-
- createSocket(String, int, InetAddress, int) - Method in class org.apache.nifi.framework.security.util.SslSocketFactory
-
- createSocket(String, int) - Method in class org.apache.nifi.framework.security.util.SslSocketFactory
-
- createSocket() - Method in class org.apache.nifi.framework.security.util.SslSocketFactory
-
- createSocket(InetSocketAddress, SocketConfiguration) - Static method in class org.apache.nifi.io.socket.SocketUtils
-
- createSocket(Socket, String, int, boolean) - Method in class org.apache.nifi.ldap.LdapsSocketFactory
-
- createSocket(InetAddress, int, InetAddress, int) - Method in class org.apache.nifi.ldap.LdapsSocketFactory
-
- createSocket(InetAddress, int) - Method in class org.apache.nifi.ldap.LdapsSocketFactory
-
- createSocket(String, int, InetAddress, int) - Method in class org.apache.nifi.ldap.LdapsSocketFactory
-
- createSocket(String, int) - Method in class org.apache.nifi.ldap.LdapsSocketFactory
-
- createSocket() - Method in class org.apache.nifi.ldap.LdapsSocketFactory
-
- createSocket() - Method in class org.apache.nifi.processors.standard.util.SocksProxySocketFactory
-
- createSocket(InetAddress, int) - Method in class org.apache.nifi.processors.standard.util.SocksProxySocketFactory
-
- createSocket(InetAddress, int, InetAddress, int) - Method in class org.apache.nifi.processors.standard.util.SocksProxySocketFactory
-
- createSocket(String, int) - Method in class org.apache.nifi.processors.standard.util.SocksProxySocketFactory
-
- createSocket(String, int, InetAddress, int) - Method in class org.apache.nifi.processors.standard.util.SocksProxySocketFactory
-
- createSolrClient(ProcessContext, String) - Method in class org.apache.nifi.processors.solr.SolrProcessor
-
Create a SolrClient based on the type of Solr specified.
- createSourceValidator() - Static method in class org.apache.nifi.processors.flume.AbstractFlumeProcessor
-
- createSplunkService(ProcessContext) - Method in class org.apache.nifi.processors.splunk.GetSplunk
-
- createSqlStringValue(JsonNode, Integer, int) - Static method in class org.apache.nifi.processors.standard.ConvertJSONToSQL
-
Try to create correct SQL String representation of value.
- createSslConnectionFactory(URI, int, String, String, String, String, String) - Static method in class org.apache.nifi.processors.standard.util.JmsFactory
-
- createSslConnectionFactory(String, int, String, String, String, String, String) - Static method in class org.apache.nifi.processors.standard.util.JmsFactory
-
- createSslContext(NiFiProperties) - Static method in class org.apache.nifi.framework.security.util.SslContextFactory
-
- createSslContext(NiFiProperties, boolean) - Static method in class org.apache.nifi.framework.security.util.SslContextFactory
-
- createSSLContext() - Method in class org.apache.nifi.io.socket.ServerSocketConfiguration
-
- createSSLContext() - Method in class org.apache.nifi.io.socket.SocketConfiguration
-
- createSslContext() - Method in class org.apache.nifi.io.socket.SSLContextFactory
-
Creates a SSLContext instance using the given information.
- createSslContext(String, char[], String, String, char[], String, SslContextFactory.ClientAuth, String) - Static method in class org.apache.nifi.security.util.SslContextFactory
-
Creates a SSLContext instance using the given information.
- createSslContext(String, char[], char[], String, String, char[], String, SslContextFactory.ClientAuth, String) - Static method in class org.apache.nifi.security.util.SslContextFactory
-
Creates a SSLContext instance using the given information.
- createSslContext(String, char[], String, String) - Static method in class org.apache.nifi.security.util.SslContextFactory
-
Creates a SSLContext instance using the given information.
- createSslContext(String, char[], char[], String, String) - Static method in class org.apache.nifi.security.util.SslContextFactory
-
Creates a SSLContext instance using the given information.
- createSSLContext(SSLContextService.ClientAuth) - Method in interface org.apache.nifi.ssl.SSLContextService
-
- createSSLContext(SSLContextService.ClientAuth) - Method in class org.apache.nifi.ssl.StandardSSLContextService
-
- createSslFactory(SSLContextService, boolean, boolean) - Method in class org.apache.nifi.websocket.jetty.AbstractJettyWebSocketService
-
- createSSLHandler(SelectionKey, D, Charset, EventFactory<E>, BlockingQueue<E>, ComponentLog) - Method in interface org.apache.nifi.processor.util.listen.handler.ChannelHandlerFactory
-
- createSSLHandler(SelectionKey, AsyncChannelDispatcher, Charset, EventFactory<E>, BlockingQueue<E>, ComponentLog) - Method in class org.apache.nifi.processor.util.listen.handler.socket.SocketChannelHandlerFactory
-
- createSSLHandler(SelectionKey, AsyncChannelDispatcher, Charset, EventFactory<E>, BlockingQueue<E>, ComponentLog) - Method in class org.apache.nifi.processors.beats.handler.BeatsSocketChannelHandlerFactory
-
- createSSLHandler(SelectionKey, AsyncChannelDispatcher, Charset, EventFactory<E>, BlockingQueue<E>, ComponentLog) - Method in class org.apache.nifi.processors.lumberjack.handler.LumberjackSocketChannelHandlerFactory
-
Deprecated.
- createSSLHandler(SelectionKey, AsyncChannelDispatcher, Charset, EventFactory<E>, BlockingQueue<E>, ComponentLog) - Method in class org.apache.nifi.processors.standard.relp.handler.RELPSocketChannelHandlerFactory
-
- createSslProperties() - Static method in class org.apache.nifi.processors.mqtt.common.MqttTestUtils
-
- createStandaloneInstance(FlowFileEventRepository, NiFiProperties, Authorizer, AuditService, StringEncryptor, BulletinRepository, VariableRegistry) - Static method in class org.apache.nifi.controller.FlowController
-
- createStandaloneInstance(FlowController, NiFiProperties, StringEncryptor, RevisionManager, Authorizer) - Static method in class org.apache.nifi.controller.StandardFlowService
-
- createState(String) - Method in class org.apache.nifi.web.security.oidc.OidcService
-
Initiates an OpenId Connection authorization code flow using the specified request identifier to maintain state.
- createStateMapDTO(Scope, StateMap) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
Creates a StateMapDTO for the given scope and state map.
- createStatusDescriptorDto(MetricDescriptor<?>) - Static method in class org.apache.nifi.controller.status.history.StatusHistoryUtil
-
- createStatusHistoryDTO(StatusHistory) - Static method in class org.apache.nifi.controller.status.history.StatusHistoryUtil
-
- createStatusHistoryEntity(StatusHistoryDTO, PermissionsDTO) - Method in class org.apache.nifi.web.api.dto.EntityFactory
-
- createStatusSnapshotDto(StatusSnapshot) - Static method in class org.apache.nifi.controller.status.history.StatusHistoryUtil
-
- createStorageConnection(ProcessContext) - Method in class org.apache.nifi.processors.azure.AbstractAzureProcessor
-
- createStorageConnection(ProcessContext, FlowFile) - Method in class org.apache.nifi.processors.azure.AbstractAzureProcessor
-
- createStorageUsageDTO(String, StorageUsage) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
Creates a StorageUsageDTO from the specified StorageUsage.
- createSystemDiagnosticsDto(SystemDiagnostics) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
Creates a SystemDiagnosticsDTO for the specified SystemDiagnostics.
- createTemplate(HttpServletRequest, String, CreateTemplateRequestEntity) - Method in class org.apache.nifi.web.api.ProcessGroupResource
-
Creates a new template based off of the specified template.
- createTemplate(TemplateDTO, String) - Method in class org.apache.nifi.web.dao.impl.StandardTemplateDAO
-
- createTemplate(TemplateDTO, String) - Method in interface org.apache.nifi.web.dao.TemplateDAO
-
Creates a template.
- createTemplate(String, String, String, String, Optional<String>) - Method in interface org.apache.nifi.web.NiFiServiceFacade
-
Creates a new Template based off the specified snippet.
- createTemplate(String, String, String, String, Optional<String>) - Method in class org.apache.nifi.web.StandardNiFiServiceFacade
-
- createTemplateDTO(Template) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
Creates a TemplateDTO from the specified template.
- createTemplateInstance(String, Double, Double, String, FlowSnippetDTO, String) - Method in interface org.apache.nifi.web.NiFiServiceFacade
-
Instantiate the corresponding template.
- createTemplateInstance(String, Double, Double, String, FlowSnippetDTO, String) - Method in class org.apache.nifi.web.StandardNiFiServiceFacade
-
- CreateTemplateRequestEntity - Class in org.apache.nifi.web.api.entity
-
A serialized representation of this class can be placed in the entity body of a request to the API.
- CreateTemplateRequestEntity() - Constructor for class org.apache.nifi.web.api.entity.CreateTemplateRequestEntity
-
- createTenantDTO(User) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
- createTenantDTO(Group) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
- createTenantEntity(TenantDTO, RevisionDTO, PermissionsDTO) - Method in class org.apache.nifi.web.api.dto.EntityFactory
-
- createTimePeriodValidator(long, TimeUnit, long, TimeUnit) - Static method in class org.apache.nifi.processor.util.StandardValidators
-
- createTopicMessageConsumer(ProcessContext) - Static method in class org.apache.nifi.processors.standard.util.JmsFactory
-
- createTopicMessageConsumer(ProcessContext, String) - Static method in class org.apache.nifi.processors.standard.util.JmsFactory
-
- createTransaction() - Method in class org.apache.nifi.processors.flume.NifiSessionChannel
-
- createTransaction() - Method in class org.apache.nifi.processors.flume.NifiSessionFactoryChannel
-
- createTransaction() - Method in class org.apache.nifi.processors.flume.NifiSinkSessionChannel
-
- createTransaction(TransferDirection) - Method in class org.apache.nifi.remote.client.http.HttpClient
-
- createTransaction(TransferDirection) - Method in interface org.apache.nifi.remote.client.SiteToSiteClient
-
Creates a new Transaction that can be used to either send data to a
remote NiFi instance or receive data from a remote NiFi instance,
depending on the value passed for the direction
argument.
- createTransaction(TransferDirection) - Method in class org.apache.nifi.remote.client.socket.SocketClient
-
- createTransaction() - Method in class org.apache.nifi.remote.HttpRemoteSiteListener
-
- createTransitUri(ProcessContext) - Method in class org.apache.nifi.processor.util.put.AbstractPutEventProcessor
-
Sub-classes construct a transit uri for provenance events.
- createTransitUri(ProcessContext) - Method in class org.apache.nifi.processors.splunk.PutSplunk
-
- createTransitUri(ProcessContext) - Method in class org.apache.nifi.processors.standard.PutTCP
-
Creates a Universal Resource Identifier (URI) for this processor.
- createTransitUri(ProcessContext) - Method in class org.apache.nifi.processors.standard.PutUDP
-
Creates a Universal Resource Identifier (URI) for this processor.
- createTransitUri(String, String) - Method in class org.apache.nifi.remote.AbstractCommunicationsSession
-
- createTransitUri(String) - Method in interface org.apache.nifi.remote.Communicant
-
- createTransitUri(String, String) - Method in class org.apache.nifi.remote.io.http.HttpCommunicationsSession
-
- createTransitUri(String) - Method in class org.apache.nifi.remote.Peer
-
- createTransitUri(Peer, String) - Method in class org.apache.nifi.remote.protocol.AbstractFlowFileServerProtocol
-
- createTransitUri(String, String) - Method in interface org.apache.nifi.remote.protocol.CommunicationsSession
-
- createTransitUri(Peer, String) - Method in class org.apache.nifi.remote.protocol.socket.SocketFlowFileServerProtocol
-
- createTrustSslContext(String, char[], String, String) - Static method in class org.apache.nifi.security.util.SslContextFactory
-
Creates a SSLContext instance using the given information.
- createUiExtensionToken(HttpServletRequest) - Method in class org.apache.nifi.web.api.AccessResource
-
Creates a single use access token for accessing a NiFi UI extension.
- createUnmarshaller() - Method in class org.apache.nifi.cluster.protocol.jaxb.JaxbProtocolContext
-
- createUnmarshaller() - Method in interface org.apache.nifi.cluster.protocol.ProtocolContext
-
Creates an unmarshaller for deserializing protocol messages.
- createUnpackager(String) - Static method in class org.apache.nifi.util.Unpackage
-
- createURLorFileValidator() - Static method in class org.apache.nifi.processor.util.StandardValidators
-
- createUser(HttpServletRequest, UserEntity) - Method in class org.apache.nifi.web.api.TenantsResource
-
Creates a new user.
- createUser(UserDTO) - Method in class org.apache.nifi.web.dao.impl.StandardPolicyBasedAuthorizerDAO
-
- createUser(UserDTO) - Method in interface org.apache.nifi.web.dao.UserDAO
-
Creates a user.
- createUser(Revision, UserDTO) - Method in interface org.apache.nifi.web.NiFiServiceFacade
-
Creates a user.
- createUser(String, Set<String>, NiFiUser, String, boolean) - Static method in class org.apache.nifi.web.security.x509.X509AuthenticationProvider
-
Returns a regular user populated with the provided values, or if the user should be anonymous, a well-formed instance of the anonymous user with the provided values.
- createUser(Revision, UserDTO) - Method in class org.apache.nifi.web.StandardNiFiServiceFacade
-
- createUserAdvice(ProceedingJoinPoint) - Method in class org.apache.nifi.audit.UserAuditor
-
Audits the creation of policies via createUser().
- createUserDto(User, Set<TenantEntity>, Set<AccessPolicySummaryEntity>) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
- createUserEntity(UserDTO, RevisionDTO, PermissionsDTO) - Method in class org.apache.nifi.web.api.dto.EntityFactory
-
- createUserGroup(HttpServletRequest, UserGroupEntity) - Method in class org.apache.nifi.web.api.TenantsResource
-
Creates a new user group.
- createUserGroup(UserGroupDTO) - Method in class org.apache.nifi.web.dao.impl.StandardPolicyBasedAuthorizerDAO
-
- createUserGroup(UserGroupDTO) - Method in interface org.apache.nifi.web.dao.UserGroupDAO
-
Creates a user group.
- createUserGroup(Revision, UserGroupDTO) - Method in interface org.apache.nifi.web.NiFiServiceFacade
-
Creates a user group.
- createUserGroup(Revision, UserGroupDTO) - Method in class org.apache.nifi.web.StandardNiFiServiceFacade
-
- createUserGroupAdvice(ProceedingJoinPoint) - Method in class org.apache.nifi.audit.UserGroupAuditor
-
Audits the creation of policies via createUser().
- createUserGroupDto(Group, Set<TenantEntity>, Set<AccessPolicySummaryEntity>) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
- createUserGroupEntity(UserGroupDTO, RevisionDTO, PermissionsDTO) - Method in class org.apache.nifi.web.api.dto.EntityFactory
-
- createVariableRegistryDto(ProcessGroup, RevisionManager) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
- createVariableRegistryEntity(VariableRegistryDTO, RevisionDTO, PermissionsDTO) - Method in class org.apache.nifi.web.api.dto.EntityFactory
-
- createVariableRegistryUpdateRequestDto(VariableRegistryUpdateRequest) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
- createVariableRegistryUpdateStepDto(VariableRegistryUpdateStep) - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
- createVersionInfoDTO() - Method in class org.apache.nifi.web.api.dto.DtoFactory
-
- createWebSocket(ServletUpgradeRequest, ServletUpgradeResponse) - Method in class org.apache.nifi.websocket.example.WebSocketServerExample.WSServlet
-
- createWebSocket(ServletUpgradeRequest, ServletUpgradeResponse) - Method in class org.apache.nifi.websocket.jetty.JettyWebSocketServer.JettyWebSocketServlet
-
- createWeightedList(ProcessContext) - Method in class org.apache.nifi.processors.standard.DistributeLoad
-
- createWriter(OutputStream, Path, Configuration, TypeInfo, long, CompressionKind, int) - Static method in class org.apache.hadoop.hive.ql.io.orc.NiFiOrcUtils
-
- createWriter(ComponentLog, RecordSchema, OutputStream) - Method in class org.apache.nifi.avro.AvroRecordSetWriter
-
- createWriter(Schema, OutputStream) - Method in class org.apache.nifi.avro.TestWriteAvroResult
-
- createWriter(Schema, OutputStream) - Method in class org.apache.nifi.avro.TestWriteAvroResultWithoutSchema
-
- createWriter(Schema, OutputStream) - Method in class org.apache.nifi.avro.TestWriteAvroResultWithSchema
-
- createWriter(ComponentLog, RecordSchema, OutputStream) - Method in class org.apache.nifi.csv.CSVRecordSetWriter
-
- createWriter(ComponentLog, RecordSchema, OutputStream) - Method in class org.apache.nifi.json.JsonRecordSetWriter
-
- createWriter(ComponentLog, RecordSchema, OutputStream) - Method in class org.apache.nifi.processors.kafka.pubsub.util.MockRecordWriter
-
- createWriter(File, TocWriter, boolean, int) - Method in class org.apache.nifi.provenance.AbstractTestRecordReaderWriter
-
- createWriter(File, AtomicLong, boolean, boolean) - Method in interface org.apache.nifi.provenance.store.RecordWriterFactory
-
- createWriter(File, TocWriter, boolean, int) - Method in class org.apache.nifi.provenance.TestEventIdFirstSchemaRecordReaderWriter
-
- createWriter(File, TocWriter, boolean, int) - Method in class org.apache.nifi.provenance.TestSchemaRecordReaderWriter
-
- createWriter(File, TocWriter, boolean, int) - Method in class org.apache.nifi.provenance.TestStandardRecordReaderWriter
-
- createWriter(ComponentLog, RecordSchema, OutputStream) - Method in class org.apache.nifi.record.script.ScriptedRecordSetWriter
-
- createWriter(ComponentLog, RecordSchema, OutputStream) - Method in class org.apache.nifi.serialization.record.MockRecordWriter
-
- createWriter(ComponentLog, RecordSchema, OutputStream) - Method in interface org.apache.nifi.serialization.RecordSetWriterFactory
-
Creates a new RecordSetWriter that is capable of writing record contents to an OutputStream.
- createWriter(ComponentLog, RecordSchema, OutputStream) - Method in class org.apache.nifi.text.FreeFormTextRecordSetWriter
-
- createWriters(RepositoryConfiguration, long) - Method in class org.apache.nifi.provenance.PersistentProvenanceRepository
-
- CredentialPropertyDescriptors - Class in org.apache.nifi.processors.aws.credentials.provider.factory
-
Shared definitions of properties that specify various AWS credentials.
- CredentialPropertyDescriptors() - Constructor for class org.apache.nifi.processors.aws.credentials.provider.factory.CredentialPropertyDescriptors
-
- CredentialPropertyDescriptors - Class in org.apache.nifi.processors.gcp.credentials.factory
-
Shared definitions of properties that specify various GCP credentials.
- CREDENTIALS_FILE - Static variable in class org.apache.nifi.processors.aws.AbstractAWSProcessor
-
Deprecated.
- CREDENTIALS_FILE - Static variable in class org.apache.nifi.processors.aws.credentials.provider.factory.CredentialPropertyDescriptors
-
- CREDENTIALS_FILE - Static variable in class org.apache.nifi.processors.aws.dynamodb.ITAbstractDynamoDBTest
-
- CREDENTIALS_FILE - Static variable in class org.apache.nifi.processors.aws.kinesis.firehose.ITPutKinesisFirehose
-
- CREDENTIALS_FILE - Static variable in class org.apache.nifi.processors.aws.kinesis.firehose.TestPutKinesisFirehose
-
- CREDENTIALS_FILE - Static variable in class org.apache.nifi.processors.aws.kinesis.stream.ITPutKinesisStream
-
- CREDENTIALS_FILE - Static variable in class org.apache.nifi.processors.aws.kinesis.stream.TestPutKinesisStream
-
- CREDENTIALS_FILE - Static variable in class org.apache.nifi.processors.aws.lambda.ITPutLambda
-
- CREDENTIALS_FILE - Static variable in class org.apache.nifi.processors.aws.s3.AbstractS3IT
-
- CredentialsFactory - Class in org.apache.nifi.processors.gcp.credentials.factory
-
Generates GCP credentials in the form of GoogleCredential implementations for processors
and controller services.
- CredentialsFactory() - Constructor for class org.apache.nifi.processors.gcp.credentials.factory.CredentialsFactory
-
- CredentialsFactoryTest - Class in org.apache.nifi.processors.gcp.credentials.factory
-
Tests of the validation and credentials provider capabilities of CredentialsFactory.
- CredentialsFactoryTest() - Constructor for class org.apache.nifi.processors.gcp.credentials.factory.CredentialsFactoryTest
-
- CredentialsProviderFactory - Class in org.apache.nifi.processors.aws.credentials.provider.factory
-
Generates AWS credentials in the form of AWSCredentialsProvider implementations for processors
and controller services.
- CredentialsProviderFactory() - Constructor for class org.apache.nifi.processors.aws.credentials.provider.factory.CredentialsProviderFactory
-
- credentialsProviderFactory - Variable in class org.apache.nifi.processors.aws.credentials.provider.service.AWSCredentialsProviderControllerService
-
- credentialsProviderFactory - Variable in class org.apache.nifi.processors.gcp.credentials.service.GCPCredentialsControllerService
-
- CredentialsStrategy - Interface in org.apache.nifi.processors.aws.credentials.provider.factory
-
Specifies a strategy for validating and creating AWS credentials from a list of properties configured on a
Processor, Controller Service, Reporting Service, or other component.
- CredentialsStrategy - Interface in org.apache.nifi.processors.gcp.credentials.factory
-
Specifies a strategy for validating and creating GCP credentials from a list of properties configured on a
Processor, Controller Service, Reporting Service, or other component.
- Criteria - Class in org.apache.nifi.update.attributes
-
Criteria for updating flow file attributes
- Criteria() - Constructor for class org.apache.nifi.update.attributes.Criteria
-
- Criteria(FlowFilePolicy, List<Rule>) - Constructor for class org.apache.nifi.update.attributes.Criteria
-
- CriteriaSerDe - Class in org.apache.nifi.update.attributes.serde
-
- CriteriaSerDe() - Constructor for class org.apache.nifi.update.attributes.serde.CriteriaSerDe
-
- crlfWhereLFdoesNotFitInInitialBuffer() - Method in class org.apache.nifi.stream.io.util.TextLineDemarcatorTest
-
- crypt_raw(byte[], byte[], int, int[]) - Method in class org.apache.nifi.security.util.crypto.bcrypt.BCrypt
-
Perform the central password hashing step in the
bcrypt scheme
- CryptoUtils - Class in org.apache.nifi.security.kms
-
- CryptoUtils() - Constructor for class org.apache.nifi.security.kms.CryptoUtils
-
- CSR_FIELD_MUST_BE_SET - Static variable in class org.apache.nifi.toolkit.tls.service.server.TlsCertificateAuthorityServiceHandler
-
- CSS_SELECTOR - Static variable in class org.apache.nifi.AbstractHTMLProcessor
-
- CSS_SELECTOR_VALIDATOR - Static variable in class org.apache.nifi.AbstractHTMLProcessor
-
- CSV - Static variable in class org.apache.nifi.processors.hive.SelectHiveQL
-
- CSV_CONTENT - Static variable in class org.apache.nifi.processors.kite.InferAvroSchema
-
- CSV_CONTENT - Static variable in class org.apache.nifi.processors.kite.TestCSVToAvroProcessor
-
- CSV_FILE - Static variable in class org.apache.nifi.lookup.SimpleCsvFileLookupService
-
- CSV_HEADER_DEFINITION - Static variable in class org.apache.nifi.processors.kite.InferAvroSchema
-
- CSV_MIME_TYPE - Static variable in class org.apache.nifi.processors.hive.SelectHiveQL
-
- CSV_MIME_TYPE - Static variable in class org.apache.nifi.processors.kite.InferAvroSchema
-
- CSV_VALUE - Static variable in class org.apache.nifi.processors.splunk.GetSplunk
-
- csvEscapeEvaluator(Evaluator<String>) - Static method in class org.apache.nifi.attribute.expression.language.evaluation.functions.CharSequenceTranslatorEvaluator
-
- CSVHeaderSchemaStrategy - Class in org.apache.nifi.csv
-
- CSVHeaderSchemaStrategy(ConfigurationContext) - Constructor for class org.apache.nifi.csv.CSVHeaderSchemaStrategy
-
- CSVHeaderSchemaStrategy(ValidationContext) - Constructor for class org.apache.nifi.csv.CSVHeaderSchemaStrategy
-
- CsvOutputOptions - Class in org.apache.nifi.util.hive
-
- CsvOutputOptions(boolean, String, String, boolean, boolean) - Constructor for class org.apache.nifi.util.hive.CsvOutputOptions
-
- CSVReader - Class in org.apache.nifi.csv
-
- CSVReader() - Constructor for class org.apache.nifi.csv.CSVReader
-
- CSVRecordReader - Class in org.apache.nifi.csv
-
- CSVRecordReader(InputStream, ComponentLog, RecordSchema, CSVFormat, boolean, boolean, String, String, String) - Constructor for class org.apache.nifi.csv.CSVRecordReader
-
- CSVRecordSetWriter - Class in org.apache.nifi.csv
-
- CSVRecordSetWriter() - Constructor for class org.apache.nifi.csv.CSVRecordSetWriter
-
- csvUnescapeEvaluator(Evaluator<String>) - Static method in class org.apache.nifi.attribute.expression.language.evaluation.functions.CharSequenceTranslatorEvaluator
-
- CSVUtils - Class in org.apache.nifi.csv
-
- CSVUtils() - Constructor for class org.apache.nifi.csv.CSVUtils
-
- CSVValidators - Class in org.apache.nifi.csv
-
- CSVValidators() - Constructor for class org.apache.nifi.csv.CSVValidators
-
- CSVValidators.SingleCharacterValidator - Class in org.apache.nifi.csv
-
- CTX_CONFIG_PATH - Static variable in class org.apache.nifi.spring.SpringContextProcessor
-
- CTX_LIB_PATH - Static variable in class org.apache.nifi.spring.SpringContextProcessor
-
- CuratorACLProviderFactory - Class in org.apache.nifi.controller.leader.election
-
- CuratorACLProviderFactory() - Constructor for class org.apache.nifi.controller.leader.election.CuratorACLProviderFactory
-
- CuratorLeaderElectionManager - Class in org.apache.nifi.controller.leader.election
-
- CuratorLeaderElectionManager(int, NiFiProperties) - Constructor for class org.apache.nifi.controller.leader.election.CuratorLeaderElectionManager
-
- CuratorNodeProtocolSender - Class in org.apache.nifi.cluster.coordination.node
-
Uses Apache Curator to determine the address of the current cluster
coordinator
- CuratorNodeProtocolSender(SocketConfiguration, ProtocolContext<ProtocolMessage>, NiFiProperties) - Constructor for class org.apache.nifi.cluster.coordination.node.CuratorNodeProtocolSender
-
- current() - Method in class org.apache.nifi.queryrecord.FlowFileEnumerator
-
- CURRENT_CONTENT_CLAIM - Static variable in class org.apache.nifi.provenance.schema.EventRecordFields
-
- CURRENT_CONTENT_CLAIM - Static variable in class org.apache.nifi.provenance.schema.LookupTableEventRecordFields
-
- CURRENT_CONTENT_CLAIM_EXPLICIT - Static variable in class org.apache.nifi.provenance.schema.LookupTableEventRecordFields
-
- CURRENT_KEY_PREFIX - Static variable in class org.apache.nifi.processors.aws.s3.ListS3
-
- CURRENT_KEY_PREFIX - Static variable in class org.apache.nifi.processors.gcp.storage.ListGCSBucket
-
- CURRENT_MICRO_BATCH_STATE_TS_KEY - Static variable in class org.apache.nifi.processors.stateful.analysis.AttributeRollingWindow
-
- CURRENT_TIMESTAMP - Static variable in class org.apache.nifi.processors.aws.s3.ListS3
-
- CURRENT_TIMESTAMP - Static variable in class org.apache.nifi.processors.gcp.storage.ListGCSBucket
-
- CURRENT_USER_URI_PATTERN - Static variable in class org.apache.nifi.cluster.coordination.http.endpoints.CurrentUserEndpointMerger
-
- CurrentFieldPath - Class in org.apache.nifi.record.path.paths
-
- CurrentFieldPath(RecordPathSegment, boolean) - Constructor for class org.apache.nifi.record.path.paths.CurrentFieldPath
-
- currentKeys - Variable in class org.apache.nifi.processors.gcp.storage.ListGCSBucket
-
- CurrentTestStandardProcessorTestRunner - Class in org.apache.nifi.util
-
- CurrentTestStandardProcessorTestRunner() - Constructor for class org.apache.nifi.util.CurrentTestStandardProcessorTestRunner
-
- currentTimestamp - Variable in class org.apache.nifi.processors.gcp.storage.ListGCSBucket
-
- CurrentUserEndpointMerger - Class in org.apache.nifi.cluster.coordination.http.endpoints
-
- CurrentUserEndpointMerger() - Constructor for class org.apache.nifi.cluster.coordination.http.endpoints.CurrentUserEndpointMerger
-
- CurrentUserEntity - Class in org.apache.nifi.web.api.entity
-
A serialized representation of this class can be placed in the entity body of a response to the API.
- CurrentUserEntity() - Constructor for class org.apache.nifi.web.api.entity.CurrentUserEntity
-
- CUSTOM_CLASS - Static variable in class org.apache.nifi.processors.standard.JoltTransformJSON
-
- CUSTOM_HOSTNAME - Static variable in class org.apache.nifi.bootstrap.notification.TestCustomNotificationService
-
- CUSTOM_PASSWORD - Static variable in class org.apache.nifi.bootstrap.notification.TestCustomNotificationService
-
- CUSTOM_TEXT - Static variable in class org.apache.nifi.processors.standard.GenerateFlowFile
-
- CUSTOM_USERNAME - Static variable in class org.apache.nifi.bootstrap.notification.TestCustomNotificationService
-
- customizeClient() - Method in class org.apache.nifi.websocket.jetty.TestJettyWebSocketCommunication
-
- customizeClient() - Method in class org.apache.nifi.websocket.jetty.TestJettyWebSocketSecureCommunication
-
- customizeServer() - Method in class org.apache.nifi.websocket.jetty.TestJettyWebSocketCommunication
-
- customizeServer() - Method in class org.apache.nifi.websocket.jetty.TestJettyWebSocketSecureCommunication
-
- CUSTOMR - Static variable in class org.apache.nifi.processors.standard.JoltTransformJSON
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.avro.AvroRecordSetWriter
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.bootstrap.notification.email.EmailNotificationService
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.components.AbstractConfigurableComponent
-
Allows subclasses to perform their own validation on the already set
properties.
- customValidate(ValidationContext) - Method in class org.apache.nifi.confluent.schemaregistry.ConfluentSchemaRegistry
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.dbcp.hive.HiveConnectionPool
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.hbase.GetHBase
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.hbase.HBase_1_1_2_ClientService
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.hbase.PutHBaseJSON
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.json.JsonPathReader
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processor.util.bin.BinFiles
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.attributes.UpdateAttribute
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.aws.AbstractAWSProcessor
-
Deprecated.
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.aws.cloudwatch.PutCloudWatchMetric
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.aws.credentials.provider.factory.MockAWSProcessor
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.aws.credentials.provider.service.AWSCredentialsProviderControllerService
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.beats.ListenBeats
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.cassandra.AbstractCassandraProcessor
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.elasticsearch.AbstractElasticsearchHttpProcessor
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.elasticsearch.AbstractElasticsearchProcessor
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.elasticsearch.PutElasticsearchHttp
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.elasticsearch.PutElasticsearchHttpRecord
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.email.ListenSMTP
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.enrich.AbstractEnrichProcessor
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.enrich.QueryWhois
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.gcp.credentials.factory.MockCredentialsFactoryProcessor
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.gcp.credentials.service.GCPCredentialsControllerService
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.hadoop.AbstractHadoopProcessor
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.hadoop.GetHDFS
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.hadoop.ListHDFS
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.kafka.pubsub.ConsumeKafka
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.kafka.pubsub.ConsumeKafka_0_10
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.kafka.pubsub.ConsumeKafka_0_11
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.kafka.pubsub.ConsumeKafkaRecord_0_10
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.kafka.pubsub.ConsumeKafkaRecord_0_11
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.kafka.pubsub.PublishKafka
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.kafka.pubsub.PublishKafka_0_10
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.kafka.pubsub.PublishKafka_0_11
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.kafka.pubsub.PublishKafkaRecord_0_10
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.kafka.pubsub.PublishKafkaRecord_0_11
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.lumberjack.ListenLumberjack
-
Deprecated.
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.mqtt.common.AbstractMQTTProcessor
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.mqtt.ConsumeMQTT
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.script.ExecuteScript
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.script.InvokeScriptedProcessor
-
Invokes the validate() routine provided by the script, allowing for
custom validation code.
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.solr.SolrProcessor
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.splunk.GetSplunk
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.splunk.PutSplunk
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.standard.AbstractDatabaseFetchProcessor
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.standard.ControlRate
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.standard.DistributeLoad
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.standard.EncryptContent
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.standard.EnforceOrder
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.standard.EvaluateJsonPath
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.standard.EvaluateXPath
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.standard.EvaluateXQuery
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.standard.ExtractText
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.standard.FetchFile
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.standard.GenerateFlowFile
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.standard.GenerateTableFetch
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.standard.GetHTTP
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.standard.GetSFTP
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.standard.InvokeHTTP
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.standard.JoltTransformJSON
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.standard.ListenRELP
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.standard.ListenSyslog
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.standard.ListenTCP
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.standard.ListenTCPRecord
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.standard.ListenUDP
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.standard.ListenUDPRecord
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.standard.LookupAttribute
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.standard.LookupRecord
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.standard.PartitionRecord
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.standard.PostHTTP
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.standard.PutEmail
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.standard.PutSyslog
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.standard.QueryRecord
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.standard.ReplaceText
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.standard.ReplaceTextWithMapping
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.standard.RouteText
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.standard.SplitContent
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.standard.SplitJson
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.standard.SplitText
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.standard.TailFile
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.standard.UpdateRecord
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.standard.ValidateCsv
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.standard.ValidateRecord
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.twitter.GetTwitter
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.windows.event.log.ConsumeWindowsEventLog
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.processors.yandex.YandexTranslate
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.redis.service.RedisConnectionPoolService
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.redis.service.RedisDistributedMapCacheClientService
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.redis.state.RedisStateProvider
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.reporting.script.ScriptedReportingTask
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.script.AbstractScriptedControllerService
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.script.ScriptingComponentHelper
-
Custom validation for ensuring exactly one of Script File or Script Body is populated
- customValidate(ValidationContext) - Method in class org.apache.nifi.serialization.SchemaRegistryRecordSetWriter
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.serialization.SchemaRegistryService
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.spring.SpringContextProcessor
-
- customValidate(ValidationContext) - Method in class org.apache.nifi.ssl.StandardSSLContextService
-