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

P

PACKAGE - Static variable in class net.floodlightcontroller.devicemanager.internal.DeviceManagerImpl
 
PACKAGE - Static variable in class net.floodlightcontroller.flowcache.FlowReconcileManager
 
PACKAGE - Static variable in class net.floodlightcontroller.topology.TopologyManager
Debug Counters
packetBandCount - Variable in class org.openflow.protocol.statistics.OFMeterBandStatistics
 
packetClient - Static variable in class net.floodlightcontroller.core.OFMessageFilterManager
 
packetCount - Variable in class org.openflow.protocol.OFFlowRemoved
 
packetCount - Variable in class org.openflow.protocol.statistics.OFAggregateStatisticsReply
 
packetCount - Variable in class org.openflow.protocol.statistics.OFFlowStatisticsReply
 
packetCount - Variable in class org.openflow.protocol.statistics.OFGroupStatisticsReply
 
packetData - Variable in class org.openflow.protocol.OFPacketIn
 
packetData - Variable in class org.openflow.protocol.OFPacketOut
 
packetInCount - Variable in class org.openflow.protocol.statistics.OFMeterStatisticsReply
 
packetInThrottleEnabled - Variable in class net.floodlightcontroller.core.OFSwitchBase
 
packetInWhileSwitchIsSlave - Variable in class net.floodlightcontroller.core.internal.Controller.Counters
 
packetOutMultiPort(byte[], IOFSwitch, int, Set<Integer>, FloodlightContext) - Method in class net.floodlightcontroller.routing.ForwardingBase
Write packetout message to sw with output actions to one or more output ports with inPort/outPorts passed in.
packetOutMultiPort(OFPacketIn, IOFSwitch, int, Set<Integer>, FloodlightContext) - Method in class net.floodlightcontroller.routing.ForwardingBase
 
packetOutMultiPort(IPacket, IOFSwitch, int, Set<Integer>, FloodlightContext) - Method in class net.floodlightcontroller.routing.ForwardingBase
 
PacketParsingException - Exception in net.floodlightcontroller.packet
 
PacketParsingException(String) - Constructor for exception net.floodlightcontroller.packet.PacketParsingException
 
PacketStreamerClient - Class in net.floodlightcontroller.packetstreamer
The PacketStreamer Sample Client.
PacketStreamerClient() - Constructor for class net.floodlightcontroller.packetstreamer.PacketStreamerClient
 
PacketStreamerHandler - Class in net.floodlightcontroller.packetstreamer
The PacketStreamer handler class that implements the service APIs.
PacketStreamerHandler() - Constructor for class net.floodlightcontroller.packetstreamer.PacketStreamerHandler
The handler's constructor
PacketStreamerHandler.SessionQueue - Class in net.floodlightcontroller.packetstreamer
The queue wrapper class that contains the queue for the streamed packets.
PacketStreamerHandler.SessionQueue() - Constructor for class net.floodlightcontroller.packetstreamer.PacketStreamerHandler.SessionQueue
The queue wrapper constructor
PacketStreamerServer - Class in net.floodlightcontroller.packetstreamer
The PacketStreamer Server that brokers the packet streaming service.
PacketStreamerServer() - Constructor for class net.floodlightcontroller.packetstreamer.PacketStreamerServer
 
packettrace(PacketTraceResource.FilterParameters) - Method in class net.floodlightcontroller.core.web.PacketTraceResource
 
PacketTraceResource - Class in net.floodlightcontroller.core.web
 
PacketTraceResource() - Constructor for class net.floodlightcontroller.core.web.PacketTraceResource
 
PacketTraceResource.FilterParameters - Class in net.floodlightcontroller.core.web
 
PacketTraceResource.FilterParameters() - Constructor for class net.floodlightcontroller.core.web.PacketTraceResource.FilterParameters
 
PacketTraceResource.PacketTraceOutput - Class in net.floodlightcontroller.core.web
 
PacketTraceResource.PacketTraceOutput() - Constructor for class net.floodlightcontroller.core.web.PacketTraceResource.PacketTraceOutput
 
pad - Variable in class net.floodlightcontroller.packet.Ethernet
 
pad0 - Variable in class com.bigswitch.floodlight.vendor.OFActionMirror
 
pad1 - Variable in class com.bigswitch.floodlight.vendor.OFActionMirror
 
pad1 - Variable in class com.bigswitch.floodlight.vendor.OFMirrorSetVendorData
 
pad1 - Variable in class com.bigswitch.floodlight.vendor.OFNetmaskVendorData
 
pad2 - Variable in class com.bigswitch.floodlight.vendor.OFActionMirror
 
pad2 - Variable in class com.bigswitch.floodlight.vendor.OFMirrorSetVendorData
 
pad2 - Variable in class com.bigswitch.floodlight.vendor.OFNetmaskVendorData
 
pad3 - Variable in class com.bigswitch.floodlight.vendor.OFMirrorSetVendorData
 
pad3 - Variable in class com.bigswitch.floodlight.vendor.OFNetmaskVendorData
 
paddingMap - Static variable in class net.floodlightcontroller.packet.ICMP
 
Pair<F,S> - Class in org.sdnplatform.sync.internal.util
Represents a pair of items.
Pair(F, S) - Constructor for class org.sdnplatform.sync.internal.util.Pair
Use the static factory method Pair.create(Object, Object) instead of this where possible.
parent - Variable in class net.floodlightcontroller.packet.BasePacket
 
parse(Options, String[]) - Static method in class org.openflow.example.cli.SimpleCLI
 
parseActions(ByteBuffer, int) - Method in class org.openflow.protocol.factory.BasicFactory
 
parseActions(ByteBuffer, int, int) - Method in class org.openflow.protocol.factory.BasicFactory
 
parseActions(ByteBuffer, int, int) - Method in class org.openflow.protocol.factory.FloodlightFactory
 
parseActions(ByteBuffer, int) - Method in interface org.openflow.protocol.factory.OFActionFactory
Attempts to parse and return all OFActions contained in the given ByteBuffer, beginning at the ByteBuffer's position, and ending at position+length.
parseActions(ByteBuffer, int, int) - Method in interface org.openflow.protocol.factory.OFActionFactory
Attempts to parse and return all OFActions contained in the given ByteBuffer, beginning at the ByteBuffer's position, and ending at position+length.
parseActionString(OFFlowMod, String, Logger) - Static method in class net.floodlightcontroller.loadbalancer.LoadBalancer
Parses OFFlowMod actions from strings.
parseActionString(OFFlowMod, String, Logger) - Static method in class net.floodlightcontroller.staticflowentry.StaticFlowEntries
Parses OFFlowMod actions from strings.
parseArgs(String[]) - Static method in class org.openflow.example.SimpleController
 
parseConfigParameters(Properties) - Method in class net.floodlightcontroller.core.module.FloodlightModuleLoader
Parses configuration parameters for each module
ParseException - Exception in org.openflow.example.cli
 
ParseException(String) - Constructor for exception org.openflow.example.cli.ParseException
 
parseHelloElements(ByteBuffer, int) - Method in class org.openflow.protocol.factory.BasicFactory
 
parseHelloElements(ByteBuffer, int, int) - Method in class org.openflow.protocol.factory.BasicFactory
 
parseHelloElements(ByteBuffer, int) - Method in interface org.openflow.protocol.factory.OFHelloElementFactory
Attempts to parse and return all OFHelloElement contained in the given ByteBuffer, beginning at the ByteBuffer's position, and ending at position+length.
parseHelloElements(ByteBuffer, int, int) - Method in interface org.openflow.protocol.factory.OFHelloElementFactory
Attempts to parse and return all OFHelloElement contained in the given ByteBuffer, beginning at the ByteBuffer's position, and ending at position+length.
parseInstructions(ByteBuffer, int) - Method in class org.openflow.protocol.factory.BasicFactory
 
parseInstructions(ByteBuffer, int, int) - Method in class org.openflow.protocol.factory.BasicFactory
 
parseInstructions(ByteBuffer, int) - Method in interface org.openflow.protocol.factory.OFInstructionFactory
Attempts to parse and return all OFInstruction contained in the given ByteBuffer, beginning at the ByteBuffer's position, and ending at position+length.
parseInstructions(ByteBuffer, int, int) - Method in interface org.openflow.protocol.factory.OFInstructionFactory
Attempts to parse and return all OFInstruction contained in the given ByteBuffer, beginning at the ByteBuffer's position, and ending at position+length.
parseMessages(ByteBuffer) - Method in class org.openflow.protocol.factory.BasicFactory
 
parseMessages(ByteBuffer, int) - Method in class org.openflow.protocol.factory.BasicFactory
 
parseMessages(ByteBuffer) - Method in interface org.openflow.protocol.factory.OFMessageFactory
Attempts to parse and return all OFMessages contained in the given ByteBuffer, beginning at the ByteBuffer's position, and ending at the ByteBuffer's limit.
parseMessages(ByteBuffer, int) - Method in interface org.openflow.protocol.factory.OFMessageFactory
Attempts to parse and return all OFMessages contained in the given ByteBuffer, beginning at the ByteBuffer's position, and ending at the ByteBuffer's limit.
parseMeterBands(ByteBuffer, int) - Method in class org.openflow.protocol.factory.BasicFactory
 
parseMeterBands(ByteBuffer, int, int) - Method in class org.openflow.protocol.factory.BasicFactory
 
parseMeterBands(ByteBuffer, int) - Method in interface org.openflow.protocol.factory.OFMeterBandFactory
Attempts to parse and return all OFMeterBands contained in the given ByteBuffer, beginning at the ByteBuffer's position, and ending at position+length.
parseMeterBands(ByteBuffer, int, int) - Method in interface org.openflow.protocol.factory.OFMeterBandFactory
Attempts to parse and return all OFMeterBands contained in the given ByteBuffer, beginning at the ByteBuffer's position, and ending at position+length.
parseQueueProperties(ByteBuffer, int) - Method in class org.openflow.protocol.factory.BasicFactory
 
parseQueueProperties(ByteBuffer, int, int) - Method in class org.openflow.protocol.factory.BasicFactory
 
parseQueueProperties(ByteBuffer, int) - Method in interface org.openflow.protocol.factory.OFQueuePropertyFactory
Attempts to parse and return all OFQueueProperties contained in the given ByteBuffer, beginning at the ByteBuffer's position, and ending at position+length.
parseQueueProperties(ByteBuffer, int, int) - Method in interface org.openflow.protocol.factory.OFQueuePropertyFactory
Attempts to parse and return all OFQueueProperties contained in the given ByteBuffer, beginning at the ByteBuffer's position, and ending at position+length.
parseStatistics(OFType, OFStatisticsType, ByteBuffer, int) - Method in class org.openflow.protocol.factory.BasicFactory
 
parseStatistics(OFType, OFStatisticsType, ByteBuffer, int, int) - Method in class org.openflow.protocol.factory.BasicFactory
 
parseStatistics(OFType, OFStatisticsType, ByteBuffer, int) - Method in interface org.openflow.protocol.factory.OFStatisticsFactory
Attempts to parse and return all OFStatistics contained in the given ByteBuffer, beginning at the ByteBuffer's position, and ending at position+length.
parseStatistics(OFType, OFStatisticsType, ByteBuffer, int, int) - Method in interface org.openflow.protocol.factory.OFStatisticsFactory
Attempts to parse and return all OFStatistics contained in the given ByteBuffer, beginning at the ByteBuffer's position, and ending at position+length.
parseTableFeaturesProperties(ByteBuffer, int) - Method in class org.openflow.protocol.factory.BasicFactory
 
parseTableFeaturesProperties(ByteBuffer, int, int) - Method in class org.openflow.protocol.factory.BasicFactory
 
parseTableFeaturesProperties(ByteBuffer, int) - Method in interface org.openflow.protocol.factory.OFTableFeaturesPropertyFactory
Attempts to parse and return all OFTableFeaturesProperties contained in the given ByteBuffer, beginning at the ByteBuffer's position, and ending at position+length.
parseTableFeaturesProperties(ByteBuffer, int, int) - Method in interface org.openflow.protocol.factory.OFTableFeaturesPropertyFactory
Attempts to parse and return all OFTableFeaturesProperties contained in the given ByteBuffer, beginning at the ByteBuffer's position, and ending at position+length.
parseVendorData(int, ByteBuffer, int) - Method in class org.openflow.protocol.factory.FloodlightFactory
Attempts to parse and return the OFVendorData contained in the given ChannelBuffer, beginning right after the vendor id.
parseVendorData(int, ByteBuffer, int) - Method in interface org.openflow.protocol.factory.OFVendorDataFactory
Attempts to parse and return the OFVendorData contained in the given ByteBuffer, beginning right after the vendor id.
parseVendorDataType(ByteBuffer, int) - Method in class org.openflow.protocol.vendor.OFBasicVendorId
This function parses enough of the data from the buffer to be able to determine the appropriate OFVendorDataType for the data.
parseVendorDataType(ByteBuffer, int) - Method in class org.openflow.protocol.vendor.OFVendorId
This function parses enough of the data from the channel buffer to be able to determine the appropriate OFVendorDataType for the data.
partialReadCount - Variable in class org.openflow.io.OFMessageAsyncStream
 
PATH_CACHE_SIZE - Static variable in class net.floodlightcontroller.topology.TopologyInstance
 
pathcache - Variable in class net.floodlightcontroller.topology.TopologyInstance
 
payload - Variable in class net.floodlightcontroller.packet.BasePacket
 
payloadLength - Variable in enum org.openflow.protocol.OFOXMFieldType
 
peek() - Method in class net.floodlightcontroller.flowcache.PriorityPendingQueue
 
peerFeatures - Variable in class net.floodlightcontroller.core.SwitchSyncRepresentation.SyncedPort
 
peerFeatures - Variable in class org.openflow.protocol.OFPhysicalPort
 
pendingFuture - Variable in class org.sdnplatform.sync.internal.rpc.RPCService.NodeConnection
 
PendingSwRespKey - Class in net.floodlightcontroller.flowcache
 
PendingSwRespKey(long, int) - Constructor for class net.floodlightcontroller.flowcache.PendingSwRespKey
 
perClassIndices - Variable in class net.floodlightcontroller.devicemanager.internal.DeviceManagerImpl
This is the list of indices we want on a per-class basis
PerfMonDataResource - Class in net.floodlightcontroller.perfmon
Return the performance monitoring data for the get rest api call
PerfMonDataResource() - Constructor for class net.floodlightcontroller.perfmon.PerfMonDataResource
 
PerfMonToggleResource - Class in net.floodlightcontroller.perfmon
 
PerfMonToggleResource() - Constructor for class net.floodlightcontroller.perfmon.PerfMonToggleResource
 
PerfWebRoutable - Class in net.floodlightcontroller.perfmon
 
PerfWebRoutable() - Constructor for class net.floodlightcontroller.perfmon.PerfWebRoutable
 
period - Variable in class net.floodlightcontroller.core.web.PacketTraceResource.FilterParameters
 
PersistException - Exception in org.sdnplatform.sync.error
An error with a persistence layer
PersistException() - Constructor for exception org.sdnplatform.sync.error.PersistException
 
PersistException(String, Throwable) - Constructor for exception org.sdnplatform.sync.error.PersistException
 
PersistException(String) - Constructor for exception org.sdnplatform.sync.error.PersistException
 
PersistException(Throwable) - Constructor for exception org.sdnplatform.sync.error.PersistException
 
pickMember(LoadBalancer.IPClient) - Method in class net.floodlightcontroller.loadbalancer.LBPool
 
pickPool(LoadBalancer.IPClient) - Method in class net.floodlightcontroller.loadbalancer.LBVip
 
pipelineExecutor - Variable in class net.floodlightcontroller.core.internal.OpenflowPipelineFactory
 
pipelineFactory - Variable in class org.sdnplatform.sync.internal.rpc.RPCService
ChannelPipelineFactory for creating connections
pktin_local_buffer - Variable in class net.floodlightcontroller.counter.CounterStore
Thread local counter stores
pktinCounters - Variable in class net.floodlightcontroller.counter.CounterStore
Counter storage across all threads.
PktInProcessingTime - Class in net.floodlightcontroller.perfmon
This class contains a set of buckets (called time buckets as the primarily contain 'times' that are used in a circular way to store information on packet in processing time.
PktInProcessingTime() - Constructor for class net.floodlightcontroller.perfmon.PktInProcessingTime
 
pktout_local_buffer - Variable in class net.floodlightcontroller.counter.CounterStore
 
pktoutCounters - Variable in class net.floodlightcontroller.counter.CounterStore
 
poll() - Method in class net.floodlightcontroller.flowcache.PriorityPendingQueue
 
poolId - Variable in class net.floodlightcontroller.loadbalancer.LBMember
 
PoolMemberResource - Class in net.floodlightcontroller.loadbalancer
 
PoolMemberResource() - Constructor for class net.floodlightcontroller.loadbalancer.PoolMemberResource
 
pools - Variable in class net.floodlightcontroller.loadbalancer.LBVip
 
pools - Variable in class net.floodlightcontroller.loadbalancer.LoadBalancer
 
PoolsResource - Class in net.floodlightcontroller.loadbalancer
 
PoolsResource() - Constructor for class net.floodlightcontroller.loadbalancer.PoolsResource
 
port - Variable in class net.floodlightcontroller.core.IOFSwitch.PortChangeEvent
 
port - Variable in class net.floodlightcontroller.flowcache.FlowReconcileQueryPortDown
 
port - Variable in class net.floodlightcontroller.loadbalancer.LBMember
 
port - Variable in class net.floodlightcontroller.loadbalancer.LBMonitor
 
port - Variable in class net.floodlightcontroller.loadbalancer.LBVip
 
port - Static variable in class net.floodlightcontroller.packetstreamer.PacketStreamerServer
 
port - Variable in class org.openflow.example.SimpleController
 
port - Variable in class org.openflow.protocol.statistics.OFPortDescription
 
port - Variable in class org.sdnplatform.sync.client.SyncClientBase.SyncClientBaseSettings
 
port - Variable in class org.sdnplatform.sync.internal.remote.RemoteSyncManager
Port to connect to
PORT_ERROR - Static variable in class net.floodlightcontroller.devicemanager.web.AbstractDeviceResource
 
portBroadcastDomainLinks - Variable in class net.floodlightcontroller.topology.TopologyManager
set of links that are broadcast domain links.
PortDownReconciliation - Class in net.floodlightcontroller.flowcache
Flow reconciliation module that is triggered by PORT_DOWN events.
PortDownReconciliation() - Constructor for class net.floodlightcontroller.flowcache.PortDownReconciliation
 
portEnabled(int) - Method in interface net.floodlightcontroller.core.IOFSwitch
 
portEnabled(String) - Method in interface net.floodlightcontroller.core.IOFSwitch
 
portEnabled(int) - Method in class net.floodlightcontroller.core.OFSwitchBase
 
portEnabled(String) - Method in class net.floodlightcontroller.core.OFSwitchBase
 
portId - Variable in class net.floodlightcontroller.packet.LLDP
 
portId - Variable in class net.floodlightcontroller.topology.NodePortTuple
 
portLinks - Variable in class net.floodlightcontroller.linkdiscovery.internal.LinkDiscoveryManager
Map from a id:port to the set of links containing it as an endpoint
portNumber - Variable in class net.floodlightcontroller.core.SwitchSyncRepresentation.SyncedPort
 
portNumber - Variable in class org.openflow.protocol.action.OFActionOutput
 
portNumber - Variable in class org.openflow.protocol.OFPhysicalPort
 
portNumber - Variable in class org.openflow.protocol.OFPortMod
 
portNumber - Variable in class org.openflow.protocol.OFQueueGetConfigReply
 
portNumber - Variable in class org.openflow.protocol.OFQueueGetConfigRequest
 
portNumber - Variable in class org.openflow.protocol.queue.OFPacketQueue
 
portNumber - Variable in class org.openflow.protocol.statistics.OFPortStatisticsReply
 
portNumber - Variable in class org.openflow.protocol.statistics.OFPortStatisticsRequest
 
portNumber - Variable in class org.openflow.protocol.statistics.OFQueueStatisticsReply
 
portNumber - Variable in class org.openflow.protocol.statistics.OFQueueStatisticsRequest
 
portNumber - Variable in class org.openflow.vendor.openflow.OFQueueVendorData
 
portToMac - Variable in class net.floodlightcontroller.virtualnetwork.VirtualNetwork
 
portToMac - Variable in class net.floodlightcontroller.virtualnetwork.VirtualNetworkFilter
 
postHandler(DebugCounterResource.CounterPost) - Method in class net.floodlightcontroller.debugcounter.web.DebugCounterResource
Reset or enable/disable counters If using curl: curl -X POST -d DATA -H "Content-Type: application/json" URL where DATA must be one of the following: {\"reset\":true} to reset counters {\"enable\":true} to enable counter {\"enable\":false} to disable counter and URL must be in one of the following forms: "http://{controller-hostname}:8080/wm/debugcounter/{param1}/{param2}/{param3}/{param4} {param1} can be null, 'all' or the name of a module {moduleName}.
postHandler(DebugEventResource.DebugEventPost) - Method in class net.floodlightcontroller.debugevent.web.DebugEventResource
Reset events If using curl: curl -X POST -d {\"reset\":true} -H "Content-Type: application/json" URL where URL must be in one of the following forms for resetting registered events: "http://{controller-hostname}:8080/wm/debugevent/ "http://{controller-hostname}:8080/wm/debugevent/{param1} "http://{controller-hostname}:8080/wm/debugevent/{param1}/{param2} Not giving {param1} will reset all events {param1} can be 'all' or the name of a module.
postNotification(String) - Method in interface net.floodlightcontroller.notification.INotificationManager
Post a notification.
postNotification(String) - Method in class net.floodlightcontroller.notification.syslog.SyslogNotificationManager
 
pQueue - Variable in class net.floodlightcontroller.packetstreamer.PacketStreamerHandler.SessionQueue
 
precedenceLevel - Variable in class org.openflow.protocol.meter.OFMeterBandDSCPRemark
 
prefix - Static variable in class net.floodlightcontroller.core.internal.Controller.Counters
 
previousMemberIndex - Variable in class net.floodlightcontroller.loadbalancer.LBPool
 
primaryIndex - Variable in class net.floodlightcontroller.devicemanager.internal.DeviceManagerImpl
This is the primary entity index that contains all entities
prime1 - Variable in class net.floodlightcontroller.routing.ForwardingBase
 
prime2 - Static variable in class net.floodlightcontroller.routing.ForwardingBase
 
printAllCounterIds() - Method in class net.floodlightcontroller.debugcounter.DebugCounter
 
printHelp(String, Options) - Static method in class org.openflow.example.cli.SimpleCLI
 
printMonitoring(ScheduledExecutorService) - Method in class net.floodlightcontroller.util.LoadMonitor
 
printTopology() - Method in class net.floodlightcontroller.topology.TopologyInstance
 
printUsage(Options) - Static method in class org.openflow.example.SimpleController
 
priority - Variable in class com.bigswitch.floodlight.vendor.OFBsnPktinSuppressionSetRequestVendorData
 
priority - Variable in class net.floodlightcontroller.firewall.FirewallRule
 
priority - Variable in class net.floodlightcontroller.flowcache.OFMatchReconcile
flow mod.
priority - Variable in class org.openflow.protocol.OFFlowMod
 
priority - Variable in class org.openflow.protocol.OFFlowRemoved
 
priority - Variable in class org.openflow.protocol.statistics.OFFlowStatisticsReply
 
priorityCode - Variable in class net.floodlightcontroller.packet.Ethernet
 
PriorityPendingQueue<E> - Class in net.floodlightcontroller.flowcache
PriorityPendingQueue class - This class is a variant implementation for PriorityBlockingQueue PriorityBlockingQueue implementation has two problems: 1.
PriorityPendingQueue() - Constructor for class net.floodlightcontroller.flowcache.PriorityPendingQueue
 
PriorityPendingQueue.EventPriority - Enum in net.floodlightcontroller.flowcache
 
processBDDPLists() - Method in class net.floodlightcontroller.linkdiscovery.internal.LinkDiscoveryManager
This method processes the quarantine list in bursts.
processDriverHandshakeMessage(OFMessage) - Method in interface net.floodlightcontroller.core.IOFSwitch
Pass the given OFMessage to the driver as part of this driver's sub-handshake.
processDriverHandshakeMessage(OFMessage) - Method in class net.floodlightcontroller.core.OFSwitchBase
 
processOFPortStatus(OFPortStatus) - Method in interface net.floodlightcontroller.core.IOFSwitch
Add or modify a switch port.
processOFPortStatus(OFPortStatus) - Method in class net.floodlightcontroller.core.OFSwitchBase
 
processor - Static variable in class net.floodlightcontroller.packetstreamer.PacketStreamerServer
 
processPacketIn(IOFSwitch, OFPacketIn, FloodlightContext) - Method in class net.floodlightcontroller.virtualnetwork.VirtualNetworkFilter
Processes an OFPacketIn message and decides if the OFPacketIn should be dropped or the processing should continue.
processPacketInMessage(IOFSwitch, OFPacketIn, FloodlightContext) - Method in class net.floodlightcontroller.devicemanager.internal.DeviceManagerImpl
 
processPacketInMessage(IOFSwitch, OFPacketIn, IRoutingDecision, FloodlightContext) - Method in class net.floodlightcontroller.firewall.Firewall
 
processPacketInMessage(IOFSwitch, OFPacketIn, IRoutingDecision, FloodlightContext) - Method in class net.floodlightcontroller.forwarding.Forwarding
 
processPacketInMessage(IOFSwitch, OFPacketIn, IRoutingDecision, FloodlightContext) - Method in class net.floodlightcontroller.routing.ForwardingBase
All subclasses must define this function if they want any specific forwarding action
processPacketInMessage(IOFSwitch, OFPacketIn, FloodlightContext) - Method in class net.floodlightcontroller.topology.TopologyManager
 
processRegistrationQueue() - Method in class org.openflow.example.SelectLoop
 
processUpdates(Queue<DeviceManagerImpl.DeviceUpdate>) - Method in class net.floodlightcontroller.devicemanager.internal.DeviceManagerImpl
Send update notifications to listeners
ProducerConsumer - Class in org.openflow.util
The following implement a producer/consumer design pattern in which both producers and consumers explicitly employ a centralized registration mechanism, and java Interfaces are used as contracts.
ProducerConsumer() - Constructor for class org.openflow.util.ProducerConsumer
 
producerMap - Variable in class org.openflow.util.ProducerConsumer
 
PROP_REQUIRES_L3_MATCH - Static variable in interface net.floodlightcontroller.core.IOFSwitch
 
PROP_SUPPORTS_NETMASK_TBL - Static variable in interface net.floodlightcontroller.core.IOFSwitch
 
PROP_SUPPORTS_OFPP_FLOOD - Static variable in interface net.floodlightcontroller.core.IOFSwitch
 
PROP_SUPPORTS_OFPP_TABLE - Static variable in interface net.floodlightcontroller.core.IOFSwitch
 
properties - Variable in class org.openflow.protocol.queue.OFPacketQueue
 
properties - Variable in class org.openflow.protocol.statistics.OFTableFeatures
 
PropertyCCProvider - Class in org.sdnplatform.sync.internal.config
 
PropertyCCProvider() - Constructor for class org.sdnplatform.sync.internal.config.PropertyCCProvider
 
PROTO_TYPE_IP - Static variable in class net.floodlightcontroller.packet.ARP
 
protocol - Variable in class net.floodlightcontroller.loadbalancer.LBMonitor
 
protocol - Variable in class net.floodlightcontroller.loadbalancer.LBPool
 
protocol - Variable in class net.floodlightcontroller.loadbalancer.LBVip
 
protocol - Variable in class net.floodlightcontroller.packet.IPv4
 
PROTOCOL_ICMP - Static variable in class net.floodlightcontroller.packet.IPv4
 
PROTOCOL_TCP - Static variable in class net.floodlightcontroller.packet.IPv4
 
PROTOCOL_UDP - Static variable in class net.floodlightcontroller.packet.IPv4
 
protocolAddressLength - Variable in class net.floodlightcontroller.packet.ARP
 
protocolClassMap - Static variable in class net.floodlightcontroller.packet.IPv4
 
protocolType - Variable in class net.floodlightcontroller.packet.ARP
 
providerMap - Variable in class net.floodlightcontroller.core.internal.Controller
 
proxyMac - Variable in class net.floodlightcontroller.loadbalancer.LBVip
 
ptWarningThresholdInNano - Variable in class net.floodlightcontroller.perfmon.PktInProcessingTime
 
pushBidirectionalVipRoutes(IOFSwitch, OFPacketIn, FloodlightContext, LoadBalancer.IPClient, LBMember) - Method in class net.floodlightcontroller.loadbalancer.LoadBalancer
used to find and push in-bound and out-bound routes using StaticFlowEntryPusher
pushMessageAsync(Message) - Method in class net.floodlightcontroller.packetstreamer.PacketStreamerHandler
The implementation for pushMessageAsync() function.
pushMessageSync(Message) - Method in class net.floodlightcontroller.packetstreamer.PacketStreamerHandler
The implementation for pushMessageSync() function.
pushPacket(IPacket, IOFSwitch, int, int, int, FloodlightContext, boolean) - Method in class net.floodlightcontroller.loadbalancer.LoadBalancer
used to push any packet - borrowed routine from Forwarding
pushPacket(IOFSwitch, OFPacketIn, boolean, int, FloodlightContext) - Method in class net.floodlightcontroller.routing.ForwardingBase
Pushes a packet-out to a switch.
pushRoute(Route, OFMatch, EnumSet<OFOXMFieldType>, OFPacketIn, long, long, FloodlightContext, boolean, boolean, byte) - Method in class net.floodlightcontroller.routing.ForwardingBase
Push routes from back to front
pushStaticVipRoute(boolean, Route, LoadBalancer.IPClient, LBMember, long) - Method in class net.floodlightcontroller.loadbalancer.LoadBalancer
used to push given route using static flow entry pusher
put(FloodlightContext, String, V) - Method in class net.floodlightcontroller.core.FloodlightContextStore
 
put(K, V) - Method in class org.sdnplatform.sync.internal.AbstractStoreClient
 
put(K, Versioned<V>) - Method in class org.sdnplatform.sync.internal.DefaultStoreClient
 
put(ByteArray, Versioned<byte[]>) - Method in class org.sdnplatform.sync.internal.remote.RemoteStore
 
put(K, Versioned<V>) - Method in class org.sdnplatform.sync.internal.store.InMemoryStorageEngine
 
put(K, Versioned<V>) - Method in interface org.sdnplatform.sync.internal.store.IStore
Associate the value with the key and version in this store
put(K, Versioned<V>) - Method in class org.sdnplatform.sync.internal.store.JacksonStore
 
put(ByteArray, Versioned<byte[]>) - Method in class org.sdnplatform.sync.internal.store.JavaDBStorageEngine
 
put(ByteArray, Versioned<byte[]>) - Method in class org.sdnplatform.sync.internal.store.ListenerStorageEngine
 
put(ByteArray, Versioned<byte[]>) - Method in class org.sdnplatform.sync.internal.store.SynchronizingStorageEngine
 
put(K, V) - Method in interface org.sdnplatform.sync.IStoreClient
Associated the given value to the key, clobbering any existing values stored for the key.
put(K, Versioned<V>) - Method in interface org.sdnplatform.sync.IStoreClient
Put the given Versioned value into the store for the given key if the version is greater to or concurrent with existing values.
putIfNotObsolete(K, Versioned<V>) - Method in class org.sdnplatform.sync.internal.AbstractStoreClient
 
putIfNotObsolete(K, Versioned<V>) - Method in interface org.sdnplatform.sync.IStoreClient
Put the versioned value to the key, ignoring any ObsoleteVersionException that may be thrown
putUnsignedByte(ByteBuffer, short) - Static method in class org.openflow.util.Unsigned
Put an unsigned byte into the specified ByteBuffer at the current position
putUnsignedByte(ByteBuffer, short, int) - Static method in class org.openflow.util.Unsigned
Put an unsigned byte into the specified ByteBuffer at the specified offset
putUnsignedInt(ByteBuffer, long) - Static method in class org.openflow.util.Unsigned
Put an unsigned int into the specified ByteBuffer at the current position
putUnsignedInt(ByteBuffer, long, int) - Static method in class org.openflow.util.Unsigned
Put an unsigned int into the specified ByteBuffer at the specified offset
putUnsignedLong(ByteBuffer, BigInteger) - Static method in class org.openflow.util.Unsigned
Put an unsigned long into the specified ByteBuffer at the current position
putUnsignedLong(ByteBuffer, BigInteger, int) - Static method in class org.openflow.util.Unsigned
Put an unsigned long into the specified ByteBuffer at the specified offset
putUnsignedShort(ByteBuffer, int) - Static method in class org.openflow.util.Unsigned
Put an unsigned short into the specified ByteBuffer at the current position
putUnsignedShort(ByteBuffer, int, int) - Static method in class org.openflow.util.Unsigned
Put an unsigned short into the specified ByteBuffer at the specified offset

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